Uses of Interface
io.vertx.rxjava3.core.streams.ReadStream
-
-
Uses of ReadStream in io.vertx.rxjava3.amqp
Classes in io.vertx.rxjava3.amqp that implement ReadStream Modifier and Type Class Description class
AmqpReceiver
Interface used to consume AMQP message as a stream of message. -
Uses of ReadStream in io.vertx.rxjava3.cassandra
Classes in io.vertx.rxjava3.cassandra that implement ReadStream Modifier and Type Class Description class
CassandraRowStream
A for consumption. -
Uses of ReadStream in io.vertx.rxjava3.config
Methods in io.vertx.rxjava3.config that return ReadStream Modifier and Type Method Description ReadStream<JsonObject>
ConfigRetriever. configStream()
-
Uses of ReadStream in io.vertx.rxjava3.core.eventbus
Classes in io.vertx.rxjava3.core.eventbus that implement ReadStream Modifier and Type Class Description class
MessageConsumer<T>
An event bus consumer object representing a stream of message to anEventBus
address that can be read from.Methods in io.vertx.rxjava3.core.eventbus that return ReadStream Modifier and Type Method Description ReadStream<T>
MessageConsumer. bodyStream()
-
Uses of ReadStream in io.vertx.rxjava3.core.file
Classes in io.vertx.rxjava3.core.file that implement ReadStream Modifier and Type Class Description class
AsyncFile
Represents a file on the file-system which can be read from, or written to asynchronously. -
Uses of ReadStream in io.vertx.rxjava3.core.http
Subinterfaces of ReadStream in io.vertx.rxjava3.core.http Modifier and Type Interface Description interface
WebSocketBase
Base WebSocket implementation.Classes in io.vertx.rxjava3.core.http that implement ReadStream Modifier and Type Class Description class
ClientWebSocket
Represents a client-side WebSocket.class
HttpClientResponse
Represents a client-side HTTP response.class
HttpServerFileUpload
Represents an file upload from an HTML FORM.class
HttpServerRequest
Represents a server-side HTTP request.class
ServerWebSocket
Represents a server side WebSocket.class
WebSocket
Common WebSocket implementation. -
Uses of ReadStream in io.vertx.rxjava3.core.net
Classes in io.vertx.rxjava3.core.net that implement ReadStream Modifier and Type Class Description class
NetSocket
Represents a socket-like interface to a TCP connection on either the client or the server side. -
Uses of ReadStream in io.vertx.rxjava3.core.parsetools
Classes in io.vertx.rxjava3.core.parsetools that implement ReadStream Modifier and Type Class Description class
JsonParser
A parser class which allows to incrementally parse json elements and emit json parse events instead of parsing a json element fully.class
RecordParser
A helper class which allows you to easily parse protocols which are delimited by a sequence of bytes, or fixed size records. -
Uses of ReadStream in io.vertx.rxjava3.core.streams
Methods in io.vertx.rxjava3.core.streams that return ReadStream Modifier and Type Method Description ReadStream<T>
ReadStream. endHandler(Handler<Void> endHandler)
Set an end handler.ReadStream<T>
ReadStream. exceptionHandler(Handler<Throwable> handler)
Set an exception handler on the read stream.ReadStream<T>
ReadStream. fetch(long amount)
Fetch the specifiedamount
of elements.ReadStream<T>
ReadStream. handler(Handler<T> handler)
Set a data handler.static <T> ReadStream<T>
ReadStream. newInstance(ReadStream arg)
static <T> ReadStream<T>
ReadStream. newInstance(ReadStream arg, io.vertx.lang.rx.TypeArg<T> __typeArg_T)
ReadStream<T>
ReadStream. pause()
Pause theReadStream
, it sets the buffer infetch
mode and clears the actual demand.ReadStream<T>
ReadStream. resume()
Resume reading, and sets the buffer inflowing
mode. -
Uses of ReadStream in io.vertx.rxjava3.ext.mail
Methods in io.vertx.rxjava3.ext.mail that return ReadStream Modifier and Type Method Description ReadStream<Buffer>
MailAttachment. getStream()
Gets the data stream. -
Uses of ReadStream in io.vertx.rxjava3.ext.mongo
Methods in io.vertx.rxjava3.ext.mongo that return ReadStream Modifier and Type Method Description ReadStream<JsonObject>
MongoClient. aggregate(String collection, JsonArray pipeline)
Run aggregate MongoDB command with defaultAggregateOptions
.ReadStream<JsonObject>
MongoClient. aggregateWithOptions(String collection, JsonArray pipeline, AggregateOptions options)
Run aggregate MongoDB command.ReadStream<JsonObject>
MongoClient. distinctBatch(String collection, String fieldName, String resultClassname)
Gets the distinct values of the specified field name.ReadStream<JsonObject>
MongoClient. distinctBatch(String collection, String fieldName, String resultClassname, DistinctOptions distinctOptions)
Gets the distinct values of the specified field name.ReadStream<JsonObject>
MongoClient. distinctBatchWithQuery(String collection, String fieldName, String resultClassname, JsonObject query)
Gets the distinct values of the specified field name filtered by specified query.ReadStream<JsonObject>
MongoClient. distinctBatchWithQuery(String collection, String fieldName, String resultClassname, JsonObject query, int batchSize)
Gets the distinct values of the specified field name filtered by specified query.ReadStream<JsonObject>
MongoClient. distinctBatchWithQuery(String collection, String fieldName, String resultClassname, JsonObject query, int batchSize, DistinctOptions distinctOptions)
Gets the distinct values of the specified field name filtered by specified query.ReadStream<JsonObject>
MongoClient. distinctBatchWithQuery(String collection, String fieldName, String resultClassname, JsonObject query, DistinctOptions distinctOptions)
Gets the distinct values of the specified field name filtered by specified query.ReadStream<JsonObject>
MongoClient. findBatch(String collection, JsonObject query)
Find matching documents in the specified collection.ReadStream<JsonObject>
MongoClient. findBatchWithOptions(String collection, JsonObject query, FindOptions options)
Find matching documents in the specified collection, specifying options.ReadStream<Buffer>
MongoGridFsClient. readByFileName(String fileName)
Read file by name to ReadStreamReadStream<Buffer>
MongoGridFsClient. readByFileNameWithOptions(String fileName, GridFsDownloadOptions options)
Read file by name to ReadStream with optionsReadStream<Buffer>
MongoGridFsClient. readById(String id)
Read file by id to ReadStreamReadStream<com.mongodb.client.model.changestream.ChangeStreamDocument<JsonObject>>
MongoClient. watch(String collection, JsonArray pipeline, boolean withUpdatedDoc, int batchSize)
Watch the collection change. -
Uses of ReadStream in io.vertx.rxjava3.ext.unit.report
Classes in io.vertx.rxjava3.ext.unit.report that implement ReadStream Modifier and Type Class Description class
TestSuiteReport
The test suite reports is basically a stream of events reporting the test suite execution.Methods in io.vertx.rxjava3.ext.unit.report that return ReadStream Modifier and Type Method Description ReadStream<TestCaseReport>
TestSuiteReport. fetch(long amount)
Fetch the specifiedamount
of elements. -
Uses of ReadStream in io.vertx.rxjava3.ext.web.handler.sockjs
Classes in io.vertx.rxjava3.ext.web.handler.sockjs that implement ReadStream Modifier and Type Class Description class
SockJSSocket
You interact with SockJS clients through instances of SockJS socket. -
Uses of ReadStream in io.vertx.rxjava3.grpc.client
Classes in io.vertx.rxjava3.grpc.client that implement ReadStream Modifier and Type Class Description class
GrpcClientResponse<Req,Resp>
A response from a gRPC server. -
Uses of ReadStream in io.vertx.rxjava3.grpc.common
Classes in io.vertx.rxjava3.grpc.common that implement ReadStream Modifier and Type Class Description class
GrpcReadStream<T>
-
Uses of ReadStream in io.vertx.rxjava3.grpc.server
Classes in io.vertx.rxjava3.grpc.server that implement ReadStream Modifier and Type Class Description class
GrpcServerRequest<Req,Resp>
-
Uses of ReadStream in io.vertx.rxjava3.httpproxy
Methods in io.vertx.rxjava3.httpproxy that return ReadStream Modifier and Type Method Description ReadStream<Buffer>
Body. stream()
Get stream of theBody
. -
Uses of ReadStream in io.vertx.rxjava3.kafka.client.consumer
Classes in io.vertx.rxjava3.kafka.client.consumer that implement ReadStream Modifier and Type Class Description class
KafkaConsumer<K,V>
Vert.x Kafka consumer. -
Uses of ReadStream in io.vertx.rxjava3.pgclient.pubsub
Classes in io.vertx.rxjava3.pgclient.pubsub that implement ReadStream Modifier and Type Class Description class
PgChannel
A channel to Postgres that tracks the subscription to a given Postgres channel using theLISTEN/UNLISTEN
commands.Methods in io.vertx.rxjava3.pgclient.pubsub that return ReadStream Modifier and Type Method Description ReadStream<String>
PgChannel. fetch(long amount)
Fetch the specifiedamount
of elements. -
Uses of ReadStream in io.vertx.rxjava3.rabbitmq
Classes in io.vertx.rxjava3.rabbitmq that implement ReadStream Modifier and Type Class Description class
RabbitMQConsumer
A stream of messages from a rabbitmq queue.Methods in io.vertx.rxjava3.rabbitmq that return ReadStream Modifier and Type Method Description ReadStream<RabbitMQPublisherConfirmation>
RabbitMQPublisher. getConfirmationStream()
Get the ReadStream that contains the message IDs for confirmed messages.Methods in io.vertx.rxjava3.rabbitmq that return types with arguments of type ReadStream Modifier and Type Method Description Single<ReadStream<RabbitMQConfirmation>>
RabbitMQClient. addConfirmListener(int maxQueueSize)
Add a Confirm Listener to the channel.Single<ReadStream<RabbitMQConfirmation>>
RabbitMQClient. rxAddConfirmListener(int maxQueueSize)
Add a Confirm Listener to the channel. -
Uses of ReadStream in io.vertx.rxjava3.redis.client
Classes in io.vertx.rxjava3.redis.client that implement ReadStream Modifier and Type Class Description class
RedisConnection
A simple Redis client. -
Uses of ReadStream in io.vertx.rxjava3.sqlclient
Classes in io.vertx.rxjava3.sqlclient that implement ReadStream Modifier and Type Class Description class
RowStream<T>
A row oriented stream.
-