Modifier and Type | Class and Description |
---|---|
class |
AmqpSender
AMQP Sender interface used to send messages.
|
Modifier and Type | Method and Description |
---|---|
WriteStream<AmqpMessage> |
AmqpSender.drainHandler(Handler<Void> handler)
Set a drain handler on the stream.
|
Modifier and Type | Method and Description |
---|---|
void |
AmqpReceiver.pipeTo(WriteStream<AmqpMessage> dst)
Pipe this
ReadStream to the WriteStream . |
void |
AmqpReceiver.pipeTo(WriteStream<AmqpMessage> dst,
Handler<AsyncResult<Void>> handler)
Pipe this
ReadStream to the WriteStream . |
Completable |
AmqpReceiver.rxPipeTo(WriteStream<AmqpMessage> dst)
Pipe this
ReadStream to the WriteStream . |
Modifier and Type | Method and Description |
---|---|
void |
CassandraRowStream.pipeTo(WriteStream<com.datastax.oss.driver.api.core.cql.Row> dst) |
void |
CassandraRowStream.pipeTo(WriteStream<com.datastax.oss.driver.api.core.cql.Row> dst,
Handler<AsyncResult<Void>> handler) |
Completable |
CassandraRowStream.rxPipeTo(WriteStream<com.datastax.oss.driver.api.core.cql.Row> dst) |
Modifier and Type | Method and Description |
---|---|
void |
TimeoutStream.pipeTo(WriteStream<Long> dst)
Pipe this
ReadStream to the WriteStream . |
void |
TimeoutStream.pipeTo(WriteStream<Long> dst,
Handler<AsyncResult<Void>> handler)
Pipe this
ReadStream to the WriteStream . |
Completable |
TimeoutStream.rxPipeTo(WriteStream<Long> dst)
Pipe this
ReadStream to the WriteStream . |
Modifier and Type | Method and Description |
---|---|
WriteStream<Buffer> |
DatagramSocket.sender(int port,
String host)
Returns a
WriteStream able to send to the
SocketAddress . |
Modifier and Type | Method and Description |
---|---|
void |
DatagramSocket.pipeTo(WriteStream<DatagramPacket> dst)
Pipe this
ReadStream to the WriteStream . |
void |
DatagramSocket.pipeTo(WriteStream<DatagramPacket> dst,
Handler<AsyncResult<Void>> handler)
Pipe this
ReadStream to the WriteStream . |
Completable |
DatagramSocket.rxPipeTo(WriteStream<DatagramPacket> dst)
Pipe this
ReadStream to the WriteStream . |
Modifier and Type | Method and Description |
---|---|
void |
MessageConsumer.pipeTo(WriteStream<Message<T>> dst)
Pipe this
ReadStream to the WriteStream . |
void |
MessageConsumer.pipeTo(WriteStream<Message<T>> dst,
Handler<AsyncResult<Void>> handler)
Pipe this
ReadStream to the WriteStream . |
Completable |
MessageConsumer.rxPipeTo(WriteStream<Message<T>> dst)
Pipe this
ReadStream to the WriteStream . |
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 | Method and Description |
---|---|
void |
AsyncFile.pipeTo(WriteStream<Buffer> dst)
Pipe this
ReadStream to the WriteStream . |
void |
AsyncFile.pipeTo(WriteStream<Buffer> dst,
Handler<AsyncResult<Void>> handler)
Pipe this
ReadStream to the WriteStream . |
Completable |
AsyncFile.rxPipeTo(WriteStream<Buffer> dst)
Pipe this
ReadStream to the WriteStream . |
Modifier and Type | Interface and Description |
---|---|
interface |
WebSocketBase
Base WebSocket implementation.
|
Modifier and Type | Class and Description |
---|---|
class |
HttpClientRequest
Represents a client-side HTTP request.
|
class |
HttpServerResponse
Represents a server-side HTTP response.
|
class |
ServerWebSocket
Represents a server side WebSocket.
|
class |
WebSocket
Represents a client-side WebSocket.
|
Modifier and Type | Method and Description |
---|---|
void |
HttpClientResponse.pipeTo(WriteStream<Buffer> dst)
Pipe this
ReadStream to the WriteStream . |
void |
ServerWebSocket.pipeTo(WriteStream<Buffer> dst)
Pipe this
ReadStream to the WriteStream . |
void |
WebSocket.pipeTo(WriteStream<Buffer> dst)
Pipe this
ReadStream to the WriteStream . |
void |
HttpServerFileUpload.pipeTo(WriteStream<Buffer> dst)
Pipe this
ReadStream to the WriteStream . |
void |
HttpServerRequest.pipeTo(WriteStream<Buffer> dst)
Pipe this
ReadStream to the WriteStream . |
void |
WebSocketBase.pipeTo(WriteStream<Buffer> dst)
Pipe this
ReadStream to the WriteStream . |
void |
HttpClientResponse.pipeTo(WriteStream<Buffer> dst,
Handler<AsyncResult<Void>> handler)
Pipe this
ReadStream to the WriteStream . |
void |
ServerWebSocket.pipeTo(WriteStream<Buffer> dst,
Handler<AsyncResult<Void>> handler)
Pipe this
ReadStream to the WriteStream . |
void |
WebSocket.pipeTo(WriteStream<Buffer> dst,
Handler<AsyncResult<Void>> handler)
Pipe this
ReadStream to the WriteStream . |
void |
HttpServerFileUpload.pipeTo(WriteStream<Buffer> dst,
Handler<AsyncResult<Void>> handler)
Pipe this
ReadStream to the WriteStream . |
void |
HttpServerRequest.pipeTo(WriteStream<Buffer> dst,
Handler<AsyncResult<Void>> handler)
Pipe this
ReadStream to the WriteStream . |
void |
WebSocketBase.pipeTo(WriteStream<Buffer> dst,
Handler<AsyncResult<Void>> handler)
Pipe this
ReadStream to the WriteStream . |
Completable |
HttpClientResponse.rxPipeTo(WriteStream<Buffer> dst)
Pipe this
ReadStream to the WriteStream . |
Completable |
ServerWebSocket.rxPipeTo(WriteStream<Buffer> dst)
Pipe this
ReadStream to the WriteStream . |
Completable |
WebSocket.rxPipeTo(WriteStream<Buffer> dst)
Pipe this
ReadStream to the WriteStream . |
Completable |
HttpServerFileUpload.rxPipeTo(WriteStream<Buffer> dst)
Pipe this
ReadStream to the WriteStream . |
Completable |
HttpServerRequest.rxPipeTo(WriteStream<Buffer> dst)
Pipe this
ReadStream to the WriteStream . |
Completable |
WebSocketBase.rxPipeTo(WriteStream<Buffer> dst)
Pipe this
ReadStream to the WriteStream . |
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 |
---|---|
void |
NetSocket.pipeTo(WriteStream<Buffer> dst)
Pipe this
ReadStream to the WriteStream . |
void |
NetSocket.pipeTo(WriteStream<Buffer> dst,
Handler<AsyncResult<Void>> handler)
Pipe this
ReadStream to the WriteStream . |
Completable |
NetSocket.rxPipeTo(WriteStream<Buffer> dst)
Pipe this
ReadStream to the WriteStream . |
Modifier and Type | Method and Description |
---|---|
void |
RecordParser.pipeTo(WriteStream<Buffer> dst)
Pipe this
ReadStream to the WriteStream . |
void |
RecordParser.pipeTo(WriteStream<Buffer> dst,
Handler<AsyncResult<Void>> handler)
Pipe this
ReadStream to the WriteStream . |
void |
JsonParser.pipeTo(WriteStream<JsonEvent> dst)
Pipe this
ReadStream to the WriteStream . |
void |
JsonParser.pipeTo(WriteStream<JsonEvent> dst,
Handler<AsyncResult<Void>> handler)
Pipe this
ReadStream to the WriteStream . |
Completable |
RecordParser.rxPipeTo(WriteStream<Buffer> dst)
Pipe this
ReadStream to the WriteStream . |
Completable |
JsonParser.rxPipeTo(WriteStream<JsonEvent> dst)
Pipe this
ReadStream to the WriteStream . |
Modifier and Type | Method and Description |
---|---|
WriteStream<T> |
WriteStream.drainHandler(Handler<Void> handler)
Set a drain handler on the stream.
|
WriteStream<T> |
WriteStream.exceptionHandler(Handler<Throwable> handler)
Set an exception handler on the write stream.
|
static <T> WriteStream<T> |
WriteStream.newInstance(WriteStream arg) |
static <T> WriteStream<T> |
WriteStream.newInstance(WriteStream arg,
io.vertx.lang.rx.TypeArg<T> __typeArg_T) |
WriteStream<T> |
WriteStream.setWriteQueueMaxSize(int maxSize)
Set the maximum size of the write queue to
maxSize . |
Modifier and Type | Method and Description |
---|---|
void |
ReadStream.pipeTo(WriteStream<T> dst)
Pipe this
ReadStream to the WriteStream . |
void |
ReadStream.pipeTo(WriteStream<T> dst,
Handler<AsyncResult<Void>> handler)
Pipe this
ReadStream to the WriteStream . |
static <T> Pump |
Pump.pump(Flowable<T> rs,
WriteStream<T> ws)
Create a new
Pump with the given ReadStream and WriteStream |
static <T> Pump |
Pump.pump(Flowable<T> rs,
WriteStream<T> ws,
int writeQueueMaxSize)
Create a new
Pump with the given ReadStream and WriteStream and
writeQueueMaxSize |
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 |
Completable |
ReadStream.rxPipeTo(WriteStream<T> dst)
Pipe this
ReadStream to the WriteStream . |
Completable |
Pipe.rxTo(WriteStream<T> dst)
Start to pipe the elements to the destination
WriteStream . |
void |
Pipe.to(WriteStream<T> dst)
Start to pipe the elements to the destination
WriteStream . |
void |
Pipe.to(WriteStream<T> dst,
Handler<AsyncResult<Void>> completionHandler)
Start to pipe the elements to the destination
WriteStream . |
Modifier and Type | Method and Description |
---|---|
void |
SQLRowStream.pipeTo(WriteStream<JsonArray> dst)
Pipe this
ReadStream to the WriteStream . |
void |
SQLRowStream.pipeTo(WriteStream<JsonArray> dst,
Handler<AsyncResult<Void>> handler)
Pipe this
ReadStream to the WriteStream . |
Completable |
SQLRowStream.rxPipeTo(WriteStream<JsonArray> dst)
Pipe this
ReadStream to the WriteStream . |
Modifier and Type | Method and Description |
---|---|
void |
TestSuiteReport.pipeTo(WriteStream<TestCaseReport> dst)
Pipe this
ReadStream to the WriteStream . |
void |
TestSuiteReport.pipeTo(WriteStream<TestCaseReport> dst,
Handler<AsyncResult<Void>> handler)
Pipe this
ReadStream to the WriteStream . |
Completable |
TestSuiteReport.rxPipeTo(WriteStream<TestCaseReport> dst)
Pipe this
ReadStream to the WriteStream . |
Modifier and Type | Method and Description |
---|---|
static BodyCodec<Void> |
BodyCodec.pipe(WriteStream<Buffer> stream)
A body codec that pipes the body to a write stream.
|
static BodyCodec<Void> |
BodyCodec.pipe(WriteStream<Buffer> stream,
boolean close)
A body codec that pipes the body to a write stream.
|
Modifier and Type | Class and Description |
---|---|
class |
SockJSSocket
You interact with SockJS clients through instances of SockJS socket.
|
Modifier and Type | Method and Description |
---|---|
void |
SockJSSocket.pipeTo(WriteStream<Buffer> dst)
Pipe this
ReadStream to the WriteStream . |
void |
SockJSSocket.pipeTo(WriteStream<Buffer> dst,
Handler<AsyncResult<Void>> handler)
Pipe this
ReadStream to the WriteStream . |
Completable |
SockJSSocket.rxPipeTo(WriteStream<Buffer> dst)
Pipe this
ReadStream to the WriteStream . |
Modifier and Type | Method and Description |
---|---|
void |
KafkaConsumer.pipeTo(WriteStream<KafkaConsumerRecord<K,V>> dst)
Pipe this
ReadStream to the WriteStream . |
void |
KafkaConsumer.pipeTo(WriteStream<KafkaConsumerRecord<K,V>> dst,
Handler<AsyncResult<Void>> handler)
Pipe this
ReadStream to the WriteStream . |
Completable |
KafkaConsumer.rxPipeTo(WriteStream<KafkaConsumerRecord<K,V>> dst)
Pipe this
ReadStream to the WriteStream . |
Modifier and Type | Class and Description |
---|---|
class |
KafkaProducer<K,V>
Vert.x Kafka producer.
|
Modifier and Type | Method and Description |
---|---|
void |
PgChannel.pipeTo(WriteStream<String> dst)
Pipe this
ReadStream to the WriteStream . |
void |
PgChannel.pipeTo(WriteStream<String> dst,
Handler<AsyncResult<Void>> handler)
Pipe this
ReadStream to the WriteStream . |
Completable |
PgChannel.rxPipeTo(WriteStream<String> dst)
Pipe this
ReadStream to the WriteStream . |
Modifier and Type | Method and Description |
---|---|
void |
RabbitMQConsumer.pipeTo(WriteStream<RabbitMQMessage> dst)
Pipe this
ReadStream to the WriteStream . |
void |
RabbitMQConsumer.pipeTo(WriteStream<RabbitMQMessage> dst,
Handler<AsyncResult<Void>> handler)
Pipe this
ReadStream to the WriteStream . |
Completable |
RabbitMQConsumer.rxPipeTo(WriteStream<RabbitMQMessage> dst)
Pipe this
ReadStream to the WriteStream . |
Modifier and Type | Method and Description |
---|---|
void |
RedisConnection.pipeTo(WriteStream<Response> dst)
Pipe this
ReadStream to the WriteStream . |
void |
RedisConnection.pipeTo(WriteStream<Response> dst,
Handler<AsyncResult<Void>> handler)
Pipe this
ReadStream to the WriteStream . |
Completable |
RedisConnection.rxPipeTo(WriteStream<Response> dst)
Pipe this
ReadStream to the WriteStream . |
Modifier and Type | Method and Description |
---|---|
void |
RowStream.pipeTo(WriteStream<T> dst)
Pipe this
ReadStream to the WriteStream . |
void |
RowStream.pipeTo(WriteStream<T> dst,
Handler<AsyncResult<Void>> handler)
Pipe this
ReadStream to the WriteStream . |
Completable |
RowStream.rxPipeTo(WriteStream<T> dst)
Pipe this
ReadStream to the WriteStream . |
Copyright © 2021 Eclipse. All rights reserved.