Uses of Interface
io.vertx.reactivex.core.streams.ReadStream
- 
- 
Uses of ReadStream in io.vertx.reactivex.amqpClasses in io.vertx.reactivex.amqp that implement ReadStream Modifier and Type Class Description classAmqpReceiverInterface used to consume AMQP message as a stream of message.
- 
Uses of ReadStream in io.vertx.reactivex.cassandraClasses in io.vertx.reactivex.cassandra that implement ReadStream Modifier and Type Class Description classCassandraRowStreamA for consumption.
- 
Uses of ReadStream in io.vertx.reactivex.configMethods in io.vertx.reactivex.config that return ReadStream Modifier and Type Method Description ReadStream<JsonObject>ConfigRetriever. configStream()
- 
Uses of ReadStream in io.vertx.reactivex.core.eventbusClasses in io.vertx.reactivex.core.eventbus that implement ReadStream Modifier and Type Class Description classMessageConsumer<T>An event bus consumer object representing a stream of message to anEventBusaddress that can be read from.Methods in io.vertx.reactivex.core.eventbus that return ReadStream Modifier and Type Method Description ReadStream<T>MessageConsumer. bodyStream()
- 
Uses of ReadStream in io.vertx.reactivex.core.fileClasses in io.vertx.reactivex.core.file that implement ReadStream Modifier and Type Class Description classAsyncFileRepresents a file on the file-system which can be read from, or written to asynchronously.
- 
Uses of ReadStream in io.vertx.reactivex.core.httpSubinterfaces of ReadStream in io.vertx.reactivex.core.http Modifier and Type Interface Description interfaceWebSocketBaseBase WebSocket implementation.Classes in io.vertx.reactivex.core.http that implement ReadStream Modifier and Type Class Description classClientWebSocketRepresents a client-side WebSocket.classHttpClientResponseRepresents a client-side HTTP response.classHttpServerFileUploadRepresents an file upload from an HTML FORM.classHttpServerRequestRepresents a server-side HTTP request.classServerWebSocketRepresents a server side WebSocket.classWebSocketCommon WebSocket implementation.Methods in io.vertx.reactivex.core.http with parameters of type ReadStream Modifier and Type Method Description Single<HttpClientResponse>HttpClientRequest. rxSend(ReadStream<Buffer> body)Send the request with a streambody.CompletableHttpServerResponse. rxSend(ReadStream<Buffer> body)Send the request with a streambody.Future<HttpClientResponse>HttpClientRequest. send(ReadStream<Buffer> body)Send the request with a streambody.Future<Void>HttpServerResponse. send(ReadStream<Buffer> body)Send the request with a streambody.
- 
Uses of ReadStream in io.vertx.reactivex.core.netClasses in io.vertx.reactivex.core.net that implement ReadStream Modifier and Type Class Description classNetSocketRepresents a socket-like interface to a TCP connection on either the client or the server side.
- 
Uses of ReadStream in io.vertx.reactivex.core.parsetoolsClasses in io.vertx.reactivex.core.parsetools that implement ReadStream Modifier and Type Class Description classJsonParserA parser class which allows to incrementally parse json elements and emit json parse events instead of parsing a json element fully.classRecordParserA helper class which allows you to easily parse protocols which are delimited by a sequence of bytes, or fixed size records.Methods in io.vertx.reactivex.core.parsetools with parameters of type ReadStream Modifier and Type Method Description static RecordParserRecordParser. newDelimited(Buffer delim, ReadStream<Buffer> stream)LikeRecordParser.newDelimited(java.lang.String, io.vertx.core.Handler<io.vertx.core.buffer.Buffer>)but wraps thestream.static RecordParserRecordParser. newDelimited(String delim, ReadStream<Buffer> stream)LikeRecordParser.newDelimited(java.lang.String, io.vertx.core.Handler<io.vertx.core.buffer.Buffer>)but wraps thestream.static RecordParserRecordParser. newFixed(int size, ReadStream<Buffer> stream)LikeRecordParser.newFixed(int)but wraps thestream.static JsonParserJsonParser. newParser(ReadStream<Buffer> stream)Create a newJsonParserinstance.
- 
Uses of ReadStream in io.vertx.reactivex.core.streamsMethods in io.vertx.reactivex.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 specifiedamountof 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 infetchmode and clears the actual demand.ReadStream<T>ReadStream. resume()Resume reading, and sets the buffer inflowingmode.
- 
Uses of ReadStream in io.vertx.reactivex.ext.mailMethods in io.vertx.reactivex.ext.mail that return ReadStream Modifier and Type Method Description ReadStream<Buffer>MailAttachment. getStream()Gets the data stream.Methods in io.vertx.reactivex.ext.mail with parameters of type ReadStream Modifier and Type Method Description MailAttachmentMailAttachment. setStream(ReadStream<Buffer> stream)Sets the data stream.
- 
Uses of ReadStream in io.vertx.reactivex.ext.mongoMethods in io.vertx.reactivex.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.Methods in io.vertx.reactivex.ext.mongo with parameters of type ReadStream Modifier and Type Method Description Single<String>MongoGridFsClient. rxUploadByFileName(ReadStream<Buffer> stream, String fileName)Single<String>MongoGridFsClient. rxUploadByFileNameWithOptions(ReadStream<Buffer> stream, String fileName, GridFsUploadOptions options)Future<String>MongoGridFsClient. uploadByFileName(ReadStream<Buffer> stream, String fileName)Future<String>MongoGridFsClient. uploadByFileNameWithOptions(ReadStream<Buffer> stream, String fileName, GridFsUploadOptions options)
- 
Uses of ReadStream in io.vertx.reactivex.ext.unit.reportClasses in io.vertx.reactivex.ext.unit.report that implement ReadStream Modifier and Type Class Description classTestSuiteReportThe test suite reports is basically a stream of events reporting the test suite execution.Methods in io.vertx.reactivex.ext.unit.report that return ReadStream Modifier and Type Method Description ReadStream<TestCaseReport>TestSuiteReport. fetch(long amount)Fetch the specifiedamountof elements.
- 
Uses of ReadStream in io.vertx.reactivex.ext.web.clientMethods in io.vertx.reactivex.ext.web.client with parameters of type ReadStream Modifier and Type Method Description Single<HttpResponse<T>>HttpRequest. rxSendStream(ReadStream<Buffer> body)LikeHttpRequest.send()but with an HTTP requestbodystream.Future<HttpResponse<T>>HttpRequest. sendStream(ReadStream<Buffer> body)LikeHttpRequest.send()but with an HTTP requestbodystream.
- 
Uses of ReadStream in io.vertx.reactivex.ext.web.handler.sockjsClasses in io.vertx.reactivex.ext.web.handler.sockjs that implement ReadStream Modifier and Type Class Description classSockJSSocketYou interact with SockJS clients through instances of SockJS socket.
- 
Uses of ReadStream in io.vertx.reactivex.grpc.clientClasses in io.vertx.reactivex.grpc.client that implement ReadStream Modifier and Type Class Description classGrpcClientResponse<Req,Resp>A response from a gRPC server.Methods in io.vertx.reactivex.grpc.client with parameters of type ReadStream Modifier and Type Method Description Single<GrpcClientResponse<Req,Resp>>GrpcClientRequest. rxSend(ReadStream<Req> body)Future<GrpcClientResponse<Req,Resp>>GrpcClientRequest. send(ReadStream<Req> body)
- 
Uses of ReadStream in io.vertx.reactivex.grpc.commonClasses in io.vertx.reactivex.grpc.common that implement ReadStream Modifier and Type Class Description classGrpcReadStream<T>
- 
Uses of ReadStream in io.vertx.reactivex.grpc.serverClasses in io.vertx.reactivex.grpc.server that implement ReadStream Modifier and Type Class Description classGrpcServerRequest<Req,Resp>Methods in io.vertx.reactivex.grpc.server with parameters of type ReadStream Modifier and Type Method Description CompletableGrpcServerResponse. rxSend(ReadStream<Resp> body)Future<Void>GrpcServerResponse. send(ReadStream<Resp> body)
- 
Uses of ReadStream in io.vertx.reactivex.kafka.client.consumerClasses in io.vertx.reactivex.kafka.client.consumer that implement ReadStream Modifier and Type Class Description classKafkaConsumer<K,V>Vert.x Kafka consumer.
- 
Uses of ReadStream in io.vertx.reactivex.pgclient.pubsubClasses in io.vertx.reactivex.pgclient.pubsub that implement ReadStream Modifier and Type Class Description classPgChannelA channel to Postgres that tracks the subscription to a given Postgres channel using theLISTEN/UNLISTENcommands.Methods in io.vertx.reactivex.pgclient.pubsub that return ReadStream Modifier and Type Method Description ReadStream<String>PgChannel. fetch(long amount)Fetch the specifiedamountof elements.
- 
Uses of ReadStream in io.vertx.reactivex.rabbitmqClasses in io.vertx.reactivex.rabbitmq that implement ReadStream Modifier and Type Class Description classRabbitMQConsumerA stream of messages from a rabbitmq queue.Methods in io.vertx.reactivex.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.reactivex.rabbitmq that return types with arguments of type ReadStream Modifier and Type Method Description Future<ReadStream<RabbitMQConfirmation>>RabbitMQClient. addConfirmListener(int maxQueueSize)Add a Confirm Listener to the channel.
- 
Uses of ReadStream in io.vertx.reactivex.redis.clientClasses in io.vertx.reactivex.redis.client that implement ReadStream Modifier and Type Class Description classRedisConnectionA simple Redis client.
- 
Uses of ReadStream in io.vertx.reactivex.sqlclientClasses in io.vertx.reactivex.sqlclient that implement ReadStream Modifier and Type Class Description classRowStream<T>A row oriented stream.
 
-