Uses of Interface
io.vertx.core.streams.WriteStream
-
-
Uses of WriteStream in io.vertx.amqp
Subinterfaces of WriteStream in io.vertx.amqp Modifier and Type Interface Description interface
AmqpSender
AMQP Sender interface used to send messages. -
Uses of WriteStream in io.vertx.cassandra
Methods in io.vertx.cassandra with parameters of type WriteStream Modifier and Type Method Description default Future<Void>
CassandraRowStream. pipeTo(WriteStream<com.datastax.oss.driver.api.core.cql.Row> dst)
-
Uses of WriteStream in io.vertx.core.datagram
Methods in io.vertx.core.datagram that return WriteStream Modifier and Type Method Description WriteStream<Buffer>
DatagramSocket. sender(int port, String host)
-
Uses of WriteStream in io.vertx.core.file
Subinterfaces of WriteStream in io.vertx.core.file Modifier and Type Interface Description interface
AsyncFile
Represents a file on the file-system which can be read from, or written to asynchronously. -
Uses of WriteStream in io.vertx.core.http
Subinterfaces of WriteStream in io.vertx.core.http Modifier and Type Interface Description interface
ClientWebSocket
Represents a client-side WebSocket.interface
HttpClientRequest
Represents a client-side HTTP request.interface
HttpServerResponse
Represents a server-side HTTP response.interface
ServerWebSocket
Represents a server side WebSocket.interface
WebSocket
Common WebSocket implementation.interface
WebSocketBase
Base WebSocket implementation. -
Uses of WriteStream in io.vertx.core.net
Subinterfaces of WriteStream in io.vertx.core.net Modifier and Type Interface Description interface
NetSocket
Represents a socket-like interface to a TCP connection on either the client or the server side. -
Uses of WriteStream in io.vertx.core.streams
Methods in io.vertx.core.streams that return WriteStream Modifier and Type Method 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.WriteStream<T>
WriteStream. setWriteQueueMaxSize(int maxSize)
Set the maximum size of the write queue tomaxSize
.Methods in io.vertx.core.streams with parameters of type WriteStream Modifier and Type Method Description default Future<Void>
ReadStream. pipeTo(WriteStream<T> dst)
Pipe thisReadStream
to theWriteStream
.Future<Void>
Pipe. to(WriteStream<T> dst)
Start to pipe the elements to the destinationWriteStream
. -
Uses of WriteStream in io.vertx.ext.mongo
Methods in io.vertx.ext.mongo with parameters of type WriteStream Modifier and Type Method Description Future<Long>
MongoGridFsClient. downloadByFileName(WriteStream<Buffer> stream, String fileName)
Future<Long>
MongoGridFsClient. downloadByFileNameWithOptions(WriteStream<Buffer> stream, String fileName, GridFsDownloadOptions options)
Future<Long>
MongoGridFsClient. downloadById(WriteStream<Buffer> stream, String id)
-
Uses of WriteStream in io.vertx.ext.reactivestreams
Subinterfaces of WriteStream in io.vertx.ext.reactivestreams Modifier and Type Interface Description interface
ReactiveWriteStream<T>
A Vert.x write stream that also implements reactive streams publisher interface. -
Uses of WriteStream in io.vertx.ext.web.codec
Methods in io.vertx.ext.web.codec with parameters of type WriteStream Modifier and Type Method 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. -
Uses of WriteStream in io.vertx.ext.web.codec.spi
Subinterfaces of WriteStream in io.vertx.ext.web.codec.spi Modifier and Type Interface Description interface
BodyStream<T>
The body stream decodes aWriteStream
into the aT
instance. -
Uses of WriteStream in io.vertx.ext.web.handler.sockjs
Subinterfaces of WriteStream in io.vertx.ext.web.handler.sockjs Modifier and Type Interface Description interface
SockJSSocket
You interact with SockJS clients through instances of SockJS socket. -
Uses of WriteStream in io.vertx.grpc.client
Subinterfaces of WriteStream in io.vertx.grpc.client Modifier and Type Interface Description interface
GrpcClientRequest<Req,Resp>
A request to a gRPC server. -
Uses of WriteStream in io.vertx.grpc.common
Subinterfaces of WriteStream in io.vertx.grpc.common Modifier and Type Interface Description interface
GrpcWriteStream<T>
-
Uses of WriteStream in io.vertx.grpc.server
Subinterfaces of WriteStream in io.vertx.grpc.server Modifier and Type Interface Description interface
GrpcServerResponse<Req,Resp>
-
Uses of WriteStream in io.vertx.grpc.stub
Classes in io.vertx.grpc.stub that implement WriteStream Modifier and Type Class Description class
GrpcWriteStream<T>
Methods in io.vertx.grpc.stub that return WriteStream Modifier and Type Method Description WriteStream<T>
GrpcWriteStream. drainHandler(Handler<Void> hndlr)
WriteStream<T>
GrpcWriteStream. exceptionHandler(Handler<Throwable> hndlr)
WriteStream<T>
GrpcWriteStream. setWriteQueueMaxSize(int i)
Method parameters in io.vertx.grpc.stub with type arguments of type WriteStream Modifier and Type Method Description static <I,O>
ReadStream<O>ClientCalls. manyToMany(io.vertx.core.internal.ContextInternal ctx, Handler<WriteStream<I>> requestHandler, java.util.function.Function<StreamObserver<O>,StreamObserver<I>> delegate)
static <I,O>
ReadStream<O>ClientCalls. manyToMany(io.vertx.core.internal.ContextInternal ctx, Handler<WriteStream<I>> requestHandler, java.util.function.Function<StreamObserver<O>,StreamObserver<I>> delegate, Handler<Throwable> exceptionHandler)
static <I,O>
ReadStream<O>ClientCalls. manyToMany(io.vertx.core.internal.ContextInternal ctx, Handler<WriteStream<I>> requestHandler, java.util.function.Function<StreamObserver<O>,StreamObserver<I>> delegate, Handler<O> handler, Handler<Void> endHandler, Handler<Throwable> exceptionHandler)
static <I,O>
StreamObserver<I>ServerCalls. manyToMany(StreamObserver<O> response, String compression, java.util.function.BiConsumer<ReadStream<I>,WriteStream<O>> delegate)
static <I,O>
Future<O>ClientCalls. manyToOne(io.vertx.core.internal.ContextInternal ctx, Handler<WriteStream<I>> requestHandler, java.util.function.Function<StreamObserver<O>,StreamObserver<I>> delegate)
static <I,O>
voidServerCalls. oneToMany(I request, StreamObserver<O> response, String compression, java.util.function.BiConsumer<I,WriteStream<O>> delegate)
-
Uses of WriteStream in io.vertx.kafka.client.producer
Subinterfaces of WriteStream in io.vertx.kafka.client.producer Modifier and Type Interface Description interface
KafkaProducer<K,V>
Vert.x Kafka producer.interface
KafkaWriteStream<K,V>
AWriteStream
for writing to KafkaProducerRecord
. -
Uses of WriteStream in io.vertx.reactivex
Methods in io.vertx.reactivex with parameters of type WriteStream Modifier and Type Method Description static <T> WriteStreamObserver<T>
RxHelper. toObserver(WriteStream<T> stream)
Adapts a Vert.xWriteStream
to an RxJavaObserver
.static <R,T>
WriteStreamObserver<R>RxHelper. toObserver(WriteStream<T> stream, java.util.function.Function<R,T> mapping)
LikeRxHelper.toObserver(WriteStream)
, except the providedmapping
function is applied to eachObservable
item.static <T> WriteStreamSubscriber<T>
RxHelper. toSubscriber(WriteStream<T> stream)
Adapts a Vert.xWriteStream
to an RxJavaSubscriber
.static <R,T>
WriteStreamSubscriber<R>RxHelper. toSubscriber(WriteStream<T> stream, java.util.function.Function<R,T> mapping)
LikeRxHelper.toSubscriber(WriteStream)
, except the providedmapping
function is applied to eachFlowable
item. -
Uses of WriteStream in io.vertx.reactivex.core.streams
Methods in io.vertx.reactivex.core.streams that return WriteStream Modifier and Type Method Description WriteStream
WriteStream. getDelegate()
Methods in io.vertx.reactivex.core.streams with parameters of type WriteStream Modifier and Type Method Description static <T> WriteStream<T>
WriteStream. newInstance(WriteStream arg)
static <T> WriteStream<T>
WriteStream. newInstance(WriteStream arg, io.vertx.lang.rx.TypeArg<T> __typeArg_T)
-
Uses of WriteStream in io.vertx.rxjava3
Methods in io.vertx.rxjava3 with parameters of type WriteStream Modifier and Type Method Description static <T> WriteStreamObserver<T>
RxHelper. toObserver(WriteStream<T> stream)
Adapts a Vert.xWriteStream
to an RxJavaObserver
.static <R,T>
WriteStreamObserver<R>RxHelper. toObserver(WriteStream<T> stream, java.util.function.Function<R,T> mapping)
LikeRxHelper.toObserver(WriteStream)
, except the providedmapping
function is applied to eachObservable
item.static <T> WriteStreamSubscriber<T>
RxHelper. toSubscriber(WriteStream<T> stream)
Adapts a Vert.xWriteStream
to an RxJavaSubscriber
.static <R,T>
WriteStreamSubscriber<R>RxHelper. toSubscriber(WriteStream<T> stream, java.util.function.Function<R,T> mapping)
LikeRxHelper.toSubscriber(WriteStream)
, except the providedmapping
function is applied to eachFlowable
item. -
Uses of WriteStream in io.vertx.rxjava3.core.streams
Methods in io.vertx.rxjava3.core.streams that return WriteStream Modifier and Type Method Description WriteStream
WriteStream. getDelegate()
Methods in io.vertx.rxjava3.core.streams with parameters of type WriteStream Modifier and Type Method Description static <T> WriteStream<T>
WriteStream. newInstance(WriteStream arg)
static <T> WriteStream<T>
WriteStream. newInstance(WriteStream arg, io.vertx.lang.rx.TypeArg<T> __typeArg_T)
-