Modifier and Type | Interface and Description |
---|---|
interface |
AmqpReceiver
Interface used to consume AMQP message as a stream of message.
|
Modifier and Type | Interface and Description |
---|---|
interface |
CassandraRowStream
A
ReadStream for Row consumption. |
Modifier and Type | Method and Description |
---|---|
ReadStream<JsonObject> |
ConfigRetriever.configStream() |
Modifier and Type | Interface and Description |
---|---|
interface |
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 | Interface and Description |
---|---|
interface |
DatagramSocket
A datagram socket can be used to send
DatagramPacket 's to remote datagram servers
and receive DatagramPacket s . |
Modifier and Type | Interface and Description |
---|---|
interface |
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 | Interface and Description |
---|---|
interface |
AsyncFile
Represents a file on the file-system which can be read from, or written to asynchronously.
|
Modifier and Type | Interface and Description |
---|---|
interface |
HttpClientRequest
Represents a client-side HTTP request.
|
interface |
HttpClientResponse
Represents a client-side HTTP response.
|
interface |
HttpServerFileUpload
Represents an file upload from an HTML FORM.
|
interface |
HttpServerRequest
Represents a server-side HTTP request.
|
interface |
ServerWebSocket
Represents a server side WebSocket.
|
interface |
WebSocket
Represents a client-side WebSocket.
|
interface |
WebSocketBase
Base WebSocket implementation.
|
Modifier and Type | Method and Description |
---|---|
ReadStream<HttpServerRequest> |
HttpServer.requestStream()
Return the request stream for the server.
|
ReadStream<ServerWebSocket> |
HttpServer.websocketStream()
Deprecated.
instead use
HttpServer.webSocketStream() |
ReadStream<ServerWebSocket> |
HttpServer.webSocketStream()
Return the WebSocket stream for the server.
|
ReadStream<WebSocket> |
HttpClient.websocketStream(int port,
String host,
String requestURI)
Deprecated.
|
ReadStream<WebSocket> |
HttpClient.websocketStream(int port,
String host,
String requestURI,
MultiMap headers)
Deprecated.
|
ReadStream<WebSocket> |
HttpClient.websocketStream(int port,
String host,
String requestURI,
MultiMap headers,
WebsocketVersion version)
Deprecated.
|
ReadStream<WebSocket> |
HttpClient.websocketStream(int port,
String host,
String requestURI,
MultiMap headers,
WebsocketVersion version,
String subProtocols)
Deprecated.
|
ReadStream<WebSocket> |
HttpClient.websocketStream(RequestOptions options)
Deprecated.
|
ReadStream<WebSocket> |
HttpClient.websocketStream(RequestOptions options,
MultiMap headers)
Deprecated.
|
ReadStream<WebSocket> |
HttpClient.websocketStream(RequestOptions options,
MultiMap headers,
WebsocketVersion version)
Deprecated.
|
ReadStream<WebSocket> |
HttpClient.websocketStream(RequestOptions options,
MultiMap headers,
WebsocketVersion version,
String subProtocols)
Deprecated.
|
ReadStream<WebSocket> |
HttpClient.websocketStream(String requestURI)
Deprecated.
use
HttpClient.webSocket(String, Handler) instead |
ReadStream<WebSocket> |
HttpClient.websocketStream(String requestURI,
MultiMap headers)
Deprecated.
|
ReadStream<WebSocket> |
HttpClient.websocketStream(String requestURI,
MultiMap headers,
WebsocketVersion version)
Deprecated.
|
ReadStream<WebSocket> |
HttpClient.websocketStream(String requestURI,
MultiMap headers,
WebsocketVersion version,
String subProtocols)
Deprecated.
|
ReadStream<WebSocket> |
HttpClient.websocketStream(String host,
String requestURI)
Deprecated.
use
HttpClient.webSocket(String, String, Handler) instead |
ReadStream<WebSocket> |
HttpClient.websocketStream(String host,
String requestURI,
MultiMap headers)
Deprecated.
|
ReadStream<WebSocket> |
HttpClient.websocketStream(String host,
String requestURI,
MultiMap headers,
WebsocketVersion version)
Deprecated.
|
ReadStream<WebSocket> |
HttpClient.websocketStream(String host,
String requestURI,
MultiMap headers,
WebsocketVersion version,
String subProtocols)
Deprecated.
|
ReadStream<WebSocket> |
HttpClient.websocketStreamAbs(String url,
MultiMap headers,
WebsocketVersion version,
String subProtocols)
Deprecated.
|
Modifier and Type | Interface and Description |
---|---|
interface |
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()
Return the connect stream for this server.
|
Modifier and Type | Interface and Description |
---|---|
interface |
JsonParser
A parser class which allows to incrementally parse json elements and emit json parse events instead of parsing a json
element fully.
|
interface |
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 |
---|---|
static RecordParser |
RecordParser.newDelimited(Buffer delim,
ReadStream<Buffer> stream)
Like
RecordParser.newDelimited(Buffer) but wraps the stream . |
static RecordParser |
RecordParser.newDelimited(String delim,
ReadStream<Buffer> stream)
Like
RecordParser.newDelimited(String) but wraps the stream . |
static RecordParser |
RecordParser.newFixed(int size,
ReadStream<Buffer> stream)
Like
RecordParser.newFixed(int) but wraps the stream . |
static JsonParser |
JsonParser.newParser(ReadStream<Buffer> stream)
Create a new
JsonParser instance. |
Modifier and Type | Method and Description |
---|---|
<T> Pump |
PumpFactory.pump(ReadStream<T> rs,
WriteStream<T> ws) |
<T> Pump |
PumpFactory.pump(ReadStream<T> rs,
WriteStream<T> ws,
int writeQueueMaxSize) |
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.
|
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 |
---|---|
static <T> Pump |
Pump.pump(ReadStream<T> rs,
WriteStream<T> ws)
Create a new
Pump with the given ReadStream and WriteStream |
static <T> Pump |
Pump.pump(ReadStream<T> rs,
WriteStream<T> ws,
int writeQueueMaxSize)
Create a new
Pump with the given ReadStream and WriteStream and
writeQueueMaxSize |
Modifier and Type | Method and Description |
---|---|
ReadStream<Map.Entry<K,V>> |
InfinispanAsyncMap.entryStream()
Get the entries of the map as a
ReadStream . |
ReadStream<K> |
InfinispanAsyncMap.keyStream()
Get the keys of the map as a
ReadStream . |
ReadStream<V> |
InfinispanAsyncMap.valueStream()
Get the values of the map as a
ReadStream . |
Modifier and Type | Method and Description |
---|---|
ReadStream<JsonObject> |
MongoClient.aggregate(String collection,
JsonArray pipeline)
Run aggregate MongoDB command with default
AggregateOptions . |
default ReadStream<JsonObject> |
MongoService.aggregate(String collection,
JsonArray pipeline) |
ReadStream<JsonObject> |
MongoClient.aggregateWithOptions(String collection,
JsonArray pipeline,
AggregateOptions options)
Run aggregate MongoDB command.
|
default ReadStream<JsonObject> |
MongoService.aggregateWithOptions(String collection,
JsonArray pipeline,
AggregateOptions options) |
ReadStream<JsonObject> |
MongoClient.distinctBatch(String collection,
String fieldName,
String resultClassname)
Gets the distinct values of the specified field name.
|
default ReadStream<JsonObject> |
MongoService.distinctBatch(String collection,
String fieldName,
String resultClassname) |
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.
|
default ReadStream<JsonObject> |
MongoService.distinctBatchWithQuery(String collection,
String fieldName,
String resultClassname,
JsonObject 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.
|
default ReadStream<JsonObject> |
MongoService.distinctBatchWithQuery(String collection,
String fieldName,
String resultClassname,
JsonObject query,
int batchSize) |
ReadStream<JsonObject> |
MongoClient.findBatch(String collection,
JsonObject query)
Find matching documents in the specified collection.
|
default ReadStream<JsonObject> |
MongoService.findBatch(String collection,
JsonObject query) |
ReadStream<JsonObject> |
MongoClient.findBatchWithOptions(String collection,
JsonObject query,
FindOptions options)
Find matching documents in the specified collection, specifying options.
|
default ReadStream<JsonObject> |
MongoService.findBatchWithOptions(String collection,
JsonObject query,
FindOptions options) |
Modifier and Type | Interface and Description |
---|---|
interface |
ReactiveReadStream<T>
A Vert.x read stream that also implements reactive streams subscriber interface.
|
Modifier and Type | Interface and Description |
---|---|
interface |
SQLRowStream
A ReadStream of Rows from the underlying RDBMS.
|
Modifier and Type | Interface and Description |
---|---|
interface |
TestSuiteReport
The test suite reports is basically a stream of events reporting the test suite execution.
|
Modifier and Type | Method and Description |
---|---|
void |
HttpRequest.sendStream(ReadStream<Buffer> body,
Handler<AsyncResult<HttpResponse<T>>> handler)
Like
HttpRequest.send(Handler) but with an HTTP request body stream. |
Modifier and Type | Interface and Description |
---|---|
interface |
SockJSSocket
You interact with SockJS clients through instances of SockJS socket.
|
Modifier and Type | Interface and Description |
---|---|
interface |
GrpcBidiExchange<I,O> |
interface |
GrpcReadStream<T> |
Modifier and Type | Interface and Description |
---|---|
interface |
KafkaConsumer<K,V>
Vert.x Kafka consumer.
|
interface |
KafkaReadStream<K,V>
A
ReadStream for consuming Kafka ConsumerRecord . |
Modifier and Type | Interface and Description |
---|---|
interface |
PgChannel
A channel to Postgres that tracks the subscription to a given Postgres channel using the
LISTEN/UNLISTEN commands. |
Modifier and Type | Interface and Description |
---|---|
interface |
RabbitMQConsumer
A stream of messages from a rabbitmq queue.
|
Modifier and Type | Method and Description |
---|---|
ReadStream |
ReadStream.getDelegate() |
Modifier and Type | Method and 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) |
Modifier and Type | Interface and Description |
---|---|
interface |
RedisConnection
A simple Redis client.
|
Modifier and Type | Method and Description |
---|---|
ReadStream |
ReadStream.getDelegate() |
Modifier and Type | Method and 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) |
Modifier and Type | Interface and Description |
---|---|
interface |
RowStream<T>
A row oriented stream.
|
Copyright © 2023 Eclipse. All rights reserved.