Uses of Interface
io.vertx.mutiny.core.streams.ReadStream
Packages that use ReadStream
Package
Description
-
Uses of ReadStream in io.vertx.mutiny.amqp
Classes in io.vertx.mutiny.amqp that implement ReadStreamModifier and TypeClassDescriptionclass
Interface used to consume AMQP message as a stream of message. -
Uses of ReadStream in io.vertx.mutiny.cassandra
Classes in io.vertx.mutiny.cassandra that implement ReadStream -
Uses of ReadStream in io.vertx.mutiny.config
Methods in io.vertx.mutiny.config that return ReadStreamModifier and TypeMethodDescriptionReadStream<io.vertx.core.json.JsonObject>
ConfigRetriever.configStream()
-
Uses of ReadStream in io.vertx.mutiny.core
Classes in io.vertx.mutiny.core that implement ReadStream -
Uses of ReadStream in io.vertx.mutiny.core.datagram
Classes in io.vertx.mutiny.core.datagram that implement ReadStreamModifier and TypeClassDescriptionclass
A datagram socket can be used to sendDatagramPacket
's to remote datagram servers and receiveDatagramPacket
s . -
Uses of ReadStream in io.vertx.mutiny.core.eventbus
Classes in io.vertx.mutiny.core.eventbus that implement ReadStreamModifier and TypeClassDescriptionclass
An event bus consumer object representing a stream of message to anEventBus
address that can be read from.Methods in io.vertx.mutiny.core.eventbus that return ReadStream -
Uses of ReadStream in io.vertx.mutiny.core.file
Classes in io.vertx.mutiny.core.file that implement ReadStreamModifier and TypeClassDescriptionclass
Represents a file on the file-system which can be read from, or written to asynchronously. -
Uses of ReadStream in io.vertx.mutiny.core.http
Subinterfaces of ReadStream in io.vertx.mutiny.core.httpClasses in io.vertx.mutiny.core.http that implement ReadStreamModifier and TypeClassDescriptionclass
Represents a client-side WebSocket initially not connected.class
Represents a client-side HTTP response.class
Represents an file upload from an HTML FORM.class
Represents a server-side HTTP request.class
Represents a server side WebSocket.class
Represents a client-side WebSocket.Methods in io.vertx.mutiny.core.http that return ReadStreamModifier and TypeMethodDescriptionHttpServer.requestStream()
Deprecated.HttpServer.webSocketStream()
Deprecated.instead use#webSocketHandler(Handler)
Methods in io.vertx.mutiny.core.http with parameters of type ReadStreamModifier and TypeMethodDescriptionio.smallrye.mutiny.Uni<HttpClientResponse>
HttpClientRequest.send
(ReadStream<Buffer> body) Send the request with a streambody
.io.smallrye.mutiny.Uni<Void>
HttpServerResponse.send
(ReadStream<Buffer> body) Send the request with a streambody
.HttpClientRequest.sendAndAwait
(ReadStream<Buffer> body) Blocking variant ofHttpClientRequest.send(io.vertx.mutiny.core.streams.ReadStream)
.HttpServerResponse.sendAndAwait
(ReadStream<Buffer> body) Blocking variant ofHttpServerResponse.send(io.vertx.mutiny.core.streams.ReadStream)
.void
HttpClientRequest.sendAndForget
(ReadStream<Buffer> body) Variant ofHttpClientRequest.send(io.vertx.mutiny.core.streams.ReadStream)
that ignores the result of the operation.void
HttpServerResponse.sendAndForget
(ReadStream<Buffer> body) Variant ofHttpServerResponse.send(io.vertx.mutiny.core.streams.ReadStream)
that ignores the result of the operation. -
Uses of ReadStream in io.vertx.mutiny.core.net
Classes in io.vertx.mutiny.core.net that implement ReadStreamModifier and TypeClassDescriptionclass
Represents a socket-like interface to a TCP connection on either the client or the server side.Methods in io.vertx.mutiny.core.net that return ReadStreamModifier and TypeMethodDescriptionNetServer.connectStream()
Deprecated.instead use#connectHandler(Handler)
-
Uses of ReadStream in io.vertx.mutiny.core.parsetools
Classes in io.vertx.mutiny.core.parsetools that implement ReadStreamModifier and TypeClassDescriptionclass
A parser class which allows to incrementally parse json elements and emit json parse events instead of parsing a json element fully.class
A 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.mutiny.core.parsetools with parameters of type ReadStreamModifier and TypeMethodDescriptionstatic RecordParser
RecordParser.newDelimited
(Buffer delim, ReadStream<Buffer> stream) static RecordParser
RecordParser.newDelimited
(String delim, ReadStream<Buffer> stream) static RecordParser
RecordParser.newFixed
(int size, ReadStream<Buffer> stream) static JsonParser
JsonParser.newParser
(ReadStream<Buffer> stream) -
Uses of ReadStream in io.vertx.mutiny.core.streams
Methods in io.vertx.mutiny.core.streams that return ReadStreamModifier and TypeMethodDescriptionReadStream.endHandler
(Runnable endHandler) ReadStream.exceptionHandler
(Consumer<Throwable> handler) ReadStream.fetch
(long amount) static <T> ReadStream<T>
ReadStream.newInstance
(io.vertx.core.streams.ReadStream arg) static <T> ReadStream<T>
ReadStream.newInstance
(io.vertx.core.streams.ReadStream arg, TypeArg<T> __typeArg_T) ReadStream.pause()
ReadStream.resume()
Methods in io.vertx.mutiny.core.streams with parameters of type ReadStreamModifier and TypeMethodDescriptionstatic <T> Pump
Pump.pump
(ReadStream<T> rs, WriteStream<T> ws) Deprecated.static <T> Pump
Pump.pump
(ReadStream<T> rs, WriteStream<T> ws, int writeQueueMaxSize) Deprecated. -
Uses of ReadStream in io.vertx.mutiny.ext.mail
Methods in io.vertx.mutiny.ext.mail that return ReadStreamMethods in io.vertx.mutiny.ext.mail with parameters of type ReadStream -
Uses of ReadStream in io.vertx.mutiny.ext.mongo
Methods in io.vertx.mutiny.ext.mongo that return ReadStreamModifier and TypeMethodDescriptionReadStream<io.vertx.core.json.JsonObject>
ReadStream<io.vertx.core.json.JsonObject>
MongoClient.aggregateWithOptions
(String collection, io.vertx.core.json.JsonArray pipeline, io.vertx.ext.mongo.AggregateOptions options) ReadStream<io.vertx.core.json.JsonObject>
MongoClient.distinctBatch
(String collection, String fieldName, String resultClassname) ReadStream<io.vertx.core.json.JsonObject>
MongoClient.distinctBatch
(String collection, String fieldName, String resultClassname, io.vertx.ext.mongo.DistinctOptions distinctOptions) ReadStream<io.vertx.core.json.JsonObject>
MongoClient.distinctBatchWithQuery
(String collection, String fieldName, String resultClassname, io.vertx.core.json.JsonObject query) ReadStream<io.vertx.core.json.JsonObject>
MongoClient.distinctBatchWithQuery
(String collection, String fieldName, String resultClassname, io.vertx.core.json.JsonObject query, int batchSize) ReadStream<io.vertx.core.json.JsonObject>
MongoClient.distinctBatchWithQuery
(String collection, String fieldName, String resultClassname, io.vertx.core.json.JsonObject query, int batchSize, io.vertx.ext.mongo.DistinctOptions distinctOptions) ReadStream<io.vertx.core.json.JsonObject>
MongoClient.distinctBatchWithQuery
(String collection, String fieldName, String resultClassname, io.vertx.core.json.JsonObject query, io.vertx.ext.mongo.DistinctOptions distinctOptions) ReadStream<io.vertx.core.json.JsonObject>
ReadStream<io.vertx.core.json.JsonObject>
MongoClient.findBatchWithOptions
(String collection, io.vertx.core.json.JsonObject query, io.vertx.ext.mongo.FindOptions options) MongoGridFsClient.readByFileName
(String fileName) MongoGridFsClient.readByFileNameWithOptions
(String fileName, io.vertx.ext.mongo.GridFsDownloadOptions options) ReadStream<com.mongodb.client.model.changestream.ChangeStreamDocument<io.vertx.core.json.JsonObject>>
MongoClient.watch
(String collection, io.vertx.core.json.JsonArray pipeline, boolean withUpdatedDoc, int batchSize) Methods in io.vertx.mutiny.ext.mongo with parameters of type ReadStreamModifier and TypeMethodDescriptionio.smallrye.mutiny.Uni<String>
MongoGridFsClient.uploadByFileName
(ReadStream<Buffer> stream, String fileName) MongoGridFsClient.uploadByFileNameAndAwait
(ReadStream<Buffer> stream, String fileName) MongoGridFsClient.uploadByFileNameAndForget
(ReadStream<Buffer> stream, String fileName) io.smallrye.mutiny.Uni<String>
MongoGridFsClient.uploadByFileNameWithOptions
(ReadStream<Buffer> stream, String fileName, io.vertx.ext.mongo.GridFsUploadOptions options) MongoGridFsClient.uploadByFileNameWithOptionsAndAwait
(ReadStream<Buffer> stream, String fileName, io.vertx.ext.mongo.GridFsUploadOptions options) MongoGridFsClient.uploadByFileNameWithOptionsAndForget
(ReadStream<Buffer> stream, String fileName, io.vertx.ext.mongo.GridFsUploadOptions options) -
Uses of ReadStream in io.vertx.mutiny.ext.sql
Classes in io.vertx.mutiny.ext.sql that implement ReadStreamModifier and TypeClassDescriptionclass
A ReadStream of Rows from the underlying RDBMS.Methods in io.vertx.mutiny.ext.sql that return ReadStreamModifier and TypeMethodDescriptionReadStream<io.vertx.core.json.JsonArray>
SQLRowStream.fetch
(long arg0) -
Uses of ReadStream in io.vertx.mutiny.ext.web.client
Methods in io.vertx.mutiny.ext.web.client with parameters of type ReadStreamModifier and TypeMethodDescriptionio.smallrye.mutiny.Uni<HttpResponse<T>>
HttpRequest.sendStream
(ReadStream<Buffer> body) LikeHttpRequest.send()
but with an HTTP requestbody
stream.HttpRequest.sendStreamAndAwait
(ReadStream<Buffer> body) Blocking variant ofHttpRequest.sendStream(io.vertx.mutiny.core.streams.ReadStream)
.void
HttpRequest.sendStreamAndForget
(ReadStream<Buffer> body) Variant ofHttpRequest.sendStream(io.vertx.mutiny.core.streams.ReadStream)
that ignores the result of the operation. -
Uses of ReadStream in io.vertx.mutiny.ext.web.handler.sockjs
Classes in io.vertx.mutiny.ext.web.handler.sockjs that implement ReadStreamModifier and TypeClassDescriptionclass
You interact with SockJS clients through instances of SockJS socket. -
Uses of ReadStream in io.vertx.mutiny.httpproxy
Methods in io.vertx.mutiny.httpproxy that return ReadStreamMethods in io.vertx.mutiny.httpproxy with parameters of type ReadStreamModifier and TypeMethodDescriptionstatic Body
Body.body
(ReadStream<Buffer> stream) static Body
Body.body
(ReadStream<Buffer> stream, long len) -
Uses of ReadStream in io.vertx.mutiny.kafka.client.consumer
Classes in io.vertx.mutiny.kafka.client.consumer that implement ReadStream -
Uses of ReadStream in io.vertx.mutiny.pgclient.pubsub
Classes in io.vertx.mutiny.pgclient.pubsub that implement ReadStreamModifier and TypeClassDescriptionclass
A channel to Postgres that tracks the subscription to a given Postgres channel using theLISTEN/UNLISTEN
commands.Methods in io.vertx.mutiny.pgclient.pubsub that return ReadStream -
Uses of ReadStream in io.vertx.mutiny.rabbitmq
Classes in io.vertx.mutiny.rabbitmq that implement ReadStreamModifier and TypeClassDescriptionclass
A stream of messages from a rabbitmq queue.Methods in io.vertx.mutiny.rabbitmq that return ReadStreamModifier and TypeMethodDescriptionReadStream<io.vertx.rabbitmq.RabbitMQConfirmation>
RabbitMQClient.addConfirmListenerAndAwait
(int maxQueueSize) Blocking variant ofRabbitMQClient.addConfirmListener(int)
.ReadStream<io.vertx.rabbitmq.RabbitMQPublisherConfirmation>
RabbitMQPublisher.getConfirmationStream()
Methods in io.vertx.mutiny.rabbitmq that return types with arguments of type ReadStreamModifier and TypeMethodDescriptionio.smallrye.mutiny.Uni<ReadStream<io.vertx.rabbitmq.RabbitMQConfirmation>>
RabbitMQClient.addConfirmListener
(int maxQueueSize) Add a Confirm Listener to the channel. -
Uses of ReadStream in io.vertx.mutiny.redis.client
Classes in io.vertx.mutiny.redis.client that implement ReadStream -
Uses of ReadStream in io.vertx.mutiny.sqlclient
Classes in io.vertx.mutiny.sqlclient that implement ReadStream
#requestHandler(Handler)