Uses of Interface
io.vertx.core.streams.StreamBase
-
-
Uses of StreamBase in io.vertx.amqp
Subinterfaces of StreamBase in io.vertx.amqp Modifier and Type Interface Description interface
AmqpReceiver
Interface used to consume AMQP message as a stream of message.interface
AmqpSender
AMQP Sender interface used to send messages. -
Uses of StreamBase in io.vertx.cassandra
Subinterfaces of StreamBase in io.vertx.cassandra Modifier and Type Interface Description interface
CassandraRowStream
AReadStream
forRow
consumption. -
Uses of StreamBase in io.vertx.core.eventbus
Subinterfaces of StreamBase in io.vertx.core.eventbus Modifier and Type Interface Description interface
MessageConsumer<T>
An event bus consumer object representing a stream of message to anEventBus
address that can be read from. -
Uses of StreamBase in io.vertx.core.file
Subinterfaces of StreamBase 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 StreamBase in io.vertx.core.http
Subinterfaces of StreamBase 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
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
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 StreamBase in io.vertx.core.net
Subinterfaces of StreamBase 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 StreamBase in io.vertx.core.parsetools
Subinterfaces of StreamBase in io.vertx.core.parsetools Modifier and Type Interface 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. -
Uses of StreamBase in io.vertx.core.streams
Subinterfaces of StreamBase in io.vertx.core.streams Modifier and Type Interface Description interface
ReadStream<T>
Represents a stream of items that can be read from.interface
WriteStream<T>
Represents a stream of data that can be written to.Methods in io.vertx.core.streams that return StreamBase Modifier and Type Method Description StreamBase
StreamBase. exceptionHandler(Handler<Throwable> handler)
Set an exception handler. -
Uses of StreamBase in io.vertx.ext.reactivestreams
Subinterfaces of StreamBase in io.vertx.ext.reactivestreams Modifier and Type Interface Description interface
ReactiveReadStream<T>
A Vert.x read stream that also implements reactive streams subscriber interface.interface
ReactiveWriteStream<T>
A Vert.x write stream that also implements reactive streams publisher interface. -
Uses of StreamBase in io.vertx.ext.unit.report
Subinterfaces of StreamBase in io.vertx.ext.unit.report Modifier and Type Interface Description interface
TestSuiteReport
The test suite reports is basically a stream of events reporting the test suite execution. -
Uses of StreamBase in io.vertx.ext.web
Subinterfaces of StreamBase in io.vertx.ext.web Modifier and Type Interface Description interface
WebServerRequest
Extends to access the routing context associated with the request. -
Uses of StreamBase in io.vertx.ext.web.codec.spi
Subinterfaces of StreamBase 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 StreamBase in io.vertx.ext.web.handler.sockjs
Subinterfaces of StreamBase 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 StreamBase in io.vertx.grpc.client
Subinterfaces of StreamBase in io.vertx.grpc.client Modifier and Type Interface Description interface
GrpcClientRequest<Req,Resp>
A request to a gRPC server.interface
GrpcClientResponse<Req,Resp>
A response from a gRPC server. -
Uses of StreamBase in io.vertx.grpc.common
Subinterfaces of StreamBase in io.vertx.grpc.common Modifier and Type Interface Description interface
GrpcReadStream<T>
interface
GrpcWriteStream<T>
-
Uses of StreamBase in io.vertx.grpc.server
Subinterfaces of StreamBase in io.vertx.grpc.server Modifier and Type Interface Description interface
GrpcServerRequest<Req,Resp>
interface
GrpcServerResponse<Req,Resp>
-
Uses of StreamBase in io.vertx.grpc.stub
Classes in io.vertx.grpc.stub that implement StreamBase Modifier and Type Class Description class
GrpcWriteStream<T>
-
Uses of StreamBase in io.vertx.kafka.client.consumer
Subinterfaces of StreamBase in io.vertx.kafka.client.consumer Modifier and Type Interface Description interface
KafkaConsumer<K,V>
Vert.x Kafka consumer.interface
KafkaReadStream<K,V>
AReadStream
for consuming KafkaConsumerRecord
. -
Uses of StreamBase in io.vertx.kafka.client.producer
Subinterfaces of StreamBase 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 StreamBase in io.vertx.pgclient.pubsub
Subinterfaces of StreamBase in io.vertx.pgclient.pubsub Modifier and Type Interface Description interface
PgChannel
A channel to Postgres that tracks the subscription to a given Postgres channel using theLISTEN/UNLISTEN
commands. -
Uses of StreamBase in io.vertx.rabbitmq
Subinterfaces of StreamBase in io.vertx.rabbitmq Modifier and Type Interface Description interface
RabbitMQConsumer
A stream of messages from a rabbitmq queue. -
Uses of StreamBase in io.vertx.reactivex.core.streams
Methods in io.vertx.reactivex.core.streams that return StreamBase Modifier and Type Method Description StreamBase
StreamBase. getDelegate()
Methods in io.vertx.reactivex.core.streams with parameters of type StreamBase Modifier and Type Method Description static StreamBase
StreamBase. newInstance(StreamBase arg)
-
Uses of StreamBase in io.vertx.redis.client
Subinterfaces of StreamBase in io.vertx.redis.client Modifier and Type Interface Description interface
RedisConnection
A simple Redis client. -
Uses of StreamBase in io.vertx.rxjava3.core.streams
Methods in io.vertx.rxjava3.core.streams that return StreamBase Modifier and Type Method Description StreamBase
StreamBase. getDelegate()
Methods in io.vertx.rxjava3.core.streams with parameters of type StreamBase Modifier and Type Method Description static StreamBase
StreamBase. newInstance(StreamBase arg)
-
Uses of StreamBase in io.vertx.sqlclient
Subinterfaces of StreamBase in io.vertx.sqlclient Modifier and Type Interface Description interface
RowStream<T>
A row oriented stream.
-