| Modifier and Type | Class and Description | 
|---|---|
class  | 
AmqpReceiver
Interface used to consume AMQP message as a stream of message. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
CassandraRowStream
A  for  consumption. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
ReadStream<JsonObject> | 
ConfigRetriever.configStream()  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
TimeoutStream
A timeout stream is triggered by a timer, the  
Handler will be call when the timer is fired,
 it can be once or several times depending on the nature of the timer related to this stream. | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
DatagramSocket
A datagram socket can be used to send  
DatagramPacket's to remote datagram servers
 and receive DatagramPackets . | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
MessageConsumer<T>
An event bus consumer object representing a stream of message to an  
EventBus address that can
 be read from. | 
| Modifier and Type | Method and Description | 
|---|---|
ReadStream<T> | 
MessageConsumer.bodyStream()  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
AsyncFile
Represents a file on the file-system which can be read from, or written to asynchronously. 
 | 
| Modifier and Type | Interface and Description | 
|---|---|
interface  | 
WebSocketBase
Base WebSocket implementation. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
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
Represents a client-side WebSocket. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
ReadStream<HttpServerRequest> | 
HttpServer.requestStream()
Deprecated.  
 | 
ReadStream<ServerWebSocket> | 
HttpServer.webSocketStream()
Deprecated.  
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
NetSocket
Represents a socket-like interface to a TCP connection on either the
 client or the server side. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
ReadStream<NetSocket> | 
NetServer.connectStream()
Deprecated.  
 | 
| Modifier and Type | Class and 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. 
 | 
| Modifier and Type | Method and 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 specified  
amount 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 the  
ReadStream, it sets the buffer in fetch mode and clears the actual demand. | 
ReadStream<T> | 
ReadStream.resume()
Resume reading, and sets the buffer in  
flowing mode. | 
| Modifier and Type | Method and Description | 
|---|---|
ReadStream<Buffer> | 
MailAttachment.getStream()
Gets the data stream. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
ReadStream<JsonObject> | 
MongoClient.aggregate(String collection,
         JsonArray pipeline)
Run aggregate MongoDB command with default  
AggregateOptions. | 
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,
                      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,
                      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.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 ReadStream 
 | 
ReadStream<Buffer> | 
MongoGridFsClient.readByFileNameWithOptions(String fileName,
                         GridFsDownloadOptions options)
Read file by name to ReadStream with options 
 | 
ReadStream<Buffer> | 
MongoGridFsClient.readById(String id)
Read file by id to ReadStream 
 | 
ReadStream<com.mongodb.client.model.changestream.ChangeStreamDocument<JsonObject>> | 
MongoClient.watch(String collection,
     JsonArray pipeline,
     boolean withUpdatedDoc,
     int batchSize)
Watch the collection change. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
TestSuiteReport
The test suite reports is basically a stream of events reporting the test suite execution. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
ReadStream<TestCaseReport> | 
TestSuiteReport.fetch(long amount)
Fetch the specified  
amount of elements. | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
SockJSSocket
You interact with SockJS clients through instances of SockJS socket. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
GrpcClientResponse<Req,Resp>
A response from a gRPC server. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
GrpcReadStream<T>  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
GrpcServerRequest<Req,Resp>  | 
| Modifier and Type | Method and Description | 
|---|---|
ReadStream<Buffer> | 
Body.stream()
Get stream of the  
Body. | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
KafkaConsumer<K,V>
Vert.x Kafka consumer. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
PgChannel
A channel to Postgres that tracks the subscription to a given Postgres channel using the  
LISTEN/UNLISTEN commands. | 
| Modifier and Type | Method and Description | 
|---|---|
ReadStream<String> | 
PgChannel.fetch(long amount)
Fetch the specified  
amount of elements. | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
RabbitMQConsumer
A stream of messages from a rabbitmq queue. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
ReadStream<RabbitMQPublisherConfirmation> | 
RabbitMQPublisher.getConfirmationStream()
Get the ReadStream that contains the message IDs for confirmed messages. 
 | 
| Modifier and Type | Method and 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. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
RedisConnection
A simple Redis client. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
RowStream<T>
A row oriented stream. 
 | 
Copyright © 2024 Eclipse. All rights reserved.