Uses of Interface
io.vertx.core.streams.ReadStream
- 
- 
Uses of ReadStream in io.vertx.amqpSubinterfaces of ReadStream in io.vertx.amqp Modifier and Type Interface Description interfaceAmqpReceiverInterface used to consume AMQP message as a stream of message.
- 
Uses of ReadStream in io.vertx.cassandraSubinterfaces of ReadStream in io.vertx.cassandra Modifier and Type Interface Description interfaceCassandraRowStreamAReadStreamforRowconsumption.
- 
Uses of ReadStream in io.vertx.configMethods in io.vertx.config that return ReadStream Modifier and Type Method Description ReadStream<JsonObject>ConfigRetriever. configStream()
- 
Uses of ReadStream in io.vertx.core.eventbusSubinterfaces of ReadStream in io.vertx.core.eventbus Modifier and Type Interface Description interfaceMessageConsumer<T>An event bus consumer object representing a stream of message to anEventBusaddress that can be read from.Methods in io.vertx.core.eventbus that return ReadStream Modifier and Type Method Description ReadStream<T>MessageConsumer. bodyStream()
- 
Uses of ReadStream in io.vertx.core.fileSubinterfaces of ReadStream in io.vertx.core.file Modifier and Type Interface Description interfaceAsyncFileRepresents a file on the file-system which can be read from, or written to asynchronously.
- 
Uses of ReadStream in io.vertx.core.httpSubinterfaces of ReadStream in io.vertx.core.http Modifier and Type Interface Description interfaceClientWebSocketRepresents a client-side WebSocket.interfaceHttpClientResponseRepresents a client-side HTTP response.interfaceHttpServerFileUploadRepresents an file upload from an HTML FORM.interfaceHttpServerRequestRepresents a server-side HTTP request.interfaceServerWebSocketRepresents a server side WebSocket.interfaceWebSocketCommon WebSocket implementation.interfaceWebSocketBaseBase WebSocket implementation.Methods in io.vertx.core.http with parameters of type ReadStream Modifier and Type Method Description default Future<HttpClientResponse>HttpClientRequest. send(ReadStream<Buffer> body)Send the request with a streambody.default Future<Void>HttpServerResponse. send(ReadStream<Buffer> body)Send the request with a streambody.
- 
Uses of ReadStream in io.vertx.core.netSubinterfaces of ReadStream in io.vertx.core.net Modifier and Type Interface Description interfaceNetSocketRepresents a socket-like interface to a TCP connection on either the client or the server side.
- 
Uses of ReadStream in io.vertx.core.parsetoolsSubinterfaces of ReadStream in io.vertx.core.parsetools Modifier and Type Interface Description interfaceJsonParserA parser class which allows to incrementally parse json elements and emit json parse events instead of parsing a json element fully.interfaceRecordParserA 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.core.parsetools with parameters of type ReadStream Modifier and Type Method Description static RecordParserRecordParser. newDelimited(Buffer delim, ReadStream<Buffer> stream)LikeRecordParser.newDelimited(Buffer)but wraps thestream.static RecordParserRecordParser. newDelimited(String delim, ReadStream<Buffer> stream)LikeRecordParser.newDelimited(String)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.core.streamsMethods in io.vertx.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.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.ext.cluster.infinispanMethods in io.vertx.ext.cluster.infinispan that return ReadStream Modifier and Type Method Description ReadStream<Map.Entry<K,V>>InfinispanAsyncMap. entryStream()Get the entries of the map as aReadStream.ReadStream<K>InfinispanAsyncMap. keyStream()Get the keys of the map as aReadStream.ReadStream<V>InfinispanAsyncMap. valueStream()Get the values of the map as aReadStream.
- 
Uses of ReadStream in io.vertx.ext.mailMethods in io.vertx.ext.mail that return ReadStream Modifier and Type Method Description ReadStream<Buffer>MailAttachment. getStream()Gets the data stream.Methods in io.vertx.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.ext.mail.mailencoderMethods in io.vertx.ext.mail.mailencoder that return ReadStream Modifier and Type Method Description ReadStream<Buffer>EncodedPart. bodyStream(Context context)ReadStream<Buffer>EncodedPart. dkimBodyStream(Context context)
- 
Uses of ReadStream in io.vertx.ext.mongoMethods in io.vertx.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.ext.mongo with parameters of type ReadStream Modifier and Type Method Description 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.ext.reactivestreamsSubinterfaces of ReadStream in io.vertx.ext.reactivestreams Modifier and Type Interface Description interfaceReactiveReadStream<T>A Vert.x read stream that also implements reactive streams subscriber interface.
- 
Uses of ReadStream in io.vertx.ext.unit.reportSubinterfaces of ReadStream in io.vertx.ext.unit.report Modifier and Type Interface Description interfaceTestSuiteReportThe test suite reports is basically a stream of events reporting the test suite execution.
- 
Uses of ReadStream in io.vertx.ext.webSubinterfaces of ReadStream in io.vertx.ext.web Modifier and Type Interface Description interfaceWebServerRequestExtends to access the routing context associated with the request.
- 
Uses of ReadStream in io.vertx.ext.web.clientMethods in io.vertx.ext.web.client with parameters of type ReadStream Modifier and Type Method Description Future<HttpResponse<T>>HttpRequest. sendStream(ReadStream<Buffer> body)LikeHttpRequest.send()but with an HTTP requestbodystream.
- 
Uses of ReadStream in io.vertx.ext.web.handler.sockjsSubinterfaces of ReadStream in io.vertx.ext.web.handler.sockjs Modifier and Type Interface Description interfaceSockJSSocketYou interact with SockJS clients through instances of SockJS socket.
- 
Uses of ReadStream in io.vertx.grpc.clientSubinterfaces of ReadStream in io.vertx.grpc.client Modifier and Type Interface Description interfaceGrpcClientResponse<Req,Resp>A response from a gRPC server.Methods in io.vertx.grpc.client with parameters of type ReadStream Modifier and Type Method Description default Future<GrpcClientResponse<Req,Resp>>GrpcClientRequest. send(ReadStream<Req> body)
- 
Uses of ReadStream in io.vertx.grpc.commonSubinterfaces of ReadStream in io.vertx.grpc.common Modifier and Type Interface Description interfaceGrpcReadStream<T>
- 
Uses of ReadStream in io.vertx.grpc.serverSubinterfaces of ReadStream in io.vertx.grpc.server Modifier and Type Interface Description interfaceGrpcServerRequest<Req,Resp>Methods in io.vertx.grpc.server with parameters of type ReadStream Modifier and Type Method Description default Future<Void>GrpcServerResponse. send(ReadStream<Resp> body)
- 
Uses of ReadStream in io.vertx.grpc.stubMethods in io.vertx.grpc.stub that return ReadStream Modifier and Type Method Description static <I,O>
 ReadStream<O>ClientCalls. manyToMany(io.vertx.core.internal.ContextInternal ctx, Handler<WriteStream<I>> requestHandler, Function<StreamObserver<O>,StreamObserver<I>> delegate)static <I,O>
 ReadStream<O>ClientCalls. manyToMany(io.vertx.core.internal.ContextInternal ctx, Handler<WriteStream<I>> requestHandler, Function<StreamObserver<O>,StreamObserver<I>> delegate, Handler<Throwable> exceptionHandler)static <I,O>
 ReadStream<O>ClientCalls. manyToMany(io.vertx.core.internal.ContextInternal ctx, Handler<WriteStream<I>> requestHandler, Function<StreamObserver<O>,StreamObserver<I>> delegate, Handler<O> handler, Handler<Void> endHandler, Handler<Throwable> exceptionHandler)static <I,O>
 ReadStream<O>ClientCalls. oneToMany(io.vertx.core.internal.ContextInternal ctx, I request, BiConsumer<I,StreamObserver<O>> delegate)static <I,O>
 ReadStream<O>ClientCalls. oneToMany(io.vertx.core.internal.ContextInternal ctx, I request, BiConsumer<I,StreamObserver<O>> delegate, Handler<O> handler, Handler<Void> endHandler, Handler<Throwable> exceptionHandler)Method parameters in io.vertx.grpc.stub with type arguments of type ReadStream Modifier and Type Method Description static <I,O>
 StreamObserver<I>ServerCalls. manyToMany(StreamObserver<O> response, String compression, BiConsumer<ReadStream<I>,WriteStream<O>> delegate)static <I,O>
 StreamObserver<I>ServerCalls. manyToOne(StreamObserver<O> response, String compression, Function<ReadStream<I>,Future<O>> delegate)
- 
Uses of ReadStream in io.vertx.httpproxyMethods in io.vertx.httpproxy that return ReadStream Modifier and Type Method Description ReadStream<Buffer>Body. stream()Get stream of theBody.Methods in io.vertx.httpproxy with parameters of type ReadStream Modifier and Type Method Description static BodyBody. body(ReadStream<Buffer> stream)Create a newBodyinstance.static BodyBody. body(ReadStream<Buffer> stream, long len)Create a newBodyinstance.static BodyBody. body(ReadStream<Buffer> stream, long len, MediaType mediatype)static BodyBody. body(ReadStream<Buffer> stream, long len, String mediatype)
- 
Uses of ReadStream in io.vertx.kafka.client.consumerSubinterfaces of ReadStream in io.vertx.kafka.client.consumer Modifier and Type Interface Description interfaceKafkaConsumer<K,V>Vert.x Kafka consumer.interfaceKafkaReadStream<K,V>AReadStreamfor consuming KafkaConsumerRecord.
- 
Uses of ReadStream in io.vertx.pgclient.pubsubSubinterfaces of ReadStream in io.vertx.pgclient.pubsub Modifier and Type Interface Description interfacePgChannelA channel to Postgres that tracks the subscription to a given Postgres channel using theLISTEN/UNLISTENcommands.
- 
Uses of ReadStream in io.vertx.rabbitmqSubinterfaces of ReadStream in io.vertx.rabbitmq Modifier and Type Interface Description interfaceRabbitMQConsumerA stream of messages from a rabbitmq queue.Methods in io.vertx.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.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.reactivexMethods in io.vertx.reactivex that return ReadStream Modifier and Type Method Description static <T> ReadStream<T>FlowableHelper. toReadStream(Flowable<T> observable)Adapts an RxJavaFlowableto a Vert.xReadStream.static <T> ReadStream<T>ObservableHelper. toReadStream(Observable<T> observable)Adapts an RxJavaObservableto a Vert.xReadStream.Methods in io.vertx.reactivex with parameters of type ReadStream Modifier and Type Method Description static <T> Flowable<T>FlowableHelper. toFlowable(ReadStream<T> stream)Adapts a Vert.xReadStreamto an RxJavaFlowable.static <T> Flowable<T>FlowableHelper. toFlowable(ReadStream<T> stream, long maxBufferSize)Adapts a Vert.xReadStreamto an RxJavaFlowable.static <T,U>
 Flowable<U>FlowableHelper. toFlowable(ReadStream<T> stream, Function<T,U> mapping)LikeFlowableHelper.toFlowable(ReadStream)but with amappingfunctionstatic <T> Observable<T>ObservableHelper. toObservable(ReadStream<T> stream)static <T,U>
 Observable<U>ObservableHelper. toObservable(ReadStream<T> stream, Function<T,U> mapping)LikeObservableHelper.toObservable(ReadStream)but with amappingfunction
- 
Uses of ReadStream in io.vertx.reactivex.core.streamsMethods in io.vertx.reactivex.core.streams that return ReadStream Modifier and Type Method Description ReadStreamReadStream. getDelegate()Methods in io.vertx.reactivex.core.streams with parameters of type ReadStream Modifier and Type Method Description static <T> ReadStream<T>ReadStream. newInstance(ReadStream arg)static <T> ReadStream<T>ReadStream. newInstance(ReadStream arg, io.vertx.lang.rx.TypeArg<T> __typeArg_T)
- 
Uses of ReadStream in io.vertx.redis.clientSubinterfaces of ReadStream in io.vertx.redis.client Modifier and Type Interface Description interfaceRedisConnectionA simple Redis client.
- 
Uses of ReadStream in io.vertx.rxjava3Methods in io.vertx.rxjava3 that return ReadStream Modifier and Type Method Description static <T> ReadStream<T>FlowableHelper. toReadStream(Flowable<T> observable)Adapts an RxJavaFlowableto a Vert.xReadStream.static <T> ReadStream<T>ObservableHelper. toReadStream(Observable<T> observable)Adapts an RxJavaObservableto a Vert.xReadStream.Methods in io.vertx.rxjava3 with parameters of type ReadStream Modifier and Type Method Description static <T> Flowable<T>FlowableHelper. toFlowable(ReadStream<T> stream)Adapts a Vert.xReadStreamto an RxJavaFlowable.static <T> Flowable<T>FlowableHelper. toFlowable(ReadStream<T> stream, long maxBufferSize)Adapts a Vert.xReadStreamto an RxJavaFlowable.static <T,U>
 Flowable<U>FlowableHelper. toFlowable(ReadStream<T> stream, Function<T,U> mapping)LikeFlowableHelper.toFlowable(ReadStream)but with amappingfunctionstatic <T> Observable<T>ObservableHelper. toObservable(ReadStream<T> stream)static <T,U>
 Observable<U>ObservableHelper. toObservable(ReadStream<T> stream, Function<T,U> mapping)LikeObservableHelper.toObservable(ReadStream)but with amappingfunctionMethod parameters in io.vertx.rxjava3 with type arguments of type ReadStream Modifier and Type Method Description static <T> Flowable<T>FlowableHelper. toFlowable(Supplier<Future<ReadStream<T>>> supplier)Adapts a Vert.xReadStreamto an RxJavaFlowable.
- 
Uses of ReadStream in io.vertx.rxjava3.core.streamsMethods in io.vertx.rxjava3.core.streams that return ReadStream Modifier and Type Method Description ReadStreamReadStream. getDelegate()Methods in io.vertx.rxjava3.core.streams with parameters of type ReadStream Modifier and Type Method Description static <T> ReadStream<T>ReadStream. newInstance(ReadStream arg)static <T> ReadStream<T>ReadStream. newInstance(ReadStream arg, io.vertx.lang.rx.TypeArg<T> __typeArg_T)
- 
Uses of ReadStream in io.vertx.sqlclientSubinterfaces of ReadStream in io.vertx.sqlclient Modifier and Type Interface Description interfaceRowStream<T>A row oriented stream.
 
-