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 |
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()
Return the WebSocket stream for the server.
|
Modifier and Type | Method and Description |
---|---|
default Future<Void> |
HttpServerResponse.send(ReadStream<Buffer> body)
Like
HttpServerResponse.send(ReadStream, Handler) but returns a Future of the asynchronous result |
default Future<HttpClientResponse> |
HttpClientRequest.send(ReadStream<Buffer> body)
Like
HttpClientRequest.send(ReadStream, Handler) but returns a Future of the asynchronous result |
default void |
HttpClientRequest.send(ReadStream<Buffer> body,
Handler<AsyncResult<HttpClientResponse>> handler)
Send the request with a stream
body . |
default void |
HttpServerResponse.send(ReadStream<Buffer> body,
Handler<AsyncResult<Void>> handler)
Send the request with a stream
body . |
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 |
---|---|
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<Buffer> |
MailAttachment.getStream()
Gets the data stream.
|
Modifier and Type | Method and Description |
---|---|
MailAttachment |
MailAttachment.setStream(ReadStream<Buffer> stream)
Sets the data stream.
|
Modifier and Type | Method and Description |
---|---|
ReadStream<Buffer> |
EncodedPart.bodyStream(Context context) |
ReadStream<Buffer> |
EncodedPart.dkimBodyStream(Context context) |
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.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.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.
|
Modifier and Type | Method and Description |
---|---|
Future<String> |
MongoGridFsClient.uploadByFileName(ReadStream<Buffer> stream,
String fileName)
Like
MongoGridFsClient.uploadByFileName(ReadStream, String, Handler) but returns a Future of the asynchronous result |
MongoGridFsClient |
MongoGridFsClient.uploadByFileName(ReadStream<Buffer> stream,
String fileName,
Handler<AsyncResult<String>> resultHandler) |
Future<String> |
MongoGridFsClient.uploadByFileNameWithOptions(ReadStream<Buffer> stream,
String fileName,
GridFsUploadOptions options)
Like
MongoGridFsClient.uploadByFileNameWithOptions(ReadStream, String, GridFsUploadOptions, Handler) but returns a Future of the asynchronous result |
MongoGridFsClient |
MongoGridFsClient.uploadByFileNameWithOptions(ReadStream<Buffer> stream,
String fileName,
GridFsUploadOptions options,
Handler<AsyncResult<String>> resultHandler) |
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 |
---|---|
default Future<HttpResponse<T>> |
HttpRequest.sendStream(ReadStream<Buffer> body) |
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 | Method and Description |
---|---|
static <I,O> ReadStream<O> |
ClientCalls.manyToMany(io.vertx.core.impl.ContextInternal ctx,
Handler<WriteStream<I>> requestHandler,
java.util.function.Function<io.grpc.stub.StreamObserver<O>,io.grpc.stub.StreamObserver<I>> delegate) |
static <I,O> ReadStream<O> |
ClientCalls.oneToMany(io.vertx.core.impl.ContextInternal ctx,
I request,
java.util.function.BiConsumer<I,io.grpc.stub.StreamObserver<O>> delegate) |
Modifier and Type | Method and Description |
---|---|
static <I,O> io.grpc.stub.StreamObserver<I> |
ServerCalls.manyToMany(io.grpc.stub.StreamObserver<O> response,
String compression,
java.util.function.BiConsumer<ReadStream<I>,WriteStream<O>> delegate) |
static <I,O> io.grpc.stub.StreamObserver<I> |
ServerCalls.manyToOne(io.grpc.stub.StreamObserver<O> response,
String compression,
java.util.function.Function<ReadStream<I>,Future<O>> delegate) |
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<RabbitMQPublisherConfirmation> |
RabbitMQPublisher.getConfirmationStream()
Get the ReadStream that contains the message IDs for confirmed messages.
|
Modifier and Type | Method and Description |
---|---|
Future<ReadStream<RabbitMQConfirmation>> |
RabbitMQClient.addConfirmListener(int maxQueueSize)
Add a Confirm Listener to the channel.
|
Modifier and Type | Method and Description |
---|---|
void |
RabbitMQClient.addConfirmListener(int maxQueueSize,
Handler<AsyncResult<ReadStream<RabbitMQConfirmation>>> resultHandler)
Add a Confirm Listener to the channel.
|
Modifier and Type | Method and Description |
---|---|
static <T> ReadStream<T> |
FlowableHelper.toReadStream(Flowable<T> observable)
Adapts an RxJava
Flowable to a Vert.x io.vertx.core.streams.ReadStream . |
static <T> ReadStream<T> |
ObservableHelper.toReadStream(Observable<T> observable)
Adapts an RxJava
Observable to a Vert.x io.vertx.core.streams.ReadStream . |
Modifier and Type | Method and Description |
---|---|
static <T> Flowable<T> |
FlowableHelper.toFlowable(ReadStream<T> stream)
Adapts a Vert.x
ReadStream to an RxJava Flowable . |
static <T,U> Flowable<U> |
FlowableHelper.toFlowable(ReadStream<T> stream,
java.util.function.Function<T,U> mapping)
Like
FlowableHelper.toFlowable(ReadStream) but with a mapping function |
static <T> Flowable<T> |
FlowableHelper.toFlowable(ReadStream<T> stream,
long maxBufferSize)
Adapts a Vert.x
ReadStream to an RxJava Flowable . |
static <T> Observable<T> |
ObservableHelper.toObservable(ReadStream<T> stream)
|
static <T,U> Observable<U> |
ObservableHelper.toObservable(ReadStream<T> stream,
java.util.function.Function<T,U> mapping)
Like
ObservableHelper.toObservable(ReadStream) but with a mapping function |
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 | Class and Description |
---|---|
class |
ReadStreamSubscriber<R,J>
|
Modifier and Type | Method and Description |
---|---|
static <R,J> ReadStream<J> |
ReadStreamSubscriber.asReadStream(Observable<R> observable,
java.util.function.Function<R,J> adapter) |
ReadStream<J> |
ReadStreamSubscriber.endHandler(Handler<Void> handler) |
ReadStream<J> |
ReadStreamSubscriber.exceptionHandler(Handler<Throwable> handler) |
ReadStream<J> |
ReadStreamSubscriber.fetch(long amount) |
ReadStream<J> |
ReadStreamSubscriber.handler(Handler<J> handler) |
ReadStream<J> |
ReadStreamSubscriber.pause() |
ReadStream<J> |
ReadStreamSubscriber.resume() |
static <T> ReadStream<T> |
RxHelper.toReadStream(Observable<T> observable)
Adapts an RxJava
Observable to a Vert.x io.vertx.core.streams.ReadStream . |
Modifier and Type | Method and Description |
---|---|
static <T> Observable<T> |
RxHelper.toObservable(ReadStream<T> stream)
Adapts a Vert.x
io.vertx.core.streams.ReadStream to an RxJava Observable . |
static <T,R> Observable<R> |
RxHelper.toObservable(ReadStream<T> stream,
java.util.function.Function<T,R> adapter)
Like
RxHelper.toObservable(ReadStream) but with a function that adapts the items. |
static <T,R> Observable<R> |
RxHelper.toObservable(ReadStream<T> stream,
java.util.function.Function<T,R> adapter,
int maxBufferSize)
Like
RxHelper.toObservable(ReadStream, int) but with a function that adapts the items. |
static <T> Observable<T> |
RxHelper.toObservable(ReadStream<T> stream,
int maxBufferSize)
Adapts a Vert.x
io.vertx.core.streams.ReadStream to an RxJava Observable . |
Constructor and Description |
---|
ObservableReadStream(ReadStream<T> stream,
java.util.function.Function<T,R> adapter) |
ObservableReadStream(ReadStream<T> stream,
java.util.function.Function<T,R> adapter,
long maxBufferSize) |
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 © 2021 Eclipse. All rights reserved.