A B C D E F G H I J K L M N O P Q R S T U V W X Z _ 
All Classes All Packages

A

abort(String) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Aborts a transaction.
abort(String, Map<String, String>) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Aborts a transaction.
abortHandler(Handler<ServerFrame>) - Method in class io.vertx.reactivex.ext.stomp.StompServerHandler
Configures the action to execute when a ABORT frame is received.
abortTransaction() - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
Aborts the ongoing transaction.
absoluteURI() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
 
absoluteURI() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
 
accept() - Method in class io.vertx.reactivex.core.http.ServerWebSocketHandshake
Accept the WebSocket and terminate the WebSocket handshake.
accept() - Method in class io.vertx.reactivex.ext.web.ParsedHeaderValues
 
accept() - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Like MqttEndpoint.accept() with no session is present.
accept(boolean) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Sends the CONNACK message to the remote MQTT client with "connection accepted" return code.
accept(boolean, MqttProperties) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Sends the CONNACK message to the remote MQTT client with "connection accepted" return code.
ACCEPT - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Accept header name
ACCEPT_CHARSET - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Accept-Charset header name
ACCEPT_ENCODING - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Accept-Encoding header name
ACCEPT_LANGUAGE - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Accept-Language header name
ACCEPT_PATCH - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Accept-Patch header name
ACCEPT_RANGES - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Accept-Ranges header name
acceptableLanguages() - Method in class io.vertx.reactivex.ext.web.RoutingContext
Returns the languages for the current request.
acceptCharset() - Method in class io.vertx.reactivex.ext.web.ParsedHeaderValues
 
accepted() - Method in class io.vertx.reactivex.amqp.AmqpMessage
When receiving a message, and when auto-acknowledgement is disabled, this method is used to acknowledge the incoming message.
acceptEncoding() - Method in class io.vertx.reactivex.ext.web.ParsedHeaderValues
 
acceptLanguage() - Method in class io.vertx.reactivex.ext.web.ParsedHeaderValues
 
ACCESS_CONTROL_ALLOW_CREDENTIALS - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Access-Control-Allow-Credentials header name
ACCESS_CONTROL_ALLOW_HEADERS - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Access-Control-Allow-Headers header name
ACCESS_CONTROL_ALLOW_METHODS - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Access-Control-Allow-Methods header name
ACCESS_CONTROL_ALLOW_ORIGIN - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Access-Control-Allow-Origin header name
ACCESS_CONTROL_ALLOW_PRIVATE_NETWORK - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Access-Control-Allow-Private-Network header name
ACCESS_CONTROL_EXPOSE_HEADERS - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Access-Control-Expose-Headers header name
ACCESS_CONTROL_MAX_AGE - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Access-Control-Max-Age header name
ACCESS_CONTROL_REQUEST_HEADERS - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Access-Control-Request-Headers header name
ACCESS_CONTROL_REQUEST_METHOD - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Access-Control-Request-Method header name
ACCESS_CONTROL_REQUEST_PRIVATE_NETWORK - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Access-Control-Request-Private-Network header name
ack() - Method in class io.vertx.reactivex.mqtt.messages.MqttPublishMessage
Send the PUBACK/PUBCOMP to the broker.
ack(StompServerConnection, Frame) - Method in class io.vertx.reactivex.ext.stomp.Destination
Handles a ACK frame.
ack(String) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Sends an acknowledgement for a specific message.
ack(String, String) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Sends an acknowledgement for the given frame.
ackHandler(Handler<ServerFrame>) - Method in class io.vertx.reactivex.ext.stomp.StompServerHandler
Configures the action to execute when a ACK frame is received.
Acknowledgement - Class in io.vertx.reactivex.ext.stomp
Structure passed to acknowledgement handler called when a ACK or NACK frame is received.
Acknowledgement(Acknowledgement) - Constructor for class io.vertx.reactivex.ext.stomp.Acknowledgement
 
Acknowledgement(Object) - Constructor for class io.vertx.reactivex.ext.stomp.Acknowledgement
 
acl(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
A container for Access List Control commands.
activeStreams() - Method in class io.vertx.reactivex.core.http.HttpClientConnection
 
actualConnection() - Method in class io.vertx.reactivex.pgclient.pubsub.PgSubscriber
 
actualPort() - Method in class io.vertx.reactivex.core.http.HttpServer
The actual port the server is listening on.
actualPort() - Method in class io.vertx.reactivex.core.net.NetServer
The actual port the server is listening on.
actualPort() - Method in class io.vertx.reactivex.ext.stomp.StompServer
Gets the port on which the server is listening.
actualPort() - Method in class io.vertx.reactivex.mqtt.MqttServer
The actual port the server is listening on.
add(AuthenticationProvider) - Method in class io.vertx.reactivex.ext.auth.ChainAuth
Appends a auth provider to the chain.
add(AuthenticationHandler) - Method in class io.vertx.reactivex.ext.web.handler.ChainAuthHandler
Appends a auth provider to the chain.
addAll(JsonObject) - Method in class io.vertx.reactivex.uritemplate.Variables
Populates with a JSON object: null are conserved JsonArray is converted to List JsonObject is converted to Map any other value is converted to a string Note that nested JSON elements are converted to a string, so { "user": { "first_name": "John", "last_name": "Doe", "address" : { "city": "Paris", etc... } } } flattens the JSON "address" to the string "{\"city\":\"Paris\",etc...}".
addAndGet(long) - Method in class io.vertx.reactivex.core.shareddata.Counter
Add the value to the counter atomically and return the new count
addArrayOfBigDecimal(BigDecimal[]) - Method in class io.vertx.reactivex.sqlclient.Tuple
Add an array of value at the end of the tuple.
addArrayOfBoolean(Boolean[]) - Method in class io.vertx.reactivex.sqlclient.Tuple
Add an array of Boolean value at the end of the tuple.
addArrayOfDouble(Double[]) - Method in class io.vertx.reactivex.sqlclient.Tuple
Add an array of Double value at the end of the tuple.
addArrayOfFloat(Float[]) - Method in class io.vertx.reactivex.sqlclient.Tuple
Add an array of Float value at the end of the tuple.
addArrayOfInteger(Integer[]) - Method in class io.vertx.reactivex.sqlclient.Tuple
Add an array of Integer value at the end of the tuple.
addArrayOfJsonArray(JsonArray[]) - Method in class io.vertx.reactivex.sqlclient.Tuple
Add an array of value at the end of the tuple.
addArrayOfJsonObject(JsonObject[]) - Method in class io.vertx.reactivex.sqlclient.Tuple
Add an array of value at the end of the tuple.
addArrayOfLocalDate(LocalDate[]) - Method in class io.vertx.reactivex.sqlclient.Tuple
Add an array of value at the end of the tuple.
addArrayOfLocalDateTime(LocalDateTime[]) - Method in class io.vertx.reactivex.sqlclient.Tuple
Add an array of value at the end of the tuple.
addArrayOfLocalTime(LocalTime[]) - Method in class io.vertx.reactivex.sqlclient.Tuple
Add an array of value at the end of the tuple.
addArrayOfLong(Long[]) - Method in class io.vertx.reactivex.sqlclient.Tuple
Add an array of Long value at the end of the tuple.
addArrayOfOffsetDateTime(OffsetDateTime[]) - Method in class io.vertx.reactivex.sqlclient.Tuple
Add an array of value at the end of the tuple.
addArrayOfOffsetTime(OffsetTime[]) - Method in class io.vertx.reactivex.sqlclient.Tuple
Add an array of value at the end of the tuple.
addArrayOfShort(Short[]) - Method in class io.vertx.reactivex.sqlclient.Tuple
Add an array of Short value at the end of the tuple.
addArrayOfString(String[]) - Method in class io.vertx.reactivex.sqlclient.Tuple
Add an array of String value at the end of the tuple.
addArrayOfTemporal(Temporal[]) - Method in class io.vertx.reactivex.sqlclient.Tuple
Add an array of value at the end of the tuple.
addArrayOfUUID(UUID[]) - Method in class io.vertx.reactivex.sqlclient.Tuple
Add an array of value at the end of the tuple.
addAuthorization(Authorization) - Method in class io.vertx.reactivex.ext.auth.authorization.AndAuthorization
 
addAuthorization(Authorization) - Method in class io.vertx.reactivex.ext.auth.authorization.OrAuthorization
 
addAuthorizationProvider(AuthorizationProvider) - Method in class io.vertx.reactivex.ext.web.handler.AuthorizationHandler
Adds a provider that shall be used to retrieve the required authorizations for the user to attest.
addBigDecimal(BigDecimal) - Method in class io.vertx.reactivex.sqlclient.Tuple
Add a value at the end of the tuple.
addBodyEndHandler(Handler<Void>) - Method in class io.vertx.reactivex.ext.web.RoutingContext
Provides a handler that will be called after the last part of the body is written to the wire.
addBoolean(Boolean) - Method in class io.vertx.reactivex.sqlclient.Tuple
Add a boolean value at the end of the tuple.
addBuffer(Buffer) - Method in class io.vertx.reactivex.sqlclient.Tuple
Add a buffer value at the end of the tuple.
addConfirmListener(int) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Add a Confirm Listener to the channel.
addCookie(Cookie) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Add a cookie.
addDefaultHandler(Handler<RoutingContext>) - Method in class io.vertx.reactivex.ext.web.handler.MultiTenantHandler
Add a default handler for the case when no tenant was matched.
addDirective(String, String) - Method in class io.vertx.reactivex.ext.web.handler.CSPHandler
Adds a single directive entry to the handler.
addDouble(Double) - Method in class io.vertx.reactivex.sqlclient.Tuple
Add a double value at the end of the tuple.
addEndHandler(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.web.RoutingContext
Add an end handler for the request/response context.
addFailureHandler(Handler<RoutingContext>) - Method in class io.vertx.reactivex.ext.web.openapi.router.OpenAPIRoute
Adds a failure handler for this route
addFloat(Float) - Method in class io.vertx.reactivex.sqlclient.Tuple
Add a float value at the end of the tuple.
addHandler(Handler<RoutingContext>) - Method in class io.vertx.reactivex.ext.web.openapi.router.OpenAPIRoute
Adds a handler for this route which is executed after the security and validation handlers defined in the contract
addHeader(KafkaHeader) - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducerRecord
Add an header to this record.
addHeader(CharSequence, CharSequence) - Method in class io.vertx.reactivex.ext.web.client.WebClientSession
Configure the client to add an HTTP header to every request.
addHeader(CharSequence, Iterable<CharSequence>) - Method in class io.vertx.reactivex.ext.web.client.WebClientSession
Configure the client to add an HTTP header to every request.
addHeader(String, Buffer) - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducerRecord
addHeader(String, Iterable<String>) - Method in class io.vertx.reactivex.ext.web.client.WebClientSession
Configure the client to add an HTTP header to every request.
addHeader(String, String) - Method in class io.vertx.reactivex.ext.mail.MailAttachment
Add an header to this attachment.
addHeader(String, String) - Method in class io.vertx.reactivex.ext.web.client.WebClientSession
Configure the client to add an HTTP header to every request.
addHeader(String, String) - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducerRecord
addHeaders(List<KafkaHeader>) - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducerRecord
Add a list of headers to this record.
addHeadersEndHandler(Handler<Void>) - Method in class io.vertx.reactivex.ext.web.RoutingContext
Add a handler that will be called just before headers are written to the response.
addInboundInterceptor(Handler<DeliveryContext<T>>) - Method in class io.vertx.reactivex.core.eventbus.EventBus
Add an interceptor that will be called whenever a message is received by Vert.x
addingHeaders(Function<RoutingContext, MultiMap>) - Method in class io.vertx.reactivex.ext.web.handler.graphql.GraphiQLHandlerBuilder
Customize the HTTP headers to add to GraphQL requests sent by the GraphiQL user interface.
addInteger(Integer) - Method in class io.vertx.reactivex.sqlclient.Tuple
Add an integer value at the end of the tuple.
addJsonArray(JsonArray) - Method in class io.vertx.reactivex.sqlclient.Tuple
Add a value at the end of the tuple.
addJsonObject(JsonObject) - Method in class io.vertx.reactivex.sqlclient.Tuple
Add a value at the end of the tuple.
addLocalDate(LocalDate) - Method in class io.vertx.reactivex.sqlclient.Tuple
Add a LocalDate value at the end of the tuple.
addLocalDateTime(LocalDateTime) - Method in class io.vertx.reactivex.sqlclient.Tuple
Add a LocalDateTime value at the end of the tuple.
addLocalTime(LocalTime) - Method in class io.vertx.reactivex.sqlclient.Tuple
Add a LocalTime value at the end of the tuple.
addLong(Long) - Method in class io.vertx.reactivex.sqlclient.Tuple
Add a long value at the end of the tuple.
addOffsetDateTime(OffsetDateTime) - Method in class io.vertx.reactivex.sqlclient.Tuple
Add a OffsetDateTime value at the end of the tuple.
addOffsetTime(OffsetTime) - Method in class io.vertx.reactivex.sqlclient.Tuple
Add a OffsetTime value at the end of the tuple.
addOrigin(String) - Method in class io.vertx.reactivex.ext.web.handler.CorsHandler
Add an origin to the list of allowed Origins.
addOrigins(List<String>) - Method in class io.vertx.reactivex.ext.web.handler.CorsHandler
Set the list of allowed origins.
addOriginsWithRegex(List<String>) - Method in class io.vertx.reactivex.ext.web.handler.CorsHandler
Set the list of allowed regex origins.
addOriginWithRegex(String) - Method in class io.vertx.reactivex.ext.web.handler.CorsHandler
Add a regex origin to the list of allowed Origins.
addOutboundInterceptor(Handler<DeliveryContext<T>>) - Method in class io.vertx.reactivex.core.eventbus.EventBus
Add an interceptor that will be called whenever a message is sent from Vert.x
addPolicy(Policy) - Method in class io.vertx.reactivex.ext.auth.abac.PolicyBasedAuthorizationProvider
 
addQueryParam(String, String) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Add a query parameter to the request.
address() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
address() - Method in class io.vertx.reactivex.amqp.AmqpReceiver
The listened address.
address() - Method in class io.vertx.reactivex.amqp.AmqpSender
 
address() - Method in class io.vertx.reactivex.core.eventbus.Message
The address the message was sent to
address() - Method in class io.vertx.reactivex.core.eventbus.MessageConsumer
 
address() - Method in class io.vertx.reactivex.core.eventbus.MessageProducer
 
address() - Method in class io.vertx.reactivex.core.net.endpoint.ServerEndpoint
 
address(String) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
addService(Service) - Method in class io.vertx.reactivex.grpc.server.GrpcServer
Add a service to this gRPC server.
addShort(Short) - Method in class io.vertx.reactivex.sqlclient.Tuple
Add a short value at the end of the tuple.
addString(String) - Method in class io.vertx.reactivex.sqlclient.Tuple
Add a string value at the end of the tuple.
addTemporal(Temporal) - Method in class io.vertx.reactivex.sqlclient.Tuple
Add a Temporal value at the end of the tuple.
addTenantHandler(String, Handler<RoutingContext>) - Method in class io.vertx.reactivex.ext.web.handler.MultiTenantHandler
Add a handler for a given tenant to this handler.
addUUID(UUID) - Method in class io.vertx.reactivex.sqlclient.Tuple
Add a UUID value at the end of the tuple.
addValue(Object) - Method in class io.vertx.reactivex.sqlclient.Tuple
Add an object value at the end of the tuple.
after(Handler<TestContext>) - Method in class io.vertx.reactivex.ext.unit.TestSuite
Set a callback executed after the tests.
afterEach(Handler<TestContext>) - Method in class io.vertx.reactivex.ext.unit.TestSuite
Set a callback executed after each test and before the suite after callback.
AGE - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Age header name
agentInfo() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the configuration and member information of the local agent
aggregate(String, JsonArray) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Run aggregate MongoDB command with default AggregateOptions.
aggregateWithOptions(String, JsonArray, AggregateOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Run aggregate MongoDB command.
all() - Method in class io.vertx.reactivex.cassandra.ResultSet
The method should not be used concurrently with others like ResultSet.fetchNextPage() or ResultSet.one().
all() - Static method in class io.vertx.reactivex.ext.auth.ChainAuth
Create a Chainable Auth Provider auth provider that will resolve if all auth providers are successful.
all() - Static method in class io.vertx.reactivex.ext.web.handler.ChainAuthHandler
Create a chain authentication handler that will assert that all handlers pass the verification.
ALLOW - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Allow header name
allowCredentials(boolean) - Method in class io.vertx.reactivex.ext.web.handler.CorsHandler
Set whether credentials are allowed.
allowedHeader(String) - Method in class io.vertx.reactivex.ext.web.handler.CorsHandler
Add an allowed header
allowedHeaders(Set<String>) - Method in class io.vertx.reactivex.ext.web.handler.CorsHandler
Add a set of allowed headers
allowedMethod(HttpMethod) - Method in class io.vertx.reactivex.ext.web.handler.CorsHandler
Add an allowed method
allowedMethods(Set<HttpMethod>) - Method in class io.vertx.reactivex.ext.web.handler.CorsHandler
Add a set of allowed methods
allowForward(AllowForwardHeaders) - Method in class io.vertx.reactivex.ext.web.Router
Set whether the router should parse "forwarded"-type headers
allowPrivateNetwork(boolean) - Method in class io.vertx.reactivex.ext.web.handler.CorsHandler
Set whether access from public to private networks are allowed.
AmazonCognitoAuth - Class in io.vertx.reactivex.ext.auth.oauth2.providers
Simplified factory to create an for Amazon Cognito.
AmazonCognitoAuth(AmazonCognitoAuth) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.AmazonCognitoAuth
 
AmazonCognitoAuth(Object) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.AmazonCognitoAuth
 
AmqpClient - Class in io.vertx.reactivex.amqp
AMQP Client entry point.
AmqpClient(AmqpClient) - Constructor for class io.vertx.reactivex.amqp.AmqpClient
 
AmqpClient(Object) - Constructor for class io.vertx.reactivex.amqp.AmqpClient
 
AmqpConnection - Class in io.vertx.reactivex.amqp
Once connected to the broker or router, you get a connection.
AmqpConnection(AmqpConnection) - Constructor for class io.vertx.reactivex.amqp.AmqpConnection
 
AmqpConnection(Object) - Constructor for class io.vertx.reactivex.amqp.AmqpConnection
 
AmqpMessage - Class in io.vertx.reactivex.amqp
Represents an AMQP message.
AmqpMessage(AmqpMessage) - Constructor for class io.vertx.reactivex.amqp.AmqpMessage
 
AmqpMessage(Object) - Constructor for class io.vertx.reactivex.amqp.AmqpMessage
 
AmqpMessageBuilder - Class in io.vertx.reactivex.amqp
Builder to create a new AmqpMessage.
AmqpMessageBuilder(AmqpMessageBuilder) - Constructor for class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
AmqpMessageBuilder(Object) - Constructor for class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
AmqpReceiver - Class in io.vertx.reactivex.amqp
Interface used to consume AMQP message as a stream of message.
AmqpReceiver(AmqpReceiver) - Constructor for class io.vertx.reactivex.amqp.AmqpReceiver
 
AmqpReceiver(Object) - Constructor for class io.vertx.reactivex.amqp.AmqpReceiver
 
AmqpSender - Class in io.vertx.reactivex.amqp
AMQP Sender interface used to send messages.
AmqpSender(AmqpSender) - Constructor for class io.vertx.reactivex.amqp.AmqpSender
 
AmqpSender(Object) - Constructor for class io.vertx.reactivex.amqp.AmqpSender
 
AndAuthorization - Class in io.vertx.reactivex.ext.auth.authorization
Allows to perform a logical 'and' between several authorizations
AndAuthorization(AndAuthorization) - Constructor for class io.vertx.reactivex.ext.auth.authorization.AndAuthorization
 
AndAuthorization(Object) - Constructor for class io.vertx.reactivex.ext.auth.authorization.AndAuthorization
 
annotate(String, String) - Method in class io.vertx.reactivex.json.schema.JsonSchema
Annotates the schema.
any() - Static method in class io.vertx.reactivex.ext.auth.ChainAuth
Create a Chainable Auth Provider auth provider that will resolve on the first success.
any() - Static method in class io.vertx.reactivex.ext.web.handler.ChainAuthHandler
Create a chain authentication handler that will assert that any handler passes the verification.
api(Redis) - Static method in class io.vertx.reactivex.redis.client.RedisAPI
 
api(RedisConnection) - Static method in class io.vertx.reactivex.redis.client.RedisAPI
 
apiKeyHandler(APIKeyHandler) - Method in class io.vertx.reactivex.ext.web.openapi.router.Security
Configure the to be used when creating the router.
APIKeyHandler - Class in io.vertx.reactivex.ext.web.handler
An authentication handler that provides API Key support.
APIKeyHandler(APIKeyHandler) - Constructor for class io.vertx.reactivex.ext.web.handler.APIKeyHandler
 
APIKeyHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.APIKeyHandler
 
append(int) - Method in class io.vertx.reactivex.core.json.pointer.JsonPointer
Append the index as reference token to JsonPointer
append(JsonPointer) - Method in class io.vertx.reactivex.core.json.pointer.JsonPointer
Append all tokens of pointer to this pointer
Note: The base URI of this pointer will remain untouched
append(String) - Method in class io.vertx.reactivex.core.json.pointer.JsonPointer
Append an unescaped token to this pointer
Note: If you provide escaped path the behaviour is undefined
append(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Append a value to a key.
append(List<String>) - Method in class io.vertx.reactivex.core.json.pointer.JsonPointer
Append an unescaped list of tokens to JsonPointer
Note: If you provide escaped paths the behaviour is undefined
appendArrayElement(Object, Object) - Method in class io.vertx.reactivex.core.json.pointer.JsonPointerIterator
Append array element
AppleIdAuth - Class in io.vertx.reactivex.ext.auth.oauth2.providers
Simplified factory to create an for Apple.
AppleIdAuth(AppleIdAuth) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.AppleIdAuth
 
AppleIdAuth(Object) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.AppleIdAuth
 
APPLICATION_HAL_JSON - Static variable in class io.vertx.reactivex.openapi.contract.MediaType
 
APPLICATION_JSON - Static variable in class io.vertx.reactivex.openapi.contract.MediaType
 
APPLICATION_JSON_UTF8 - Static variable in class io.vertx.reactivex.openapi.contract.MediaType
 
APPLICATION_OCTET_STREAM - Static variable in class io.vertx.reactivex.openapi.contract.MediaType
 
APPLICATION_X_WWW_FORM_URLENCODED - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
application/x-www-form-urlencoded header value
applicationLayerProtocol() - Method in class io.vertx.reactivex.core.net.NetSocket
 
applicationProperties() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
applicationProperties(JsonObject) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
apply(RoutingContext) - Method in class io.vertx.reactivex.ext.web.validation.RequestPredicate
 
arrayEventMode() - Method in class io.vertx.reactivex.core.parsetools.JsonParser
Flip the parser to emit a stream of events for each new json array.
ArrayParserFactory - Class in io.vertx.reactivex.ext.web.validation.builder
This interface is used to create able to parse serialized array structures.
ArrayParserFactory(ArrayParserFactory) - Constructor for class io.vertx.reactivex.ext.web.validation.builder.ArrayParserFactory
 
ArrayParserFactory(Object) - Constructor for class io.vertx.reactivex.ext.web.validation.builder.ArrayParserFactory
 
arrayValueMode() - Method in class io.vertx.reactivex.core.parsetools.JsonParser
Flip the parser to emit a single value event for each new json array.
as(BodyCodec<U>) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Configure the request to decode the response with the responseCodec.
asJsonArray() - Method in class io.vertx.reactivex.ext.web.RequestBody
 
asJsonArray(int) - Method in class io.vertx.reactivex.ext.web.RequestBody
Gets the current body buffer as a .
asJsonObject() - Method in class io.vertx.reactivex.ext.web.RequestBody
 
asJsonObject(int) - Method in class io.vertx.reactivex.ext.web.RequestBody
Gets the current body buffer as a .
asking() - Method in class io.vertx.reactivex.redis.client.RedisAPI
Sent by cluster clients after an -ASK redirect.
asPojo(Class<R>) - Method in class io.vertx.reactivex.ext.web.RequestBody
 
asPojo(Class<R>, int) - Method in class io.vertx.reactivex.ext.web.RequestBody
 
assertEquals(Object, Object) - Method in class io.vertx.reactivex.ext.unit.TestContext
Assert the expected argument is equals to the actual argument.
assertEquals(Object, Object, String) - Method in class io.vertx.reactivex.ext.unit.TestContext
Assert the expected argument is equals to the actual argument.
assertFalse(boolean) - Method in class io.vertx.reactivex.ext.unit.TestContext
Assert the specified condition is false.
assertFalse(boolean, String) - Method in class io.vertx.reactivex.ext.unit.TestContext
Assert the specified condition is false.
assertInRange(double, double, double) - Method in class io.vertx.reactivex.ext.unit.TestContext
Asserts that the expected double argument is equals to the actual double argument within a positive delta.
assertInRange(double, double, double, String) - Method in class io.vertx.reactivex.ext.unit.TestContext
Asserts that the expected double argument is equals to the actual double argument within a positive delta.
assertNotEquals(Object, Object) - Method in class io.vertx.reactivex.ext.unit.TestContext
Assert the first argument is not equals to the second argument.
assertNotEquals(Object, Object, String) - Method in class io.vertx.reactivex.ext.unit.TestContext
Assert the first argument is not equals to the second argument.
assertNotNull(Object) - Method in class io.vertx.reactivex.ext.unit.TestContext
Assert the expected argument is not null.
assertNotNull(Object, String) - Method in class io.vertx.reactivex.ext.unit.TestContext
Assert the expected argument is not null.
assertNull(Object) - Method in class io.vertx.reactivex.ext.unit.TestContext
Assert the expected argument is null.
assertNull(Object, String) - Method in class io.vertx.reactivex.ext.unit.TestContext
Assert the expected argument is null.
assertTrue(boolean) - Method in class io.vertx.reactivex.ext.unit.TestContext
Assert the specified condition is true.
assertTrue(boolean, String) - Method in class io.vertx.reactivex.ext.unit.TestContext
Assert the specified condition is true.
assign(TopicPartition) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Manually assign a partition to this consumer.
assign(Set<TopicPartition>) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Manually assign a list of partition to this consumer.
assignment() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Get the set of partitions currently assigned to this consumer.
asString() - Method in class io.vertx.reactivex.ext.web.RequestBody
 
asString(String) - Method in class io.vertx.reactivex.ext.web.RequestBody
Get the entire HTTP request body as a string, assuming the specified encoding.
async() - Method in class io.vertx.reactivex.ext.unit.TestContext
Create and returns a new async object, the returned async controls the completion of the test.
async(int) - Method in class io.vertx.reactivex.ext.unit.TestContext
Create and returns a new async object, the returned async controls the completion of the test.
Async - Class in io.vertx.reactivex.ext.unit
An asynchronous exit point for a test.
Async(Async) - Constructor for class io.vertx.reactivex.ext.unit.Async
 
Async(Object) - Constructor for class io.vertx.reactivex.ext.unit.Async
 
asyncAssertFailure() - Method in class io.vertx.reactivex.ext.unit.TestContext
Creates and returns a new async handler, the returned handler controls the completion of the test.
asyncAssertFailure(Handler<Throwable>) - Method in class io.vertx.reactivex.ext.unit.TestContext
Creates and returns a new async handler, the returned handler controls the completion of the test.
asyncAssertSuccess() - Method in class io.vertx.reactivex.ext.unit.TestContext
Creates and returns a new async handler, the returned handler controls the completion of the test.
asyncAssertSuccess(Handler<T>) - Method in class io.vertx.reactivex.ext.unit.TestContext
Creates and returns a new async handler, the returned handler controls the completion of the test.
AsyncFile - Class in io.vertx.reactivex.core.file
Represents a file on the file-system which can be read from, or written to asynchronously.
AsyncFile(AsyncFile) - Constructor for class io.vertx.reactivex.core.file.AsyncFile
 
AsyncFile(Object) - Constructor for class io.vertx.reactivex.core.file.AsyncFile
 
AsyncFileLock - Class in io.vertx.reactivex.core.file
A lock on a region of an AsyncFile.
AsyncFileLock(AsyncFileLock) - Constructor for class io.vertx.reactivex.core.file.AsyncFileLock
 
AsyncFileLock(Object) - Constructor for class io.vertx.reactivex.core.file.AsyncFileLock
 
AsyncMap<K,​V> - Class in io.vertx.reactivex.core.shareddata
An asynchronous map.
AsyncMap(AsyncMap) - Constructor for class io.vertx.reactivex.core.shareddata.AsyncMap
 
AsyncMap(Object, TypeArg<K>, TypeArg<V>) - Constructor for class io.vertx.reactivex.core.shareddata.AsyncMap
 
attachment(String) - Method in class io.vertx.reactivex.ext.web.RoutingContext
Set Content-Disposition get to "attachment" with optional filename mime type.
attribute(String, String) - Method in class io.vertx.reactivex.ext.web.multipart.MultipartForm
Add an attribute form data part.
Attribute - Class in io.vertx.reactivex.ext.auth.abac
An attribute is a simple matcher for policies.
Attribute(Attribute) - Constructor for class io.vertx.reactivex.ext.auth.abac.Attribute
 
Attribute(Object) - Constructor for class io.vertx.reactivex.ext.auth.abac.Attribute
 
attributes() - Method in class io.vertx.reactivex.ext.auth.User
Gets extra attributes of the user.
audit(Marker, boolean) - Method in class io.vertx.reactivex.ext.auth.audit.SecurityAudit
 
auditHandlerFor(Marker) - Method in class io.vertx.reactivex.ext.auth.audit.SecurityAudit
 
auth() - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
 
auth(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Authenticate to the server.
authenticate(Function<RoutingContext, Single<User>>) - Method in class io.vertx.reactivex.ext.web.handler.SimpleAuthenticationHandler
This function will allow you to perform authentication the way you intended to.
authenticate(Credentials) - Method in class io.vertx.reactivex.ext.auth.authentication.AuthenticationProvider
Authenticate a user.
authenticate(Function<RoutingContext, Future<User>>) - Method in class io.vertx.reactivex.ext.web.handler.SimpleAuthenticationHandler
This function will allow you to perform authentication the way you intended to.
authenticated() - Method in class io.vertx.reactivex.ext.web.UserContext
 
authentication(Credentials) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Configure the request to perform HTTP Authentication.
authenticationData() - Method in class io.vertx.reactivex.mqtt.messages.MqttAuthenticationExchangeMessage
 
authenticationExchange(MqttAuthenticationExchangeMessage) - Method in class io.vertx.reactivex.mqtt.MqttClient
It is used for Enhanced Authentication and is able to carry an authentication method and authentication data.
authenticationExchange(MqttAuthenticationExchangeMessage) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Sends the AUTH message to the remote MQTT client
authenticationExchangeHandler(Handler<MqttAuthenticationExchangeMessage>) - Method in class io.vertx.reactivex.mqtt.MqttClient
Sets handler which will be called after AUTH packet receiving
authenticationExchangeHandler(Handler<MqttAuthenticationExchangeMessage>) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Set the auth handler on the MQTT endpoint.
AuthenticationHandler - Interface in io.vertx.reactivex.ext.web.handler
Base interface for auth handlers.
authenticationMethod() - Method in class io.vertx.reactivex.mqtt.messages.MqttAuthenticationExchangeMessage
 
AuthenticationProvider - Class in io.vertx.reactivex.ext.auth.authentication
User-facing interface for authenticating users.
AuthenticationProvider(AuthenticationProvider) - Constructor for class io.vertx.reactivex.ext.auth.authentication.AuthenticationProvider
 
AuthenticationProvider(Object) - Constructor for class io.vertx.reactivex.ext.auth.authentication.AuthenticationProvider
 
authenticatorFetcher(Function<String, Single<Authenticator>>) - Method in class io.vertx.reactivex.ext.auth.otp.hotp.HotpAuth
Provide a that can fetch s from a backend given an identifier argument.
authenticatorFetcher(Function<String, Single<Authenticator>>) - Method in class io.vertx.reactivex.ext.auth.otp.totp.TotpAuth
Provide a that can fetch s from a backend given an identifier argument.
authenticatorFetcher(Function<String, Future<Authenticator>>) - Method in class io.vertx.reactivex.ext.auth.otp.hotp.HotpAuth
Provide a that can fetch s from a backend given an identifier argument.
authenticatorFetcher(Function<String, Future<Authenticator>>) - Method in class io.vertx.reactivex.ext.auth.otp.totp.TotpAuth
Provide a that can fetch s from a backend given an identifier argument.
authenticatorUpdater(Function<Authenticator, Completable>) - Method in class io.vertx.reactivex.ext.auth.otp.hotp.HotpAuth
Provide a that can update or insert a .
authenticatorUpdater(Function<Authenticator, Completable>) - Method in class io.vertx.reactivex.ext.auth.otp.totp.TotpAuth
Provide a that can update or insert a .
authenticatorUpdater(Function<Authenticator, Future<Void>>) - Method in class io.vertx.reactivex.ext.auth.otp.hotp.HotpAuth
Provide a that can update or insert a .
authenticatorUpdater(Function<Authenticator, Future<Void>>) - Method in class io.vertx.reactivex.ext.auth.otp.totp.TotpAuth
Provide a that can update or insert a .
authority() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
 
authority() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
 
authority() - Method in class io.vertx.reactivex.core.http.ServerWebSocketHandshake
 
authority(HostAndPort) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Override the request authority, when using HTTP/1.x this overrides the request host header, when using HTTP/2 this sets the authority pseudo header.
authorization(Authorization) - Method in class io.vertx.reactivex.ext.auth.audit.SecurityAudit
 
Authorization - Interface in io.vertx.reactivex.ext.auth.authorization
Interface representing any kind of authorization such as: Role based authorization Permission based authorization Logical authorization (AND, OR, NOT) Time based authorization (ie: allow access the last 5 days of the month, from 8am till 10am, etc.)
AUTHORIZATION - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Authorization header name
AuthorizationContext - Class in io.vertx.reactivex.ext.auth.authorization
The AuthorizationContext contains properties that can be used to match authorizations.
AuthorizationContext(AuthorizationContext) - Constructor for class io.vertx.reactivex.ext.auth.authorization.AuthorizationContext
 
AuthorizationContext(Object) - Constructor for class io.vertx.reactivex.ext.auth.authorization.AuthorizationContext
 
AuthorizationHandler - Class in io.vertx.reactivex.ext.web.handler
Base interface for authorization handlers that provide authorization support.
AuthorizationHandler(AuthorizationHandler) - Constructor for class io.vertx.reactivex.ext.web.handler.AuthorizationHandler
 
AuthorizationHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.AuthorizationHandler
 
AuthorizationProvider - Interface in io.vertx.reactivex.ext.auth.authorization
The role of an AuthorizationProvider is to return a set of Authorization.
authorizations() - Method in class io.vertx.reactivex.ext.auth.User
Returns user's authorizations that have been previously loaded by the providers.
Authorizations - Class in io.vertx.reactivex.ext.auth.authorization
Represents a cache map of authorizations per provider.
Authorizations(Authorizations) - Constructor for class io.vertx.reactivex.ext.auth.authorization.Authorizations
 
Authorizations(Object) - Constructor for class io.vertx.reactivex.ext.auth.authorization.Authorizations
 
authorizeURL(OAuth2AuthorizationURL) - Method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
The client sends the end-user's browser to this endpoint to request their authentication and consent.
authProvider(AuthenticationProvider) - Method in class io.vertx.reactivex.ext.stomp.StompServerHandler
Configures the to be used to authenticate the user.
autoKeepAlive(boolean) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Enable/disable auto keep alive (sending ping response)
available() - Method in class io.vertx.reactivex.ext.web.RequestBody
Return true if a BodyHandler was executed before this call in the lifetime of the request.
await() - Method in class io.vertx.reactivex.ext.unit.Completion
Cause the current thread to wait until this completion completes.
await(long) - Method in class io.vertx.reactivex.ext.unit.Completion
Cause the current thread to wait until this completion completes with a configurable timeout.
awaitSuccess() - Method in class io.vertx.reactivex.ext.unit.Completion
Cause the current thread to wait until this completion completes and succeeds.
awaitSuccess(long) - Method in class io.vertx.reactivex.ext.unit.Completion
Cause the current thread to wait until this completion completes and succeeds with a configurable timeout.
AzureADAuth - Class in io.vertx.reactivex.ext.auth.oauth2.providers
Simplified factory to create an for Azure AD.
AzureADAuth(AzureADAuth) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.AzureADAuth
 
AzureADAuth(Object) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.AzureADAuth
 

B

BaseBridgeEvent - Class in io.vertx.reactivex.ext.bridge
Represents an event that occurs on the event bus bridge.
BaseBridgeEvent(BaseBridgeEvent) - Constructor for class io.vertx.reactivex.ext.bridge.BaseBridgeEvent
 
BaseBridgeEvent(Object) - Constructor for class io.vertx.reactivex.ext.bridge.BaseBridgeEvent
 
basicAck(long, boolean) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Acknowledge one or several received messages.
basicAuthentication(Buffer, Buffer) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Configure the request to perform basic access authentication.
basicAuthentication(String, String) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Configure the request to perform basic access authentication.
BasicAuthHandler - Class in io.vertx.reactivex.ext.web.handler
An auth handler that provides HTTP Basic Authentication support.
BasicAuthHandler(BasicAuthHandler) - Constructor for class io.vertx.reactivex.ext.web.handler.BasicAuthHandler
 
BasicAuthHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.BasicAuthHandler
 
basicConsumer(String) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
 
basicConsumer(String, QueueOptions) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Create a consumer with the given options.
basicGet(String, boolean) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Retrieve a message from a queue using AMQP.Basic.Get
basicNack(long, boolean, boolean) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Reject one or several received messages.
basicPublish(String, String, BasicProperties, Buffer) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Publish a message.
basicPublish(String, String, Buffer) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Publish a message.
basicPublishWithDeliveryTag(String, String, BasicProperties, Buffer, Handler<Long>) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Publish a message.
basicQos(int) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Request a specific prefetchCount "quality of service" settings for this channel.
basicQos(int, boolean) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Request a specific prefetchCount "quality of service" settings for this channel.
basicQos(int, int, boolean) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Request specific "quality of service" settings.
batch(List<Request>) - Method in class io.vertx.reactivex.redis.client.Redis
Sends a list of commands in a single IO operation, this prevents any inter twinning to happen from other client users.
batch(List<Request>) - Method in class io.vertx.reactivex.redis.client.RedisConnection
Sends a list of commands in a single IO operation, this prevents any inter twinning to happen from other client users.
batchHandler(Handler<KafkaConsumerRecords<K, V>>) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Set the handler to be used when batches of messages are fetched from the Kafka server.
bearerTokenAuthentication(String) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Configure the request to perform bearer token authentication.
before(Handler<TestContext>) - Method in class io.vertx.reactivex.ext.unit.TestSuite
Set a callback executed before the tests.
beforeEach(Handler<TestContext>) - Method in class io.vertx.reactivex.ext.unit.TestSuite
Set a callback executed before each test and after the suite before callback.
beforeExecute(Handler<ExecutionInputBuilderWithContext<Message>>) - Method in class io.vertx.reactivex.ext.web.handler.graphql.ws.GraphQLWSHandlerBuilder
Set a callback to invoke before executing a GraphQL query.
beforeExecute(Handler<ExecutionInputBuilderWithContext<RoutingContext>>) - Method in class io.vertx.reactivex.ext.web.handler.graphql.GraphQLHandlerBuilder
Set a callback to invoke before executing a GraphQL query.
begin() - Method in class io.vertx.reactivex.sqlclient.SqlConnection
Begin a transaction and returns a Transaction for controlling and tracking this transaction.
beginHandler(Handler<ServerFrame>) - Method in class io.vertx.reactivex.ext.stomp.StompServerHandler
Configures the action to execute when a BEGIN frame is received.
beginningOffsets(TopicPartition) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Get the first offset for the given partitions.
beginTime() - Method in class io.vertx.reactivex.ext.unit.report.TestResult
The time at which the test began in millis.
beginTransaction() - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
Starts a new kafka transaction.
beginTX(String) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Begins a transaction.
beginTX(String, Map<String, String>) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Begins a transaction.
bfAdd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command BF.ADD.
bfCard(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command BF.CARD.
bfDebug(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command BF.DEBUG.
bfExists(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command BF.EXISTS.
bfInfo(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command BF.INFO.
bfInsert(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command BF.INSERT.
bfLoadchunk(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command BF.LOADCHUNK.
bfMadd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command BF.MADD.
bfMexists(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command BF.MEXISTS.
bfReserve(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command BF.RESERVE.
bfScandump(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command BF.SCANDUMP.
bgrewriteaof() - Method in class io.vertx.reactivex.redis.client.RedisAPI
Asynchronously rewrite the append-only file.
bgsave(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Asynchronously save the dataset to disk.
binaryFileUpload(String, String, Buffer, String) - Method in class io.vertx.reactivex.ext.web.multipart.MultipartForm
Add a binary file upload form data part.
binaryFileUpload(String, String, String, String) - Method in class io.vertx.reactivex.ext.web.multipart.MultipartForm
Add a binary file upload form data part.
binaryHandlerID() - Method in class io.vertx.reactivex.core.http.ClientWebSocket
When a WebSocket is created, it may register an event handler with the event bus - the ID of that handler is given by this method.
binaryHandlerID() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
When a WebSocket is created, it may register an event handler with the event bus - the ID of that handler is given by this method.
binaryHandlerID() - Method in class io.vertx.reactivex.core.http.WebSocket
When a WebSocket is created, it may register an event handler with the event bus - the ID of that handler is given by this method.
binaryHandlerID() - Method in interface io.vertx.reactivex.core.http.WebSocketBase
When a WebSocket is created, it may register an event handler with the event bus - the ID of that handler is given by this method.
binaryMessageHandler(Handler<Buffer>) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
 
binaryMessageHandler(Handler<Buffer>) - Method in class io.vertx.reactivex.core.http.WebSocket
 
binaryMessageHandler(Handler<Buffer>) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Set a binary message handler on the connection.
bindings() - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
 
bitcount(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Count set bits in a string.
bitfield(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Perform arbitrary bitfield integer operations on strings.
bitfieldRo(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Perform arbitrary bitfield integer operations on strings.
bitop(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Perform bitwise operations between strings.
bitpos(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Find first bit set or clear in a string.
blmove(String, String, String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Pop an element from a list, push it to another list and return it; or block until one is available.
blmpop(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Pop elements from a list, or block until one is available.
blockingHandler(Handler<RoutingContext>) - Method in class io.vertx.reactivex.ext.web.Route
blockingHandler(Handler<RoutingContext>, boolean) - Method in class io.vertx.reactivex.ext.web.Route
Specify a blocking request handler for the route.
blockMulticastGroup(String, String) - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
Block the given address for the given multicast address and notifies the once the operation completes.
blockMulticastGroup(String, String, String) - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
Block the given address for the given multicast address on the given network interface and notifies the once the operation completes.
blpop(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove and get the first element in a list, or block until one is available.
Bodies - Class in io.vertx.reactivex.ext.web.validation.builder
In this interface you can find all available BodyProcessorFactory to use in ValidationHandlerBuilder.
Bodies(Bodies) - Constructor for class io.vertx.reactivex.ext.web.validation.builder.Bodies
 
Bodies(Object) - Constructor for class io.vertx.reactivex.ext.web.validation.builder.Bodies
 
body() - Method in class io.vertx.reactivex.core.eventbus.DeliveryContext
 
body() - Method in class io.vertx.reactivex.core.eventbus.Message
The body of the message.
body() - Method in class io.vertx.reactivex.core.http.HttpClientResponse
Convenience method for receiving the entire request body in one piece.
body() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
Convenience method for receiving the entire request body in one piece.
body() - Method in class io.vertx.reactivex.ext.web.client.HttpResponse
 
body() - Method in class io.vertx.reactivex.ext.web.RoutingContext
 
body() - Method in class io.vertx.reactivex.ext.web.validation.RequestParameters
Return request body when parsed.
body() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQMessage
 
body(BodyProcessor) - Method in class io.vertx.reactivex.ext.web.validation.builder.ValidationHandlerBuilder
 
body(BodyProcessorFactory) - Method in class io.vertx.reactivex.ext.web.validation.builder.ValidationHandlerBuilder
 
BODY_REQUIRED - Static variable in class io.vertx.reactivex.ext.web.validation.RequestPredicate
Request predicate that checks if body exists or not
bodyAsBinary() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
bodyAsBoolean() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
bodyAsBuffer() - Method in class io.vertx.reactivex.ext.web.client.HttpResponse
 
bodyAsByte() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
bodyAsChar() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
bodyAsDouble() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
bodyAsFloat() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
bodyAsInteger() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
bodyAsJson(Class<R>) - Method in class io.vertx.reactivex.ext.web.client.HttpResponse
 
bodyAsJsonArray() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
bodyAsJsonArray() - Method in class io.vertx.reactivex.ext.web.client.HttpResponse
 
bodyAsJsonObject() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
bodyAsJsonObject() - Method in class io.vertx.reactivex.ext.web.client.HttpResponse
 
bodyAsList() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
bodyAsLong() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
bodyAsShort() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
bodyAsString() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
bodyAsString() - Method in class io.vertx.reactivex.ext.web.client.HttpResponse
 
bodyAsString(String) - Method in class io.vertx.reactivex.ext.web.client.HttpResponse
 
bodyAsSymbol() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
bodyAsTimestamp() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
bodyAsUUID() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
bodyCodec() - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
 
BodyCodec<T> - Class in io.vertx.reactivex.ext.web.codec
A codec for encoding and decoding HTTP bodies.
BodyCodec(BodyCodec) - Constructor for class io.vertx.reactivex.ext.web.codec.BodyCodec
 
BodyCodec(Object, TypeArg<T>) - Constructor for class io.vertx.reactivex.ext.web.codec.BodyCodec
 
bodyEndHandler(Handler<Void>) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Provides a handler that will be called after the last part of the body is written to the wire.
bodyHandler(Handler<Buffer>) - Method in class io.vertx.reactivex.core.http.HttpClientResponse
Convenience method for receiving the entire request body in one piece.
bodyHandler(Handler<Buffer>) - Method in class io.vertx.reactivex.core.http.HttpServerRequest
Convenience method for receiving the entire request body in one piece.
BodyHandler - Class in io.vertx.reactivex.ext.web.handler
A handler which gathers the entire request body and sets it on the .
BodyHandler(BodyHandler) - Constructor for class io.vertx.reactivex.ext.web.handler.BodyHandler
 
BodyHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.BodyHandler
 
BodyProcessorFactory - Class in io.vertx.reactivex.ext.web.validation.builder
This interface is used to build body processors.
BodyProcessorFactory(BodyProcessorFactory) - Constructor for class io.vertx.reactivex.ext.web.validation.builder.BodyProcessorFactory
 
BodyProcessorFactory(Object) - Constructor for class io.vertx.reactivex.ext.web.validation.builder.BodyProcessorFactory
 
bodyStream() - Method in class io.vertx.reactivex.core.eventbus.MessageConsumer
 
BoxAuth - Class in io.vertx.reactivex.ext.auth.oauth2.providers
Simplified factory to create an for box.com.
BoxAuth(BoxAuth) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.BoxAuth
 
BoxAuth(Object) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.BoxAuth
 
bridge(BridgeOptions) - Method in class io.vertx.reactivex.ext.stomp.StompServerHandler
Configures the STOMP server to act as a bridge with the Vert.x event bus.
bridge(SockJSBridgeOptions) - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSHandler
Bridge the SockJS handler to the Vert.x event bus.
bridge(SockJSBridgeOptions, Handler<BridgeEvent>) - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSHandler
Like SockJSHandler.bridge(io.vertx.ext.web.handler.sockjs.SockJSBridgeOptions) but specifying a handler that will receive bridge events.
bridge(Vertx, BridgeOptions) - Static method in class io.vertx.reactivex.ext.stomp.Destination
 
bridge(AuthorizationProvider, SockJSBridgeOptions, Handler<BridgeEvent>) - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSHandler
Like SockJSHandler.bridge(io.vertx.ext.web.handler.sockjs.SockJSBridgeOptions) but specifying a handler that will receive bridge events.
BridgeEvent - Class in io.vertx.reactivex.ext.eventbus.bridge.tcp
Represents an event that occurs on the event bus bridge.
BridgeEvent - Class in io.vertx.reactivex.ext.web.handler.sockjs
Represents an event that occurs on the event bus bridge.
BridgeEvent(BridgeEvent) - Constructor for class io.vertx.reactivex.ext.eventbus.bridge.tcp.BridgeEvent
 
BridgeEvent(BridgeEvent) - Constructor for class io.vertx.reactivex.ext.web.handler.sockjs.BridgeEvent
 
BridgeEvent(Object) - Constructor for class io.vertx.reactivex.ext.eventbus.bridge.tcp.BridgeEvent
 
BridgeEvent(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.sockjs.BridgeEvent
 
brpop(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove and get the last element in a list, or block until one is available.
brpoplpush(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Deprecated.
buffer() - Static method in class io.vertx.reactivex.ext.web.codec.BodyCodec
 
buffer() - Method in class io.vertx.reactivex.ext.web.RequestBody
 
build() - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
build() - Method in class io.vertx.reactivex.core.http.HttpClientBuilder
Build and return the client.
build() - Method in class io.vertx.reactivex.ext.web.handler.graphql.GraphiQLHandlerBuilder
 
build() - Method in class io.vertx.reactivex.ext.web.handler.graphql.GraphQLHandlerBuilder
 
build() - Static method in class io.vertx.reactivex.ext.web.handler.graphql.UploadScalar
 
build() - Method in class io.vertx.reactivex.ext.web.handler.graphql.ws.GraphQLWSHandlerBuilder
 
build() - Method in class io.vertx.reactivex.ext.web.validation.builder.ValidationHandlerBuilder
Build the from this builder
build() - Method in class io.vertx.reactivex.grpc.client.GrpcClientBuilder
Build and return the client.
build() - Method in class io.vertx.reactivex.sqlclient.ClientBuilder
Build and return the client.
builder() - Method in class io.vertx.reactivex.ext.web.handler.graphql.ExecutionInputBuilderWithContext
 
builder(GraphQL) - Static method in class io.vertx.reactivex.ext.web.handler.graphql.GraphQLHandler
Create a new GraphQLHandlerBuilder that will use the provided graphQL to build a GraphQLHandler.
builder(GraphQL) - Static method in class io.vertx.reactivex.ext.web.handler.graphql.ws.GraphQLWSHandler
Create a new GraphQLWSHandlerBuilder that will use the provided graphQL to build a GraphQLWSHandler.
builder(Vertx) - Static method in class io.vertx.reactivex.ext.web.handler.graphql.GraphiQLHandler
builder(Vertx) - Static method in class io.vertx.reactivex.grpc.client.GrpcClient
Provide a builder for GrpcClient, it can be used to configure advanced client settings like a load balancer or an address resolver.
bulkWrite(String, List<BulkOperation>) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Execute a bulk operation.
bulkWriteWithOptions(String, List<BulkOperation>, BulkWriteOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Execute a bulk operation with the specified write options.
bytesRead() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
 
bytesWritten() - Method in class io.vertx.reactivex.core.http.HttpServerResponse
 
bzmpop(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove and return members with scores in a sorted set or block until one is available.
bzpopmax(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove and return the member with the highest score from one or more sorted sets, or block until one is available.
bzpopmin(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove and return the member with the lowest score from one or more sorted sets, or block until one is available.

C

CACHE_CONTROL - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Cache-Control header name
cached() - Method in class io.vertx.reactivex.servicediscovery.ServiceReference
Gets the service object if already retrieved.
cachedAs(Class<X>) - Method in class io.vertx.reactivex.servicediscovery.ServiceReference
Gets the service object if already retrieved.
CachingWebClient - Class in io.vertx.reactivex.ext.web.client
An asynchronous cache aware HTTP / HTTP/2 client called CachingWebClient.
CachingWebClient(CachingWebClient) - Constructor for class io.vertx.reactivex.ext.web.client.CachingWebClient
 
CachingWebClient(Object) - Constructor for class io.vertx.reactivex.ext.web.client.CachingWebClient
 
callHandler(Handler<GrpcServerRequest<Buffer, Buffer>>) - Method in class io.vertx.reactivex.grpc.server.GrpcServer
Set a call handler that handles any call made to the server.
callHandler(ServiceMethod<Req, Resp>, Handler<GrpcServerRequest<Req, Resp>>) - Method in class io.vertx.reactivex.grpc.server.GrpcServer
Set a service method call handler that handles any call made to the server for the fullMethodName service method.
cancel() - Method in class io.vertx.reactivex.ext.web.FileUpload
Try to cancel the file upload.
cancel() - Method in class io.vertx.reactivex.grpc.common.GrpcWriteStream
Cancel the stream.
cancel() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQConsumer
Stop message consumption from a queue.
cancelAndCleanupFileUploads() - Method in class io.vertx.reactivex.ext.web.RoutingContext
Cancel all unfinished file upload in progress and delete all uploaded files.
cancelRequest() - Method in class io.vertx.reactivex.pgclient.PgConnection
Send a request cancellation message to tell the server to cancel processing request in this connection.
cancelStreamToFileSystem() - Method in class io.vertx.reactivex.core.http.HttpServerFileUpload
Try to cancel the file system streaming, the streamed file will be deleted.
canUpgradeToWebSocket() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
 
CassandraClient - Class in io.vertx.reactivex.cassandra
Eclipse Vert.x Cassandra client.
CassandraClient(CassandraClient) - Constructor for class io.vertx.reactivex.cassandra.CassandraClient
 
CassandraClient(Object) - Constructor for class io.vertx.reactivex.cassandra.CassandraClient
 
CassandraRowStream - Class in io.vertx.reactivex.cassandra
A for consumption.
CassandraRowStream(CassandraRowStream) - Constructor for class io.vertx.reactivex.cassandra.CassandraRowStream
 
CassandraRowStream(Object) - Constructor for class io.vertx.reactivex.cassandra.CassandraRowStream
 
cast(SqlConnection) - Static method in class io.vertx.reactivex.db2client.DB2Connection
Cast a to DB2Connection.
cast(SqlConnection) - Static method in class io.vertx.reactivex.mssqlclient.MSSQLConnection
Cast a to MSSQLConnection.
cast(SqlConnection) - Static method in class io.vertx.reactivex.mysqlclient.MySQLConnection
Cast a to MySQLConnection.
cast(SqlConnection) - Static method in class io.vertx.reactivex.oracleclient.OracleConnection
Cast a to OracleConnection.
cast(SqlConnection) - Static method in class io.vertx.reactivex.pgclient.PgConnection
Cast a to PgConnection.
catalogDatacenters() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Return all the datacenters that are known by the Consul server
catalogNodes() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the nodes registered in a datacenter
catalogNodeServices(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the node's registered services
catalogNodeServicesWithOptions(String, BlockingQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the node's registered services This is blocking query unlike ConsulClient.catalogNodeServices(java.lang.String)
catalogNodesWithOptions(NodeQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the nodes registered in a datacenter
catalogServiceNodes(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the nodes providing a service
catalogServiceNodesWithOptions(String, ServiceQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the nodes providing a service
catalogServices() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the services registered in a datacenter
catalogServicesWithOptions(BlockingQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the services registered in a datacenter This is blocking query unlike ConsulClient.catalogServices()
cause() - Method in class io.vertx.reactivex.ext.consul.WatchResult
A Throwable describing failure.
cfAdd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CF.ADD.
cfAddnx(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CF.ADDNX.
cfCompact(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CF.COMPACT.
cfCount(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CF.COUNT.
cfDebug(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CF.DEBUG.
cfDel(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CF.DEL.
cfExists(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CF.EXISTS.
cfInfo(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CF.INFO.
cfInsert(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CF.INSERT.
cfInsertnx(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CF.INSERTNX.
cfLoadchunk(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CF.LOADCHUNK.
cfMexists(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CF.MEXISTS.
cfReserve(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CF.RESERVE.
cfScandump(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CF.SCANDUMP.
ChainAuth - Class in io.vertx.reactivex.ext.auth
Chain several authentication providers as if they were one.
ChainAuth(ChainAuth) - Constructor for class io.vertx.reactivex.ext.auth.ChainAuth
 
ChainAuth(Object) - Constructor for class io.vertx.reactivex.ext.auth.ChainAuth
 
ChainAuthHandler - Class in io.vertx.reactivex.ext.web.handler
An auth handler that chains to a sequence of handlers.
ChainAuthHandler(ChainAuthHandler) - Constructor for class io.vertx.reactivex.ext.web.handler.ChainAuthHandler
 
ChainAuthHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.ChainAuthHandler
 
changeUser(MySQLAuthOptions) - Method in class io.vertx.reactivex.mysqlclient.MySQLConnection
Send a CHANGE_USER command to change the user of the current connection, this operation will also reset connection state.
channel(String) - Method in class io.vertx.reactivex.pgclient.pubsub.PgSubscriber
Return a channel for the given name.
charset() - Method in class io.vertx.reactivex.core.http.HttpServerFileUpload
 
charSet() - Method in class io.vertx.reactivex.ext.web.FileUpload
 
checkStatus() - Method in class io.vertx.reactivex.ext.healthchecks.HealthChecks
Invokes the registered procedures.
checkStatus(String) - Method in class io.vertx.reactivex.ext.healthchecks.HealthChecks
Invokes the registered procedure with the given name and sub-procedures.
chmod(String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
Change the permissions on the file represented by path to perms, asynchronously.
chmodBlocking(String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
Blocking version of #chmod(String, String)
chmodRecursive(String, String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
Change the permissions on the file represented by path to perms, asynchronously.
chmodRecursiveBlocking(String, String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
chown(String, String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
Change the ownership on the file represented by path to user and {code group}, asynchronously.
chownBlocking(String, String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
CHUNKED - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
chunked header value
CircuitBreaker - Class in io.vertx.reactivex.circuitbreaker
An implementation of the circuit breaker pattern for Vert.x
CircuitBreaker(CircuitBreaker) - Constructor for class io.vertx.reactivex.circuitbreaker.CircuitBreaker
 
CircuitBreaker(Object) - Constructor for class io.vertx.reactivex.circuitbreaker.CircuitBreaker
 
claimKey() - Method in class io.vertx.reactivex.ext.auth.oauth2.authorization.ScopeAuthorization
Returns the configured claim key.
clear() - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
Clear all entries in the map
clear() - Method in class io.vertx.reactivex.core.shareddata.LocalMap
Clear all entries in the map
clear() - Method in class io.vertx.reactivex.ext.auth.abac.PolicyBasedAuthorizationProvider
 
clear() - Method in class io.vertx.reactivex.ext.auth.authorization.Authorizations
Clears the authorizations.
clear() - Method in class io.vertx.reactivex.ext.web.Router
Remove all the routes from this router
clear() - Method in class io.vertx.reactivex.ext.web.sstore.SessionStore
Remove all sessions from the store.
clear() - Method in class io.vertx.reactivex.ext.web.UserContext
Clear can be called from any route handler which needs to terminate a login session.
clear() - Method in class io.vertx.reactivex.sqlclient.Tuple
 
clear() - Method in class io.vertx.reactivex.uritemplate.Variables
 
clearCache() - Method in class io.vertx.reactivex.ext.web.common.template.TemplateEngine
Clears any internal caches used by this engine.
client() - Static method in class io.vertx.reactivex.db2client.DB2Builder
Provide a builder for DB2 client backed by a connection pool.
client() - Static method in class io.vertx.reactivex.mysqlclient.MySQLBuilder
Provide a builder for MySQL client backed by a connection pool.
client() - Static method in class io.vertx.reactivex.pgclient.PgBuilder
Provide a builder for PostgreSQL client backed by a connection pool.
client(Handler<ClientBuilder<SqlClient>>) - Static method in class io.vertx.reactivex.db2client.DB2Builder
Build a client backed by a connection pool with the specified block argument.
client(Handler<ClientBuilder<SqlClient>>) - Static method in class io.vertx.reactivex.mysqlclient.MySQLBuilder
Build a client backed by a connection pool with the specified block argument.
client(Handler<ClientBuilder<SqlClient>>) - Static method in class io.vertx.reactivex.pgclient.PgBuilder
Build a client backed by a connection pool with the specified block argument.
client(Vertx) - Static method in class io.vertx.reactivex.grpc.client.GrpcClient
Create a client.
client(Vertx, HttpClientOptions) - Static method in class io.vertx.reactivex.grpc.client.GrpcClient
Create a client with the specified options.
client(Vertx, GrpcClientOptions) - Static method in class io.vertx.reactivex.grpc.client.GrpcClient
Create a client.
client(Vertx, GrpcClientOptions, HttpClientOptions) - Static method in class io.vertx.reactivex.grpc.client.GrpcClient
Create a client with the specified options.
client(Vertx, HttpClient) - Static method in class io.vertx.reactivex.grpc.client.GrpcClient
Create a client wrapping an existing .
client(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
A container for client connection commands.
ClientBuilder<C> - Class in io.vertx.reactivex.sqlclient
Builder for SqlClient instances.
ClientBuilder(ClientBuilder) - Constructor for class io.vertx.reactivex.sqlclient.ClientBuilder
 
ClientBuilder(Object, TypeArg<C>) - Constructor for class io.vertx.reactivex.sqlclient.ClientBuilder
 
clientId() - Method in class io.vertx.reactivex.mqtt.MqttClient
 
clientIdentifier() - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
 
ClientWebSocket - Class in io.vertx.reactivex.core.http
Represents a client-side WebSocket.
ClientWebSocket(ClientWebSocket) - Constructor for class io.vertx.reactivex.core.http.ClientWebSocket
 
ClientWebSocket(Object) - Constructor for class io.vertx.reactivex.core.http.ClientWebSocket
 
cloneAclToken(String, CloneAclTokenOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Clones an existing ACL token
close() - Method in class io.vertx.reactivex.amqp.AmqpClient
Closes the client.
close() - Method in class io.vertx.reactivex.amqp.AmqpConnection
Closes the AMQP connection, i.e. allows the Close frame to be emitted.
close() - Method in class io.vertx.reactivex.amqp.AmqpReceiver
Closes the receiver.
close() - Method in class io.vertx.reactivex.amqp.AmqpSender
Closes the sender.
close() - Method in class io.vertx.reactivex.cassandra.CassandraClient
Closes this client.
close() - Method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
Closes the circuit breaker.
close() - Method in class io.vertx.reactivex.config.ConfigRetriever
Closes the retriever.
close() - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
Closes the DatagramSocket implementation asynchronous and notifies the handler once done.
close() - Method in class io.vertx.reactivex.core.dns.DnsClient
Close the client.
close() - Method in class io.vertx.reactivex.core.eventbus.MessageProducer
Closes the producer, this method should be called when the message producer is not used anymore.
close() - Method in class io.vertx.reactivex.core.file.AsyncFile
Close the file.
close() - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Close the WebSocket sending the default close frame.
close() - Method in interface io.vertx.reactivex.core.http.HttpClient
Close immediately (shutdown(0, TimeUnit.SECONDS).
close() - Method in class io.vertx.reactivex.core.http.HttpClientAgent
Close immediately (shutdown(0, TimeUnit.SECONDS).
close() - Method in class io.vertx.reactivex.core.http.HttpClientConnection
 
close() - Method in class io.vertx.reactivex.core.http.HttpConnection
Close immediately (shutdown(0, TimeUnit.SECONDS).
close() - Method in class io.vertx.reactivex.core.http.HttpServer
Close the server.
close() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
The WebSocket handshake will be accepted when it hasn't yet been settled or when an asynchronous handshake is in progress.
close() - Method in class io.vertx.reactivex.core.http.WebSocket
Close the WebSocket sending the default close frame.
close() - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Close the WebSocket sending the default close frame.
close() - Method in class io.vertx.reactivex.core.http.WebSocketClient
Close immediately (shutdown(0, TimeUnit.SECONDS).
close() - Method in class io.vertx.reactivex.core.net.NetClient
Close immediately (shutdown(0, TimeUnit.SECONDS).
close() - Method in class io.vertx.reactivex.core.net.NetServer
Close the server.
close() - Method in class io.vertx.reactivex.core.net.NetSocket
Close the socket
close() - Method in class io.vertx.reactivex.core.shareddata.LocalMap
Close and release the map
close() - Method in class io.vertx.reactivex.core.streams.Pipe
Close the pipe.
close() - Method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
Releases any resources or timers used by this instance.
close() - Method in class io.vertx.reactivex.ext.auth.prng.VertxContextPRNG
stop seeding the PRNG
close() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Close the client and release its resources
close() - Method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.TcpEventBusBridge
Close the current socket.
close() - Method in class io.vertx.reactivex.ext.mail.MailClient
Close the MailClient
close() - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Close the client and release its resources
close() - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
Close the client and release its resources
close() - Method in class io.vertx.reactivex.ext.stomp.StompClient
Closes the client.
close() - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Closes the connection without sending the DISCONNECT frame.
close() - Method in class io.vertx.reactivex.ext.stomp.StompServer
Closes the server.
close() - Method in class io.vertx.reactivex.ext.stomp.StompServerConnection
Closes the connection with the client.
close() - Method in class io.vertx.reactivex.ext.web.client.WebClient
Close the client.
close() - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
Close it
close() - Method in class io.vertx.reactivex.ext.web.sstore.SessionStore
Close the store
close() - Method in class io.vertx.reactivex.grpc.client.GrpcClient
Close this client.
close() - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
Close the admin client
close() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Close the consumer
close() - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
Close the producer
close() - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Close the endpoint, so the connection with remote MQTT client
close() - Method in class io.vertx.reactivex.mqtt.MqttServer
Close the server.
close() - Method in class io.vertx.reactivex.pgclient.pubsub.PgSubscriber
Close the subscriber, the retry policy will not be invoked.
close() - Method in class io.vertx.reactivex.redis.client.Redis
Closes the client and terminates any connection.
close() - Method in class io.vertx.reactivex.redis.client.RedisAPI
 
close() - Method in class io.vertx.reactivex.redis.client.RedisConnection
Closes the connection or returns to the pool.
close() - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
Closes the service discovery
close() - Method in class io.vertx.reactivex.sqlclient.Cursor
Release the cursor.
close() - Method in class io.vertx.reactivex.sqlclient.PreparedStatement
Close the prepared query and release its resources.
close() - Method in class io.vertx.reactivex.sqlclient.RowStream
Close the stream and release the resources.
close() - Method in class io.vertx.reactivex.sqlclient.SqlClient
Close the client and release the associated resources.
close(int, String) - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
Close it giving a status code and reason.
close(long) - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
Close the admin client
close(long) - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
Close the producer
close(short) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Close the WebSocket sending a close frame with specified status code.
close(short) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Close the WebSocket sending a close frame with specified status code.
close(short) - Method in class io.vertx.reactivex.core.http.WebSocket
Close the WebSocket sending a close frame with specified status code.
close(short) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Close the WebSocket sending a close frame with specified status code.
close(short, String) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Close sending a close frame with specified status code and reason.
close(short, String) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Close sending a close frame with specified status code and reason.
close(short, String) - Method in class io.vertx.reactivex.core.http.WebSocket
Close sending a close frame with specified status code and reason.
close(short, String) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Close sending a close frame with specified status code and reason.
close(Handler<Void>) - Method in class io.vertx.reactivex.servicediscovery.spi.ServiceExporter
Close the exporter
close(Handler<Void>) - Method in class io.vertx.reactivex.servicediscovery.spi.ServiceImporter
Closes the importer
CLOSE - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
close header value
closed() - Method in class io.vertx.reactivex.core.http.HttpServerResponse
 
closed() - Method in class io.vertx.reactivex.pgclient.pubsub.PgSubscriber
 
closeFuture() - Method in class io.vertx.reactivex.amqp.AmqpConnection
 
closeHandler(Handler<StompClientConnection>) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Sets a handler notified when the STOMP connection is closed.
closeHandler(Handler<StompServerConnection>) - Method in class io.vertx.reactivex.ext.stomp.StompServerHandler
Configures the action to execute when a connection with the client is closed.
closeHandler(Handler<Void>) - Method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
Sets a to be invoked when the circuit breaker state switches to closed.
closeHandler(Handler<Void>) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
 
closeHandler(Handler<Void>) - Method in class io.vertx.reactivex.core.http.HttpConnection
Set a close handler.
closeHandler(Handler<Void>) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Set a close handler for the response, this is called when the underlying connection is closed and the response was still using the connection.
closeHandler(Handler<Void>) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
 
closeHandler(Handler<Void>) - Method in class io.vertx.reactivex.core.http.WebSocket
 
closeHandler(Handler<Void>) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Set a close handler.
closeHandler(Handler<Void>) - Method in class io.vertx.reactivex.core.net.NetSocket
Set a handler notified when the socket is closed
closeHandler(Handler<Void>) - Method in class io.vertx.reactivex.db2client.DB2Connection
 
closeHandler(Handler<Void>) - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
 
closeHandler(Handler<Void>) - Method in class io.vertx.reactivex.mqtt.MqttClient
Set a handler that will be called when the connection with server is closed
closeHandler(Handler<Void>) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Set a close handler.
closeHandler(Handler<Void>) - Method in class io.vertx.reactivex.mssqlclient.MSSQLConnection
 
closeHandler(Handler<Void>) - Method in class io.vertx.reactivex.mysqlclient.MySQLConnection
 
closeHandler(Handler<Void>) - Method in class io.vertx.reactivex.oracleclient.OracleConnection
 
closeHandler(Handler<Void>) - Method in class io.vertx.reactivex.pgclient.PgConnection
 
closeHandler(Handler<Void>) - Method in class io.vertx.reactivex.pgclient.pubsub.PgSubscriber
Set an handler called when the subscriber is closed.
closeHandler(Handler<Void>) - Method in class io.vertx.reactivex.sqlclient.SqlConnection
Set an handler called when the connection is closed.
closeReason() - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Returns the close reason message from the remote endpoint or null when not yet received.
closeReason() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Returns the close reason message from the remote endpoint or null when not yet received.
closeReason() - Method in class io.vertx.reactivex.core.http.WebSocket
Returns the close reason message from the remote endpoint or null when not yet received.
closeReason() - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Returns the close reason message from the remote endpoint or null when not yet received.
closeStatusCode() - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Returns the close status code received from the remote endpoint or null when not yet received.
closeStatusCode() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Returns the close status code received from the remote endpoint or null when not yet received.
closeStatusCode() - Method in class io.vertx.reactivex.core.http.WebSocket
Returns the close status code received from the remote endpoint or null when not yet received.
closeStatusCode() - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Returns the close status code received from the remote endpoint or null when not yet received.
CloudFoundryAuth - Class in io.vertx.reactivex.ext.auth.oauth2.providers
Simplified factory to create an for CloudFoundry UAA.
CloudFoundryAuth(CloudFoundryAuth) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.CloudFoundryAuth
 
CloudFoundryAuth(Object) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.CloudFoundryAuth
 
cluster(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
A container for cluster commands.
ClusteredSessionStore - Class in io.vertx.reactivex.ext.web.sstore
A session store which stores sessions in a distributed map so they are available across the cluster.
ClusteredSessionStore(ClusteredSessionStore) - Constructor for class io.vertx.reactivex.ext.web.sstore.ClusteredSessionStore
 
ClusteredSessionStore(Object) - Constructor for class io.vertx.reactivex.ext.web.sstore.ClusteredSessionStore
 
clusterSerializableChecker(Function<String, Boolean>) - Method in class io.vertx.reactivex.core.eventbus.EventBus
Register a predicate to invoke when verifying if an object is forbidden to be encoded/decoded as ClusterSerializable.
cmsIncrby(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CMS.INCRBY.
cmsInfo(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CMS.INFO.
cmsInitbydim(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CMS.INITBYDIM.
cmsInitbyprob(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CMS.INITBYPROB.
cmsMerge(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CMS.MERGE.
cmsQuery(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CMS.QUERY.
code() - Method in class io.vertx.reactivex.mqtt.messages.MqttConnAckMessage
 
code() - Method in class io.vertx.reactivex.mqtt.messages.MqttDisconnectMessage
 
code() - Method in class io.vertx.reactivex.mqtt.messages.MqttPubAckMessage
 
code() - Method in class io.vertx.reactivex.mqtt.messages.MqttPubCompMessage
 
code() - Method in class io.vertx.reactivex.mqtt.messages.MqttPubRecMessage
 
code() - Method in class io.vertx.reactivex.mqtt.messages.MqttPubRelMessage
 
codecSelector(Function<Object, String>) - Method in class io.vertx.reactivex.core.eventbus.EventBus
Set selector to be invoked when the bus has not found any codec for a Message body.
columnDefinitions() - Method in class io.vertx.reactivex.cassandra.CassandraRowStream
Get the provided by the backing ResultSet for this stream.
ColumnDescriptor - Class in io.vertx.reactivex.sqlclient.desc
 
ColumnDescriptor(ColumnDescriptor) - Constructor for class io.vertx.reactivex.sqlclient.desc.ColumnDescriptor
 
ColumnDescriptor(Object) - Constructor for class io.vertx.reactivex.sqlclient.desc.ColumnDescriptor
 
columnDescriptors() - Method in class io.vertx.reactivex.sqlclient.SqlResult
Get the column descriptors in the SqlResult.
columnsNames() - Method in class io.vertx.reactivex.sqlclient.SqlResult
Get the names of columns in the SqlResult.
command(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get array of Redis command details.
commaSeparatedArrayParser() - Static method in class io.vertx.reactivex.ext.web.validation.builder.Parsers
 
commaSeparatedObjectParser() - Static method in class io.vertx.reactivex.ext.web.validation.builder.Parsers
 
commaSeparatedTupleParser() - Static method in class io.vertx.reactivex.ext.web.validation.builder.Parsers
 
commit() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Commit current offsets for all the subscribed list of topics and partition.
commit() - Method in class io.vertx.reactivex.sqlclient.Transaction
Commit the current transaction.
commit(String) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Commits a transaction.
commit(String, Map<String, String>) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Commits a transaction.
commitHandler(Handler<ServerFrame>) - Method in class io.vertx.reactivex.ext.stomp.StompServerHandler
Configures the action to execute when a COMMIT frame is received.
committed(TopicPartition) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Get the last committed offset for the given partition (whether the commit happened by this process or another).
commitTransaction() - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
Commits the ongoing transaction.
compareAndSet(long, long) - Method in class io.vertx.reactivex.core.shareddata.Counter
Set the counter to the specified value only if the current value is the expectec value.
complete() - Method in class io.vertx.reactivex.ext.unit.Async
Signals the asynchronous operation is done, this method must be called with a count greater than 0, otherwise it throws an IllegalStateException to signal the error.
complete(Boolean) - Method in class io.vertx.reactivex.ext.bridge.BaseBridgeEvent
Set the result.
complete(Boolean) - Method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.BridgeEvent
Set the result.
complete(Boolean) - Method in class io.vertx.reactivex.ext.web.handler.sockjs.BridgeEvent
Set the result.
complete(Boolean, Throwable) - Method in class io.vertx.reactivex.ext.bridge.BaseBridgeEvent
 
complete(Boolean, Throwable) - Method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.BridgeEvent
 
complete(Boolean, Throwable) - Method in class io.vertx.reactivex.ext.web.handler.sockjs.BridgeEvent
 
complete(Object) - Method in class io.vertx.reactivex.ext.web.handler.graphql.ws.ConnectionInitEvent
Set the result.
complete(Object, Throwable) - Method in class io.vertx.reactivex.ext.web.handler.graphql.ws.ConnectionInitEvent
 
completion() - Method in class io.vertx.reactivex.core.eventbus.MessageConsumer
 
completion() - Method in class io.vertx.reactivex.sqlclient.Transaction
Return the transaction completion Future that succeeds when the transaction commits and fails with TransactionRollbackException when the transaction rolls back.
Completion<T> - Class in io.vertx.reactivex.ext.unit
A completion object that emits completion notifications either succeeded or failed.
Completion(Completion) - Constructor for class io.vertx.reactivex.ext.unit.Completion
 
Completion(Object, TypeArg<T>) - Constructor for class io.vertx.reactivex.ext.unit.Completion
 
component() - Method in class io.vertx.reactivex.ext.web.MIMEHeader
Gets the parsed component part of the MIME.
computeIfAbsent(String, Function<String, Object>) - Method in class io.vertx.reactivex.ext.web.Session
Put some data in a session if absent.
config(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
A container for server configuration commands.
ConfigRetriever - Class in io.vertx.reactivex.config
Defines a configuration retriever that read configuration from and tracks changes periodically.
ConfigRetriever(ConfigRetriever) - Constructor for class io.vertx.reactivex.config.ConfigRetriever
 
ConfigRetriever(Object) - Constructor for class io.vertx.reactivex.config.ConfigRetriever
 
configStream() - Method in class io.vertx.reactivex.config.ConfigRetriever
 
configureHeartbeat(long, long, Handler<StompServerConnection>) - Method in class io.vertx.reactivex.ext.stomp.StompServerConnection
Configures the heartbeat.
confirmSelect() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Enables publisher acknowledgements on this channel.
connect() - Method in class io.vertx.reactivex.amqp.AmqpClient
Connects to the AMQP broker or router.
connect() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Create an HTTP tunnel to the server.
connect() - Method in class io.vertx.reactivex.ext.stomp.StompClient
Connects to the server using the host and port configured in the client's options.
connect() - Method in class io.vertx.reactivex.ext.web.Router
Add a route that matches any HTTP CONNECT request
connect() - Method in class io.vertx.reactivex.pgclient.pubsub.PgSubscriber
Connect the subscriber to Postgres.
connect() - Method in class io.vertx.reactivex.redis.client.Redis
Connects to the Redis server.
connect(int, String) - Method in class io.vertx.reactivex.core.net.NetClient
Open a connection to a server at the specific port and host.
connect(int, String) - Method in class io.vertx.reactivex.ext.stomp.StompClient
Connects to the server.
connect(int, String) - Method in class io.vertx.reactivex.mqtt.MqttClient
Connects to an MQTT server calling connectHandler after connection
connect(int, String, String) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Connect this WebSocket to the specified port, host and relative request URI.
connect(int, String, String) - Method in class io.vertx.reactivex.core.http.WebSocketClient
Connect a WebSocket to the specified port, host and relative request URI.
connect(int, String, String) - Method in class io.vertx.reactivex.core.net.NetClient
Open a connection to a server at the specific port and host.
connect(int, String, String) - Method in class io.vertx.reactivex.mqtt.MqttClient
Connects to an MQTT server calling connectHandler after connection
connect(HttpConnectOptions) - Method in class io.vertx.reactivex.core.http.HttpClientAgent
Connect to a remote HTTP server with the specific options, the connection is un-pooled and the management of the connection is left to the user.
connect(WebSocketConnectOptions) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Connect this WebSocket with the specified options.
connect(WebSocketConnectOptions) - Method in class io.vertx.reactivex.core.http.WebSocketClient
Connect a WebSocket with the specified options.
connect(ConnectOptions) - Method in class io.vertx.reactivex.core.net.NetClient
Open a connection to a server at the specific connectOptions.
connect(SocketAddress) - Method in class io.vertx.reactivex.core.net.NetClient
Open a connection to a server at the specific remoteAddress.
connect(SocketAddress, String) - Method in class io.vertx.reactivex.core.net.NetClient
Open a connection to a server at the specific remoteAddress.
connect(Vertx) - Static method in class io.vertx.reactivex.pgclient.PgConnection
connect(Vertx, DB2ConnectOptions) - Static method in class io.vertx.reactivex.db2client.DB2Connection
Create a connection to DB2 server with the given connectOptions.
connect(Vertx, MSSQLConnectOptions) - Static method in class io.vertx.reactivex.mssqlclient.MSSQLConnection
Create a connection to SQL Server with the given connectOptions.
connect(Vertx, MySQLConnectOptions) - Static method in class io.vertx.reactivex.mysqlclient.MySQLConnection
Create a connection to MySQL server with the given connectOptions.
connect(Vertx, OracleConnectOptions) - Static method in class io.vertx.reactivex.oracleclient.OracleConnection
Create a connection to Oracle with the given connectOptions.
connect(Vertx, PgConnectOptions) - Static method in class io.vertx.reactivex.pgclient.PgConnection
Connects to the database and returns the connection if that succeeds.
connect(Vertx, String) - Static method in class io.vertx.reactivex.db2client.DB2Connection
connect(Vertx, String) - Static method in class io.vertx.reactivex.mssqlclient.MSSQLConnection
connect(Vertx, String) - Static method in class io.vertx.reactivex.mysqlclient.MySQLConnection
connect(Vertx, String) - Static method in class io.vertx.reactivex.oracleclient.OracleConnection
connect(Vertx, String) - Static method in class io.vertx.reactivex.pgclient.PgConnection
connect(String) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Connect this WebSocket at the relative request URI using the default host and port.
connect(String) - Method in class io.vertx.reactivex.core.http.WebSocketClient
Connect a WebSocket to the default client port, default client host and specified, relative request URI.
connect(String) - Method in class io.vertx.reactivex.ext.web.Router
Add a route that matches a HTTP CONNECT request and the specified path
connect(String, String) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Connect this WebSocket to the host and relative request URI and default port.
connect(String, String) - Method in class io.vertx.reactivex.core.http.WebSocketClient
Connect a WebSocket to the default client port and specified host and relative request URI.
connectHandler(Handler<NetSocket>) - Method in class io.vertx.reactivex.core.net.NetServer
Supply a connect handler for this server.
connectHandler(Handler<ServerFrame>) - Method in class io.vertx.reactivex.ext.stomp.StompServerHandler
Configures the action to execute when a CONNECT frame is received.
connectingTo(SqlConnectOptions) - Method in class io.vertx.reactivex.sqlclient.ClientBuilder
Configure the database the client should connect to.
connectingTo(String) - Method in class io.vertx.reactivex.sqlclient.ClientBuilder
Configure the database the client should connect to.
connectingTo(Supplier<Future<SqlConnectOptions>>) - Method in class io.vertx.reactivex.sqlclient.ClientBuilder
Configure the database the client should connect to.
connectingTo(List<SqlConnectOptions>) - Method in class io.vertx.reactivex.sqlclient.ClientBuilder
Configure the database the client should connect to.
connection() - Method in class io.vertx.reactivex.amqp.AmqpReceiver
Gets the connection having created the receiver.
connection() - Method in class io.vertx.reactivex.amqp.AmqpSender
Gets the connection having created the sender.
connection() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
 
connection() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
 
connection() - Method in class io.vertx.reactivex.ext.stomp.ServerFrame
 
connection() - Method in class io.vertx.reactivex.grpc.client.GrpcClientRequest
 
connection() - Method in class io.vertx.reactivex.grpc.server.GrpcServerRequest
 
CONNECTION - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Connection header name
connectionDroppedHandler(Handler<StompClientConnection>) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Sets a handler notified when the server does not respond to a ping request in time.
connectionHandler(Handler<HttpConnection>) - Method in class io.vertx.reactivex.core.http.HttpServer
Set a connection handler for the server.
ConnectionInitEvent - Class in io.vertx.reactivex.ext.web.handler.graphql.ws
 
ConnectionInitEvent(ConnectionInitEvent) - Constructor for class io.vertx.reactivex.ext.web.handler.graphql.ws.ConnectionInitEvent
 
ConnectionInitEvent(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.graphql.ws.ConnectionInitEvent
 
connectionParams() - Method in class io.vertx.reactivex.ext.web.handler.graphql.ws.Message
 
connectProperties() - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
 
connectTimeout() - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
 
connectTimeout(long) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Sets the amount of time after which, if the request is not obtained from the client within the timeout period, the response is failed with a TimeoutException.
connectWithRegex(String) - Method in class io.vertx.reactivex.ext.web.Router
Add a route that matches a HTTP CONNECT request and the specified path regex
constantDelay(long) - Static method in class io.vertx.reactivex.circuitbreaker.RetryPolicy
Create a constant delay retry policy.
ConsulClient - Class in io.vertx.reactivex.ext.consul
A Vert.x service used to interact with Consul.
ConsulClient(ConsulClient) - Constructor for class io.vertx.reactivex.ext.consul.ConsulClient
 
ConsulClient(Object) - Constructor for class io.vertx.reactivex.ext.consul.ConsulClient
 
consumer(MessageConsumerOptions) - Method in class io.vertx.reactivex.core.eventbus.EventBus
Create a message consumer against the specified options address.
consumer(MessageConsumerOptions, Handler<Message<T>>) - Method in class io.vertx.reactivex.core.eventbus.EventBus
Create a consumer and register it against the specified options address.
consumer(String) - Method in class io.vertx.reactivex.core.eventbus.EventBus
Create a message consumer against the specified address.
consumer(String, Handler<Message<T>>) - Method in class io.vertx.reactivex.core.eventbus.EventBus
Create a consumer and register it against the specified address.
consumerTag() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQConsumer
 
consumerTag() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQMessage
 
consumes(String) - Method in class io.vertx.reactivex.ext.web.Route
Add a content type consumed by this route.
contains(String) - Method in class io.vertx.reactivex.ext.auth.authorization.Authorizations
Logical check if the this object contains the given provider id
containsKey(Object) - Method in class io.vertx.reactivex.core.shareddata.LocalMap
Returns true if this map contains a mapping for the specified key.
containsKey(String) - Method in class io.vertx.reactivex.ext.auth.User
Checks if a value exists on the user object.
containsKey(String) - Method in class io.vertx.reactivex.json.schema.JsonSchema
Checks if the given key is present in the schema object.
containsValue(Object) - Method in class io.vertx.reactivex.core.shareddata.LocalMap
Returns @{code true} if this map maps one or more keys to the specified value.
content() - Method in class io.vertx.reactivex.ext.web.multipart.FormDataPart
 
CONTENT_BASE - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Content-Base header name
CONTENT_DISPOSITION - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Content-Disposition header name
CONTENT_ENCODING - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Content-Encoding header name
CONTENT_LANGUAGE - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Content-Language header name
CONTENT_LENGTH - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Content-Length header name
CONTENT_LOCATION - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Content-Location header name
CONTENT_MD5 - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Content-MD5 header name
CONTENT_RANGE - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Content-Rage header name
CONTENT_TRANSFER_ENCODING - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Content-Transfer-Encoding header name
CONTENT_TYPE - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Content-Type header name
contentEncoding() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
contentEncoding(String) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
contentTransferEncoding() - Method in class io.vertx.reactivex.core.http.HttpServerFileUpload
 
contentTransferEncoding() - Method in class io.vertx.reactivex.ext.web.FileUpload
 
contentType() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
contentType() - Method in class io.vertx.reactivex.core.http.HttpServerFileUpload
 
contentType() - Method in class io.vertx.reactivex.ext.web.FileUpload
 
contentType() - Method in class io.vertx.reactivex.ext.web.ParsedHeaderValues
 
contentType(String) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
contentType(String) - Static method in class io.vertx.reactivex.core.http.HttpResponseExpectation
Creates an expectation validating the response has a content-type header matching the mimeType.
contentType(String...) - Static method in class io.vertx.reactivex.core.http.HttpResponseExpectation
Creates an expectation validating the response has a content-type header matching one of the mimeTypes.
contentType(List<String>) - Static method in class io.vertx.reactivex.core.http.HttpResponseExpectation
Creates an expectation validating the response has a content-type header matching one of the mimeTypes.
context() - Method in class io.vertx.reactivex.ext.web.handler.graphql.ExecutionInputBuilderWithContext
 
CONTINUE - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
100-continue header value
continueHandler(Handler<Void>) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
If you send an HTTP request with the header Expect set to the value 100-continue and the server responds with an interim HTTP response with a status code of 100 and a Continue handler has been set using this method, then the handler will be called.
cookie(String) - Method in class io.vertx.reactivex.ext.web.handler.APIKeyHandler
Specify the source for the api key extraction as an HTTP cookie with the given name.
COOKIE - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Content-Cookie header name
cookieCount() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
 
cookieParameter(ParameterProcessorFactory) - Method in class io.vertx.reactivex.ext.web.validation.builder.ValidationHandlerBuilder
 
cookieParameter(StyledParameterProcessorFactory) - Method in class io.vertx.reactivex.ext.web.validation.builder.ValidationHandlerBuilder
 
cookieParameter(String) - Method in class io.vertx.reactivex.ext.web.validation.RequestParameters
Get cookie parameter by name
cookieParametersNames() - Method in class io.vertx.reactivex.ext.web.validation.RequestParameters
Get list of all parameter names inside cookie
cookies() - Method in class io.vertx.reactivex.core.http.HttpClientResponse
 
cookies() - Method in interface io.vertx.reactivex.core.http.HttpResponseHead
 
cookies() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
Returns a modifiable set of parsed cookies from the COOKIE header.
cookies() - Method in class io.vertx.reactivex.ext.web.client.HttpResponse
 
cookies(String) - Method in class io.vertx.reactivex.core.http.HttpServerRequest
Returns a read only set of parsed cookies that match the given name, or an empty set.
CookieSessionStore - Class in io.vertx.reactivex.ext.web.sstore.cookie
A SessionStore that uses a Cookie to store the session data.
CookieSessionStore(CookieSessionStore) - Constructor for class io.vertx.reactivex.ext.web.sstore.cookie.CookieSessionStore
 
CookieSessionStore(Object) - Constructor for class io.vertx.reactivex.ext.web.sstore.cookie.CookieSessionStore
 
cookieStore() - Method in class io.vertx.reactivex.ext.web.client.WebClientSession
Returns this client's CookieStore
coordinateDatacenters() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the WAN network coordinates for all Consul servers, organized by DCs
coordinateNodes() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the LAN network coordinates for all nodes in a given DC
coordinateNodesWithOptions(BlockingQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the LAN network coordinates for all nodes in a given DC This is blocking query unlike ConsulClient.coordinateNodes()
copy() - Method in class io.vertx.reactivex.core.json.pointer.JsonPointer
Copy a JsonPointer
copy() - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Copy this request
copy(String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
Copy a file from the path from to path to, asynchronously.
copy(String, String, CopyOptions) - Method in class io.vertx.reactivex.core.file.FileSystem
Copy a file from the path from to path to, asynchronously.
copy(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Copy a key.
copyBlocking(String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
copyRecursive(String, String, boolean) - Method in class io.vertx.reactivex.core.file.FileSystem
Copy a file from the path from to path to, asynchronously.
copyRecursiveBlocking(String, String, boolean) - Method in class io.vertx.reactivex.core.file.FileSystem
correlationId() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
correlationId(String) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
CorsHandler - Class in io.vertx.reactivex.ext.web.handler
A handler which implements server side http://www.w3.org/TR/cors/[CORS] support for Vert.x-Web.
CorsHandler(CorsHandler) - Constructor for class io.vertx.reactivex.ext.web.handler.CorsHandler
 
CorsHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.CorsHandler
 
count() - Method in class io.vertx.reactivex.ext.unit.Async
 
count(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Count matching documents in a collection.
countDown() - Method in class io.vertx.reactivex.ext.unit.Async
Count down the async.
Counter - Class in io.vertx.reactivex.core.shareddata
An asynchronous counter that can be used to across the cluster to maintain a consistent count.
Counter(Counter) - Constructor for class io.vertx.reactivex.core.shareddata.Counter
 
Counter(Object) - Constructor for class io.vertx.reactivex.core.shareddata.Counter
 
countWithOptions(String, JsonObject, CountOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Count matching documents in a collection.
create() - Static method in class io.vertx.reactivex.amqp.AmqpMessage
 
create() - Static method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
create() - Static method in class io.vertx.reactivex.core.json.pointer.JsonPointer
Build an empty JsonPointer
create() - Static method in class io.vertx.reactivex.ext.auth.abac.PolicyBasedAuthorizationProvider
 
create() - Static method in class io.vertx.reactivex.ext.auth.audit.SecurityAudit
 
create() - Static method in class io.vertx.reactivex.ext.auth.authorization.AndAuthorization
 
create() - Static method in class io.vertx.reactivex.ext.auth.authorization.OrAuthorization
 
create() - Static method in class io.vertx.reactivex.ext.auth.jwt.authorization.MicroProfileAuthorization
Factory method to create a Authorization provider for tokens adhering to the MP-JWT 1.1 spec.
create() - Static method in class io.vertx.reactivex.ext.auth.oauth2.authorization.KeycloakAuthorization
Factory method to create an Authorization Provider for tokens adhering to the Keycloak token format.
create() - Static method in class io.vertx.reactivex.ext.auth.oauth2.authorization.ScopeAuthorization
Factory method to create a Authorization provider for Oauth 2.0 scopes using the default separator " ".
create() - Static method in class io.vertx.reactivex.ext.auth.otp.hotp.HotpAuth
Creates an instance of HotpAuth.
create() - Static method in class io.vertx.reactivex.ext.auth.otp.OtpKeyGenerator
Creates an instance of OtpKeyGenerator.
create() - Static method in class io.vertx.reactivex.ext.auth.otp.totp.TotpAuth
Creates an instance of TotpAuth.
create() - Static method in class io.vertx.reactivex.ext.mail.MailAttachment
construct an empty MailAttachment object that can be filled with the setters
create() - Static method in class io.vertx.reactivex.ext.web.handler.AuthorizationHandler
create the handler that will check the attribute based authorization.
create() - Static method in class io.vertx.reactivex.ext.web.handler.BodyHandler
Create a body handler with defaults.
create() - Static method in class io.vertx.reactivex.ext.web.handler.CorsHandler
Create a empty CORS handler that allows * origin.
create() - Static method in class io.vertx.reactivex.ext.web.handler.CSPHandler
Creates a new instance of the handler.
create() - Static method in class io.vertx.reactivex.ext.web.handler.HSTSHandler
Creates a new instance that does not consider the configuration for sub domains.
create() - Static method in class io.vertx.reactivex.ext.web.handler.LoggerHandler
Create a handler with default format
create() - Static method in class io.vertx.reactivex.ext.web.handler.MethodOverrideHandler
Create a X-HTTP-METHOD-OVERRIDE handler with safe downgrade of methods
create() - Static method in class io.vertx.reactivex.ext.web.handler.ResponseContentTypeHandler
Create a response content type handler.
create() - Static method in class io.vertx.reactivex.ext.web.handler.ResponseTimeHandler
Create a handler
create() - Static method in class io.vertx.reactivex.ext.web.handler.SecurityAuditLoggerHandler
Create a new instance of the handler.
create() - Static method in class io.vertx.reactivex.ext.web.handler.SimpleAuthenticationHandler
Creates a new instance of the simple authentication handler.
create() - Static method in class io.vertx.reactivex.ext.web.handler.StaticHandler
Create a handler using defaults
create() - Static method in class io.vertx.reactivex.ext.web.handler.TimeoutHandler
Create a handler
create() - Static method in class io.vertx.reactivex.ext.web.multipart.MultipartForm
 
create() - Static method in class io.vertx.reactivex.ext.web.templ.rocker.RockerTemplateEngine
Create a template engine using defaults
create() - Static method in class io.vertx.reactivex.micrometer.PrometheusRequestHandler
Creates a handler with a new PrometheusMeterRegistry and the default metrics endpoint ("/metrics").
create() - Static method in class io.vertx.reactivex.micrometer.PrometheusScrapingHandler
Creates a Vert.x Web Route handler for Prometheus metrics scraping.
create(boolean) - Static method in class io.vertx.reactivex.ext.web.handler.BodyHandler
Create a body handler setting if it should handle file uploads.
create(boolean) - Static method in class io.vertx.reactivex.ext.web.handler.HSTSHandler
Creates a new instance that shall consider the configuration for sub domains.
create(boolean) - Static method in class io.vertx.reactivex.ext.web.handler.MethodOverrideHandler
Create a X-HTTP-METHOD-OVERRIDE handler
create(boolean, LoggerFormat) - Static method in class io.vertx.reactivex.ext.web.handler.LoggerHandler
Create a handler with he specified format
create(int) - Static method in class io.vertx.reactivex.openapi.validation.ValidatableResponse
Creates a new ValidatableResponse object based on the passed parameters.
create(int, MqttQoS, boolean, boolean, String, Buffer, MqttProperties) - Static method in class io.vertx.reactivex.mqtt.messages.MqttPublishMessage
Create a concrete instance of a Vert.x publish message
create(int, Buffer, String) - Static method in class io.vertx.reactivex.openapi.validation.ValidatableResponse
Creates a new ValidatableResponse object based on the passed parameters.
create(int, MqttPubAckReasonCode, MqttProperties) - Static method in class io.vertx.reactivex.mqtt.messages.MqttPubAckMessage
Create a concrete instance of a Vert.x puback message
create(int, MqttPubCompReasonCode, MqttProperties) - Static method in class io.vertx.reactivex.mqtt.messages.MqttPubCompMessage
Create a concrete instance of a Vert.x pubcomp message
create(int, MqttPubRecReasonCode, MqttProperties) - Static method in class io.vertx.reactivex.mqtt.messages.MqttPubRecMessage
Create a concrete instance of a Vert.x pubrec message
create(int, MqttPubRelReasonCode, MqttProperties) - Static method in class io.vertx.reactivex.mqtt.messages.MqttPubRelMessage
Create a concrete instance of a Vert.x pubrel message
create(int, List<MqttTopicSubscription>, MqttProperties) - Static method in class io.vertx.reactivex.mqtt.messages.MqttSubscribeMessage
Create a concrete instance of a Vert.x subscribe message
create(int, List<String>, MqttProperties) - Static method in class io.vertx.reactivex.mqtt.messages.MqttUnsubscribeMessage
Create a concrete instance of a Vert.x unsubscribe message
create(int, Map<String, String>) - Static method in class io.vertx.reactivex.openapi.validation.ValidatableResponse
Creates a new ValidatableResponse object based on the passed parameters.
create(int, Map<String, String>, Buffer, String) - Static method in class io.vertx.reactivex.openapi.validation.ValidatableResponse
Creates a new ValidatableResponse object based on the passed parameters.
create(long) - Static method in class io.vertx.reactivex.ext.web.handler.TimeoutHandler
Create a handler
create(long, boolean) - Static method in class io.vertx.reactivex.ext.web.handler.HSTSHandler
Creates a new instance that shall consider the configuration for sub domains.
create(long, int) - Static method in class io.vertx.reactivex.ext.web.handler.TimeoutHandler
Create a handler
create(GraphQL) - Static method in class io.vertx.reactivex.ext.web.handler.graphql.GraphQLHandler
Create a new GraphQLHandler that will use the provided graphQL object to execute queries.
create(GraphQL) - Static method in class io.vertx.reactivex.ext.web.handler.graphql.ws.GraphQLWSHandler
Create a new GraphQLWSHandler that will use the provided graphQL object to execute requests.
create(GraphQL, GraphQLHandlerOptions) - Static method in class io.vertx.reactivex.ext.web.handler.graphql.GraphQLHandler
Create a new GraphQLHandler that will use the provided graphQL object to execute queries.
create(GraphQL, GraphQLWSOptions) - Static method in class io.vertx.reactivex.ext.web.handler.graphql.ws.GraphQLWSHandler
Create a new GraphQLWSHandler that will use the provided graphQL object to execute requests.
create(PrometheusMeterRegistry) - Static method in class io.vertx.reactivex.micrometer.PrometheusRequestHandler
Creates a handler with the specified PrometheusMeterRegistry and the default metrics endpoint ("/metrics").
create(PrometheusMeterRegistry) - Static method in class io.vertx.reactivex.micrometer.PrometheusScrapingHandler
Creates a Vert.x Web Route handler for Prometheus metrics scraping.
create(PrometheusMeterRegistry, String) - Static method in class io.vertx.reactivex.micrometer.PrometheusRequestHandler
Creates a handler with the specified PrometheusMeterRegistry and metrics endpoint.
create(MqttConnectReturnCode, boolean) - Static method in class io.vertx.reactivex.mqtt.messages.MqttConnAckMessage
Create a concrete instance of a Vert.x connack message
create(MqttConnectReturnCode, boolean, MqttProperties) - Static method in class io.vertx.reactivex.mqtt.messages.MqttConnAckMessage
Create a concrete instance of a Vert.x connack message
create(AmqpClientOptions) - Static method in class io.vertx.reactivex.amqp.AmqpClient
Creates a new instance of AmqpClient using an internal Vert.x instance (with default configuration) and the given AMQP client configuration.
create(JsonObject) - Static method in class io.vertx.reactivex.ext.auth.User
Factory for user instances that are free form.
create(JsonObject) - Static method in class io.vertx.reactivex.ext.mail.MailAttachment
create a MailAttachment object from a JsonObject representation
create(JsonObject, JsonObject) - Static method in class io.vertx.reactivex.ext.auth.User
Factory for user instances that are free form.
create(HotpAuthOptions) - Static method in class io.vertx.reactivex.ext.auth.otp.hotp.HotpAuth
Creates an instance of HotpAuth.
create(TotpAuthOptions) - Static method in class io.vertx.reactivex.ext.auth.otp.totp.TotpAuth
Creates an instance of TotpAuth.
create(FileSystemAccess, String) - Static method in class io.vertx.reactivex.ext.web.handler.StaticHandler
Create a handler, specifying web-root and access option: absolute path or relative
create(LoggerFormat) - Static method in class io.vertx.reactivex.ext.web.handler.LoggerHandler
Create a handler with he specified format
create(ParameterLocation, SchemaRepository) - Method in class io.vertx.reactivex.ext.web.validation.builder.ParameterProcessorFactory
 
create(ParameterLocation, SchemaRepository) - Method in class io.vertx.reactivex.ext.web.validation.builder.StyledParameterProcessorFactory
 
create(JsonSchemaOptions) - Static method in class io.vertx.reactivex.json.schema.SchemaRepository
Create a repository with some initial configuration.
create(JsonSchemaOptions, JsonFormatValidator) - Static method in class io.vertx.reactivex.json.schema.SchemaRepository
Create a repository with some initial configuration.
create(MqttAuthenticateReasonCode, MqttProperties) - Static method in class io.vertx.reactivex.mqtt.messages.MqttAuthenticationExchangeMessage
Create a concrete instance of a Vert.x auth message
create(MqttDisconnectReasonCode, MqttProperties) - Static method in class io.vertx.reactivex.mqtt.messages.MqttDisconnectMessage
Create a concrete instance of a Vert.x disconnect message
create(AmqpMessage) - Static method in class io.vertx.reactivex.amqp.AmqpMessage
Creates a builder to create a new AmqpMessage copying the metadata from the passed message.
create(Measured) - Static method in class io.vertx.reactivex.micrometer.MetricsService
Creates a metric service for a given object.
create(Vertx) - Static method in class io.vertx.reactivex.cassandra.CassandraClient
create(Vertx) - Static method in class io.vertx.reactivex.config.ConfigRetriever
Creates an instance of the default implementation of the ConfigRetriever, using the default settings (json file, system properties and environment variables).
create(Vertx) - Static method in class io.vertx.reactivex.ext.auth.htdigest.HtdigestAuth
Creates an instance of HtdigestAuth.
create(Vertx) - Static method in class io.vertx.reactivex.ext.auth.htpasswd.HtpasswdAuth
 
create(Vertx) - Static method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
Create a OAuth2 auth provider.
create(Vertx) - Static method in class io.vertx.reactivex.ext.auth.webauthn4j.WebAuthn4J
Create a WebAuthN auth provider
create(Vertx) - Static method in class io.vertx.reactivex.ext.consul.ConsulClient
Create a Consul client with default options.
create(Vertx) - Static method in class io.vertx.reactivex.ext.dropwizard.MetricsService
Creates a metric service for a given Vertx instance.
create(Vertx) - Static method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.TcpEventBusBridge
 
create(Vertx) - Static method in class io.vertx.reactivex.ext.healthchecks.HealthChecks
Creates a new instance of the default implementation of HealthChecks.
create(Vertx) - Static method in class io.vertx.reactivex.ext.stomp.StompClient
Creates a StompClient using the default implementation.
create(Vertx) - Static method in class io.vertx.reactivex.ext.stomp.StompServer
Creates a StompServer based on the default Stomp Server implementation, and use the default options.
create(Vertx) - Static method in class io.vertx.reactivex.ext.stomp.StompServerHandler
Creates an instance of StompServerHandler using the default (compliant) implementation.
create(Vertx) - Static method in class io.vertx.reactivex.ext.web.client.WebClient
Create a web client using the provided vertx instance and default options.
create(Vertx) - Static method in class io.vertx.reactivex.ext.web.handler.ErrorHandler
Create an error handler using defaults
create(Vertx) - Static method in class io.vertx.reactivex.ext.web.handler.FaviconHandler
Create a handler with defaults
create(Vertx) - Static method in class io.vertx.reactivex.ext.web.handler.graphql.GraphiQLHandler
Create a new GraphiQLHandler.
create(Vertx) - Static method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSHandler
Create a SockJS handler
create(Vertx) - Static method in class io.vertx.reactivex.ext.web.healthchecks.HealthCheckHandler
Creates an instance of the default implementation of the HealthCheckHandler.
create(Vertx) - Static method in class io.vertx.reactivex.ext.web.sstore.ClusteredSessionStore
Create a session store
create(Vertx) - Static method in class io.vertx.reactivex.ext.web.sstore.LocalSessionStore
Create a session store
create(Vertx) - Static method in class io.vertx.reactivex.ext.web.sstore.SessionStore
Create a Session store given a backend and configuration JSON.
create(Vertx) - Static method in class io.vertx.reactivex.ext.web.templ.freemarker.FreeMarkerTemplateEngine
Create a template engine using defaults
create(Vertx) - Static method in class io.vertx.reactivex.ext.web.templ.handlebars.HandlebarsTemplateEngine
Create a template engine using defaults
create(Vertx) - Static method in class io.vertx.reactivex.ext.web.templ.mvel.MVELTemplateEngine
Create a template engine using defaults
create(Vertx) - Static method in class io.vertx.reactivex.ext.web.templ.pebble.PebbleTemplateEngine
Create a template engine using defaults
create(Vertx) - Static method in class io.vertx.reactivex.ext.web.templ.pug.PugTemplateEngine
Create a template engine using defaults
create(Vertx) - Static method in class io.vertx.reactivex.ext.web.templ.thymeleaf.ThymeleafTemplateEngine
Create a template engine using defaults
create(Vertx) - Static method in class io.vertx.reactivex.mqtt.MqttClient
Return an MQTT client instance using the default options
create(Vertx) - Static method in class io.vertx.reactivex.mqtt.MqttServer
Return an MQTT server instance using default options
create(Vertx) - Static method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Create and return a client configured with the default options.
create(Vertx) - Static method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
Creates a new instance of ServiceDiscovery using the default configuration.
create(Vertx, boolean) - Static method in class io.vertx.reactivex.ext.web.handler.ErrorHandler
Create an error handler
create(Vertx, long) - Static method in class io.vertx.reactivex.ext.web.handler.FaviconHandler
Create a handler with the specified max cache time
create(Vertx, long) - Static method in class io.vertx.reactivex.ext.web.sstore.ClusteredSessionStore
Create a session store.
create(Vertx, long, Redis) - Static method in class io.vertx.reactivex.ext.web.sstore.redis.RedisSessionStore
Creates a RedisSessionStore with the given retry TO.
create(Vertx, PebbleEngine) - Static method in class io.vertx.reactivex.ext.web.templ.pebble.PebbleTemplateEngine
Create a template engine using a custom Builder, e.g. if you want use custom Filters or Functions.
create(Vertx, AmqpClientOptions) - Static method in class io.vertx.reactivex.amqp.AmqpClient
Creates a new instance of AmqpClient with the given Vert.x instance and the given options.
create(Vertx, CassandraClientOptions) - Static method in class io.vertx.reactivex.cassandra.CassandraClient
Create a Cassandra client which maintains its own driver session.
create(Vertx, ConfigRetrieverOptions) - Static method in class io.vertx.reactivex.config.ConfigRetriever
Creates an instance of the default implementation of the ConfigRetriever.
create(Vertx, Handler<TestSuiteReport>) - Static method in class io.vertx.reactivex.ext.unit.collect.EventBusCollector
 
create(Vertx, JsonObject) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.GoogleAuth
Create a OAuth2Auth provider for Google Service Account (Server to Server)
create(Vertx, JsonObject) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.KeycloakAuth
Create a OAuth2Auth provider for Keycloak
create(Vertx, JsonObject) - Static method in class io.vertx.reactivex.ext.mongo.MongoClient
Create a Mongo client which maintains its own data source.
create(Vertx, JsonObject) - Static method in class io.vertx.reactivex.ext.web.sstore.infinispan.InfinispanSessionStore
Create a new InfinispanSessionStore for the given configuration.
create(Vertx, JsonObject) - Static method in class io.vertx.reactivex.ext.web.sstore.SessionStore
Create a Session store given a backend and configuration JSON.
create(Vertx, JsonObject, HttpClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.GoogleAuth
Create a OAuth2Auth provider for Google Service Account (Server to Server)
create(Vertx, JsonObject, HttpClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.KeycloakAuth
Create a OAuth2Auth provider for Keycloak
create(Vertx, JsonObject, RemoteCacheManager) - Static method in class io.vertx.reactivex.ext.web.sstore.infinispan.InfinispanSessionStore
create(Vertx, HtpasswdAuthOptions) - Static method in class io.vertx.reactivex.ext.auth.htpasswd.HtpasswdAuth
 
create(Vertx, JWTAuthOptions) - Static method in class io.vertx.reactivex.ext.auth.jwt.JWTAuth
Create a JWT auth provider
create(Vertx, LdapAuthenticationOptions) - Static method in class io.vertx.reactivex.ext.auth.ldap.LdapAuthentication
Create a LDAP authentication provider
create(Vertx, OAuth2FlowType, JsonObject) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.KeycloakAuth
Create a OAuth2Auth provider for Keycloak
create(Vertx, OAuth2FlowType, JsonObject, HttpClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.KeycloakAuth
Create a OAuth2Auth provider for Keycloak
create(Vertx, OAuth2Options) - Static method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
Create a OAuth2 auth provider
create(Vertx, WebAuthn4JOptions) - Static method in class io.vertx.reactivex.ext.auth.webauthn4j.WebAuthn4J
Create a WebAuthN auth provider
create(Vertx, BridgeOptions) - Static method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.TcpEventBusBridge
 
create(Vertx, BridgeOptions, NetServerOptions) - Static method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.TcpEventBusBridge
 
create(Vertx, BridgeOptions, NetServerOptions, Handler<BridgeEvent>) - Static method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.TcpEventBusBridge
 
create(Vertx, ConsulClientOptions) - Static method in class io.vertx.reactivex.ext.consul.ConsulClient
Create a Consul client.
create(Vertx, MailConfig) - Static method in class io.vertx.reactivex.ext.mail.MailClient
Create a non shared instance of the mail client.
create(Vertx, StompClientOptions) - Static method in class io.vertx.reactivex.ext.stomp.StompClient
Creates a StompClient using the default implementation.
create(Vertx, StompServerOptions) - Static method in class io.vertx.reactivex.ext.stomp.StompServer
Creates a StompServer based on the default Stomp Server implementation.
create(Vertx, ReportingOptions) - Static method in class io.vertx.reactivex.ext.unit.collect.EventBusCollector
Create a message handler reporting with the specified options.
create(Vertx, WebClientOptions) - Static method in class io.vertx.reactivex.ext.web.client.WebClient
Create a web client using the provided vertx instance and default pooling options.
create(Vertx, WebClientOptions, PoolOptions) - Static method in class io.vertx.reactivex.ext.web.client.WebClient
Create a web client using the provided vertx instance.
create(Vertx, GraphiQLHandlerOptions) - Static method in class io.vertx.reactivex.ext.web.handler.graphql.GraphiQLHandler
Create a new GraphiQLHandler.
create(Vertx, SockJSHandlerOptions) - Static method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSHandler
Create a SockJS handler
create(Vertx, KafkaClientOptions) - Static method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Create a new KafkaConsumer instance
create(Vertx, KafkaClientOptions, Class<K>, Class<V>) - Static method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Create a new KafkaConsumer instance
create(Vertx, MqttClientOptions) - Static method in class io.vertx.reactivex.mqtt.MqttClient
Return an MQTT client instance
create(Vertx, MqttServerOptions) - Static method in class io.vertx.reactivex.mqtt.MqttServer
Return an MQTT server instance
create(Vertx, RabbitMQOptions) - Static method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Create and return a client.
create(Vertx, NetServer) - Static method in class io.vertx.reactivex.ext.stomp.StompServer
Creates a StompServer based on the default Stomp Server implementation.
create(Vertx, NetServer, StompServerOptions) - Static method in class io.vertx.reactivex.ext.stomp.StompServer
Creates a StompServer based on the default Stomp Server implementation.
create(Vertx, AuthenticationProvider) - Static method in class io.vertx.reactivex.ext.web.healthchecks.HealthCheckHandler
Creates an instance of the default implementation of the HealthCheckHandler.
create(Vertx, HtdigestAuth) - Static method in class io.vertx.reactivex.ext.web.handler.DigestAuthHandler
Create a digest auth handler
create(Vertx, HtdigestAuth, long) - Static method in class io.vertx.reactivex.ext.web.handler.DigestAuthHandler
Create a digest auth handler, specifying the expire timeout for nonces.
create(Vertx, OAuth2Auth) - Static method in class io.vertx.reactivex.ext.web.handler.OAuth2AuthHandler
Create a OAuth2 auth handler without host pinning.Most providers will not look to the redirect url but always redirect to the preconfigured callback.
create(Vertx, OAuth2Auth, String) - Static method in class io.vertx.reactivex.ext.web.handler.OAuth2AuthHandler
Create a OAuth2 auth handler with host pinning.
create(Vertx, OpenAPIContract) - Static method in class io.vertx.reactivex.ext.web.openapi.router.RouterBuilder
Create a new RouterBuilder.
create(Vertx, OpenAPIContract) - Static method in class io.vertx.reactivex.openapi.validation.RequestValidator
Create a new RequestValidator.
create(Vertx, OpenAPIContract, RequestExtractor) - Static method in class io.vertx.reactivex.ext.web.openapi.router.RouterBuilder
Create a new RouterBuilder.
create(Vertx, RabbitMQClient, RabbitMQPublisherOptions) - Static method in class io.vertx.reactivex.rabbitmq.RabbitMQPublisher
Create and return a publisher using the specified client.
create(Vertx, Redis) - Static method in class io.vertx.reactivex.ext.web.sstore.redis.RedisSessionStore
Creates a RedisSessionStore with the default retry TO.
create(Vertx, ServiceDiscoveryOptions) - Static method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
Creates an instance of ServiceDiscovery.
create(Vertx, String) - Static method in class io.vertx.reactivex.ext.auth.htdigest.HtdigestAuth
Creates an instance of HtdigestAuth by using the given htfile file.
create(Vertx, String) - Static method in class io.vertx.reactivex.ext.auth.properties.PropertyFileAuthentication
Create a File authentication provider
create(Vertx, String) - Static method in class io.vertx.reactivex.ext.auth.properties.PropertyFileAuthorization
Create a File authentication provider
create(Vertx, String) - Method in class io.vertx.reactivex.ext.stomp.DestinationFactory
Creates a destination for the given address.
create(Vertx, String) - Static method in class io.vertx.reactivex.ext.web.handler.CSRFHandler
Instantiate a new CSRFHandlerImpl with a secret
create(Vertx, String) - Static method in class io.vertx.reactivex.ext.web.handler.ErrorHandler
Create an error handler
create(Vertx, String) - Static method in class io.vertx.reactivex.ext.web.handler.FaviconHandler
Create a handler attempting to load favicon file from the specified path
create(Vertx, String) - Static method in class io.vertx.reactivex.ext.web.sstore.ClusteredSessionStore
Create a session store
create(Vertx, String) - Static method in class io.vertx.reactivex.ext.web.sstore.LocalSessionStore
Create a session store
create(Vertx, String) - Static method in class io.vertx.reactivex.ext.web.templ.freemarker.FreeMarkerTemplateEngine
Create a template engine using defaults
create(Vertx, String) - Static method in class io.vertx.reactivex.ext.web.templ.handlebars.HandlebarsTemplateEngine
Create a template engine using defaults
create(Vertx, String) - Static method in class io.vertx.reactivex.ext.web.templ.mvel.MVELTemplateEngine
Create a template engine using defaults
create(Vertx, String) - Static method in class io.vertx.reactivex.ext.web.templ.pebble.PebbleTemplateEngine
Create a template engine using defaults
create(Vertx, String) - Static method in class io.vertx.reactivex.ext.web.templ.pug.PugTemplateEngine
Create a template engine using defaults
create(Vertx, String, boolean) - Static method in class io.vertx.reactivex.ext.web.handler.ErrorHandler
Create an error handler
create(Vertx, String, long) - Static method in class io.vertx.reactivex.ext.web.handler.FaviconHandler
Create a handler attempting to load favicon file from the specified path, and with the specified max cache time
create(Vertx, String, long) - Static method in class io.vertx.reactivex.ext.web.sstore.ClusteredSessionStore
Create a session store.
create(Vertx, String, long) - Static method in class io.vertx.reactivex.ext.web.sstore.LocalSessionStore
Create a session store
create(Vertx, String, PebbleEngine) - Static method in class io.vertx.reactivex.ext.web.templ.pebble.PebbleTemplateEngine
Create a template engine using a custom Builder, e.g. if you want use custom Filters or Functions.
create(Vertx, String, Buffer) - Static method in class io.vertx.reactivex.ext.web.sstore.cookie.CookieSessionStore
Creates a CookieSessionStore.
create(Vertx, String, String) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.BoxAuth
Create a OAuth2Auth provider for App.net
create(Vertx, String, String) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.DropboxAuth
Create a OAuth2Auth provider for Dropbox
create(Vertx, String, String) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.FacebookAuth
Create a OAuth2Auth provider for Facebook
create(Vertx, String, String) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.FoursquareAuth
Create a OAuth2Auth provider for Foursquare
create(Vertx, String, String) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.GiteeAuth
Create a OAuth2Auth provider for Gitee
create(Vertx, String, String) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.GithubAuth
Create a OAuth2Auth provider for Github
create(Vertx, String, String) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.GitLabAuth
Create a OAuth2Auth provider for GitLab.com.
create(Vertx, String, String) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.GoogleAuth
Create a OAuth2Auth provider for Google
create(Vertx, String, String) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.HerokuAuth
Create a OAuth2Auth provider for Heroku
create(Vertx, String, String) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.InstagramAuth
Create a OAuth2Auth provider for Instagram
create(Vertx, String, String) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.LinkedInAuth
Create a OAuth2Auth provider for LinkedIn
create(Vertx, String, String) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.LiveAuth
Create a OAuth2Auth provider for live.com
create(Vertx, String, String) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.MailchimpAuth
Create a OAuth2Auth provider for Mailchimp
create(Vertx, String, String) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.SalesforceAuth
Create a OAuth2Auth provider for Salesforce
create(Vertx, String, String) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.SoundcloudAuth
Create a OAuth2Auth provider for SoundCloud
create(Vertx, String, String) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.StripeAuth
Create a OAuth2Auth provider for Stripe
create(Vertx, String, String) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.TwitterAuth
Create a OAuth2Auth provider for Twitter
create(Vertx, String, String) - Static method in class io.vertx.reactivex.ext.web.templ.pug.PugTemplateEngine
Create a template engine using defaults
create(Vertx, String, String, HttpClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.BoxAuth
Create a OAuth2Auth provider for App.net
create(Vertx, String, String, HttpClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.DropboxAuth
Create a OAuth2Auth provider for Dropbox
create(Vertx, String, String, HttpClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.FacebookAuth
Create a OAuth2Auth provider for Facebook
create(Vertx, String, String, HttpClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.FoursquareAuth
Create a OAuth2Auth provider for Foursquare
create(Vertx, String, String, HttpClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.GiteeAuth
Create a OAuth2Auth provider for Gitee
create(Vertx, String, String, HttpClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.GithubAuth
Create a OAuth2Auth provider for Github
create(Vertx, String, String, HttpClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.GoogleAuth
Create a OAuth2Auth provider for Google
create(Vertx, String, String, HttpClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.HerokuAuth
Create a OAuth2Auth provider for Heroku
create(Vertx, String, String, HttpClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.InstagramAuth
Create a OAuth2Auth provider for Instagram
create(Vertx, String, String, HttpClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.LinkedInAuth
Create a OAuth2Auth provider for LinkedIn
create(Vertx, String, String, HttpClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.LiveAuth
Create a OAuth2Auth provider for live.com
create(Vertx, String, String, HttpClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.MailchimpAuth
Create a OAuth2Auth provider for Mailchimp
create(Vertx, String, String, HttpClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.SalesforceAuth
Create a OAuth2Auth provider for Salesforce
create(Vertx, String, String, HttpClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.SoundcloudAuth
Create a OAuth2Auth provider for SoundCloud
create(Vertx, String, String, HttpClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.StripeAuth
Create a OAuth2Auth provider for Stripe
create(Vertx, String, String, HttpClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.TwitterAuth
Create a OAuth2Auth provider for Twitter
create(Vertx, String, String, PubSecKeyOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.AppleIdAuth
Create a OAuth2Auth provider for Apple
create(Vertx, String, String, PubSecKeyOptions, HttpClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.AppleIdAuth
Create a OAuth2Auth provider for Apple
create(Vertx, String, String, String) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.AzureADAuth
Create a OAuth2Auth provider for Microsoft Azure Active Directory
create(Vertx, String, String, String) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.CloudFoundryAuth
Create a OAuth2Auth provider for CloudFoundry UAA
create(Vertx, String, String, String) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.GitLabAuth
Create a OAuth2Auth provider for GitLab.
create(Vertx, String, String, String) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.ShopifyAuth
Create a OAuth2Auth provider for Shopify
create(Vertx, String, String, String, HttpClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.AzureADAuth
Create a OAuth2Auth provider for Microsoft Azure Active Directory
create(Vertx, String, String, String, HttpClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.CloudFoundryAuth
Create a OAuth2Auth provider for CloudFoundry UAA
create(Vertx, String, String, String, HttpClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.GitLabAuth
Create a OAuth2Auth provider for GitLab.
create(Vertx, String, String, String, HttpClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.ShopifyAuth
Create a OAuth2Auth provider for Shopify
create(Vertx, String, String, String, String) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.IBMCloudAuth
Create a OAuth2Auth provider for IBM Cloud
create(Vertx, String, String, String, String, HttpClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.IBMCloudAuth
Create a OAuth2Auth provider for IBM Cloud
create(Vertx, String, String, String, String, String) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.AmazonCognitoAuth
Create a OAuth2Auth provider for Amazon Cognito
create(Vertx, String, String, String, String, String, HttpClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.AmazonCognitoAuth
Create a OAuth2Auth provider for Amazon Cognito
create(Vertx, Map<String, String>) - Static method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
Create a new KafkaAdminClient instance
create(Vertx, Map<String, String>) - Static method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Create a new KafkaConsumer instance
create(Vertx, Map<String, String>) - Static method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
Create a new KafkaProducer instance
create(Vertx, Map<String, String>, Class<K>, Class<V>) - Static method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Create a new KafkaConsumer instance
create(Vertx, Map<String, String>, Class<K>, Class<V>) - Static method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
Create a new KafkaProducer instance
create(Vertx, Consumer<K, V>) - Static method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Create a new KafkaConsumer instance from a native .
create(Vertx, Consumer<K, V>, KafkaClientOptions) - Static method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Create a new KafkaConsumer instance from a native .
create(Vertx, Producer<K, V>) - Static method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
Create a new KafkaProducer instance from a native .
create(Vertx, Producer<K, V>, KafkaClientOptions) - Static method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
Create a new KafkaProducer instance from a native .
create(AuthenticationProvider) - Static method in class io.vertx.reactivex.ext.web.handler.APIKeyHandler
Create an API Key authentication handler
create(AuthenticationProvider) - Static method in class io.vertx.reactivex.ext.web.handler.BasicAuthHandler
Create a basic auth handler
create(AuthenticationProvider) - Static method in class io.vertx.reactivex.ext.web.handler.FormLoginHandler
Create a handler
create(AuthenticationProvider) - Static method in class io.vertx.reactivex.ext.web.handler.RedirectAuthHandler
Create a handler
create(AuthenticationProvider, String) - Static method in class io.vertx.reactivex.ext.web.handler.BasicAuthHandler
Create a basic auth handler, specifying realm
create(AuthenticationProvider, String) - Static method in class io.vertx.reactivex.ext.web.handler.RedirectAuthHandler
Create a handler
create(AuthenticationProvider, String, String) - Static method in class io.vertx.reactivex.ext.web.handler.RedirectAuthHandler
Create a handler
create(AuthenticationProvider, String, String, String, String) - Static method in class io.vertx.reactivex.ext.web.handler.FormLoginHandler
Create a handler
create(Authorization) - Static method in class io.vertx.reactivex.ext.auth.authorization.NotAuthorization
 
create(Authorization) - Static method in class io.vertx.reactivex.ext.web.handler.AuthorizationHandler
create the handler that will check the specified authorization Note that to check several authorizations, you can specify a sub-interface such as AndAuthorization or OrAuthorization
create(JWTAuth) - Static method in class io.vertx.reactivex.ext.web.handler.JWTAuthHandler
Create a JWT auth handler.
create(JWTAuth, String) - Static method in class io.vertx.reactivex.ext.web.handler.JWTAuthHandler
Create a JWT auth handler.
create(HotpAuth) - Static method in class io.vertx.reactivex.ext.web.handler.OtpAuthHandler
Create a new instance of this handler using a hash based one time password authentication provider.
create(TotpAuth) - Static method in class io.vertx.reactivex.ext.web.handler.OtpAuthHandler
Create a new instance of this handler using a time based one time password authentication provider.
create(User) - Static method in class io.vertx.reactivex.ext.auth.authorization.AuthorizationContext
Factory for Authorization Context
create(User, MultiMap) - Static method in class io.vertx.reactivex.ext.auth.authorization.AuthorizationContext
Factory for Authorization Context
create(WebAuthn4J) - Static method in class io.vertx.reactivex.ext.web.handler.WebAuthn4JHandler
Create a WebAuthN auth handler.
create(MailAttachment) - Static method in class io.vertx.reactivex.ext.mail.MailAttachment
create a copy of a MailAttachment object
create(WebClient) - Static method in class io.vertx.reactivex.ext.web.client.CachingWebClient
Create a cache aware web client using the provided WebClient.
create(WebClient) - Static method in class io.vertx.reactivex.ext.web.client.WebClientSession
Create a session aware web client using the provided webClient instance.
create(WebClient, CachingWebClientOptions) - Static method in class io.vertx.reactivex.ext.web.client.CachingWebClient
Create a cache aware web client using the provided WebClient.
create(WebClient, CacheStore) - Static method in class io.vertx.reactivex.ext.web.client.CachingWebClient
Create a cache aware web client using the provided WebClient.
create(WebClient, CacheStore, CachingWebClientOptions) - Static method in class io.vertx.reactivex.ext.web.client.CachingWebClient
Create a cache aware web client using the provided WebClient.
create(WebClient, CookieStore) - Static method in class io.vertx.reactivex.ext.web.client.WebClientSession
Create a session aware web client using the provided webClient instance.
create(WebClient, OAuth2Auth) - Static method in class io.vertx.reactivex.ext.web.client.OAuth2WebClient
Create a session aware web client using the provided webClient instance.
create(WebClient, OAuth2Auth, OAuth2WebClientOptions) - Static method in class io.vertx.reactivex.ext.web.client.OAuth2WebClient
Create a session aware web client using the provided webClient instance.
create(TemplateEngine) - Static method in class io.vertx.reactivex.ext.web.handler.TemplateHandler
Create a handler
create(TemplateEngine, String, String) - Static method in class io.vertx.reactivex.ext.web.handler.TemplateHandler
Create a handler
create(SessionStore) - Static method in class io.vertx.reactivex.ext.web.handler.SessionHandler
Create a session handler
create(JsonSchema, JsonSchemaOptions) - Static method in class io.vertx.reactivex.json.schema.Validator
Creates a new validator with some initial schema and options.
create(JsonSchema, JsonSchemaOptions, JsonFormatValidator) - Static method in class io.vertx.reactivex.json.schema.Validator
Creates a new validator with some initial schema, options and a custom JSON format validator.
create(SchemaRepository) - Method in class io.vertx.reactivex.ext.web.validation.builder.BodyProcessorFactory
 
create(SchemaRepository) - Static method in class io.vertx.reactivex.ext.web.validation.builder.ValidationHandlerBuilder
 
create(Redis) - Static method in class io.vertx.reactivex.redis.client.RedisCluster
 
create(RedisConnection) - Static method in class io.vertx.reactivex.redis.client.RedisCluster
 
create(SqlClient) - Static method in class io.vertx.reactivex.ext.auth.sqlclient.SqlAuthentication
Create a JDBC auth provider implementation
create(SqlClient) - Static method in class io.vertx.reactivex.ext.auth.sqlclient.SqlAuthorization
Create a JDBC authorization provider implementation
create(SqlClient) - Static method in class io.vertx.reactivex.ext.auth.sqlclient.SqlUserUtil
Create an instance of the user helper.
create(SqlClient, SqlAuthenticationOptions) - Static method in class io.vertx.reactivex.ext.auth.sqlclient.SqlAuthentication
Create a JDBC auth provider implementation
create(SqlClient, SqlAuthorizationOptions) - Static method in class io.vertx.reactivex.ext.auth.sqlclient.SqlAuthorization
Create a JDBC authorization provider implementation
create(SqlClient, String, String, String) - Static method in class io.vertx.reactivex.ext.auth.sqlclient.SqlUserUtil
Create an instance of the user helper with custom queries.
create(Object) - Static method in class io.vertx.reactivex.ext.web.validation.RequestParameter
 
create(String) - Static method in class io.vertx.reactivex.ext.auth.authorization.PermissionBasedAuthorization
 
create(String) - Static method in class io.vertx.reactivex.ext.auth.authorization.RoleBasedAuthorization
 
create(String) - Static method in class io.vertx.reactivex.ext.auth.authorization.WildcardPermissionBasedAuthorization
 
create(String) - Static method in class io.vertx.reactivex.ext.auth.jwt.authorization.JWTAuthorization
Factory method to create a Authorization provider for JWT tokens.
create(String) - Static method in class io.vertx.reactivex.ext.auth.oauth2.authorization.ScopeAuthorization
Factory method to create a Authorization provider for Oauth 2.0 scopes.
create(String) - Static method in class io.vertx.reactivex.ext.auth.otp.OtpKeyGenerator
Creates an instance of OtpKeyGenerator.
create(String) - Static method in class io.vertx.reactivex.ext.unit.TestSuite
Create and return a new test suite.
create(String) - Static method in class io.vertx.reactivex.ext.web.handler.BodyHandler
Create a body handler and use the given upload directory.
create(String) - Static method in class io.vertx.reactivex.ext.web.handler.MultiTenantHandler
Create a MultiTenant handler that will extract the tenant id from a given header name.
create(String) - Static method in class io.vertx.reactivex.ext.web.handler.ResponseContentTypeHandler
Create a response content type handler with a custom disable flag.
create(String) - Static method in class io.vertx.reactivex.ext.web.handler.StaticHandler
Create a handler, specifying web-root
create(String) - Static method in class io.vertx.reactivex.ext.web.handler.XFrameHandler
Creates a new handler that will add the X-FRAME-OPTIONS header to the current response.
create(String) - Static method in class io.vertx.reactivex.ext.web.templ.rocker.RockerTemplateEngine
Create a template engine using a custom extension
create(String) - Static method in class io.vertx.reactivex.micrometer.PrometheusScrapingHandler
Creates a Vert.x Web Route handler for Prometheus metrics scraping.
create(String, Handler<TestContext>) - Static method in class io.vertx.reactivex.ext.unit.TestCase
Create a test case.
create(String, Vertx) - Static method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
Creates a new instance of CircuitBreaker, with default options.
create(String, Vertx, CircuitBreakerOptions) - Static method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
Creates a new instance of CircuitBreaker.
create(String, Class<T>) - Static method in class io.vertx.reactivex.sqlclient.PropertyKind
 
create(String, String) - Static method in class io.vertx.reactivex.ext.auth.oauth2.authorization.ScopeAuthorization
Factory method to create a Authorization provider for OpenID Connect scopes.
create(String, K, V) - Static method in class io.vertx.reactivex.kafka.client.producer.KafkaProducerRecord
Create a concrete instance of a Vert.x producer record
create(String, K, V, Long, Integer) - Static method in class io.vertx.reactivex.kafka.client.producer.KafkaProducerRecord
Create a concrete instance of a Vert.x producer record
create(String, V) - Static method in class io.vertx.reactivex.kafka.client.producer.KafkaProducerRecord
Create a concrete instance of a Vert.x producer record
create(Function<User, Boolean>) - Static method in class io.vertx.reactivex.ext.auth.abac.Attribute
A custom function to be used during matching.
create(Function<RoutingContext, String>) - Static method in class io.vertx.reactivex.ext.web.handler.MultiTenantHandler
Create a MultiTenant handler using a custom tenant extraction function.
create(Function<RoutingContext, String>, String) - Static method in class io.vertx.reactivex.ext.web.handler.MultiTenantHandler
Create a MultiTenant handler using a custom tenant extraction function.
createAclPolicy(AclPolicy) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Creates a new ACL policy
createAcls(List<AclBinding>) - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
Create the ACL rules.
createAclToken(AclToken) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Create an Acl token
createAnonymousSender() - Method in class io.vertx.reactivex.amqp.AmqpConnection
Creates an anonymous sender.
createAuthenticator(String, OtpKey) - Method in class io.vertx.reactivex.ext.auth.otp.hotp.HotpAuth
Creating authenticator from user id and key.
createAuthenticator(String, OtpKey) - Method in class io.vertx.reactivex.ext.auth.otp.totp.TotpAuth
Creating authenticator from user id and key.
createClient(Vertx) - Static method in class io.vertx.reactivex.redis.client.Redis
Create a new Redis client using the default client options.
createClient(Vertx, RedisOptions) - Static method in class io.vertx.reactivex.redis.client.Redis
Create a new Redis client using the given client options.
createClient(Vertx, String) - Static method in class io.vertx.reactivex.redis.client.Redis
Create a new Redis client using the default client options.
createClusterClient(Vertx, RedisOptions, Supplier<Future<RedisClusterConnectOptions>>) - Static method in class io.vertx.reactivex.redis.client.Redis
Creates a new cluster Redis client.
createCollection(String) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Create a new collection
createCollectionWithOptions(String, CreateCollectionOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Create a new collection with options
createCredentialsOptions(JsonObject) - Method in class io.vertx.reactivex.ext.auth.webauthn4j.WebAuthn4J
Gets a challenge and any other parameters for the navigator.credentials.create() call.
createDefaultGridFsBucketService() - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Creates a MongoGridFsClient used to interact with Mongo GridFS.
createDynamicReceiver() - Method in class io.vertx.reactivex.amqp.AmqpConnection
Creates a dynamic receiver.
createErrorFrame(String, Map<String, String>, String) - Static method in class io.vertx.reactivex.ext.stomp.Frames
 
createFile(String) - Method in class io.vertx.reactivex.core.file.FileSystem
Creates an empty file with the specified path, asynchronously.
createFile(String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
Creates an empty file with the specified path and permissions perms, asynchronously.
createFileBlocking(String) - Method in class io.vertx.reactivex.core.file.FileSystem
createFileBlocking(String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
createGridFsBucketService(String) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Creates a MongoGridFsClient used to interact with Mongo GridFS.
createHashedUser(String, String) - Method in class io.vertx.reactivex.ext.auth.sqlclient.SqlUserUtil
Insert a user into a database.
createIndex(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Creates an index.
createIndexes(String, List<IndexModel>) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
creates an indexes
createIndexWithOptions(String, JsonObject, IndexOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Creates an index.
createOptimized(String) - Static method in class io.vertx.reactivex.core.http.HttpHeaders
Create an optimized CharSequence which can be used as header name or value.
createPartitions(Map<String, NewPartitions>) - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
Creates a batch of new partitions in the Kafka topic
createPreparedQuery(PreparedQueryDefinition) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
 
createReceiptFrame(String, Map<String, String>) - Static method in class io.vertx.reactivex.ext.stomp.Frames
 
createReceiver(String) - Method in class io.vertx.reactivex.amqp.AmqpClient
Creates a receiver used to consume messages from the given address.
createReceiver(String) - Method in class io.vertx.reactivex.amqp.AmqpConnection
Creates a receiver used to consume messages from the given address.
createReceiver(String, AmqpReceiverOptions) - Method in class io.vertx.reactivex.amqp.AmqpClient
Creates a receiver used to consumer messages from the given address.
createReceiver(String, AmqpReceiverOptions) - Method in class io.vertx.reactivex.amqp.AmqpConnection
Creates a receiver used to consumer messages from the given address.
createRecord(String, boolean, String, int, String, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.HttpEndpoint
createRecord(String, JsonObject, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.MongoDataSource
Convenient method to create a record for a Mongo data source.
createRecord(String, JsonObject, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.RedisDataSource
Convenient method to create a record for a Redis data source.
createRecord(String, String) - Static method in class io.vertx.reactivex.servicediscovery.types.HttpEndpoint
createRecord(String, String) - Static method in class io.vertx.reactivex.servicediscovery.types.MessageSource
createRecord(String, String, int, String) - Static method in class io.vertx.reactivex.servicediscovery.types.HttpEndpoint
createRecord(String, String, int, String, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.HttpEndpoint
Convenient method to create a record for a HTTP endpoint.
createRecord(String, String, String) - Static method in class io.vertx.reactivex.servicediscovery.types.EventBusService
Creates a record based on the parameters.
createRecord(String, String, String) - Static method in class io.vertx.reactivex.servicediscovery.types.MessageSource
createRecord(String, String, String, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.EventBusService
Sugar method to creates a record for this type.
createRecord(String, String, String, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.MessageSource
Create a record representing a data producer.
createReplicationClient(Vertx, RedisOptions, Supplier<Future<RedisReplicationConnectOptions>>) - Static method in class io.vertx.reactivex.redis.client.Redis
Creates a new replication Redis client.
createRolePermission(String, String) - Method in class io.vertx.reactivex.ext.auth.sqlclient.SqlUserUtil
Insert a role permission into a database.
createRouter() - Method in class io.vertx.reactivex.ext.web.openapi.router.RouterBuilder
Construct a new router based on the related OpenAPI contract.
createSender(String) - Method in class io.vertx.reactivex.amqp.AmqpClient
Creates a sender used to send messages to the given address.
createSender(String) - Method in class io.vertx.reactivex.amqp.AmqpConnection
Creates a sender used to send messages to the given address.
createSender(String, AmqpSenderOptions) - Method in class io.vertx.reactivex.amqp.AmqpClient
Creates a sender used to send messages to the given address.
createSender(String, AmqpSenderOptions) - Method in class io.vertx.reactivex.amqp.AmqpConnection
Creates a sender used to send messages to the given address.
createSentinelClient(Vertx, RedisOptions, Supplier<Future<RedisSentinelConnectOptions>>) - Static method in class io.vertx.reactivex.redis.client.Redis
Creates a new sentinel Redis client.
createSession() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Initialize a new session
createSession(long) - Method in class io.vertx.reactivex.ext.web.sstore.SessionStore
Create a new session using the default min length.
createSession(long, int) - Method in class io.vertx.reactivex.ext.web.sstore.SessionStore
Create a new session.
createSessionWithOptions(SessionOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Initialize a new session
createShared(Vertx) - Static method in class io.vertx.reactivex.cassandra.CassandraClient
Like CassandraClient.createShared(io.vertx.reactivex.core.Vertx) with default options and client name.
createShared(Vertx, CassandraClientOptions) - Static method in class io.vertx.reactivex.cassandra.CassandraClient
createShared(Vertx, JsonObject) - Static method in class io.vertx.reactivex.ext.mongo.MongoClient
createShared(Vertx, JsonObject, String) - Static method in class io.vertx.reactivex.ext.mongo.MongoClient
Create a Mongo client which shares its data source with any other Mongo clients created with the same data source name
createShared(Vertx, MailConfig) - Static method in class io.vertx.reactivex.ext.mail.MailClient
createShared(Vertx, MailConfig, String) - Static method in class io.vertx.reactivex.ext.mail.MailClient
Create a Mail client which shares its connection pool with any other Mail clients created with the same pool name
createShared(Vertx, String) - Static method in class io.vertx.reactivex.cassandra.CassandraClient
createShared(Vertx, String, CassandraClientOptions) - Static method in class io.vertx.reactivex.cassandra.CassandraClient
Create a Cassandra client that shares its driver session with any other client having the same name.
createShared(Vertx, String, KafkaClientOptions) - Static method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
Get or create a KafkaProducer instance which shares its stream with any other KafkaProducer created with the same name
createShared(Vertx, String, KafkaClientOptions, Class<K>, Class<V>) - Static method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
Get or create a KafkaProducer instance which shares its stream with any other KafkaProducer created with the same name
createShared(Vertx, String, Map<String, String>) - Static method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
Get or create a KafkaProducer instance which shares its stream with any other KafkaProducer created with the same name
createShared(Vertx, String, Map<String, String>, Class<K>, Class<V>) - Static method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
Get or create a KafkaProducer instance which shares its stream with any other KafkaProducer created with the same name
createStandaloneClient(Vertx, RedisOptions, Supplier<Future<RedisStandaloneConnectOptions>>) - Static method in class io.vertx.reactivex.redis.client.Redis
Creates a new standalone Redis client.
createStream(int) - Method in class io.vertx.reactivex.sqlclient.PreparedStatement
Like PreparedStatement.createStream(int) but with empty arguments.
createStream(int, Tuple) - Method in class io.vertx.reactivex.sqlclient.PreparedStatement
Execute the prepared query with a cursor and createStream the result.
createTempDirectory(String) - Method in class io.vertx.reactivex.core.file.FileSystem
Creates a new directory in the default temporary-file directory, using the given prefix to generate its name, asynchronously.
createTempDirectory(String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
Creates a new directory in the default temporary-file directory, using the given prefix to generate its name, asynchronously.
createTempDirectory(String, String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
Creates a new directory in the directory provided by the path path, using the given prefix to generate its name, asynchronously.
createTempDirectoryBlocking(String) - Method in class io.vertx.reactivex.core.file.FileSystem
createTempDirectoryBlocking(String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
createTempDirectoryBlocking(String, String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
createTempFile(String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
Creates a new file in the default temporary-file directory, using the given prefix and suffix to generate its name, asynchronously.
createTempFile(String, String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
Creates a new file in the directory provided by the path dir, using the given prefix and suffix to generate its name, asynchronously.
createTempFile(String, String, String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
Creates a new file in the directory provided by the path dir, using the given prefix and suffix to generate its name, asynchronously.
createTempFileBlocking(String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
createTempFileBlocking(String, String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
createTempFileBlocking(String, String, String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
createTopics(List<NewTopic>) - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
Creates a batch of new Kafka topics
createUser(String, String) - Method in class io.vertx.reactivex.ext.auth.sqlclient.SqlUserUtil
Insert a user into a database.
createUserRole(String, String) - Method in class io.vertx.reactivex.ext.auth.sqlclient.SqlUserUtil
Insert a user role into a database.
createWithHealthChecks(HealthChecks) - Static method in class io.vertx.reactivex.ext.web.healthchecks.HealthCheckHandler
Creates an instance of the default implementation of the HealthCheckHandler.
createWithHealthChecks(HealthChecks, AuthenticationProvider) - Static method in class io.vertx.reactivex.ext.web.healthchecks.HealthCheckHandler
Creates an instance of the default implementation of the HealthCheckHandler.
creationTime() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
creationTime(long) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
credentials(Credentials) - Method in class io.vertx.reactivex.ext.auth.audit.SecurityAudit
 
credentialStorage(CredentialStorage) - Method in class io.vertx.reactivex.ext.auth.webauthn4j.WebAuthn4J
Provide a CredentialStorage that can fetch Authenticators from storage and update them.
CredentialStorage - Class in io.vertx.reactivex.ext.auth.webauthn4j
Used to represent persistent storage of credentials, this gives you a way to abstract how you want to store them (in memory, database, other).
CredentialStorage(CredentialStorage) - Constructor for class io.vertx.reactivex.ext.auth.webauthn4j.CredentialStorage
 
CredentialStorage(Object) - Constructor for class io.vertx.reactivex.ext.auth.webauthn4j.CredentialStorage
 
CSPHandler - Class in io.vertx.reactivex.ext.web.handler
Content Security Policy (CSP) is an added layer of security that helps to detect and mitigate certain types of attacks, including Cross Site Scripting (XSS) and data injection attacks.
CSPHandler(CSPHandler) - Constructor for class io.vertx.reactivex.ext.web.handler.CSPHandler
 
CSPHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.CSPHandler
 
CSRFHandler - Class in io.vertx.reactivex.ext.web.handler
This handler adds a CSRF token to requests which mutate state.
CSRFHandler(CSRFHandler) - Constructor for class io.vertx.reactivex.ext.web.handler.CSRFHandler
 
CSRFHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.CSRFHandler
 
current() - Static method in class io.vertx.reactivex.ext.auth.prng.VertxContextPRNG
Get or create a secure non blocking random number generator using the current vert.x context.
current(Vertx) - Static method in class io.vertx.reactivex.ext.auth.prng.VertxContextPRNG
Get or create a secure non blocking random number generator using the current vert.x instance.
currentPage() - Method in class io.vertx.reactivex.cassandra.ResultSet
 
currentRoute() - Method in class io.vertx.reactivex.ext.web.RoutingContext
 
cursor() - Method in class io.vertx.reactivex.sqlclient.PreparedStatement
Like PreparedStatement.cursor() but with empty arguments.
cursor(Tuple) - Method in class io.vertx.reactivex.sqlclient.PreparedStatement
Create a cursor with the provided arguments.
Cursor - Class in io.vertx.reactivex.sqlclient
A cursor that reads progressively rows from the database, it is useful for reading very large result sets.
Cursor(Cursor) - Constructor for class io.vertx.reactivex.sqlclient.Cursor
 
Cursor(Object) - Constructor for class io.vertx.reactivex.sqlclient.Cursor
 
customFormatter(LoggerFormatter) - Method in class io.vertx.reactivex.ext.web.handler.LoggerHandler
Set the custom formatter to be used by the handler.
customFrameHandler(Handler<HttpFrame>) - Method in class io.vertx.reactivex.core.http.HttpClientResponse
Set an custom frame handler.
customFrameHandler(Handler<HttpFrame>) - Method in class io.vertx.reactivex.core.http.HttpServerRequest
Set a custom frame handler.

D

data() - Method in class io.vertx.reactivex.ext.web.RoutingContext
 
data() - Method in class io.vertx.reactivex.ext.web.Session
 
databaseMetadata() - Method in class io.vertx.reactivex.sqlclient.SqlConnection
 
DatabaseMetadata - Class in io.vertx.reactivex.sqlclient.spi
Contains static metadata about the backend database server
DatabaseMetadata(DatabaseMetadata) - Constructor for class io.vertx.reactivex.sqlclient.spi.DatabaseMetadata
 
DatabaseMetadata(Object) - Constructor for class io.vertx.reactivex.sqlclient.spi.DatabaseMetadata
 
DatagramSocket - Class in io.vertx.reactivex.core.datagram
A datagram socket can be used to send DatagramPacket's to remote datagram servers and receive DatagramPackets .
DatagramSocket(DatagramSocket) - Constructor for class io.vertx.reactivex.core.datagram.DatagramSocket
 
DatagramSocket(Object) - Constructor for class io.vertx.reactivex.core.datagram.DatagramSocket
 
DATE - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Date header name
DB2Builder - Class in io.vertx.reactivex.db2client
Entry point for building DB2 clients.
DB2Builder(DB2Builder) - Constructor for class io.vertx.reactivex.db2client.DB2Builder
 
DB2Builder(Object) - Constructor for class io.vertx.reactivex.db2client.DB2Builder
 
DB2Connection - Class in io.vertx.reactivex.db2client
A connection to DB2 server.
DB2Connection(DB2Connection) - Constructor for class io.vertx.reactivex.db2client.DB2Connection
 
DB2Connection(Object) - Constructor for class io.vertx.reactivex.db2client.DB2Connection
 
dbsize() - Method in class io.vertx.reactivex.redis.client.RedisAPI
Return the number of keys in the selected database.
deadline() - Method in class io.vertx.reactivex.grpc.client.GrpcClientRequest
 
deadline() - Method in class io.vertx.reactivex.grpc.server.GrpcServerRequest
 
debug() - Method in class io.vertx.reactivex.db2client.DB2Connection
Send a DEBUG command to dump debug information to the server's stdout.
debug() - Method in class io.vertx.reactivex.mysqlclient.MySQLConnection
Send a DEBUG command to dump debug information to the server's stdout.
debug(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
A container for debugging commands.
decr(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Decrement the integer value of a key by one.
decrby(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Decrement the integer value of a key by the given number.
decrementAndGet() - Method in class io.vertx.reactivex.core.shareddata.Counter
Decrement the counter atomically and return the new count
deepObjectParam(String, ObjectSchemaBuilder) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Parameters
Creates a required deep object parameter.
deepToString() - Method in class io.vertx.reactivex.sqlclient.Tuple
 
DEFAULT_ALWAYS_ASYNC_FS - Static variable in class io.vertx.reactivex.ext.web.handler.StaticHandler
Default of whether async filesystem access should always be used
DEFAULT_BODY_LIMIT - Static variable in class io.vertx.reactivex.ext.web.handler.BodyHandler
Default max size for a request body in bytes = 10485760, i.e. 10 megabytes
DEFAULT_CACHE_ENTRY_TIMEOUT - Static variable in class io.vertx.reactivex.ext.web.handler.StaticHandler
Default cache entry timeout, when caching
DEFAULT_CACHING_ENABLED - Static variable in class io.vertx.reactivex.ext.web.handler.StaticHandler
Default of whether cache header handling is enabled
DEFAULT_CONTENT_TYPE - Static variable in class io.vertx.reactivex.ext.web.handler.TemplateHandler
The default content type header to be used in the response
DEFAULT_COOKIE_HTTP_ONLY_FLAG - Static variable in class io.vertx.reactivex.ext.web.handler.SessionHandler
Default of whether the cookie has the HttpOnly flag set More info: https://www.owasp.org/index.php/HttpOnly
DEFAULT_COOKIE_NAME - Static variable in class io.vertx.reactivex.ext.web.handler.CSRFHandler
 
DEFAULT_COOKIE_PATH - Static variable in class io.vertx.reactivex.ext.web.handler.CSRFHandler
 
DEFAULT_COOKIE_SECURE_FLAG - Static variable in class io.vertx.reactivex.ext.web.handler.SessionHandler
Default of whether the cookie has the 'secure' flag set to allow transmission over https only.
DEFAULT_DB_NAME - Static variable in class io.vertx.reactivex.ext.mongo.MongoClient
The name of the default database
DEFAULT_DELETE_UPLOADED_FILES_ON_END - Static variable in class io.vertx.reactivex.ext.web.handler.BodyHandler
Default value of whether uploaded files should be removed after handling the request
DEFAULT_DIRECTORY_LISTING - Static variable in class io.vertx.reactivex.ext.web.handler.StaticHandler
Default of whether directory listing is enabled
DEFAULT_DIRECTORY_TEMPLATE - Static variable in class io.vertx.reactivex.ext.web.handler.StaticHandler
Default template file to use for directory listing
DEFAULT_DISABLE_FLAG - Static variable in class io.vertx.reactivex.ext.web.handler.ResponseContentTypeHandler
 
DEFAULT_ENABLE_FS_TUNING - Static variable in class io.vertx.reactivex.ext.web.handler.StaticHandler
Default of whether fs async/sync tuning should be used
DEFAULT_ERROR_HANDLER_TEMPLATE - Static variable in class io.vertx.reactivex.ext.web.handler.ErrorHandler
The default template to use for rendering
DEFAULT_ERRORCODE - Static variable in class io.vertx.reactivex.ext.web.handler.TimeoutHandler
The default error code
DEFAULT_FILES_READ_ONLY - Static variable in class io.vertx.reactivex.ext.web.handler.StaticHandler
Default value of whether files are read -only and never will be updated
DEFAULT_FORMAT - Static variable in class io.vertx.reactivex.ext.web.handler.LoggerHandler
 
DEFAULT_HEADER_NAME - Static variable in class io.vertx.reactivex.ext.web.handler.CSRFHandler
 
DEFAULT_INCLUDE_HIDDEN - Static variable in class io.vertx.reactivex.ext.web.handler.StaticHandler
Default of whether hidden files can be served
DEFAULT_INDEX_PAGE - Static variable in class io.vertx.reactivex.ext.web.handler.StaticHandler
The default index page
DEFAULT_INDEX_TEMPLATE - Static variable in class io.vertx.reactivex.ext.web.handler.TemplateHandler
The default index page
DEFAULT_LAZY_SESSION - Static variable in class io.vertx.reactivex.ext.web.handler.SessionHandler
Default of whether the session should be created lazily.
DEFAULT_LOGIN_REDIRECT_URL - Static variable in class io.vertx.reactivex.ext.web.handler.RedirectAuthHandler
Default path the user will be redirected to
DEFAULT_MAX_AGE - Static variable in class io.vertx.reactivex.ext.web.handler.HSTSHandler
 
DEFAULT_MAX_AGE_SECONDS - Static variable in class io.vertx.reactivex.ext.web.handler.FaviconHandler
The default max age in seconds as set in the cache-control header
DEFAULT_MAX_AGE_SECONDS - Static variable in class io.vertx.reactivex.ext.web.handler.StaticHandler
Default max age for cache headers
DEFAULT_MAX_AVG_SERVE_TIME_NS - Static variable in class io.vertx.reactivex.ext.web.handler.StaticHandler
Default max avg serve time, in ns, over which serving will be considered slow
DEFAULT_MAX_CACHE_SIZE - Static variable in class io.vertx.reactivex.ext.web.handler.StaticHandler
The default max cache size
DEFAULT_MERGE_FORM_ATTRIBUTES - Static variable in class io.vertx.reactivex.ext.web.handler.BodyHandler
Default value of whether form attributes should be merged into request params
DEFAULT_NAG_HTTPS - Static variable in class io.vertx.reactivex.ext.web.handler.SessionHandler
Default of whether a nagging log warning should be written if the session handler is accessed over HTTP, not HTTPS
DEFAULT_NONCE_EXPIRE_TIMEOUT - Static variable in class io.vertx.reactivex.ext.web.handler.DigestAuthHandler
The default nonce expire timeout to use in milliseconds.
DEFAULT_PASSWORD_PARAM - Static variable in class io.vertx.reactivex.ext.web.handler.FormLoginHandler
The default value of the form attribute which will contain the password
DEFAULT_POOL_NAME - Static variable in class io.vertx.reactivex.ext.mail.MailClient
The name of the default pool
DEFAULT_POOL_NAME - Static variable in class io.vertx.reactivex.ext.mongo.MongoClient
The name of the default pool
DEFAULT_PREALLOCATE_BODY_BUFFER - Static variable in class io.vertx.reactivex.ext.web.handler.BodyHandler
Default value of whether to pre-allocate the body buffer size according to the content-length HTTP request header
DEFAULT_RANGE_SUPPORT - Static variable in class io.vertx.reactivex.ext.web.handler.StaticHandler
Default of whether Range request handling support should be used
DEFAULT_REALM - Static variable in class io.vertx.reactivex.ext.web.handler.BasicAuthHandler
The default realm to use
DEFAULT_REAPER_INTERVAL - Static variable in class io.vertx.reactivex.ext.web.sstore.LocalSessionStore
Default of how often, in ms, to check for expired sessions
DEFAULT_RETRY_TIMEOUT - Static variable in class io.vertx.reactivex.ext.web.sstore.ClusteredSessionStore
Default retry time out, in ms, for a session not found in this store.
DEFAULT_RETRY_TIMEOUT_MS - Static variable in class io.vertx.reactivex.ext.web.sstore.redis.RedisSessionStore
 
DEFAULT_RETURN_URL_PARAM - Static variable in class io.vertx.reactivex.ext.web.handler.FormLoginHandler
The default value of the session attribute which will contain the return url
DEFAULT_RETURN_URL_PARAM - Static variable in class io.vertx.reactivex.ext.web.handler.RedirectAuthHandler
Default name of param used to store return url information in session
DEFAULT_ROOT_FILESYSTEM_ACCESS - Static variable in class io.vertx.reactivex.ext.web.handler.StaticHandler
Default of whether access to the root of the file system should be allowed or just allow from the current working directory.
DEFAULT_SEND_VARY_HEADER - Static variable in class io.vertx.reactivex.ext.web.handler.StaticHandler
Default of whether vary header should be sent.
DEFAULT_SESSION_COOKIE_NAME - Static variable in class io.vertx.reactivex.ext.web.handler.SessionHandler
Default name of session cookie
DEFAULT_SESSION_COOKIE_PATH - Static variable in class io.vertx.reactivex.ext.web.handler.SessionHandler
Default path of session cookie
DEFAULT_SESSION_MAP_NAME - Static variable in class io.vertx.reactivex.ext.web.sstore.ClusteredSessionStore
The default name used for the session map
DEFAULT_SESSION_MAP_NAME - Static variable in class io.vertx.reactivex.ext.web.sstore.LocalSessionStore
Default name for map used to store sessions
DEFAULT_SESSION_TIMEOUT - Static variable in class io.vertx.reactivex.ext.web.handler.SessionHandler
Default time, in ms, that a session lasts for without being accessed before expiring.
DEFAULT_SESSIONID_LENGTH - Static variable in class io.vertx.reactivex.ext.web.sstore.ClusteredSessionStore
Default length for a session id.
DEFAULT_SESSIONID_LENGTH - Static variable in class io.vertx.reactivex.ext.web.sstore.cookie.CookieSessionStore
Default length for a session id.
DEFAULT_SESSIONID_LENGTH - Static variable in class io.vertx.reactivex.ext.web.sstore.infinispan.InfinispanSessionStore
Default length for a session id.
DEFAULT_SESSIONID_LENGTH - Static variable in class io.vertx.reactivex.ext.web.sstore.LocalSessionStore
Default length for a session id.
DEFAULT_SESSIONID_LENGTH - Static variable in class io.vertx.reactivex.ext.web.sstore.redis.RedisSessionStore
Default length for a session id.
DEFAULT_SESSIONID_LENGTH - Static variable in class io.vertx.reactivex.ext.web.sstore.SessionStore
Default length for a session id.
DEFAULT_SESSIONID_MIN_LENGTH - Static variable in class io.vertx.reactivex.ext.web.handler.SessionHandler
Default min length for a session id.
DEFAULT_SHARED_CLIENT_NAME - Static variable in class io.vertx.reactivex.cassandra.CassandraClient
The default shared client name.
DEFAULT_TEMPLATE_DIRECTORY - Static variable in class io.vertx.reactivex.ext.web.handler.TemplateHandler
The default directory where templates will be looked for
DEFAULT_TEMPLATE_EXTENSION - Static variable in class io.vertx.reactivex.ext.web.templ.freemarker.FreeMarkerTemplateEngine
Default template extension
DEFAULT_TEMPLATE_EXTENSION - Static variable in class io.vertx.reactivex.ext.web.templ.handlebars.HandlebarsTemplateEngine
Default template extension
DEFAULT_TEMPLATE_EXTENSION - Static variable in class io.vertx.reactivex.ext.web.templ.mvel.MVELTemplateEngine
Default template extension
DEFAULT_TEMPLATE_EXTENSION - Static variable in class io.vertx.reactivex.ext.web.templ.pebble.PebbleTemplateEngine
Default template extension
DEFAULT_TEMPLATE_EXTENSION - Static variable in class io.vertx.reactivex.ext.web.templ.pug.PugTemplateEngine
Default template extension
DEFAULT_TEMPLATE_EXTENSION - Static variable in class io.vertx.reactivex.ext.web.templ.rocker.RockerTemplateEngine
Default template extension
DEFAULT_TEMPLATE_MODE - Static variable in class io.vertx.reactivex.ext.web.templ.thymeleaf.ThymeleafTemplateEngine
 
DEFAULT_TIMEOUT - Static variable in class io.vertx.reactivex.ext.web.handler.TimeoutHandler
The default timeout, in ms
DEFAULT_UPLOADS_DIRECTORY - Static variable in class io.vertx.reactivex.ext.web.handler.BodyHandler
Default uploads directory on server for file uploads
DEFAULT_USERNAME_PARAM - Static variable in class io.vertx.reactivex.ext.web.handler.FormLoginHandler
The default value of the form attribute which will contain the username
DEFAULT_VALIDATOR - Static variable in class io.vertx.reactivex.json.schema.JsonFormatValidator
The default validator which performs a NOOP.
DEFAULT_WEB_ROOT - Static variable in class io.vertx.reactivex.ext.web.handler.StaticHandler
Default value of the web-root, where files are served from
DEFAULT_WEIGHT - Static variable in class io.vertx.reactivex.ext.web.LanguageHeader
If no "q" parameter is present, the default weight is 1.
DEFAULT_WEIGHT - Static variable in class io.vertx.reactivex.ext.web.MIMEHeader
If no "q" parameter is present, the default weight is 1.
defaultPolicy() - Static method in class io.vertx.reactivex.circuitbreaker.FailurePolicy
The default policy, which considers an asynchronous result as a failure if returns true.
DEFLATE_GZIP - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
deflate,gzip header value
DEFLATE_GZIP_BR - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
deflate,gzip,br header value
DEFLATE_GZIP_ZSTD - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
deflate,gzip,zstd header value
DEFLATE_GZIP_ZSTD_BR_SNAPPY - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
deflate,gzip,zstd,br header value
del(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Delete a key.
delay(Throwable, int) - Method in class io.vertx.reactivex.circuitbreaker.RetryPolicy
Compute a delay in milliseconds before retry is executed.
delete() - Method in class io.vertx.reactivex.ext.web.FileUpload
Delete the uploaded file on the disk.
delete() - Method in class io.vertx.reactivex.ext.web.Router
Add a route that matches any HTTP DELETE request
delete(int, String, UriTemplate) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP DELETE request to send to the server at the specified host and port.
delete(int, String, String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP DELETE request to send to the server at the specified host and port.
delete(UriTemplate) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP DELETE request to send to the server at the default host and port.
delete(String) - Method in class io.vertx.reactivex.core.file.FileSystem
Deletes the file represented by the specified path, asynchronously.
delete(String) - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
Deletes a file by it's ID
delete(String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP DELETE request to send to the server at the default host and port.
delete(String) - Method in class io.vertx.reactivex.ext.web.Router
Add a route that matches a HTTP DELETE request and the specified path
delete(String) - Method in class io.vertx.reactivex.ext.web.sstore.SessionStore
Delete the session with the specified ID.
delete(String, UriTemplate) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP DELETE request to send to the server at the specified host and default port.
delete(String, String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP DELETE request to send to the server at the specified host and default port.
deleteAbs(UriTemplate) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP DELETE request to send to the server using an absolute URI, specifying a response handler to receive the response
deleteAbs(String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP DELETE request to send to the server using an absolute URI, specifying a response handler to receive the response
deleteAcls(List<AclBindingFilter>) - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
Delete the ACL rules.
deleteAclToken(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Deletes an ACL token
deleteBlocking(String) - Method in class io.vertx.reactivex.core.file.FileSystem
deleteConsumerGroupOffsets(String, Set<TopicPartition>) - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
Delete committed offsets for a set of partitions in a consumer group.
deleteConsumerGroups(List<String>) - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
Delete consumer groups from the cluster.
deletePolicy(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
This endpoint deletes an ACL policy
deletePreparedQuery(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Deletes an existing prepared query
deleteRecursive(String) - Method in class io.vertx.reactivex.core.file.FileSystem
Deletes the file represented by the specified path, asynchronously.
deleteRecursiveBlocking(String) - Method in class io.vertx.reactivex.core.file.FileSystem
deleteTopics(List<String>) - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
Deletes a batch of Kafka topics
deleteValue(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Remove the key/value pair that corresponding to the specified key
deleteValues(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Removes all the key/value pair that corresponding to the specified key prefix
deleteWithRegex(String) - Method in class io.vertx.reactivex.ext.web.Router
Add a route that matches a HTTP DELETE request and the specified path regex
delimitedMode(Buffer) - Method in class io.vertx.reactivex.core.parsetools.RecordParser
Flip the parser into delimited mode, and where the delimiter can be represented by the delimiter delim.
delimitedMode(String) - Method in class io.vertx.reactivex.core.parsetools.RecordParser
Flip the parser into delimited mode, and where the delimiter can be represented by the String delim encoded in latin-1 .
DeliveryContext<T> - Class in io.vertx.reactivex.core.eventbus
Encapsulates a message being delivered by Vert.x as well as providing control over the message delivery.
DeliveryContext(DeliveryContext) - Constructor for class io.vertx.reactivex.core.eventbus.DeliveryContext
 
DeliveryContext(Object, TypeArg<T>) - Constructor for class io.vertx.reactivex.core.eventbus.DeliveryContext
 
deliveryCount() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
deliveryCount(int) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
deliveryOptions(DeliveryOptions) - Method in class io.vertx.reactivex.core.eventbus.MessageProducer
Update the delivery options of this producer.
demand() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Returns the current demand.
DENY - Static variable in class io.vertx.reactivex.ext.web.handler.XFrameHandler
The page cannot be displayed in a frame, regardless of the site attempting to do so.
dereference(JsonSchema) - Method in class io.vertx.reactivex.json.schema.SchemaRepository
Dereferences a schema to the repository.
dereference(String, JsonSchema) - Method in class io.vertx.reactivex.json.schema.SchemaRepository
Dereferences a schema to the repository.
deregisterCatalogService(String, String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Deregister entities from the node or deregister the node itself.
deregisterCheck(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Remove a check from the local agent.
deregisterService(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Remove a service from the local agent.
describeAcls(AclBindingFilter) - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
Describe the ACL rules.
describeCluster() - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
Describe the nodes in the cluster with the default options
describeCluster(DescribeClusterOptions) - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
Like KafkaAdminClient.describeCluster() but allows customized options.
describeConsumerGroups(List<String>) - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
Describe some group ids in the cluster, with the default options
describeConsumerGroups(List<String>, DescribeConsumerGroupsOptions) - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
describeTopics(List<String>) - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
Describe some topics in the cluster, with the default options.
describeTopics(List<String>, DescribeTopicsOptions) - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
destination() - Method in class io.vertx.reactivex.ext.stomp.Destination
 
destination(SocketAddress) - Method in class io.vertx.reactivex.ext.auth.audit.SecurityAudit
 
Destination - Class in io.vertx.reactivex.ext.stomp
Represents a STOMP destination.
Destination(Destination) - Constructor for class io.vertx.reactivex.ext.stomp.Destination
 
Destination(Object) - Constructor for class io.vertx.reactivex.ext.stomp.Destination
 
destinationFactory(DestinationFactory) - Method in class io.vertx.reactivex.ext.stomp.StompServerHandler
Configures the DestinationFactory used to create Destination objects.
DestinationFactory - Class in io.vertx.reactivex.ext.stomp
Interface implemented to customize the destination creation.
DestinationFactory(DestinationFactory) - Constructor for class io.vertx.reactivex.ext.stomp.DestinationFactory
 
DestinationFactory(Object) - Constructor for class io.vertx.reactivex.ext.stomp.DestinationFactory
 
destroy() - Method in class io.vertx.reactivex.ext.web.Session
Destroy the session
destroySession(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Destroys the given session
determineContentType(String) - Method in class io.vertx.reactivex.openapi.contract.RequestBody
This method tries to determine the best fitting MediaType based on the passed content type.
development() - Static method in class io.vertx.reactivex.ext.web.common.WebEnvironment
Will return true if the mode is not null and equals ignoring case the string "dev"
DigestAuthHandler - Class in io.vertx.reactivex.ext.web.handler
An auth handler that provides HTTP Basic Authentication support.
DigestAuthHandler(DigestAuthHandler) - Constructor for class io.vertx.reactivex.ext.web.handler.DigestAuthHandler
 
DigestAuthHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.DigestAuthHandler
 
disable() - Method in class io.vertx.reactivex.ext.web.Route
Disable this route.
discard() - Method in class io.vertx.reactivex.redis.client.RedisAPI
Discard all commands issued after MULTI.
disconnect() - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Disconnects the client.
disconnect() - Method in class io.vertx.reactivex.mqtt.MqttClient
Disconnects from the MQTT server
disconnect(Frame) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Disconnects the client.
disconnect(MqttDisconnectReasonCode, MqttProperties) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Sends the DISCONNECT message to the remote MQTT client
disconnectHandler(Handler<ServerFrame>) - Method in class io.vertx.reactivex.ext.stomp.StompServerHandler
Configures the action to execute when a DISCONNECT frame is received.
disconnectHandler(Handler<Void>) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Set a disconnect handler on the MQTT endpoint.
disconnectMessageHandler(Handler<MqttDisconnectMessage>) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Set a disconnect handler on the MQTT endpoint.
discover(Vertx, OAuth2Options) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.AmazonCognitoAuth
Create a OAuth2Auth provider for OpenID Connect Discovery.
discover(Vertx, OAuth2Options) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.AzureADAuth
Create a OAuth2Auth provider for OpenID Connect Discovery.
discover(Vertx, OAuth2Options) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.GoogleAuth
Create a OAuth2Auth provider for OpenID Connect Discovery.
discover(Vertx, OAuth2Options) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.IBMCloudAuth
Create a OAuth2Auth provider for OpenID Connect Discovery.
discover(Vertx, OAuth2Options) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.KeycloakAuth
Create a OAuth2Auth provider for OpenID Connect Discovery.
discover(Vertx, OAuth2Options) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.OpenIDConnectAuth
Create a OAuth2Auth provider for OpenID Connect Discovery.
discover(Vertx, OAuth2Options) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.SalesforceAuth
Create a OAuth2Auth provider for OpenID Connect Discovery.
discover(Vertx, PubSecKeyOptions, OAuth2Options) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.AppleIdAuth
Create a OAuth2Auth provider for OpenID Connect Discovery.
dispatch(StompServerConnection, Frame) - Method in class io.vertx.reactivex.ext.stomp.Destination
Dispatches the given frame.
distinct(String, String, String) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Gets the distinct values of the specified field name.
distinct(String, String, String, DistinctOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Gets the distinct values of the specified field name.
distinctBatch(String, String, String) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Gets the distinct values of the specified field name.
distinctBatch(String, String, String, DistinctOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Gets the distinct values of the specified field name.
distinctBatchWithQuery(String, String, String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Gets the distinct values of the specified field name filtered by specified query.
distinctBatchWithQuery(String, String, String, JsonObject, int) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Gets the distinct values of the specified field name filtered by specified query.
distinctBatchWithQuery(String, String, String, JsonObject, int, DistinctOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Gets the distinct values of the specified field name filtered by specified query.
distinctBatchWithQuery(String, String, String, JsonObject, DistinctOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Gets the distinct values of the specified field name filtered by specified query.
distinctWithQuery(String, String, String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Gets the distinct values of the specified field name filtered by specified query.
distinctWithQuery(String, String, String, JsonObject, DistinctOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Gets the distinct values of the specified field name filtered by specified query.
DnsClient - Class in io.vertx.reactivex.core.dns
Provides a way to asynchronously lookup information from DNS servers.
DnsClient(DnsClient) - Constructor for class io.vertx.reactivex.core.dns.DnsClient
 
DnsClient(Object) - Constructor for class io.vertx.reactivex.core.dns.DnsClient
 
doSecurity() - Method in class io.vertx.reactivex.ext.web.openapi.router.OpenAPIRoute
 
doValidation() - Method in class io.vertx.reactivex.ext.web.openapi.router.OpenAPIRoute
 
downloadByFileName(WriteStream<Buffer>, String) - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
 
downloadByFileNameWithOptions(WriteStream<Buffer>, String, GridFsDownloadOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
 
downloadById(WriteStream<Buffer>, String) - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
 
downloadFile(String) - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
Downloads a file.
downloadFileAs(String, String) - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
Downloads a file and gives it a new name.
downloadFileByID(String, String) - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
Downloads a file using the ID generated by GridFs.
drainHandler(Handler<Void>) - Method in class io.vertx.reactivex.amqp.AmqpSender
Set a drain handler on the stream.
drainHandler(Handler<Void>) - Method in class io.vertx.reactivex.core.file.AsyncFile
 
drainHandler(Handler<Void>) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
 
drainHandler(Handler<Void>) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
 
drainHandler(Handler<Void>) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
 
drainHandler(Handler<Void>) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
 
drainHandler(Handler<Void>) - Method in class io.vertx.reactivex.core.http.WebSocket
 
drainHandler(Handler<Void>) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
 
drainHandler(Handler<Void>) - Method in class io.vertx.reactivex.core.net.NetSocket
 
drainHandler(Handler<Void>) - Method in interface io.vertx.reactivex.core.streams.WriteStream
Set a drain handler on the stream.
drainHandler(Handler<Void>) - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
 
drainHandler(Handler<Void>) - Method in class io.vertx.reactivex.grpc.client.GrpcClientRequest
 
drainHandler(Handler<Void>) - Method in class io.vertx.reactivex.grpc.common.GrpcWriteStream
 
drainHandler(Handler<Void>) - Method in class io.vertx.reactivex.grpc.server.GrpcServerResponse
 
drainHandler(Handler<Void>) - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
 
drop() - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
Drops the entire file bucket with all of its contents
DropboxAuth - Class in io.vertx.reactivex.ext.auth.oauth2.providers
Simplified factory to create an for Dropbox.
DropboxAuth(DropboxAuth) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.DropboxAuth
 
DropboxAuth(Object) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.DropboxAuth
 
dropCollection(String) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Drop a collection
dropIndex(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Drops the index given the keys used to create it.
dropIndex(String, String) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Drops the index given its name.
dump(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Return a serialized version of the value stored at the specified key.
durable(boolean) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
durationTime() - Method in class io.vertx.reactivex.ext.unit.report.TestResult
How long the test lasted in millis.

E

earlyHintsHandler(Handler<MultiMap>) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
If the server responds with an interim HTTP response with a status code of 103 and a Early Hints handler has been set using this method, then the handler will be called.
echo(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Echo the given string.
enable() - Method in class io.vertx.reactivex.ext.web.Route
Enable this route.
encode(List<String>) - Method in class io.vertx.reactivex.ext.auth.oauth2.authorization.ScopeAuthorization
Returns a String with the given scopes concatenated with the given separator.
encoding() - Method in class io.vertx.reactivex.grpc.common.GrpcReadStream
 
encoding(String) - Method in class io.vertx.reactivex.grpc.client.GrpcClientRequest
 
encoding(String) - Method in class io.vertx.reactivex.grpc.common.GrpcWriteStream
Set the stream encoding, e.g.
encoding(String) - Method in class io.vertx.reactivex.grpc.server.GrpcServerResponse
 
end() - Method in class io.vertx.reactivex.amqp.AmqpSender
Ends the stream.
end() - Method in class io.vertx.reactivex.core.file.AsyncFile
Ends the stream.
end() - Method in class io.vertx.reactivex.core.http.ClientWebSocket
end() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Ends the request.
end() - Method in class io.vertx.reactivex.core.http.HttpClientResponse
Returns a future signaling when the response has been fully received successfully or failed.
end() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
Returns a future signaling when the request has been fully received successfully or failed.
end() - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Ends the response.
end() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
end() - Method in class io.vertx.reactivex.core.http.WebSocket
end() - Method in interface io.vertx.reactivex.core.http.WebSocketBase
end() - Method in class io.vertx.reactivex.core.net.NetSocket
end() - Method in class io.vertx.reactivex.core.parsetools.JsonParser
End the stream, this must be called after all the json stream has been processed.
end() - Method in interface io.vertx.reactivex.core.streams.WriteStream
Ends the stream.
end() - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
end() - Method in class io.vertx.reactivex.ext.web.RoutingContext
Shortcut to the response end.
end() - Method in class io.vertx.reactivex.grpc.client.GrpcClientRequest
Ends the stream.
end() - Method in class io.vertx.reactivex.grpc.common.GrpcReadStream
 
end() - Method in class io.vertx.reactivex.grpc.common.GrpcWriteStream
Ends the stream.
end() - Method in class io.vertx.reactivex.grpc.server.GrpcServerResponse
Ends the stream.
end() - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
Ends the stream.
end(Buffer) - Method in class io.vertx.reactivex.core.file.AsyncFile
Same as WriteStream.end() but writes some data to the stream before ending.
end(Buffer) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Same as WebSocketBase.end(io.vertx.core.buffer.Buffer) but writes some data to the stream before ending.
end(Buffer) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Same as HttpClientRequest.end(java.lang.String) but writes some data to the request body before ending.
end(Buffer) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Same as HttpServerResponse.end(java.lang.String) but writes some data to the response body before ending.
end(Buffer) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Same as WebSocketBase.end(io.vertx.core.buffer.Buffer) but writes some data to the stream before ending.
end(Buffer) - Method in class io.vertx.reactivex.core.http.WebSocket
Same as WebSocketBase.end(io.vertx.core.buffer.Buffer) but writes some data to the stream before ending.
end(Buffer) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Same as WebSocketBase.end(io.vertx.core.buffer.Buffer) but writes some data to the stream before ending.
end(Buffer) - Method in class io.vertx.reactivex.core.net.NetSocket
Same as NetSocket.end(io.vertx.core.buffer.Buffer) but writes some data to the stream before ending.
end(Buffer) - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
Same as SockJSSocket.end(io.vertx.core.buffer.Buffer) but writes some data to the stream before ending.
end(Buffer) - Method in class io.vertx.reactivex.ext.web.RoutingContext
Shortcut to the response end.
end(AmqpMessage) - Method in class io.vertx.reactivex.amqp.AmqpSender
Same as WriteStream.end() but writes some data to the stream before ending.
end(KafkaProducerRecord<K, V>) - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
Same as WriteStream.end() but writes some data to the stream before ending.
end(String) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Same as HttpClientRequest.end(java.lang.String) but writes a String in UTF-8 encoding
end(String) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Same as HttpServerResponse.end(java.lang.String) but writes a String in UTF-8 encoding before ending the response.
end(String) - Method in class io.vertx.reactivex.ext.web.RoutingContext
Shortcut to the response end.
end(String, String) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Same as HttpClientRequest.end(java.lang.String) but writes a String with the specified encoding
end(String, String) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Same as HttpServerResponse.end(java.lang.String) but writes a String with the specified encoding before ending the response.
end(Req) - Method in class io.vertx.reactivex.grpc.client.GrpcClientRequest
Same as WriteStream.end() but writes some data to the stream before ending.
end(Resp) - Method in class io.vertx.reactivex.grpc.server.GrpcServerResponse
Same as WriteStream.end() but writes some data to the stream before ending.
end(T) - Method in interface io.vertx.reactivex.core.streams.WriteStream
Same as WriteStream.end() but writes some data to the stream before ending.
end(T) - Method in class io.vertx.reactivex.grpc.common.GrpcWriteStream
Same as WriteStream.end() but writes some data to the stream before ending.
ended() - Method in class io.vertx.reactivex.core.http.HttpServerResponse
 
endHandler(Handler<TestResult>) - Method in class io.vertx.reactivex.ext.unit.report.TestCaseReport
Set a callback for completion, the specified handler is invoked when the test exec has completed.
endHandler(Handler<Void>) - Method in class io.vertx.reactivex.amqp.AmqpReceiver
 
endHandler(Handler<Void>) - Method in class io.vertx.reactivex.cassandra.CassandraRowStream
 
endHandler(Handler<Void>) - Method in class io.vertx.reactivex.core.eventbus.MessageConsumer
 
endHandler(Handler<Void>) - Method in class io.vertx.reactivex.core.file.AsyncFile
 
endHandler(Handler<Void>) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
 
endHandler(Handler<Void>) - Method in class io.vertx.reactivex.core.http.HttpClientResponse
 
endHandler(Handler<Void>) - Method in class io.vertx.reactivex.core.http.HttpServerFileUpload
 
endHandler(Handler<Void>) - Method in class io.vertx.reactivex.core.http.HttpServerRequest
 
endHandler(Handler<Void>) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Set an end handler for the response.
endHandler(Handler<Void>) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
 
endHandler(Handler<Void>) - Method in class io.vertx.reactivex.core.http.WebSocket
 
endHandler(Handler<Void>) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
 
endHandler(Handler<Void>) - Method in class io.vertx.reactivex.core.net.NetSocket
This handler might be called after the close handler when the socket is paused and there are still buffers to deliver.
endHandler(Handler<Void>) - Method in class io.vertx.reactivex.core.parsetools.JsonParser
 
endHandler(Handler<Void>) - Method in class io.vertx.reactivex.core.parsetools.RecordParser
 
endHandler(Handler<Void>) - Method in interface io.vertx.reactivex.core.streams.ReadStream
Set an end handler.
endHandler(Handler<Void>) - Method in class io.vertx.reactivex.ext.unit.report.TestSuiteReport
 
endHandler(Handler<Void>) - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
 
endHandler(Handler<Void>) - Method in class io.vertx.reactivex.grpc.client.GrpcClientResponse
 
endHandler(Handler<Void>) - Method in class io.vertx.reactivex.grpc.common.GrpcReadStream
 
endHandler(Handler<Void>) - Method in class io.vertx.reactivex.grpc.server.GrpcServerRequest
 
endHandler(Handler<Void>) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
 
endHandler(Handler<Void>) - Method in class io.vertx.reactivex.pgclient.pubsub.PgChannel
Set an handler to be called when no more notifications will be received.
endHandler(Handler<Void>) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQConsumer
Set an end handler.
endHandler(Handler<Void>) - Method in class io.vertx.reactivex.redis.client.RedisConnection
 
endHandler(Handler<Void>) - Method in class io.vertx.reactivex.sqlclient.RowStream
 
endMessage(GrpcMessage) - Method in class io.vertx.reactivex.grpc.common.GrpcWriteStream
End the stream with an encoded gRPC message.
endOffsets(TopicPartition) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Get the last offset for the given partition.
endOnComplete(boolean) - Method in class io.vertx.reactivex.core.streams.Pipe
Set to true to call WriteStream.end() when the source ReadStream completes, false otherwise.
endOnFailure(boolean) - Method in class io.vertx.reactivex.core.streams.Pipe
Set to true to call WriteStream.end() when the source ReadStream fails, false otherwise.
endOnSuccess(boolean) - Method in class io.vertx.reactivex.core.streams.Pipe
Set to true to call WriteStream.end() when the source ReadStream succeeds, false otherwise.
Endpoint - Class in io.vertx.reactivex.core.net.endpoint
 
Endpoint(Endpoint) - Constructor for class io.vertx.reactivex.core.net.endpoint.Endpoint
 
Endpoint(Object) - Constructor for class io.vertx.reactivex.core.net.endpoint.Endpoint
 
endpointHandler(Handler<MqttEndpoint>) - Method in class io.vertx.reactivex.mqtt.MqttServer
Set the endpoint handler for the server.
EndpointResolver - Class in io.vertx.reactivex.core.net.endpoint
A resolver for endpoints.
EndpointResolver(EndpointResolver) - Constructor for class io.vertx.reactivex.core.net.endpoint.EndpointResolver
 
EndpointResolver(Object) - Constructor for class io.vertx.reactivex.core.net.endpoint.EndpointResolver
 
endSessionURL(User) - Method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
The logout (end-session) endpoint is specified in OpenID Connect Session Management 1.0.
endSessionURL(User, JsonObject) - Method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
The logout (end-session) endpoint is specified in OpenID Connect Session Management 1.0.
ENV_VARIABLE_NAME - Static variable in class io.vertx.reactivex.ext.web.common.WebEnvironment
 
envelope() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQMessage
 
eq(String, Object) - Static method in class io.vertx.reactivex.ext.auth.abac.Attribute
Verifies whether the attribute matches the specified.
equals(Object) - Method in class io.vertx.reactivex.amqp.AmqpClient
 
equals(Object) - Method in class io.vertx.reactivex.amqp.AmqpConnection
 
equals(Object) - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
equals(Object) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
equals(Object) - Method in class io.vertx.reactivex.amqp.AmqpReceiver
 
equals(Object) - Method in class io.vertx.reactivex.amqp.AmqpSender
 
equals(Object) - Method in class io.vertx.reactivex.cassandra.CassandraClient
 
equals(Object) - Method in class io.vertx.reactivex.cassandra.CassandraRowStream
 
equals(Object) - Method in class io.vertx.reactivex.cassandra.ResultSet
 
equals(Object) - Method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
 
equals(Object) - Method in class io.vertx.reactivex.circuitbreaker.FailurePolicy
 
equals(Object) - Method in class io.vertx.reactivex.circuitbreaker.RetryPolicy
 
equals(Object) - Method in class io.vertx.reactivex.config.ConfigRetriever
 
equals(Object) - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
 
equals(Object) - Method in class io.vertx.reactivex.core.dns.DnsClient
 
equals(Object) - Method in class io.vertx.reactivex.core.eventbus.DeliveryContext
 
equals(Object) - Method in class io.vertx.reactivex.core.eventbus.EventBus
 
equals(Object) - Method in class io.vertx.reactivex.core.eventbus.Message
 
equals(Object) - Method in class io.vertx.reactivex.core.eventbus.MessageConsumer
 
equals(Object) - Method in class io.vertx.reactivex.core.eventbus.MessageProducer
 
equals(Object) - Method in class io.vertx.reactivex.core.file.AsyncFile
 
equals(Object) - Method in class io.vertx.reactivex.core.file.AsyncFileLock
 
equals(Object) - Method in class io.vertx.reactivex.core.file.FileSystem
 
equals(Object) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
 
equals(Object) - Method in class io.vertx.reactivex.core.http.HttpClientAgent
 
equals(Object) - Method in class io.vertx.reactivex.core.http.HttpClientBuilder
 
equals(Object) - Method in class io.vertx.reactivex.core.http.HttpClientConnection
 
equals(Object) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
 
equals(Object) - Method in class io.vertx.reactivex.core.http.HttpClientResponse
 
equals(Object) - Method in class io.vertx.reactivex.core.http.HttpConnection
 
equals(Object) - Method in class io.vertx.reactivex.core.http.HttpHeaders
 
equals(Object) - Method in class io.vertx.reactivex.core.http.HttpRequestHead
 
equals(Object) - Method in class io.vertx.reactivex.core.http.HttpServer
 
equals(Object) - Method in class io.vertx.reactivex.core.http.HttpServerFileUpload
 
equals(Object) - Method in class io.vertx.reactivex.core.http.HttpServerRequest
 
equals(Object) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
 
equals(Object) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
 
equals(Object) - Method in class io.vertx.reactivex.core.http.ServerWebSocketHandshake
 
equals(Object) - Method in class io.vertx.reactivex.core.http.WebSocket
 
equals(Object) - Method in class io.vertx.reactivex.core.http.WebSocketClient
 
equals(Object) - Method in class io.vertx.reactivex.core.json.pointer.JsonPointer
 
equals(Object) - Method in class io.vertx.reactivex.core.json.pointer.JsonPointerIterator
 
equals(Object) - Method in class io.vertx.reactivex.core.net.endpoint.Endpoint
 
equals(Object) - Method in class io.vertx.reactivex.core.net.endpoint.EndpointResolver
 
equals(Object) - Method in class io.vertx.reactivex.core.net.endpoint.ServerEndpoint
 
equals(Object) - Method in class io.vertx.reactivex.core.net.endpoint.ServerInteraction
 
equals(Object) - Method in class io.vertx.reactivex.core.net.NetClient
 
equals(Object) - Method in class io.vertx.reactivex.core.net.NetServer
 
equals(Object) - Method in class io.vertx.reactivex.core.net.NetSocket
 
equals(Object) - Method in class io.vertx.reactivex.core.parsetools.JsonParser
 
equals(Object) - Method in class io.vertx.reactivex.core.parsetools.RecordParser
 
equals(Object) - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
 
equals(Object) - Method in class io.vertx.reactivex.core.shareddata.Counter
 
equals(Object) - Method in class io.vertx.reactivex.core.shareddata.LocalMap
 
equals(Object) - Method in class io.vertx.reactivex.core.shareddata.Lock
 
equals(Object) - Method in class io.vertx.reactivex.core.shareddata.SharedData
 
equals(Object) - Method in class io.vertx.reactivex.core.streams.Pipe
 
equals(Object) - Method in class io.vertx.reactivex.db2client.DB2Builder
 
equals(Object) - Method in class io.vertx.reactivex.db2client.DB2Connection
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.abac.Attribute
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.abac.PolicyBasedAuthorizationProvider
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.audit.SecurityAudit
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.authentication.AuthenticationProvider
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.authorization.AndAuthorization
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.authorization.AuthorizationContext
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.authorization.Authorizations
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.authorization.NotAuthorization
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.authorization.OrAuthorization
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.authorization.PermissionBasedAuthorization
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.authorization.RoleBasedAuthorization
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.authorization.WildcardPermissionBasedAuthorization
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.ChainAuth
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.hashing.HashingAlgorithm
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.hashing.HashingStrategy
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.htdigest.HtdigestAuth
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.htpasswd.HtpasswdAuth
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.jwt.authorization.JWTAuthorization
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.jwt.authorization.MicroProfileAuthorization
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.jwt.JWTAuth
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.ldap.LdapAuthentication
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.oauth2.authorization.KeycloakAuthorization
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.oauth2.authorization.ScopeAuthorization
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.AmazonCognitoAuth
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.AppleIdAuth
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.AzureADAuth
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.BoxAuth
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.CloudFoundryAuth
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.DropboxAuth
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.FacebookAuth
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.FoursquareAuth
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.GiteeAuth
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.GithubAuth
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.GitLabAuth
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.GoogleAuth
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.HerokuAuth
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.IBMCloudAuth
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.InstagramAuth
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.KeycloakAuth
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.LinkedInAuth
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.LiveAuth
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.MailchimpAuth
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.OpenIDConnectAuth
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.SalesforceAuth
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.ShopifyAuth
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.SoundcloudAuth
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.StripeAuth
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.TwitterAuth
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.otp.hotp.HotpAuth
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.otp.OtpKeyGenerator
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.otp.totp.TotpAuth
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.prng.VertxContextPRNG
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.properties.PropertyFileAuthentication
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.properties.PropertyFileAuthorization
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.sqlclient.SqlAuthentication
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.sqlclient.SqlAuthorization
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.sqlclient.SqlUserUtil
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.User
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.webauthn4j.CredentialStorage
 
equals(Object) - Method in class io.vertx.reactivex.ext.auth.webauthn4j.WebAuthn4J
 
equals(Object) - Method in class io.vertx.reactivex.ext.bridge.BaseBridgeEvent
 
equals(Object) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
 
equals(Object) - Method in class io.vertx.reactivex.ext.consul.Watch
 
equals(Object) - Method in class io.vertx.reactivex.ext.consul.WatchResult
 
equals(Object) - Method in class io.vertx.reactivex.ext.dropwizard.MetricsService
 
equals(Object) - Method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.BridgeEvent
 
equals(Object) - Method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.TcpEventBusBridge
 
equals(Object) - Method in class io.vertx.reactivex.ext.healthchecks.HealthChecks
 
equals(Object) - Method in class io.vertx.reactivex.ext.mail.MailAttachment
 
equals(Object) - Method in class io.vertx.reactivex.ext.mail.MailClient
 
equals(Object) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
 
equals(Object) - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
 
equals(Object) - Method in class io.vertx.reactivex.ext.stomp.Acknowledgement
 
equals(Object) - Method in class io.vertx.reactivex.ext.stomp.Destination
 
equals(Object) - Method in class io.vertx.reactivex.ext.stomp.DestinationFactory
 
equals(Object) - Method in class io.vertx.reactivex.ext.stomp.Frames
 
equals(Object) - Method in class io.vertx.reactivex.ext.stomp.ServerFrame
 
equals(Object) - Method in class io.vertx.reactivex.ext.stomp.StompClient
 
equals(Object) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
 
equals(Object) - Method in class io.vertx.reactivex.ext.stomp.StompServer
 
equals(Object) - Method in class io.vertx.reactivex.ext.stomp.StompServerConnection
 
equals(Object) - Method in class io.vertx.reactivex.ext.stomp.StompServerHandler
 
equals(Object) - Method in class io.vertx.reactivex.ext.unit.Async
 
equals(Object) - Method in class io.vertx.reactivex.ext.unit.collect.EventBusCollector
 
equals(Object) - Method in class io.vertx.reactivex.ext.unit.Completion
 
equals(Object) - Method in class io.vertx.reactivex.ext.unit.report.Failure
 
equals(Object) - Method in class io.vertx.reactivex.ext.unit.report.TestCaseReport
 
equals(Object) - Method in class io.vertx.reactivex.ext.unit.report.TestResult
 
equals(Object) - Method in class io.vertx.reactivex.ext.unit.report.TestSuiteReport
 
equals(Object) - Method in class io.vertx.reactivex.ext.unit.TestCase
 
equals(Object) - Method in class io.vertx.reactivex.ext.unit.TestCompletion
 
equals(Object) - Method in class io.vertx.reactivex.ext.unit.TestContext
 
equals(Object) - Method in class io.vertx.reactivex.ext.unit.TestSuite
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.client.CachingWebClient
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.client.HttpResponse
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.client.OAuth2WebClient
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.client.WebClient
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.client.WebClientSession
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.codec.BodyCodec
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.common.template.TemplateEngine
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.common.WebEnvironment
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.FileUpload
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.APIKeyHandler
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.AuthorizationHandler
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.BasicAuthHandler
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.BodyHandler
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.ChainAuthHandler
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.CorsHandler
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.CSPHandler
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.CSRFHandler
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.DigestAuthHandler
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.ErrorHandler
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.FaviconHandler
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.FormLoginHandler
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.graphql.ExecutionInputBuilderWithContext
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.graphql.GraphiQLHandler
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.graphql.GraphiQLHandlerBuilder
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.graphql.GraphQLHandler
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.graphql.GraphQLHandlerBuilder
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.graphql.UploadScalar
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.graphql.ws.ConnectionInitEvent
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.graphql.ws.GraphQLWSHandler
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.graphql.ws.GraphQLWSHandlerBuilder
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.graphql.ws.Message
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.HSTSHandler
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.JWTAuthHandler
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.LoggerFormatter
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.LoggerHandler
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.MethodOverrideHandler
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.MultiTenantHandler
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.OAuth2AuthHandler
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.OtpAuthHandler
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.RedirectAuthHandler
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.ResponseContentTypeHandler
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.ResponseTimeHandler
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.SecurityAuditLoggerHandler
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.SessionHandler
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.SimpleAuthenticationHandler
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.sockjs.BridgeEvent
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSHandler
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.StaticHandler
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.TemplateHandler
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.TimeoutHandler
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.WebAuthn4JHandler
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.handler.XFrameHandler
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.healthchecks.HealthCheckHandler
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.LanguageHeader
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.MIMEHeader
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.multipart.FormDataPart
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.multipart.MultipartForm
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.openapi.router.OpenAPIRoute
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.openapi.router.RequestExtractor
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.openapi.router.RouterBuilder
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.openapi.router.Security
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.ParsedHeaderValues
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.RequestBody
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.Route
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.Router
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.RoutingContext
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.Session
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.sstore.ClusteredSessionStore
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.sstore.cookie.CookieSessionStore
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.sstore.infinispan.InfinispanSessionStore
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.sstore.LocalSessionStore
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.sstore.redis.RedisSessionStore
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.sstore.SessionStore
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.templ.freemarker.FreeMarkerTemplateEngine
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.templ.handlebars.HandlebarsTemplateEngine
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.templ.mvel.MVELTemplateEngine
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.templ.pebble.PebbleTemplateEngine
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.templ.pug.PugTemplateEngine
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.templ.rocker.RockerTemplateEngine
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.templ.thymeleaf.ThymeleafTemplateEngine
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.UserContext
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.validation.builder.ArrayParserFactory
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.validation.builder.Bodies
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.validation.builder.BodyProcessorFactory
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.validation.builder.ObjectParserFactory
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.validation.builder.ParameterProcessorFactory
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.validation.builder.Parameters
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.validation.builder.Parsers
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.validation.builder.StyledParameterProcessorFactory
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.validation.builder.TupleParserFactory
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.validation.builder.ValidationHandlerBuilder
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.validation.RequestParameter
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.validation.RequestParameters
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.validation.RequestPredicate
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.validation.RequestPredicateResult
 
equals(Object) - Method in class io.vertx.reactivex.ext.web.validation.ValidationHandler
 
equals(Object) - Method in class io.vertx.reactivex.grpc.client.GrpcClient
 
equals(Object) - Method in class io.vertx.reactivex.grpc.client.GrpcClientBuilder
 
equals(Object) - Method in class io.vertx.reactivex.grpc.client.GrpcClientRequest
 
equals(Object) - Method in class io.vertx.reactivex.grpc.client.GrpcClientResponse
 
equals(Object) - Method in class io.vertx.reactivex.grpc.common.GrpcReadStream
 
equals(Object) - Method in class io.vertx.reactivex.grpc.common.GrpcWriteStream
 
equals(Object) - Method in class io.vertx.reactivex.grpc.server.GrpcServer
 
equals(Object) - Method in class io.vertx.reactivex.grpc.server.GrpcServerRequest
 
equals(Object) - Method in class io.vertx.reactivex.grpc.server.GrpcServerResponse
 
equals(Object) - Method in class io.vertx.reactivex.jdbcclient.JDBCConnection
 
equals(Object) - Method in class io.vertx.reactivex.jdbcclient.JDBCPool
 
equals(Object) - Method in class io.vertx.reactivex.jdbcclient.SqlOutParam
 
equals(Object) - Method in class io.vertx.reactivex.json.schema.JsonFormatValidator
 
equals(Object) - Method in class io.vertx.reactivex.json.schema.JsonSchema
 
equals(Object) - Method in class io.vertx.reactivex.json.schema.Ref
 
equals(Object) - Method in class io.vertx.reactivex.json.schema.SchemaRepository
 
equals(Object) - Method in class io.vertx.reactivex.json.schema.Validator
 
equals(Object) - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
 
equals(Object) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
 
equals(Object) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumerRecord
 
equals(Object) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumerRecords
 
equals(Object) - Method in class io.vertx.reactivex.kafka.client.producer.KafkaHeader
 
equals(Object) - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
 
equals(Object) - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducerRecord
 
equals(Object) - Method in class io.vertx.reactivex.micrometer.MetricsService
 
equals(Object) - Method in class io.vertx.reactivex.micrometer.PrometheusRequestHandler
 
equals(Object) - Method in class io.vertx.reactivex.micrometer.PrometheusScrapingHandler
 
equals(Object) - Method in class io.vertx.reactivex.mqtt.messages.MqttAuthenticationExchangeMessage
 
equals(Object) - Method in class io.vertx.reactivex.mqtt.messages.MqttConnAckMessage
 
equals(Object) - Method in class io.vertx.reactivex.mqtt.messages.MqttDisconnectMessage
 
equals(Object) - Method in class io.vertx.reactivex.mqtt.messages.MqttPubAckMessage
 
equals(Object) - Method in class io.vertx.reactivex.mqtt.messages.MqttPubCompMessage
 
equals(Object) - Method in class io.vertx.reactivex.mqtt.messages.MqttPublishMessage
 
equals(Object) - Method in class io.vertx.reactivex.mqtt.messages.MqttPubRecMessage
 
equals(Object) - Method in class io.vertx.reactivex.mqtt.messages.MqttPubRelMessage
 
equals(Object) - Method in class io.vertx.reactivex.mqtt.messages.MqttSubAckMessage
 
equals(Object) - Method in class io.vertx.reactivex.mqtt.messages.MqttSubscribeMessage
 
equals(Object) - Method in class io.vertx.reactivex.mqtt.messages.MqttUnsubscribeMessage
 
equals(Object) - Method in class io.vertx.reactivex.mqtt.MqttClient
 
equals(Object) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
 
equals(Object) - Method in class io.vertx.reactivex.mqtt.MqttServer
 
equals(Object) - Method in class io.vertx.reactivex.mqtt.MqttTopicSubscription
 
equals(Object) - Method in class io.vertx.reactivex.mssqlclient.MSSQLBuilder
 
equals(Object) - Method in class io.vertx.reactivex.mssqlclient.MSSQLConnection
 
equals(Object) - Method in class io.vertx.reactivex.mysqlclient.MySQLBuilder
 
equals(Object) - Method in class io.vertx.reactivex.mysqlclient.MySQLClient
 
equals(Object) - Method in class io.vertx.reactivex.mysqlclient.MySQLConnection
 
equals(Object) - Method in class io.vertx.reactivex.openapi.contract.MediaType
 
equals(Object) - Method in class io.vertx.reactivex.openapi.contract.OAuthFlow
 
equals(Object) - Method in class io.vertx.reactivex.openapi.contract.OAuthFlows
 
equals(Object) - Method in class io.vertx.reactivex.openapi.contract.OpenAPIContract
 
equals(Object) - Method in class io.vertx.reactivex.openapi.contract.Operation
 
equals(Object) - Method in class io.vertx.reactivex.openapi.contract.Parameter
 
equals(Object) - Method in class io.vertx.reactivex.openapi.contract.Path
 
equals(Object) - Method in class io.vertx.reactivex.openapi.contract.RequestBody
 
equals(Object) - Method in class io.vertx.reactivex.openapi.contract.Response
 
equals(Object) - Method in class io.vertx.reactivex.openapi.contract.SecurityRequirement
 
equals(Object) - Method in class io.vertx.reactivex.openapi.contract.SecurityScheme
 
equals(Object) - Method in class io.vertx.reactivex.openapi.contract.Server
 
equals(Object) - Method in class io.vertx.reactivex.openapi.validation.RequestParameter
 
equals(Object) - Method in class io.vertx.reactivex.openapi.validation.RequestValidator
 
equals(Object) - Method in class io.vertx.reactivex.openapi.validation.ResponseParameter
 
equals(Object) - Method in class io.vertx.reactivex.openapi.validation.ValidatableRequest
 
equals(Object) - Method in class io.vertx.reactivex.openapi.validation.ValidatableResponse
 
equals(Object) - Method in class io.vertx.reactivex.openapi.validation.ValidatedRequest
 
equals(Object) - Method in class io.vertx.reactivex.openapi.validation.ValidatedResponse
 
equals(Object) - Method in class io.vertx.reactivex.oracleclient.OracleBuilder
 
equals(Object) - Method in class io.vertx.reactivex.oracleclient.OracleClient
 
equals(Object) - Method in class io.vertx.reactivex.oracleclient.OracleConnection
 
equals(Object) - Method in class io.vertx.reactivex.pgclient.PgBuilder
 
equals(Object) - Method in class io.vertx.reactivex.pgclient.PgConnection
 
equals(Object) - Method in class io.vertx.reactivex.pgclient.pubsub.PgChannel
 
equals(Object) - Method in class io.vertx.reactivex.pgclient.pubsub.PgSubscriber
 
equals(Object) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
 
equals(Object) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQConsumer
 
equals(Object) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQMessage
 
equals(Object) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQPublisher
 
equals(Object) - Method in class io.vertx.reactivex.redis.client.Redis
 
equals(Object) - Method in class io.vertx.reactivex.redis.client.RedisAPI
 
equals(Object) - Method in class io.vertx.reactivex.redis.client.RedisCluster
 
equals(Object) - Method in class io.vertx.reactivex.redis.client.RedisConnection
 
equals(Object) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
 
equals(Object) - Method in class io.vertx.reactivex.servicediscovery.ServiceReference
 
equals(Object) - Method in class io.vertx.reactivex.servicediscovery.spi.ServiceExporter
 
equals(Object) - Method in class io.vertx.reactivex.servicediscovery.spi.ServiceImporter
 
equals(Object) - Method in class io.vertx.reactivex.servicediscovery.spi.ServicePublisher
 
equals(Object) - Method in class io.vertx.reactivex.servicediscovery.types.EventBusService
 
equals(Object) - Method in class io.vertx.reactivex.servicediscovery.types.HttpEndpoint
 
equals(Object) - Method in class io.vertx.reactivex.servicediscovery.types.MessageSource
 
equals(Object) - Method in class io.vertx.reactivex.servicediscovery.types.MongoDataSource
 
equals(Object) - Method in class io.vertx.reactivex.servicediscovery.types.RedisDataSource
 
equals(Object) - Method in class io.vertx.reactivex.sqlclient.ClientBuilder
 
equals(Object) - Method in class io.vertx.reactivex.sqlclient.Cursor
 
equals(Object) - Method in class io.vertx.reactivex.sqlclient.desc.ColumnDescriptor
 
equals(Object) - Method in class io.vertx.reactivex.sqlclient.Pool
 
equals(Object) - Method in class io.vertx.reactivex.sqlclient.PreparedQuery
 
equals(Object) - Method in class io.vertx.reactivex.sqlclient.PreparedStatement
 
equals(Object) - Method in class io.vertx.reactivex.sqlclient.PropertyKind
 
equals(Object) - Method in class io.vertx.reactivex.sqlclient.Query
 
equals(Object) - Method in class io.vertx.reactivex.sqlclient.Row
 
equals(Object) - Method in class io.vertx.reactivex.sqlclient.RowIterator
 
equals(Object) - Method in class io.vertx.reactivex.sqlclient.RowSet
 
equals(Object) - Method in class io.vertx.reactivex.sqlclient.RowStream
 
equals(Object) - Method in class io.vertx.reactivex.sqlclient.spi.DatabaseMetadata
 
equals(Object) - Method in class io.vertx.reactivex.sqlclient.SqlClient
 
equals(Object) - Method in class io.vertx.reactivex.sqlclient.SqlConnection
 
equals(Object) - Method in class io.vertx.reactivex.sqlclient.SqlResult
 
equals(Object) - Method in class io.vertx.reactivex.sqlclient.templates.RowMapper
 
equals(Object) - Method in class io.vertx.reactivex.sqlclient.templates.SqlTemplate
 
equals(Object) - Method in class io.vertx.reactivex.sqlclient.templates.TupleMapper
 
equals(Object) - Method in class io.vertx.reactivex.sqlclient.Transaction
 
equals(Object) - Method in class io.vertx.reactivex.sqlclient.Tuple
 
equals(Object) - Method in class io.vertx.reactivex.uritemplate.UriTemplate
 
equals(Object) - Method in class io.vertx.reactivex.uritemplate.Variables
 
errorFrameHandler(Handler<Frame>) - Method in class io.vertx.reactivex.ext.stomp.StompClient
A general error frame handler.
errorHandler(int, Handler<RoutingContext>) - Method in class io.vertx.reactivex.ext.web.Router
Specify an handler to handle an error for a particular status code.
errorHandler(Handler<Frame>) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Sets a handler notified when an ERROR frame is received by the client.
errorHandler(Handler<GrpcError>) - Method in class io.vertx.reactivex.grpc.client.GrpcClientResponse
 
errorHandler(Handler<GrpcError>) - Method in class io.vertx.reactivex.grpc.common.GrpcReadStream
Set a handler to be notified with gRPC errors.
errorHandler(Handler<GrpcError>) - Method in class io.vertx.reactivex.grpc.server.GrpcServerRequest
 
ErrorHandler - Class in io.vertx.reactivex.ext.web.handler
A pretty error handler for rendering error pages.
ErrorHandler(ErrorHandler) - Constructor for class io.vertx.reactivex.ext.web.handler.ErrorHandler
 
ErrorHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.ErrorHandler
 
etag(String) - Method in class io.vertx.reactivex.ext.web.RoutingContext
Set the ETag of a response.
ETAG - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Etag header name
eval(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Execute a Lua script server side.
evalRo(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Execute a read-only Lua script server side.
evalsha(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Execute a Lua script server side.
evalshaRo(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Execute a read-only Lua script server side.
EVENT_ID - Static variable in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
Constant for id field of usage events.
EVENT_RECORD - Static variable in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
Constant for record field of usage events.
EVENT_TEST_CASE_BEGIN - Static variable in class io.vertx.reactivex.ext.unit.collect.EventBusCollector
Json type field value that signals a test case begins, used as part of the test reporting protocol for the event bus.
EVENT_TEST_CASE_END - Static variable in class io.vertx.reactivex.ext.unit.collect.EventBusCollector
Json type field value that signals a test case ends, used as part of the test reporting protocol for the event bus.
EVENT_TEST_SUITE_BEGIN - Static variable in class io.vertx.reactivex.ext.unit.collect.EventBusCollector
Json type field value that signals a test suite begins, used as part of the test reporting protocol for the event bus.
EVENT_TEST_SUITE_END - Static variable in class io.vertx.reactivex.ext.unit.collect.EventBusCollector
Json type field value that signals a test suite ends, used as part of the test reporting protocol for the event bus.
EVENT_TEST_SUITE_ERROR - Static variable in class io.vertx.reactivex.ext.unit.collect.EventBusCollector
Json type field value that reports a test suite error, used as part of the test reporting protocol for the event bus.
EVENT_TYPE - Static variable in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
Constant for type field of usage events.
EVENT_TYPE_BIND - Static variable in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
Constant for event type `Bind`.
EVENT_TYPE_RELEASE - Static variable in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
Constant for event type `Release`.
EventBus - Class in io.vertx.reactivex.core.eventbus
A Vert.x event-bus is a light-weight distributed messaging system which allows different parts of your application, or different applications and services to communicate with each in a loosely coupled way.
EventBus(EventBus) - Constructor for class io.vertx.reactivex.core.eventbus.EventBus
 
EventBus(Object) - Constructor for class io.vertx.reactivex.core.eventbus.EventBus
 
EventBusCollector - Class in io.vertx.reactivex.ext.unit.collect
The event bus collector listen to events on the Vert.x event bus and translate them into reports.
EventBusCollector(EventBusCollector) - Constructor for class io.vertx.reactivex.ext.unit.collect.EventBusCollector
 
EventBusCollector(Object) - Constructor for class io.vertx.reactivex.ext.unit.collect.EventBusCollector
 
EventBusService - Class in io.vertx.reactivex.servicediscovery.types
for event bus services (service proxies).
EventBusService(EventBusService) - Constructor for class io.vertx.reactivex.servicediscovery.types.EventBusService
 
EventBusService(Object) - Constructor for class io.vertx.reactivex.servicediscovery.types.EventBusService
 
events(String, Vertx) - Static method in class io.vertx.reactivex.ext.consul.Watch
Creates Watch to monitoring the custom user events.
events(String, Vertx, ConsulClientOptions) - Static method in class io.vertx.reactivex.ext.consul.Watch
Creates Watch to monitoring the custom user events.
exceptionHandler() - Method in class io.vertx.reactivex.ext.unit.TestContext
 
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.amqp.AmqpConnection
Registers a handler called on disconnection.
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.amqp.AmqpReceiver
 
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.amqp.AmqpSender
 
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.cassandra.CassandraRowStream
 
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
 
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.core.eventbus.MessageConsumer
 
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.core.file.AsyncFile
Set an exception handler on the read stream and on the write stream.
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
 
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
 
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.core.http.HttpClientResponse
 
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.core.http.HttpConnection
Set an handler called when a connection error happens
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.core.http.HttpServer
Set an exception handler called for socket errors happening before the HTTP connection is established, e.g during the TLS handshake.
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.core.http.HttpServerFileUpload
 
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.core.http.HttpServerRequest
 
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
 
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
 
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.core.http.WebSocket
 
exceptionHandler(Handler<Throwable>) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
 
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.core.net.NetSocket
 
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.core.parsetools.JsonParser
 
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.core.parsetools.RecordParser
 
exceptionHandler(Handler<Throwable>) - Method in interface io.vertx.reactivex.core.streams.ReadStream
Set an exception handler on the read stream.
exceptionHandler(Handler<Throwable>) - Method in interface io.vertx.reactivex.core.streams.StreamBase
Set an exception handler.
exceptionHandler(Handler<Throwable>) - Method in interface io.vertx.reactivex.core.streams.WriteStream
Set an exception handler on the write stream.
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.db2client.DB2Connection
 
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.ext.stomp.StompClient
Sets an exception handler notified for TCP-level errors.
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Configures the exception handler notified upon TCP-level errors.
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.ext.unit.report.TestSuiteReport
Set an exception handler, the exception handler reports the test suite errors, it can be called mulitple times before the test ends.
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
 
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.grpc.client.GrpcClientRequest
 
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.grpc.client.GrpcClientResponse
 
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.grpc.common.GrpcReadStream
 
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.grpc.common.GrpcWriteStream
 
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.grpc.server.GrpcServerRequest
 
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.grpc.server.GrpcServerResponse
 
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
 
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
 
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.mqtt.MqttClient
Set an exception handler for the client, that will be called when an error happens in internal netty structures.
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Set an exception handler.
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.mqtt.MqttServer
Set an exception handler for the server, that will be called when an error happens independantly of an accepted MqttEndpoint, like a rejected connection
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.mssqlclient.MSSQLConnection
 
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.mysqlclient.MySQLConnection
 
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.oracleclient.OracleConnection
 
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.pgclient.PgConnection
 
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.pgclient.pubsub.PgChannel
 
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQConsumer
Set an exception handler on the read stream.
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.redis.client.RedisConnection
 
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.sqlclient.RowStream
 
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.reactivex.sqlclient.SqlConnection
Set an handler called with connection errors.
exchangeBind(String, String, String) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Bind an exchange to an exchange.
exchangeBind(String, String, String, Map<String, Object>) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Bind an exchange to an exchange.
exchangeDeclare(String, String, boolean, boolean) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Declare an exchange.
exchangeDeclare(String, String, boolean, boolean, JsonObject) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Declare an exchange with additional parameters such as dead lettering, an alternate exchange or TTL.
exchangeDelete(String) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Delete an exchange, without regard for whether it is in use or not.
exchangeUnbind(String, String, String) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Unbind an exchange from an exchange.
exchangeUnbind(String, String, String, Map<String, Object>) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Unbind an exchange from an exchange.
EXCLUDE_ANNOTATION_ENTRIES - Static variable in class io.vertx.reactivex.json.schema.JsonSchema
Predicate to filter out annotation keys.
EXCLUDE_ANNOTATIONS - Static variable in class io.vertx.reactivex.json.schema.JsonSchema
Predicate to filter out annotation keys.
exec() - Method in class io.vertx.reactivex.redis.client.RedisAPI
Execute all commands issued after MULTI.
execute() - Method in class io.vertx.reactivex.sqlclient.PreparedQuery
Execute the query.
execute() - Method in class io.vertx.reactivex.sqlclient.Query
Execute the query.
execute(Statement) - Method in class io.vertx.reactivex.cassandra.CassandraClient
Execute the statement and provide a handler for consuming results.
execute(I) - Method in class io.vertx.reactivex.sqlclient.templates.SqlTemplate
Execute the query with the parameters
execute(Handler<Promise<T>>) - Method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
execute(Tuple) - Method in class io.vertx.reactivex.sqlclient.PreparedQuery
Execute the query.
execute(String) - Method in class io.vertx.reactivex.cassandra.CassandraClient
Execute the query and provide a handler for consuming results.
execute(Supplier<Future<T>>) - Method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
executeAndReport(Promise<T>, Handler<Promise<T>>) - Method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
executeAndReportWithFallback(Promise<T>, Handler<Promise<T>>, Function<Throwable, T>) - Method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
Executes the given operation with the circuit breaker control.
executeBatch(List<I>) - Method in class io.vertx.reactivex.sqlclient.templates.SqlTemplate
Execute a batch query with the batch.
executeBatch(List<Tuple>) - Method in class io.vertx.reactivex.sqlclient.PreparedQuery
Execute the query with a batch of tuples.
executePreparedQuery(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Executes an existing prepared query.
executePreparedQueryWithOptions(String, PreparedQueryExecuteOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Executes an existing prepared query.
executeWithFallback(Handler<Promise<T>>, Function<Throwable, T>) - Method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
Executes the given operation with the circuit breaker control.
executeWithFallback(Supplier<Future<T>>, Function<Throwable, T>) - Method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
Executes the given operation with the circuit breaker control.
executeWithFullFetch(Statement) - Method in class io.vertx.reactivex.cassandra.CassandraClient
Execute the query and provide a handler for consuming results.
executeWithFullFetch(String) - Method in class io.vertx.reactivex.cassandra.CassandraClient
Execute the query and provide a handler for consuming results.
executionInfo() - Method in class io.vertx.reactivex.cassandra.CassandraRowStream
Get the provided by the backing ResultSet for this stream.
ExecutionInputBuilderWithContext<C> - Class in io.vertx.reactivex.ext.web.handler.graphql
Holds a with a contextual object.
ExecutionInputBuilderWithContext(ExecutionInputBuilderWithContext) - Constructor for class io.vertx.reactivex.ext.web.handler.graphql.ExecutionInputBuilderWithContext
 
ExecutionInputBuilderWithContext(Object, TypeArg<C>) - Constructor for class io.vertx.reactivex.ext.web.handler.graphql.ExecutionInputBuilderWithContext
 
exists(String) - Method in class io.vertx.reactivex.core.file.FileSystem
Determines whether the file as specified by the path path exists, asynchronously.
exists(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Determine if a key exists.
existsBlocking(String) - Method in class io.vertx.reactivex.core.file.FileSystem
expandToString(Variables) - Method in class io.vertx.reactivex.uritemplate.UriTemplate
Expand this template to a string.
expandToString(Variables, ExpandOptions) - Method in class io.vertx.reactivex.uritemplate.UriTemplate
Expand this template to a string.
EXPECT - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Expect header name
expire(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Set a key's time to live in seconds.
expireat(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Set the expiration for a key as a UNIX timestamp.
expired() - Method in class io.vertx.reactivex.ext.auth.User
Flags this user object to be expired.
expired(int) - Method in class io.vertx.reactivex.ext.auth.User
Flags this user object to be expired.
EXPIRES - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Expires header name
expiretime(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the expiration Unix timestamp for a key.
expiryTime() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
expiryTime(long) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
explodedParam(String, ArraySchemaBuilder) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Parameters
Creates a required exploded array parameter.
explodedParam(String, ObjectSchemaBuilder) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Parameters
Creates a required exploded object parameter.
explodedParam(String, TupleSchemaBuilder) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Parameters
Creates a required exploded tuple parameter.
exponentialDelayWithJitter(long, long) - Static method in class io.vertx.reactivex.circuitbreaker.RetryPolicy
Create an exponential delay with jitter retry policy.
exposedHeader(String) - Method in class io.vertx.reactivex.ext.web.handler.CorsHandler
Add an exposed header
exposedHeaders(Set<String>) - Method in class io.vertx.reactivex.ext.web.handler.CorsHandler
Add a set of exposed headers
extractValidatableRequest(RoutingContext, Operation) - Method in class io.vertx.reactivex.ext.web.openapi.router.RequestExtractor
Extracts and transforms the parameters and the body of an incoming request into a that can be validated by the RequestValidator.
extraParams(JsonObject) - Method in class io.vertx.reactivex.ext.web.handler.OAuth2AuthHandler
Extra parameters needed to be passed while requesting a token.

F

FacebookAuth - Class in io.vertx.reactivex.ext.auth.oauth2.providers
Simplified factory to create an for Facebook.
FacebookAuth(FacebookAuth) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.FacebookAuth
 
FacebookAuth(Object) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.FacebookAuth
 
fail() - Method in class io.vertx.reactivex.ext.unit.TestContext
Throw a failure.
fail(int) - Method in class io.vertx.reactivex.ext.web.RoutingContext
Fail the context with the specified status code.
fail(int, String) - Method in class io.vertx.reactivex.core.eventbus.Message
Signal to the sender that processing of this message failed.
fail(int, Throwable) - Method in class io.vertx.reactivex.ext.web.RoutingContext
Fail the context with the specified throwable and the specified the status code.
fail(String) - Method in class io.vertx.reactivex.ext.unit.TestContext
Throw a failure with the specified failure message.
fail(Throwable) - Method in class io.vertx.reactivex.ext.unit.TestContext
Throw a failure with the specified failure cause.
fail(Throwable) - Method in class io.vertx.reactivex.ext.web.RoutingContext
Fail the context with the specified throwable and 500 status code.
failCheck(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Set status of the check to "critical".
failCheckWithNote(String, String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Set status of the check to "critical".
failed() - Method in class io.vertx.reactivex.ext.consul.WatchResult
Did it fail?
failed() - Method in class io.vertx.reactivex.ext.unit.report.TestResult
Did it fail?
failed() - Method in class io.vertx.reactivex.ext.web.RoutingContext
 
failed(String) - Static method in class io.vertx.reactivex.ext.web.validation.RequestPredicateResult
 
failover(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Start a coordinated failover between this server and one of its replicas.
failure() - Method in class io.vertx.reactivex.ext.unit.report.TestResult
An exception describing failure, null if the test succeeded.
failure() - Method in class io.vertx.reactivex.ext.web.RoutingContext
If the context is being routed to failure handlers after a failure has been triggered by calling RoutingContext.fail(int) then this will return that throwable.
Failure - Class in io.vertx.reactivex.ext.unit.report
A failure provides the details of a failure that happened during the execution of a test case.
Failure(Failure) - Constructor for class io.vertx.reactivex.ext.unit.report.Failure
 
Failure(Object) - Constructor for class io.vertx.reactivex.ext.unit.report.Failure
 
failureCount() - Method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
 
failureHandler(Handler<RoutingContext>) - Method in class io.vertx.reactivex.ext.web.Route
Append a failure handler to the route failure handlers list.
failurePolicy(FailurePolicy<T>) - Method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
Configures the failure policy for this circuit-breaker.
FailurePolicy<T> - Class in io.vertx.reactivex.circuitbreaker
A failure policy for the CircuitBreaker.
FailurePolicy(FailurePolicy) - Constructor for class io.vertx.reactivex.circuitbreaker.FailurePolicy
 
FailurePolicy(Object, TypeArg<T>) - Constructor for class io.vertx.reactivex.circuitbreaker.FailurePolicy
 
fallback(Function<Throwable, T>) - Method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
Sets a default fallback to be invoked when the circuit breaker is open or when failure occurs and CircuitBreakerOptions is enabled.
FaviconHandler - Class in io.vertx.reactivex.ext.web.handler
A handler that serves favicons.
FaviconHandler(FaviconHandler) - Constructor for class io.vertx.reactivex.ext.web.handler.FaviconHandler
 
FaviconHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.FaviconHandler
 
fcall(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Invoke a function.
fcallRo(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Invoke a read-only function.
fetch(long) - Method in class io.vertx.reactivex.amqp.AmqpReceiver
 
fetch(long) - Method in class io.vertx.reactivex.cassandra.CassandraRowStream
 
fetch(long) - Method in class io.vertx.reactivex.core.eventbus.MessageConsumer
 
fetch(long) - Method in class io.vertx.reactivex.core.file.AsyncFile
 
fetch(long) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
 
fetch(long) - Method in class io.vertx.reactivex.core.http.HttpClientResponse
 
fetch(long) - Method in class io.vertx.reactivex.core.http.HttpServerFileUpload
 
fetch(long) - Method in class io.vertx.reactivex.core.http.HttpServerRequest
 
fetch(long) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
 
fetch(long) - Method in class io.vertx.reactivex.core.http.WebSocket
 
fetch(long) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
 
fetch(long) - Method in class io.vertx.reactivex.core.net.NetSocket
 
fetch(long) - Method in class io.vertx.reactivex.core.parsetools.JsonParser
 
fetch(long) - Method in class io.vertx.reactivex.core.parsetools.RecordParser
 
fetch(long) - Method in interface io.vertx.reactivex.core.streams.ReadStream
Fetch the specified amount of elements.
fetch(long) - Method in class io.vertx.reactivex.ext.unit.report.TestSuiteReport
Fetch the specified amount of elements.
fetch(long) - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
 
fetch(long) - Method in class io.vertx.reactivex.grpc.client.GrpcClientResponse
 
fetch(long) - Method in class io.vertx.reactivex.grpc.common.GrpcReadStream
 
fetch(long) - Method in class io.vertx.reactivex.grpc.server.GrpcServerRequest
 
fetch(long) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
 
fetch(long) - Method in class io.vertx.reactivex.pgclient.pubsub.PgChannel
Fetch the specified amount of elements.
fetch(long) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQConsumer
Fetch the specified amount of elements.
fetch(long) - Method in class io.vertx.reactivex.redis.client.RedisConnection
 
fetch(long) - Method in class io.vertx.reactivex.sqlclient.RowStream
 
fetchNextPage() - Method in class io.vertx.reactivex.cassandra.ResultSet
 
fieldNames() - Method in class io.vertx.reactivex.json.schema.JsonSchema
Returns the field names on the underlying object.
file() - Method in class io.vertx.reactivex.core.http.HttpServerFileUpload
 
filename() - Method in class io.vertx.reactivex.core.http.HttpServerFileUpload
 
filename() - Method in class io.vertx.reactivex.ext.web.multipart.FormDataPart
 
fileName() - Method in class io.vertx.reactivex.ext.web.FileUpload
 
FileSystem - Class in io.vertx.reactivex.core.file
Contains a broad set of operations for manipulating files on the file system.
FileSystem(FileSystem) - Constructor for class io.vertx.reactivex.core.file.FileSystem
 
FileSystem(Object) - Constructor for class io.vertx.reactivex.core.file.FileSystem
 
FileUpload - Class in io.vertx.reactivex.ext.web
Represents a file-upload from an HTTP multipart form submission.
FileUpload(FileUpload) - Constructor for class io.vertx.reactivex.ext.web.FileUpload
 
FileUpload(Object) - Constructor for class io.vertx.reactivex.ext.web.FileUpload
 
fileUploads() - Method in class io.vertx.reactivex.ext.web.RoutingContext
 
find(String) - Method in class io.vertx.reactivex.json.schema.SchemaRepository
Look up a schema using a JSON pointer notation
find(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Find matching documents in the specified collection
find(String, String) - Method in class io.vertx.reactivex.ext.auth.webauthn4j.CredentialStorage
Finds an existing list of credentials for a given user name and credential ID.
findAllIds() - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
Finds all file ids in the bucket
findBatch(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Find matching documents in the specified collection.
findBatchWithOptions(String, JsonObject, FindOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Find matching documents in the specified collection, specifying options.
findIds(JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
Finds all file ids that match a query.
findOne(String, JsonObject, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Find a single matching document in the specified collection
findOneAndDelete(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Find a single matching document in the specified collection and delete it.
findOneAndDeleteWithOptions(String, JsonObject, FindOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Find a single matching document in the specified collection and delete it.
findOneAndReplace(String, JsonObject, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Find a single matching document in the specified collection and replace it.
findOneAndReplaceWithOptions(String, JsonObject, JsonObject, FindOptions, UpdateOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Find a single matching document in the specified collection and replace it.
findOneAndUpdate(String, JsonObject, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Find a single matching document in the specified collection and update it.
findOneAndUpdateWithOptions(String, JsonObject, JsonObject, FindOptions, UpdateOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Find a single matching document in the specified collection and update it.
findOperation(String, HttpMethod) - Method in class io.vertx.reactivex.openapi.contract.OpenAPIContract
Finds the related Operation object based on the passed url path and method.
findPath(String) - Method in class io.vertx.reactivex.openapi.contract.OpenAPIContract
Finds the related Path object based on the passed url path.
findWithOptions(String, JsonObject, FindOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Find matching documents in the specified collection, specifying options
fireEvent(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Fires a new user event
fireEventWithOptions(String, EventOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Fires a new user event
firstAcquirer(boolean) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
fixedSizeMode(int) - Method in class io.vertx.reactivex.core.parsetools.RecordParser
Flip the parser into fixed size mode, where the record size is specified by size in bytes.
flush() - Method in class io.vertx.reactivex.core.file.AsyncFile
Flush any writes made to this file to underlying persistent storage.
flush() - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
Invoking this method makes all buffered records immediately available to write
flush(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.SessionHandler
Flush a context session earlier to the store, this will allow the end user to have full control on the event of a failure at the store level.
flush(RoutingContext, boolean) - Method in class io.vertx.reactivex.ext.web.handler.SessionHandler
Flush a context session earlier to the store, this will allow the end user to have full control on the event of a failure at the store level.
flushall(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove all keys from all databases.
flushdb(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove all keys from the current database.
followedRedirects() - Method in class io.vertx.reactivex.ext.web.client.HttpResponse
 
followRedirects() - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
 
followRedirects(boolean) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Set whether to follow request redirections
format() - Method in class io.vertx.reactivex.grpc.common.GrpcReadStream
 
format(WireFormat) - Method in class io.vertx.reactivex.grpc.client.GrpcClientRequest
 
format(WireFormat) - Method in class io.vertx.reactivex.grpc.common.GrpcWriteStream
Set the stream format, e.g.
format(WireFormat) - Method in class io.vertx.reactivex.grpc.server.GrpcServerResponse
 
format(RoutingContext, long) - Method in class io.vertx.reactivex.ext.web.handler.LoggerFormatter
Formats and returns the log statement
formAttributes() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
Returns a map of all form attributes in the request.
FormDataPart - Class in io.vertx.reactivex.ext.web.multipart
A form data part of a MultipartForm.
FormDataPart(FormDataPart) - Constructor for class io.vertx.reactivex.ext.web.multipart.FormDataPart
 
FormDataPart(Object) - Constructor for class io.vertx.reactivex.ext.web.multipart.FormDataPart
 
FormLoginHandler - Class in io.vertx.reactivex.ext.web.handler
Handler that handles login from a form on a custom login page.
FormLoginHandler(FormLoginHandler) - Constructor for class io.vertx.reactivex.ext.web.handler.FormLoginHandler
 
FormLoginHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.FormLoginHandler
 
formUrlEncoded(ObjectSchemaBuilder) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Bodies
Create a form application/x-www-form-urlencoded processor
forQuery(SqlClient, String) - Static method in class io.vertx.reactivex.sqlclient.templates.SqlTemplate
Create an SQL template for query purpose consuming map parameters and returning .
forUpdate(SqlClient, String) - Static method in class io.vertx.reactivex.sqlclient.templates.SqlTemplate
Create an SQL template for query purpose consuming map parameters and returning void.
FoursquareAuth - Class in io.vertx.reactivex.ext.auth.oauth2.providers
Simplified factory to create an for Foursquare.
FoursquareAuth(FoursquareAuth) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.FoursquareAuth
 
FoursquareAuth(Object) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.FoursquareAuth
 
frame() - Method in class io.vertx.reactivex.ext.stomp.ServerFrame
 
frameHandler(Handler<WebSocketFrame>) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
 
frameHandler(Handler<WebSocketFrame>) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
 
frameHandler(Handler<WebSocketFrame>) - Method in class io.vertx.reactivex.core.http.WebSocket
 
frameHandler(Handler<WebSocketFrame>) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Set a frame handler on the connection.
frames() - Method in class io.vertx.reactivex.ext.stomp.Acknowledgement
 
Frames - Class in io.vertx.reactivex.ext.stomp
Utility methods to build common Frames.
Frames(Frames) - Constructor for class io.vertx.reactivex.ext.stomp.Frames
 
Frames(Object) - Constructor for class io.vertx.reactivex.ext.stomp.Frames
 
FreeMarkerTemplateEngine - Class in io.vertx.reactivex.ext.web.templ.freemarker
A template engine that uses the FreeMarker library.
FreeMarkerTemplateEngine(FreeMarkerTemplateEngine) - Constructor for class io.vertx.reactivex.ext.web.templ.freemarker.FreeMarkerTemplateEngine
 
FreeMarkerTemplateEngine(Object) - Constructor for class io.vertx.reactivex.ext.web.templ.freemarker.FreeMarkerTemplateEngine
 
from(Vertx, JsonObject) - Static method in class io.vertx.reactivex.openapi.contract.OpenAPIContract
Resolves / dereferences the passed contract and creates an OpenAPIContract instance.
from(Vertx, JsonObject, Map<String, JsonObject>) - Static method in class io.vertx.reactivex.openapi.contract.OpenAPIContract
Resolves / dereferences the passed contract and creates an OpenAPIContract instance.
from(Vertx, String) - Static method in class io.vertx.reactivex.openapi.contract.OpenAPIContract
Resolves / dereferences the passed contract and creates an OpenAPIContract instance.
from(Vertx, String, Map<String, String>) - Static method in class io.vertx.reactivex.openapi.contract.OpenAPIContract
Resolves / dereferences the passed contract and creates an OpenAPIContract instance.
from(Object[]) - Static method in class io.vertx.reactivex.sqlclient.Tuple
Wrap the provided array with a tuple.
from(String) - Static method in class io.vertx.reactivex.core.json.pointer.JsonPointer
Build a JsonPointer from a json pointer string
from(List<T>) - Static method in class io.vertx.reactivex.sqlclient.Tuple
Wrap the provided list with a tuple.
FROM - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
From header name
fromName(String) - Static method in class io.vertx.reactivex.ext.auth.User
Factory for user instances that are single string.
fromToken(String) - Static method in class io.vertx.reactivex.ext.auth.User
Factory for user instances that are single string.
fromURI(URI) - Static method in class io.vertx.reactivex.core.json.pointer.JsonPointer
Build a JsonPointer from a URI.
fsProps(String) - Method in class io.vertx.reactivex.core.file.FileSystem
Returns properties of the file-system being used by the specified path, asynchronously.
fsPropsBlocking(String) - Method in class io.vertx.reactivex.core.file.FileSystem
ftAdd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.ADD.
ftAggregate(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.AGGREGATE.
ftAliasadd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.ALIASADD.
ftAliasaddifnx(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.
ftAliasdel(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.ALIASDEL.
ftAliasdelifx(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.
ftAliasupdate(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.ALIASUPDATE.
ftAlter(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.ALTER.
ftAlterifnx(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.
ftConfig(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.CONFIG.
ftCreate(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.CREATE.
ftCreateifnx(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.
ftCursor(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.CURSOR.
ftDebug(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.DEBUG.
ftDel(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.DEL.
ftDictadd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.DICTADD.
ftDictdel(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.DICTDEL.
ftDictdump(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.DICTDUMP.
ftDrop(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.DROP.
ftDropifx(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.
ftDropindex(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.DROPINDEX.
ftDropindexifx(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.
ftExplain(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.EXPLAIN.
ftExplaincli(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.EXPLAINCLI.
ftGet(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.GET.
ftInfo(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.INFO.
ftList(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.
ftMget(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.MGET.
ftProfile(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.PROFILE.
ftSafeadd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.SAFEADD.
ftSearch(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.SEARCH.
ftSpellcheck(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.SPELLCHECK.
ftSugadd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.SUGADD.
ftSugdel(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.SUGDEL.
ftSugget(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.SUGGET.
ftSuglen(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.SUGLEN.
ftSynadd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.SYNADD.
ftSyndump(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.SYNDUMP.
ftSynupdate(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.SYNUPDATE.
ftTagvals(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.TAGVALS.
fullMethodName() - Method in class io.vertx.reactivex.grpc.server.GrpcServerRequest
 
fullMethodName(String) - Method in class io.vertx.reactivex.grpc.client.GrpcClientRequest
Set the full method name to call, it must follow the format package-name + '.' + service-name + '/' + method-name or an IllegalArgumentException is thrown.
fullVersion() - Method in class io.vertx.reactivex.sqlclient.spi.DatabaseMetadata
 
function(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
A container for function commands.
future() - Method in class io.vertx.reactivex.ext.bridge.BaseBridgeEvent
 
future() - Method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.BridgeEvent
 
future() - Method in class io.vertx.reactivex.ext.web.handler.graphql.ws.ConnectionInitEvent
 
future() - Method in class io.vertx.reactivex.ext.web.handler.sockjs.BridgeEvent
 

G

generate() - Method in class io.vertx.reactivex.ext.auth.otp.OtpKeyGenerator
Generate key with default size;
generate(int) - Method in class io.vertx.reactivex.ext.auth.otp.OtpKeyGenerator
Generate key
GENERATED_KEYS - Static variable in class io.vertx.reactivex.jdbcclient.JDBCPool
The property to be used to retrieve the generated keys
GENERATED_KEYS - Static variable in class io.vertx.reactivex.oracleclient.OracleClient
The property to be used to retrieve the generated keys
generateToken(JsonObject) - Method in class io.vertx.reactivex.ext.auth.jwt.JWTAuth
Generate a new JWT token.
generateToken(JsonObject, JWTOptions) - Method in class io.vertx.reactivex.ext.auth.jwt.JWTAuth
Generate a new JWT token.
generateUri(OtpKey, String) - Method in class io.vertx.reactivex.ext.auth.otp.hotp.HotpAuth
Creating URI for register in key in user device.
generateUri(OtpKey, String) - Method in class io.vertx.reactivex.ext.auth.otp.totp.TotpAuth
Creating URI for register in key in user device.
generateUri(OtpKey, String, String) - Method in class io.vertx.reactivex.ext.auth.otp.hotp.HotpAuth
Creating URI for register in key in user device.
generateUri(OtpKey, String, String) - Method in class io.vertx.reactivex.ext.auth.otp.totp.TotpAuth
Creating URI for register in key in user device.
generateUri(OtpKey, String, String, String) - Method in class io.vertx.reactivex.ext.auth.otp.hotp.HotpAuth
Creating URI for register in key in user device.
generateUri(OtpKey, String, String, String) - Method in class io.vertx.reactivex.ext.auth.otp.totp.TotpAuth
Creating URI for register in key in user device.
geoadd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Add one or more geospatial items in the geospatial index represented using a sorted set.
geodist(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Returns the distance between two members of a geospatial index.
geohash(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Returns members of a geospatial index as standard geohash strings.
geopos(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Returns longitude and latitude of members of a geospatial index.
georadius(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Deprecated.
georadiusbymember(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Deprecated.
georadiusbymemberRo(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Deprecated.
georadiusRo(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Deprecated.
geosearch(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Query a sorted set representing a geospatial index to fetch members inside an area of a box or a circle.
geosearchstore(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Query a sorted set representing a geospatial index to fetch members inside an area of a box or a circle, and store the result in another key.
get() - Method in class io.vertx.reactivex.core.shareddata.Counter
Get the current value of the counter
get() - Method in class io.vertx.reactivex.ext.web.Router
Add a route that matches any HTTP GET request
get() - Method in class io.vertx.reactivex.ext.web.UserContext
Get the authenticated user (if any).
get() - Method in class io.vertx.reactivex.ext.web.validation.RequestParameter
 
get() - Method in interface io.vertx.reactivex.openapi.validation.Parameter
 
get() - Method in class io.vertx.reactivex.openapi.validation.RequestParameter
 
get() - Method in class io.vertx.reactivex.openapi.validation.ResponseParameter
 
get() - Method in class io.vertx.reactivex.servicediscovery.ServiceReference
Gets the object to access the service.
get(int, String, UriTemplate) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP GET request to send to the server at the specified host and port.
get(int, String, String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP GET request to send to the server at the specified host and port.
get(UriTemplate) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP GET request to send to the server at the default host and port.
get(Class<T>, int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get the the at the specified position and the specified type.
get(Class<T>, String) - Method in class io.vertx.reactivex.sqlclient.Row
Like Tuple.get(java.lang.Class<T>, int) but specifying the column instead of the position.
get(Object) - Method in class io.vertx.reactivex.core.shareddata.LocalMap
Get a value from the map
get(String) - Method in class io.vertx.reactivex.ext.auth.hashing.HashingStrategy
Get an algorithm interface by its Id
get(String) - Method in class io.vertx.reactivex.ext.auth.User
Get a value from the user object.
get(String) - Method in class io.vertx.reactivex.ext.unit.TestContext
Get some data from the context.
get(String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP GET request to send to the server at the default host and port.
get(String) - Method in class io.vertx.reactivex.ext.web.Router
Add a route that matches a HTTP GET request and the specified path
get(String) - Method in class io.vertx.reactivex.ext.web.RoutingContext
Get some data from the context.
get(String) - Method in class io.vertx.reactivex.ext.web.Session
Get some data from the session
get(String) - Method in class io.vertx.reactivex.ext.web.sstore.SessionStore
Get the session with the specified ID.
get(String) - Method in class io.vertx.reactivex.json.schema.JsonSchema
Get a type casted value by key.
get(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the value of a key.
get(String) - Method in class io.vertx.reactivex.uritemplate.Variables
 
get(String, UriTemplate) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP GET request to send to the server at the specified host and default port.
get(String, String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP GET request to send to the server at the specified host and default port.
get(String, R) - Method in class io.vertx.reactivex.json.schema.JsonSchema
Get a type casted value by key.
get(String, T) - Method in class io.vertx.reactivex.ext.web.RoutingContext
Get some data from the context.
get(K) - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
Get a value from the map, asynchronously.
GET - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
GET header value
getAbs(UriTemplate) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP GET request to send to the server using an absolute URI, specifying a response handler to receive the response
getAbs(String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP GET request to send to the server using an absolute URI, specifying a response handler to receive the response
getAbsoluteOpenAPIPath() - Method in class io.vertx.reactivex.openapi.contract.Operation
 
getAcceptableContentType() - Method in class io.vertx.reactivex.ext.web.RoutingContext
If the route specifies produces matches, e.g. produces `text/html` and `text/plain`, and the `accept` header matches one or more of these then this returns the most acceptable match.
getAclPolicies() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
This endpoint lists all the ACL policies.
getAclTokens() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Get list of Acl token
getAlgorithm() - Method in class io.vertx.reactivex.ext.auth.otp.OtpKeyGenerator
 
getAllPreparedQueries() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns a list of all prepared queries.
getAndAdd(long) - Method in class io.vertx.reactivex.core.shareddata.Counter
Add the value to the counter atomically and return the value before the add
getAndIncrement() - Method in class io.vertx.reactivex.core.shareddata.Counter
Increment the counter atomically and return the value before the increment.
getArrayElement(Object, int) - Method in class io.vertx.reactivex.core.json.pointer.JsonPointerIterator
Move the iterator the array element at specified index
getArrayOfBigDecimals(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get an array of value at pos.
getArrayOfBigDecimals(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get an array of value for the given column.
getArrayOfBooleans(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get an array of Boolean value at pos.
getArrayOfBooleans(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get an array of Boolean value for the given column.
getArrayOfDoubles(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get an array of Double value at pos.
getArrayOfDoubles(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get an array of Double value for the given column.
getArrayOfFloats(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get an array of Float value at pos.
getArrayOfFloats(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get an array of Float value for the given column.
getArrayOfIntegers(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get an array of Integer value at pos.
getArrayOfIntegers(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get an array of Integer value for the given column.
getArrayOfJsonArrays(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get an array of value at pos.
getArrayOfJsonArrays(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get an array of value for the given column.
getArrayOfJsonObjects(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get an array of value at pos.
getArrayOfJsonObjects(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get an array of value for the given column.
getArrayOfJsons(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get an array of JSON elements at pos, the element might be #JSON_NULL null or one of the following types: String Number JsonObject JsonArray Boolean
getArrayOfJsons(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get an array of JSON elements for the given column, the element might be #JSON_NULL null or one of the following types: String Number JsonObject JsonArray Boolean
getArrayOfLocalDates(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get an array of value at pos.
getArrayOfLocalDates(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get an array of value for the given column.
getArrayOfLocalDateTimes(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get an array of value at pos.
getArrayOfLocalDateTimes(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get an array of value for the given column.
getArrayOfLocalTimes(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get an array of value at pos.
getArrayOfLocalTimes(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get an array of value for the given column.
getArrayOfLongs(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get an array of Long value at pos.
getArrayOfLongs(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get an array of Long value for the given column.
getArrayOfNumerics(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get an array of value at pos.
getArrayOfNumerics(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get an array of value for the given column.
getArrayOfOffsetDateTimes(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get an array of value at pos.
getArrayOfOffsetDateTimes(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get an array of value for the given column.
getArrayOfOffsetTimes(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get an array of value at pos.
getArrayOfOffsetTimes(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get an array of value for the given column.
getArrayOfShorts(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get an array of Short value at pos.
getArrayOfShorts(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get an array of Short value for the given column.
getArrayOfStrings(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get an array of String value at pos.
getArrayOfStrings(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get an array of String value for the given column.
getArrayOfTemporals(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get an array of value at pos.
getArrayOfTemporals(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get an array of value for the given column.
getArrayOfUUIDs(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get an array of value at pos.
getArrayOfUUIDs(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get an array of value for the given column.
getAs(Class<X>) - Method in class io.vertx.reactivex.servicediscovery.ServiceReference
Gets the object to access the service.
getAsyncMap(String) - Method in class io.vertx.reactivex.core.shareddata.SharedData
Get the AsyncMap with the specified name.
getAuthorization() - Method in class io.vertx.reactivex.ext.auth.authorization.NotAuthorization
 
getAuthorizationCode() - Method in class io.vertx.reactivex.openapi.contract.OAuthFlows
Configuration for the OAuth Authorization Code flow.
getAuthorizations() - Method in class io.vertx.reactivex.ext.auth.authorization.AndAuthorization
 
getAuthorizations() - Method in class io.vertx.reactivex.ext.auth.authorization.OrAuthorization
 
getAuthorizations(User) - Method in class io.vertx.reactivex.ext.auth.abac.PolicyBasedAuthorizationProvider
Updates the user with the set of authorizations.
getAuthorizations(User) - Method in interface io.vertx.reactivex.ext.auth.authorization.AuthorizationProvider
Updates the user with the set of authorizations.
getAuthorizations(User) - Method in class io.vertx.reactivex.ext.auth.jwt.authorization.JWTAuthorization
Updates the user with the set of authorizations.
getAuthorizations(User) - Method in class io.vertx.reactivex.ext.auth.jwt.authorization.MicroProfileAuthorization
Updates the user with the set of authorizations.
getAuthorizations(User) - Method in class io.vertx.reactivex.ext.auth.oauth2.authorization.KeycloakAuthorization
Updates the user with the set of authorizations.
getAuthorizations(User) - Method in class io.vertx.reactivex.ext.auth.oauth2.authorization.ScopeAuthorization
Updates the user with the set of authorizations.
getAuthorizations(User) - Method in class io.vertx.reactivex.ext.auth.properties.PropertyFileAuthorization
Updates the user with the set of authorizations.
getAuthorizations(User) - Method in class io.vertx.reactivex.ext.auth.sqlclient.SqlAuthorization
Updates the user with the set of authorizations.
getAuthorizationUrl() - Method in class io.vertx.reactivex.openapi.contract.OAuthFlow
The authorization URL to be used for this flow.
getBaseName() - Method in class io.vertx.reactivex.micrometer.MetricsService
 
getBaseName(Measured) - Method in class io.vertx.reactivex.ext.dropwizard.MetricsService
 
getBasePath() - Method in class io.vertx.reactivex.openapi.contract.Server
The base path is used to indicate that the location where the OpenAPI contract is served is different from the path specified in the OpenAPI contract.
getBearerFormat() - Method in class io.vertx.reactivex.openapi.contract.SecurityScheme
A hint to the client to identify how the bearer token is formatted.
getBigDecimal(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get value at pos.
getBigDecimal(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get value for the given column.
getbit(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Returns the bit value at offset in the string value stored at key.
getBody() - Method in class io.vertx.reactivex.openapi.validation.ValidatableResponse
 
getBody() - Method in class io.vertx.reactivex.openapi.validation.ValidatedRequest
 
getBody() - Method in class io.vertx.reactivex.openapi.validation.ValidatedResponse
 
getBoolean() - Method in class io.vertx.reactivex.ext.web.validation.RequestParameter
 
getBoolean() - Method in interface io.vertx.reactivex.openapi.validation.Parameter
 
getBoolean() - Method in class io.vertx.reactivex.openapi.validation.RequestParameter
 
getBoolean() - Method in class io.vertx.reactivex.openapi.validation.ResponseParameter
 
getBoolean(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get a boolean value at pos.
getBoolean(Boolean) - Method in interface io.vertx.reactivex.openapi.validation.Parameter
 
getBoolean(Boolean) - Method in class io.vertx.reactivex.openapi.validation.RequestParameter
 
getBoolean(Boolean) - Method in class io.vertx.reactivex.openapi.validation.ResponseParameter
 
getBoolean(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get a boolean value for the given column.
getBuffer() - Method in class io.vertx.reactivex.ext.web.validation.RequestParameter
 
getBuffer() - Method in interface io.vertx.reactivex.openapi.validation.Parameter
 
getBuffer() - Method in class io.vertx.reactivex.openapi.validation.RequestParameter
 
getBuffer() - Method in class io.vertx.reactivex.openapi.validation.ResponseParameter
 
getBuffer(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get a buffer value at pos.
getBuffer(Buffer) - Method in interface io.vertx.reactivex.openapi.validation.Parameter
 
getBuffer(Buffer) - Method in class io.vertx.reactivex.openapi.validation.RequestParameter
 
getBuffer(Buffer) - Method in class io.vertx.reactivex.openapi.validation.ResponseParameter
 
getBuffer(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get a buffer value for the given column.
getCachedConfig() - Method in class io.vertx.reactivex.config.ConfigRetriever
Gets the last computed configuration.
getCharset() - Method in class io.vertx.reactivex.ext.web.multipart.MultipartForm
 
getClient(ServiceDiscovery, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.HttpEndpoint
Convenient method that looks for a HTTP endpoint and provides the configured .
getClient(ServiceDiscovery, JsonObject, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.HttpEndpoint
Convenient method that looks for a HTTP endpoint and provides the configured .
getClient(ServiceDiscovery, Function<Record, Boolean>) - Static method in class io.vertx.reactivex.servicediscovery.types.HttpEndpoint
Convenient method that looks for a HTTP endpoint and provides the configured .
getClient(ServiceDiscovery, Function<Record, Boolean>, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.HttpEndpoint
Convenient method that looks for a HTTP endpoint and provides the configured .
getClientCredentials() - Method in class io.vertx.reactivex.openapi.contract.OAuthFlows
Configuration for the OAuth Client Credentials flow.
getClusterWideMap(String) - Method in class io.vertx.reactivex.core.shareddata.SharedData
Get the cluster wide map with the specified name.
getCollections() - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Get a list of all collections in the database.
getColumnDefinitions() - Method in class io.vertx.reactivex.cassandra.ResultSet
 
getColumnIndex(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get a column position for the given @code column}.
getColumnName(int) - Method in class io.vertx.reactivex.sqlclient.Row
Get a column name at pos.
getConfig() - Method in class io.vertx.reactivex.config.ConfigRetriever
Reads the configuration from the different and computes the final configuration.
getConfirmationStream() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQPublisher
Get the ReadStream that contains the message IDs for confirmed messages.
getConnection() - Method in class io.vertx.reactivex.sqlclient.Pool
Get a connection from the pool.
getConsumer(ServiceDiscovery, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.MessageSource
Convenient method that looks for a message source and provides the configured .
getConsumer(ServiceDiscovery, Function<Record, Boolean>) - Static method in class io.vertx.reactivex.servicediscovery.types.MessageSource
Convenient method that looks for a message source and provides the configured .
getContent() - Method in class io.vertx.reactivex.openapi.contract.RequestBody
 
getContent() - Method in class io.vertx.reactivex.openapi.contract.Response
 
getContentId() - Method in class io.vertx.reactivex.ext.mail.MailAttachment
get the Content-ID field
getContentType() - Method in class io.vertx.reactivex.ext.mail.MailAttachment
get the Content-Type
getContentType() - Method in class io.vertx.reactivex.openapi.validation.ValidatableRequest
 
getContentType() - Method in class io.vertx.reactivex.openapi.validation.ValidatableResponse
 
getCookie(String) - Method in class io.vertx.reactivex.core.http.HttpServerRequest
Get the cookie with the specified name.
getCookie(String, String, String) - Method in class io.vertx.reactivex.core.http.HttpServerRequest
Get the cookie with the specified .
getCookies() - Method in class io.vertx.reactivex.openapi.validation.ValidatedRequest
 
getCounter(String) - Method in class io.vertx.reactivex.core.shareddata.SharedData
Get an asynchronous counter.
getCredentialsOptions(String) - Method in class io.vertx.reactivex.ext.auth.webauthn4j.WebAuthn4J
Creates an assertion challenge and any other parameters for the navigator.credentials.get() call.
getData() - Method in class io.vertx.reactivex.ext.mail.MailAttachment
get the data
getDefaultResponse() - Method in class io.vertx.reactivex.openapi.contract.Operation
 
getdel(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the value of a key and delete the key.
getDelegate() - Method in class io.vertx.reactivex.amqp.AmqpClient
 
getDelegate() - Method in class io.vertx.reactivex.amqp.AmqpConnection
 
getDelegate() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
getDelegate() - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
getDelegate() - Method in class io.vertx.reactivex.amqp.AmqpReceiver
 
getDelegate() - Method in class io.vertx.reactivex.amqp.AmqpSender
 
getDelegate() - Method in class io.vertx.reactivex.cassandra.CassandraClient
 
getDelegate() - Method in class io.vertx.reactivex.cassandra.CassandraRowStream
 
getDelegate() - Method in class io.vertx.reactivex.cassandra.ResultSet
 
getDelegate() - Method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
 
getDelegate() - Method in class io.vertx.reactivex.circuitbreaker.FailurePolicy
 
getDelegate() - Method in class io.vertx.reactivex.circuitbreaker.RetryPolicy
 
getDelegate() - Method in class io.vertx.reactivex.config.ConfigRetriever
 
getDelegate() - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
 
getDelegate() - Method in class io.vertx.reactivex.core.dns.DnsClient
 
getDelegate() - Method in class io.vertx.reactivex.core.eventbus.DeliveryContext
 
getDelegate() - Method in class io.vertx.reactivex.core.eventbus.EventBus
 
getDelegate() - Method in class io.vertx.reactivex.core.eventbus.Message
 
getDelegate() - Method in class io.vertx.reactivex.core.eventbus.MessageConsumer
 
getDelegate() - Method in class io.vertx.reactivex.core.eventbus.MessageProducer
 
getDelegate() - Method in class io.vertx.reactivex.core.file.AsyncFile
 
getDelegate() - Method in class io.vertx.reactivex.core.file.AsyncFileLock
 
getDelegate() - Method in class io.vertx.reactivex.core.file.FileSystem
 
getDelegate() - Method in class io.vertx.reactivex.core.http.ClientWebSocket
 
getDelegate() - Method in interface io.vertx.reactivex.core.http.HttpClient
 
getDelegate() - Method in class io.vertx.reactivex.core.http.HttpClientAgent
 
getDelegate() - Method in class io.vertx.reactivex.core.http.HttpClientBuilder
 
getDelegate() - Method in class io.vertx.reactivex.core.http.HttpClientConnection
 
getDelegate() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
 
getDelegate() - Method in class io.vertx.reactivex.core.http.HttpClientResponse
 
getDelegate() - Method in class io.vertx.reactivex.core.http.HttpConnection
 
getDelegate() - Method in class io.vertx.reactivex.core.http.HttpHeaders
 
getDelegate() - Method in class io.vertx.reactivex.core.http.HttpRequestHead
 
getDelegate() - Method in interface io.vertx.reactivex.core.http.HttpResponseHead
 
getDelegate() - Method in class io.vertx.reactivex.core.http.HttpServer
 
getDelegate() - Method in class io.vertx.reactivex.core.http.HttpServerFileUpload
 
getDelegate() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
 
getDelegate() - Method in class io.vertx.reactivex.core.http.HttpServerResponse
 
getDelegate() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
 
getDelegate() - Method in class io.vertx.reactivex.core.http.ServerWebSocketHandshake
 
getDelegate() - Method in class io.vertx.reactivex.core.http.WebSocket
 
getDelegate() - Method in interface io.vertx.reactivex.core.http.WebSocketBase
 
getDelegate() - Method in class io.vertx.reactivex.core.http.WebSocketClient
 
getDelegate() - Method in class io.vertx.reactivex.core.json.pointer.JsonPointer
 
getDelegate() - Method in class io.vertx.reactivex.core.json.pointer.JsonPointerIterator
 
getDelegate() - Method in interface io.vertx.reactivex.core.metrics.Measured
 
getDelegate() - Method in class io.vertx.reactivex.core.net.endpoint.Endpoint
 
getDelegate() - Method in class io.vertx.reactivex.core.net.endpoint.EndpointResolver
 
getDelegate() - Method in class io.vertx.reactivex.core.net.endpoint.ServerEndpoint
 
getDelegate() - Method in class io.vertx.reactivex.core.net.endpoint.ServerInteraction
 
getDelegate() - Method in class io.vertx.reactivex.core.net.NetClient
 
getDelegate() - Method in class io.vertx.reactivex.core.net.NetServer
 
getDelegate() - Method in class io.vertx.reactivex.core.net.NetSocket
 
getDelegate() - Method in class io.vertx.reactivex.core.parsetools.JsonParser
 
getDelegate() - Method in class io.vertx.reactivex.core.parsetools.RecordParser
 
getDelegate() - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
 
getDelegate() - Method in class io.vertx.reactivex.core.shareddata.Counter
 
getDelegate() - Method in class io.vertx.reactivex.core.shareddata.LocalMap
 
getDelegate() - Method in class io.vertx.reactivex.core.shareddata.Lock
 
getDelegate() - Method in class io.vertx.reactivex.core.shareddata.SharedData
 
getDelegate() - Method in class io.vertx.reactivex.core.streams.Pipe
 
getDelegate() - Method in interface io.vertx.reactivex.core.streams.ReadStream
 
getDelegate() - Method in interface io.vertx.reactivex.core.streams.StreamBase
 
getDelegate() - Method in interface io.vertx.reactivex.core.streams.WriteStream
 
getDelegate() - Method in class io.vertx.reactivex.db2client.DB2Builder
 
getDelegate() - Method in class io.vertx.reactivex.db2client.DB2Connection
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.abac.Attribute
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.abac.PolicyBasedAuthorizationProvider
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.audit.SecurityAudit
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.authentication.AuthenticationProvider
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.authorization.AndAuthorization
 
getDelegate() - Method in interface io.vertx.reactivex.ext.auth.authorization.Authorization
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.authorization.AuthorizationContext
 
getDelegate() - Method in interface io.vertx.reactivex.ext.auth.authorization.AuthorizationProvider
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.authorization.Authorizations
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.authorization.NotAuthorization
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.authorization.OrAuthorization
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.authorization.PermissionBasedAuthorization
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.authorization.RoleBasedAuthorization
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.authorization.WildcardPermissionBasedAuthorization
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.ChainAuth
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.hashing.HashingAlgorithm
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.hashing.HashingStrategy
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.htdigest.HtdigestAuth
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.htpasswd.HtpasswdAuth
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.jwt.authorization.JWTAuthorization
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.jwt.authorization.MicroProfileAuthorization
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.jwt.JWTAuth
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.ldap.LdapAuthentication
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.oauth2.authorization.KeycloakAuthorization
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.oauth2.authorization.ScopeAuthorization
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.AmazonCognitoAuth
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.AppleIdAuth
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.AzureADAuth
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.BoxAuth
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.CloudFoundryAuth
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.DropboxAuth
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.FacebookAuth
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.FoursquareAuth
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.GiteeAuth
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.GithubAuth
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.GitLabAuth
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.GoogleAuth
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.HerokuAuth
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.IBMCloudAuth
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.InstagramAuth
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.KeycloakAuth
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.LinkedInAuth
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.LiveAuth
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.MailchimpAuth
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.OpenIDConnectAuth
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.SalesforceAuth
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.ShopifyAuth
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.SoundcloudAuth
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.StripeAuth
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.TwitterAuth
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.otp.hotp.HotpAuth
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.otp.OtpKeyGenerator
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.otp.totp.TotpAuth
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.prng.VertxContextPRNG
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.properties.PropertyFileAuthentication
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.properties.PropertyFileAuthorization
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.sqlclient.SqlAuthentication
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.sqlclient.SqlAuthorization
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.sqlclient.SqlUserUtil
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.User
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.webauthn4j.CredentialStorage
 
getDelegate() - Method in class io.vertx.reactivex.ext.auth.webauthn4j.WebAuthn4J
 
getDelegate() - Method in class io.vertx.reactivex.ext.bridge.BaseBridgeEvent
 
getDelegate() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
 
getDelegate() - Method in class io.vertx.reactivex.ext.consul.Watch
 
getDelegate() - Method in class io.vertx.reactivex.ext.consul.WatchResult
 
getDelegate() - Method in class io.vertx.reactivex.ext.dropwizard.MetricsService
 
getDelegate() - Method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.BridgeEvent
 
getDelegate() - Method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.TcpEventBusBridge
 
getDelegate() - Method in class io.vertx.reactivex.ext.healthchecks.HealthChecks
 
getDelegate() - Method in class io.vertx.reactivex.ext.mail.MailAttachment
 
getDelegate() - Method in class io.vertx.reactivex.ext.mail.MailClient
 
getDelegate() - Method in class io.vertx.reactivex.ext.mongo.MongoClient
 
getDelegate() - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
 
getDelegate() - Method in class io.vertx.reactivex.ext.stomp.Acknowledgement
 
getDelegate() - Method in class io.vertx.reactivex.ext.stomp.Destination
 
getDelegate() - Method in class io.vertx.reactivex.ext.stomp.DestinationFactory
 
getDelegate() - Method in class io.vertx.reactivex.ext.stomp.Frames
 
getDelegate() - Method in class io.vertx.reactivex.ext.stomp.ServerFrame
 
getDelegate() - Method in class io.vertx.reactivex.ext.stomp.StompClient
 
getDelegate() - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
 
getDelegate() - Method in class io.vertx.reactivex.ext.stomp.StompServer
 
getDelegate() - Method in class io.vertx.reactivex.ext.stomp.StompServerConnection
 
getDelegate() - Method in class io.vertx.reactivex.ext.stomp.StompServerHandler
 
getDelegate() - Method in class io.vertx.reactivex.ext.unit.Async
 
getDelegate() - Method in class io.vertx.reactivex.ext.unit.collect.EventBusCollector
 
getDelegate() - Method in class io.vertx.reactivex.ext.unit.Completion
 
getDelegate() - Method in class io.vertx.reactivex.ext.unit.report.Failure
 
getDelegate() - Method in class io.vertx.reactivex.ext.unit.report.TestCaseReport
 
getDelegate() - Method in class io.vertx.reactivex.ext.unit.report.TestResult
 
getDelegate() - Method in class io.vertx.reactivex.ext.unit.report.TestSuiteReport
 
getDelegate() - Method in class io.vertx.reactivex.ext.unit.TestCase
 
getDelegate() - Method in class io.vertx.reactivex.ext.unit.TestCompletion
 
getDelegate() - Method in class io.vertx.reactivex.ext.unit.TestContext
 
getDelegate() - Method in class io.vertx.reactivex.ext.unit.TestSuite
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.client.CachingWebClient
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.client.HttpResponse
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.client.OAuth2WebClient
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.client.WebClient
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.client.WebClientSession
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.codec.BodyCodec
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.common.template.TemplateEngine
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.common.WebEnvironment
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.FileUpload
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.APIKeyHandler
 
getDelegate() - Method in interface io.vertx.reactivex.ext.web.handler.AuthenticationHandler
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.AuthorizationHandler
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.BasicAuthHandler
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.BodyHandler
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.ChainAuthHandler
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.CorsHandler
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.CSPHandler
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.CSRFHandler
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.DigestAuthHandler
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.ErrorHandler
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.FaviconHandler
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.FormLoginHandler
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.graphql.ExecutionInputBuilderWithContext
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.graphql.GraphiQLHandler
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.graphql.GraphiQLHandlerBuilder
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.graphql.GraphQLHandler
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.graphql.GraphQLHandlerBuilder
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.graphql.UploadScalar
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.graphql.ws.ConnectionInitEvent
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.graphql.ws.GraphQLWSHandler
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.graphql.ws.GraphQLWSHandlerBuilder
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.graphql.ws.Message
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.HSTSHandler
 
getDelegate() - Method in interface io.vertx.reactivex.ext.web.handler.InputTrustHandler
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.JWTAuthHandler
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.LoggerFormatter
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.LoggerHandler
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.MethodOverrideHandler
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.MultiTenantHandler
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.OAuth2AuthHandler
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.OtpAuthHandler
 
getDelegate() - Method in interface io.vertx.reactivex.ext.web.handler.PlatformHandler
 
getDelegate() - Method in interface io.vertx.reactivex.ext.web.handler.ProtocolUpgradeHandler
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.RedirectAuthHandler
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.ResponseContentTypeHandler
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.ResponseTimeHandler
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.SecurityAuditLoggerHandler
 
getDelegate() - Method in interface io.vertx.reactivex.ext.web.handler.SecurityPolicyHandler
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.SessionHandler
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.SimpleAuthenticationHandler
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.sockjs.BridgeEvent
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSHandler
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.StaticHandler
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.TemplateHandler
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.TimeoutHandler
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.WebAuthn4JHandler
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.XFrameHandler
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.healthchecks.HealthCheckHandler
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.LanguageHeader
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.MIMEHeader
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.multipart.FormDataPart
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.multipart.MultipartForm
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.openapi.router.OpenAPIRoute
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.openapi.router.RequestExtractor
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.openapi.router.RouterBuilder
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.openapi.router.Security
 
getDelegate() - Method in interface io.vertx.reactivex.ext.web.ParsedHeaderValue
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.ParsedHeaderValues
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.RequestBody
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.Route
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.Router
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.RoutingContext
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.Session
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.sstore.ClusteredSessionStore
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.sstore.cookie.CookieSessionStore
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.sstore.infinispan.InfinispanSessionStore
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.sstore.LocalSessionStore
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.sstore.redis.RedisSessionStore
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.sstore.SessionStore
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.templ.freemarker.FreeMarkerTemplateEngine
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.templ.handlebars.HandlebarsTemplateEngine
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.templ.mvel.MVELTemplateEngine
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.templ.pebble.PebbleTemplateEngine
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.templ.pug.PugTemplateEngine
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.templ.rocker.RockerTemplateEngine
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.templ.thymeleaf.ThymeleafTemplateEngine
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.UserContext
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.validation.builder.ArrayParserFactory
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.validation.builder.Bodies
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.validation.builder.BodyProcessorFactory
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.validation.builder.ObjectParserFactory
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.validation.builder.ParameterProcessorFactory
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.validation.builder.Parameters
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.validation.builder.Parsers
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.validation.builder.StyledParameterProcessorFactory
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.validation.builder.TupleParserFactory
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.validation.builder.ValidationHandlerBuilder
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.validation.RequestParameter
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.validation.RequestParameters
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.validation.RequestPredicate
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.validation.RequestPredicateResult
 
getDelegate() - Method in class io.vertx.reactivex.ext.web.validation.ValidationHandler
 
getDelegate() - Method in class io.vertx.reactivex.grpc.client.GrpcClient
 
getDelegate() - Method in class io.vertx.reactivex.grpc.client.GrpcClientBuilder
 
getDelegate() - Method in class io.vertx.reactivex.grpc.client.GrpcClientRequest
 
getDelegate() - Method in class io.vertx.reactivex.grpc.client.GrpcClientResponse
 
getDelegate() - Method in class io.vertx.reactivex.grpc.common.GrpcReadStream
 
getDelegate() - Method in class io.vertx.reactivex.grpc.common.GrpcWriteStream
 
getDelegate() - Method in class io.vertx.reactivex.grpc.server.GrpcServer
 
getDelegate() - Method in class io.vertx.reactivex.grpc.server.GrpcServerRequest
 
getDelegate() - Method in class io.vertx.reactivex.grpc.server.GrpcServerResponse
 
getDelegate() - Method in class io.vertx.reactivex.jdbcclient.JDBCConnection
 
getDelegate() - Method in class io.vertx.reactivex.jdbcclient.JDBCPool
 
getDelegate() - Method in class io.vertx.reactivex.jdbcclient.SqlOutParam
 
getDelegate() - Method in class io.vertx.reactivex.json.schema.JsonFormatValidator
 
getDelegate() - Method in class io.vertx.reactivex.json.schema.JsonSchema
 
getDelegate() - Method in class io.vertx.reactivex.json.schema.Ref
 
getDelegate() - Method in class io.vertx.reactivex.json.schema.SchemaRepository
 
getDelegate() - Method in class io.vertx.reactivex.json.schema.Validator
 
getDelegate() - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
 
getDelegate() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
 
getDelegate() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumerRecord
 
getDelegate() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumerRecords
 
getDelegate() - Method in class io.vertx.reactivex.kafka.client.producer.KafkaHeader
 
getDelegate() - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
 
getDelegate() - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducerRecord
 
getDelegate() - Method in class io.vertx.reactivex.micrometer.MetricsService
 
getDelegate() - Method in class io.vertx.reactivex.micrometer.PrometheusRequestHandler
 
getDelegate() - Method in class io.vertx.reactivex.micrometer.PrometheusScrapingHandler
 
getDelegate() - Method in class io.vertx.reactivex.mqtt.messages.MqttAuthenticationExchangeMessage
 
getDelegate() - Method in class io.vertx.reactivex.mqtt.messages.MqttConnAckMessage
 
getDelegate() - Method in class io.vertx.reactivex.mqtt.messages.MqttDisconnectMessage
 
getDelegate() - Method in interface io.vertx.reactivex.mqtt.messages.MqttMessage
 
getDelegate() - Method in class io.vertx.reactivex.mqtt.messages.MqttPubAckMessage
 
getDelegate() - Method in class io.vertx.reactivex.mqtt.messages.MqttPubCompMessage
 
getDelegate() - Method in class io.vertx.reactivex.mqtt.messages.MqttPublishMessage
 
getDelegate() - Method in class io.vertx.reactivex.mqtt.messages.MqttPubRecMessage
 
getDelegate() - Method in class io.vertx.reactivex.mqtt.messages.MqttPubRelMessage
 
getDelegate() - Method in class io.vertx.reactivex.mqtt.messages.MqttSubAckMessage
 
getDelegate() - Method in class io.vertx.reactivex.mqtt.messages.MqttSubscribeMessage
 
getDelegate() - Method in class io.vertx.reactivex.mqtt.messages.MqttUnsubscribeMessage
 
getDelegate() - Method in class io.vertx.reactivex.mqtt.MqttClient
 
getDelegate() - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
 
getDelegate() - Method in class io.vertx.reactivex.mqtt.MqttServer
 
getDelegate() - Method in class io.vertx.reactivex.mqtt.MqttTopicSubscription
 
getDelegate() - Method in class io.vertx.reactivex.mssqlclient.MSSQLBuilder
 
getDelegate() - Method in class io.vertx.reactivex.mssqlclient.MSSQLConnection
 
getDelegate() - Method in class io.vertx.reactivex.mysqlclient.MySQLBuilder
 
getDelegate() - Method in class io.vertx.reactivex.mysqlclient.MySQLClient
 
getDelegate() - Method in class io.vertx.reactivex.mysqlclient.MySQLConnection
 
getDelegate() - Method in class io.vertx.reactivex.openapi.contract.MediaType
 
getDelegate() - Method in class io.vertx.reactivex.openapi.contract.OAuthFlow
 
getDelegate() - Method in class io.vertx.reactivex.openapi.contract.OAuthFlows
 
getDelegate() - Method in class io.vertx.reactivex.openapi.contract.OpenAPIContract
 
getDelegate() - Method in class io.vertx.reactivex.openapi.contract.Operation
 
getDelegate() - Method in class io.vertx.reactivex.openapi.contract.Parameter
 
getDelegate() - Method in class io.vertx.reactivex.openapi.contract.Path
 
getDelegate() - Method in class io.vertx.reactivex.openapi.contract.RequestBody
 
getDelegate() - Method in class io.vertx.reactivex.openapi.contract.Response
 
getDelegate() - Method in class io.vertx.reactivex.openapi.contract.SecurityRequirement
 
getDelegate() - Method in class io.vertx.reactivex.openapi.contract.SecurityScheme
 
getDelegate() - Method in class io.vertx.reactivex.openapi.contract.Server
 
getDelegate() - Method in interface io.vertx.reactivex.openapi.validation.Parameter
 
getDelegate() - Method in class io.vertx.reactivex.openapi.validation.RequestParameter
 
getDelegate() - Method in class io.vertx.reactivex.openapi.validation.RequestValidator
 
getDelegate() - Method in class io.vertx.reactivex.openapi.validation.ResponseParameter
 
getDelegate() - Method in class io.vertx.reactivex.openapi.validation.ValidatableRequest
 
getDelegate() - Method in class io.vertx.reactivex.openapi.validation.ValidatableResponse
 
getDelegate() - Method in class io.vertx.reactivex.openapi.validation.ValidatedRequest
 
getDelegate() - Method in class io.vertx.reactivex.openapi.validation.ValidatedResponse
 
getDelegate() - Method in class io.vertx.reactivex.oracleclient.OracleBuilder
 
getDelegate() - Method in class io.vertx.reactivex.oracleclient.OracleClient
 
getDelegate() - Method in class io.vertx.reactivex.oracleclient.OracleConnection
 
getDelegate() - Method in class io.vertx.reactivex.pgclient.PgBuilder
 
getDelegate() - Method in class io.vertx.reactivex.pgclient.PgConnection
 
getDelegate() - Method in class io.vertx.reactivex.pgclient.pubsub.PgChannel
 
getDelegate() - Method in class io.vertx.reactivex.pgclient.pubsub.PgSubscriber
 
getDelegate() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
 
getDelegate() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQConsumer
 
getDelegate() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQMessage
 
getDelegate() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQPublisher
 
getDelegate() - Method in class io.vertx.reactivex.redis.client.Redis
 
getDelegate() - Method in class io.vertx.reactivex.redis.client.RedisAPI
 
getDelegate() - Method in class io.vertx.reactivex.redis.client.RedisCluster
 
getDelegate() - Method in class io.vertx.reactivex.redis.client.RedisConnection
 
getDelegate() - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
 
getDelegate() - Method in class io.vertx.reactivex.servicediscovery.ServiceReference
 
getDelegate() - Method in class io.vertx.reactivex.servicediscovery.spi.ServiceExporter
 
getDelegate() - Method in class io.vertx.reactivex.servicediscovery.spi.ServiceImporter
 
getDelegate() - Method in class io.vertx.reactivex.servicediscovery.spi.ServicePublisher
 
getDelegate() - Method in class io.vertx.reactivex.servicediscovery.types.EventBusService
 
getDelegate() - Method in class io.vertx.reactivex.servicediscovery.types.HttpEndpoint
 
getDelegate() - Method in class io.vertx.reactivex.servicediscovery.types.MessageSource
 
getDelegate() - Method in class io.vertx.reactivex.servicediscovery.types.MongoDataSource
 
getDelegate() - Method in class io.vertx.reactivex.servicediscovery.types.RedisDataSource
 
getDelegate() - Method in class io.vertx.reactivex.sqlclient.ClientBuilder
 
getDelegate() - Method in class io.vertx.reactivex.sqlclient.Cursor
 
getDelegate() - Method in class io.vertx.reactivex.sqlclient.desc.ColumnDescriptor
 
getDelegate() - Method in class io.vertx.reactivex.sqlclient.Pool
 
getDelegate() - Method in class io.vertx.reactivex.sqlclient.PreparedQuery
 
getDelegate() - Method in class io.vertx.reactivex.sqlclient.PreparedStatement
 
getDelegate() - Method in class io.vertx.reactivex.sqlclient.PropertyKind
 
getDelegate() - Method in class io.vertx.reactivex.sqlclient.Query
 
getDelegate() - Method in class io.vertx.reactivex.sqlclient.Row
 
getDelegate() - Method in class io.vertx.reactivex.sqlclient.RowIterator
 
getDelegate() - Method in class io.vertx.reactivex.sqlclient.RowSet
 
getDelegate() - Method in class io.vertx.reactivex.sqlclient.RowStream
 
getDelegate() - Method in class io.vertx.reactivex.sqlclient.spi.DatabaseMetadata
 
getDelegate() - Method in class io.vertx.reactivex.sqlclient.SqlClient
 
getDelegate() - Method in class io.vertx.reactivex.sqlclient.SqlConnection
 
getDelegate() - Method in class io.vertx.reactivex.sqlclient.SqlResult
 
getDelegate() - Method in class io.vertx.reactivex.sqlclient.templates.RowMapper
 
getDelegate() - Method in class io.vertx.reactivex.sqlclient.templates.SqlTemplate
 
getDelegate() - Method in class io.vertx.reactivex.sqlclient.templates.TupleMapper
 
getDelegate() - Method in class io.vertx.reactivex.sqlclient.Transaction
 
getDelegate() - Method in class io.vertx.reactivex.sqlclient.Tuple
 
getDelegate() - Method in class io.vertx.reactivex.uritemplate.UriTemplate
 
getDelegate() - Method in class io.vertx.reactivex.uritemplate.Variables
 
getDescription() - Method in class io.vertx.reactivex.ext.mail.MailAttachment
get the description field
getDestination(String) - Method in class io.vertx.reactivex.ext.stomp.StompServerHandler
Gets the destination with the given name.
getDestinations() - Method in class io.vertx.reactivex.ext.stomp.StompServerHandler
 
getDisposition() - Method in class io.vertx.reactivex.ext.mail.MailAttachment
get the disposition field
getDouble() - Method in class io.vertx.reactivex.ext.web.validation.RequestParameter
 
getDouble() - Method in interface io.vertx.reactivex.openapi.validation.Parameter
 
getDouble() - Method in class io.vertx.reactivex.openapi.validation.RequestParameter
 
getDouble() - Method in class io.vertx.reactivex.openapi.validation.ResponseParameter
 
getDouble(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get a double value at pos.
getDouble(Double) - Method in interface io.vertx.reactivex.openapi.validation.Parameter
 
getDouble(Double) - Method in class io.vertx.reactivex.openapi.validation.RequestParameter
 
getDouble(Double) - Method in class io.vertx.reactivex.openapi.validation.ResponseParameter
 
getDouble(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get a double value for the given column.
getErrorMessage() - Method in class io.vertx.reactivex.ext.web.validation.RequestPredicateResult
Get error of failure
getex(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the value of a key and optionally set its expiration.
getExecutionInfo() - Method in class io.vertx.reactivex.cassandra.ResultSet
 
getFloat() - Method in class io.vertx.reactivex.ext.web.validation.RequestParameter
 
getFloat() - Method in interface io.vertx.reactivex.openapi.validation.Parameter
 
getFloat() - Method in class io.vertx.reactivex.openapi.validation.RequestParameter
 
getFloat() - Method in class io.vertx.reactivex.openapi.validation.ResponseParameter
 
getFloat(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get a float value at pos.
getFloat(Float) - Method in interface io.vertx.reactivex.openapi.validation.Parameter
 
getFloat(Float) - Method in class io.vertx.reactivex.openapi.validation.RequestParameter
 
getFloat(Float) - Method in class io.vertx.reactivex.openapi.validation.ResponseParameter
 
getFloat(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get a float value for the given column.
getFlows() - Method in class io.vertx.reactivex.openapi.contract.SecurityScheme
An object containing configuration information for the flow types supported.
getFormAttribute(String) - Method in class io.vertx.reactivex.core.http.HttpServerRequest
Return the first form attribute value with the specified name
getHeader(CharSequence) - Method in class io.vertx.reactivex.core.http.HttpClientResponse
Return the first header value with the specified name
getHeader(CharSequence) - Method in class io.vertx.reactivex.core.http.HttpRequestHead
Return the first header value with the specified name
getHeader(CharSequence) - Method in class io.vertx.reactivex.ext.web.client.HttpResponse
Return the first header value with the specified name
getHeader(String) - Method in class io.vertx.reactivex.core.http.HttpClientResponse
Return the first header value with the specified name
getHeader(String) - Method in class io.vertx.reactivex.core.http.HttpRequestHead
Return the first header value with the specified name
getHeader(String) - Method in interface io.vertx.reactivex.core.http.HttpResponseHead
Return the first header value with the specified name
getHeader(String) - Method in class io.vertx.reactivex.ext.web.client.HttpResponse
Return the first header value with the specified name
getHeaders() - Method in class io.vertx.reactivex.ext.mail.MailAttachment
Get the headers to be added for this attachment.
getHeaders() - Method in class io.vertx.reactivex.openapi.contract.Response
 
getHeaders() - Method in class io.vertx.reactivex.openapi.validation.ValidatableResponse
 
getHeaders() - Method in class io.vertx.reactivex.openapi.validation.ValidatedRequest
 
getHeaders() - Method in class io.vertx.reactivex.openapi.validation.ValidatedResponse
 
getHttpMethod() - Method in class io.vertx.reactivex.openapi.contract.Operation
 
getId() - Method in class io.vertx.reactivex.ext.auth.abac.PolicyBasedAuthorizationProvider
returns the id of the authorization provider
getId() - Method in interface io.vertx.reactivex.ext.auth.authorization.AuthorizationProvider
returns the id of the authorization provider
getId() - Method in class io.vertx.reactivex.ext.auth.jwt.authorization.JWTAuthorization
returns the id of the authorization provider
getId() - Method in class io.vertx.reactivex.ext.auth.jwt.authorization.MicroProfileAuthorization
returns the id of the authorization provider
getId() - Method in class io.vertx.reactivex.ext.auth.oauth2.authorization.KeycloakAuthorization
returns the id of the authorization provider
getId() - Method in class io.vertx.reactivex.ext.auth.oauth2.authorization.ScopeAuthorization
returns the id of the authorization provider
getId() - Method in class io.vertx.reactivex.ext.auth.properties.PropertyFileAuthorization
returns the id of the authorization provider
getId() - Method in class io.vertx.reactivex.ext.auth.sqlclient.SqlAuthorization
returns the id of the authorization provider
getIdentifier() - Method in class io.vertx.reactivex.openapi.contract.MediaType
 
getImplicit() - Method in class io.vertx.reactivex.openapi.contract.OAuthFlows
Configuration for the OAuth Implicit flow.
getIn() - Method in class io.vertx.reactivex.openapi.contract.Parameter
 
getIn() - Method in class io.vertx.reactivex.openapi.contract.SecurityScheme
The location of the API key.
getInteger() - Method in class io.vertx.reactivex.ext.web.validation.RequestParameter
 
getInteger() - Method in interface io.vertx.reactivex.openapi.validation.Parameter
 
getInteger() - Method in class io.vertx.reactivex.openapi.validation.RequestParameter
 
getInteger() - Method in class io.vertx.reactivex.openapi.validation.ResponseParameter
 
getInteger(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get an integer value at pos.
getInteger(Integer) - Method in interface io.vertx.reactivex.openapi.validation.Parameter
 
getInteger(Integer) - Method in class io.vertx.reactivex.openapi.validation.RequestParameter
 
getInteger(Integer) - Method in class io.vertx.reactivex.openapi.validation.ResponseParameter
 
getInteger(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get an integer value for the given column.
getInternalStatistics() - Method in class io.vertx.reactivex.mysqlclient.MySQLConnection
Send a STATISTICS command to get a human readable string of the server internal status.
getJson(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get a JSON element at pos, the element might be #JSON_NULL null or one of the following types: String Number JsonObject JsonArray Boolean
getJson(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get a JSON element for the given column, the element might be #JSON_NULL null or one of the following types: String Number JsonObject JsonArray Boolean
getJsonArray() - Method in class io.vertx.reactivex.ext.web.validation.RequestParameter
 
getJsonArray() - Method in interface io.vertx.reactivex.openapi.validation.Parameter
 
getJsonArray() - Method in class io.vertx.reactivex.openapi.validation.RequestParameter
 
getJsonArray() - Method in class io.vertx.reactivex.openapi.validation.ResponseParameter
 
getJsonArray(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get a value at pos.
getJsonArray(JsonArray) - Method in interface io.vertx.reactivex.openapi.validation.Parameter
 
getJsonArray(JsonArray) - Method in class io.vertx.reactivex.openapi.validation.RequestParameter
 
getJsonArray(JsonArray) - Method in class io.vertx.reactivex.openapi.validation.ResponseParameter
 
getJsonArray(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get a value for the given column.
getJsonObject() - Method in class io.vertx.reactivex.ext.web.validation.RequestParameter
Returns null if value is not a , otherwise it returns value
getJsonObject() - Method in interface io.vertx.reactivex.openapi.validation.Parameter
 
getJsonObject() - Method in class io.vertx.reactivex.openapi.validation.RequestParameter
 
getJsonObject() - Method in class io.vertx.reactivex.openapi.validation.ResponseParameter
 
getJsonObject(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get a value at pos.
getJsonObject(JsonObject) - Method in interface io.vertx.reactivex.openapi.validation.Parameter
 
getJsonObject(JsonObject) - Method in class io.vertx.reactivex.openapi.validation.RequestParameter
 
getJsonObject(JsonObject) - Method in class io.vertx.reactivex.openapi.validation.ResponseParameter
 
getJsonObject(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get a value for the given column.
getKeys(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the list of keys that corresponding to the specified key prefix.
getKeysWithOptions(String, BlockingQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the list of keys that corresponding to the specified key prefix.
getList(String) - Method in class io.vertx.reactivex.uritemplate.Variables
 
getLocalAsyncMap(String) - Method in class io.vertx.reactivex.core.shareddata.SharedData
Get the AsyncMap with the specified name.
getLocalCounter(String) - Method in class io.vertx.reactivex.core.shareddata.SharedData
Get an asynchronous local counter.
getLocalDate(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get LocalDate value at pos.
getLocalDate(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get LocalDate value for the given column.
getLocalDateTime(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get LocalDateTime value at pos.
getLocalDateTime(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get LocalDateTime value for the given column.
getLocalLock(String) - Method in class io.vertx.reactivex.core.shareddata.SharedData
Get an asynchronous local lock with the specified name.
getLocalLockWithTimeout(String, long) - Method in class io.vertx.reactivex.core.shareddata.SharedData
Like SharedData.getLocalLock(java.lang.String) but specifying a timeout.
getLocalMap(String) - Method in class io.vertx.reactivex.core.shareddata.SharedData
Return a LocalMap with the specific name.
getLocalTime(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get LocalTime value at pos.
getLocalTime(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get LocalTime value for the given column.
getLock(String) - Method in class io.vertx.reactivex.core.shareddata.SharedData
Get an asynchronous lock with the specified name.
getLockWithTimeout(String, long) - Method in class io.vertx.reactivex.core.shareddata.SharedData
Like SharedData.getLock(java.lang.String) but specifying a timeout.
getLong() - Method in class io.vertx.reactivex.ext.web.validation.RequestParameter
 
getLong() - Method in interface io.vertx.reactivex.openapi.validation.Parameter
 
getLong() - Method in class io.vertx.reactivex.openapi.validation.RequestParameter
 
getLong() - Method in class io.vertx.reactivex.openapi.validation.ResponseParameter
 
getLong(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get a long value at pos.
getLong(Long) - Method in interface io.vertx.reactivex.openapi.validation.Parameter
 
getLong(Long) - Method in class io.vertx.reactivex.openapi.validation.RequestParameter
 
getLong(Long) - Method in class io.vertx.reactivex.openapi.validation.ResponseParameter
 
getLong(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get a long value for the given column.
getMap(String) - Method in class io.vertx.reactivex.uritemplate.Variables
 
getMaxRedirects() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
 
getMetadata(String) - Method in class io.vertx.reactivex.ext.web.Route
Get some data from metadata.
getMetadata(String) - Method in class io.vertx.reactivex.ext.web.Router
Get some data from metadata.
getMethod() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
The HTTP method for the request.
getMetricsSnapshot() - Method in class io.vertx.reactivex.micrometer.MetricsService
Will return the metrics that correspond with the measured object, null if no metrics is available.
getMetricsSnapshot(Measured) - Method in class io.vertx.reactivex.ext.dropwizard.MetricsService
Will return the metrics that correspond with the measured object, null if no metrics is available.
getMetricsSnapshot(String) - Method in class io.vertx.reactivex.ext.dropwizard.MetricsService
Will return the metrics that begins with the baseName, null if no metrics is available.
getMetricsSnapshot(String) - Method in class io.vertx.reactivex.micrometer.MetricsService
Will return the metrics that begins with the baseName, null if no metrics is available.
getMongoClient(ServiceDiscovery, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.MongoDataSource
Convenient method that looks for a Mongo datasource source and provides the configured MongoClient.
getMongoClient(ServiceDiscovery, JsonObject, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.MongoDataSource
Convenient method that looks for a Mongo datasource source and provides the configured MongoClient.
getMongoClient(ServiceDiscovery, Function<Record, Boolean>) - Static method in class io.vertx.reactivex.servicediscovery.types.MongoDataSource
Convenient method that looks for a Mongo datasource source and provides the configured MongoClient.
getName() - Method in class io.vertx.reactivex.ext.mail.MailAttachment
get the name
getName() - Method in class io.vertx.reactivex.ext.web.Route
 
getName() - Method in class io.vertx.reactivex.openapi.contract.Parameter
 
getName() - Method in class io.vertx.reactivex.openapi.contract.Path
 
getName() - Method in class io.vertx.reactivex.openapi.contract.SecurityScheme
The name of the header, query or cookie parameter to be used.
getNames() - Method in class io.vertx.reactivex.openapi.contract.SecurityRequirement
Return the name at a given index
getNumeric(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get value at pos.
getNumeric(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get value for the given column.
getObjectParameter(Object, String, boolean) - Method in class io.vertx.reactivex.core.json.pointer.JsonPointerIterator
Returns the object parameter with specified key.
getOffsetDateTime(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get OffsetDateTime value at pos.
getOffsetDateTime(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get OffsetDateTime value for the given column.
getOffsetTime(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get OffsetTime value at pos.
getOffsetTime(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get OffsetTime value for the given column.
getOpenAPIPath() - Method in class io.vertx.reactivex.openapi.contract.Operation
 
getOpenIdConnectUrl() - Method in class io.vertx.reactivex.openapi.contract.SecurityScheme
OpenId Connect URL to discover OAuth2 configuration values.
getOperation() - Method in class io.vertx.reactivex.ext.web.openapi.router.OpenAPIRoute
 
getOperationId() - Method in class io.vertx.reactivex.openapi.contract.Operation
 
getOperations() - Method in class io.vertx.reactivex.openapi.contract.Path
 
getOrCreateDestination(String) - Method in class io.vertx.reactivex.ext.stomp.StompServerHandler
Gets a Destination object if existing, or create a new one.
getOrDefault(Object, V) - Method in class io.vertx.reactivex.core.shareddata.LocalMap
Returns the value to which the specified key is mapped, or defaultValue if this map contains no mapping for the key.
getOrDefault(String, T) - Method in class io.vertx.reactivex.ext.auth.User
Get a value from the user object.
getParam(String) - Method in class io.vertx.reactivex.core.http.HttpServerRequest
Return the first param value with the specified name
getParam(String, String) - Method in class io.vertx.reactivex.core.http.HttpServerRequest
Return the first param value with the specified name or defaultValue when the query param is not present
getParameters() - Method in class io.vertx.reactivex.openapi.contract.Operation
 
getParameters() - Method in class io.vertx.reactivex.openapi.contract.Path
 
getParamsCharset() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
 
getPassword() - Method in class io.vertx.reactivex.openapi.contract.OAuthFlows
Configuration for the OAuth Resource Owner Password flow
getPath() - Method in class io.vertx.reactivex.ext.web.Route
 
getPathParameters() - Method in class io.vertx.reactivex.openapi.validation.ValidatedRequest
 
getPaths() - Method in class io.vertx.reactivex.openapi.contract.OpenAPIContract
 
getPermission() - Method in class io.vertx.reactivex.ext.auth.authorization.PermissionBasedAuthorization
returns the value of the permission
getPermission() - Method in class io.vertx.reactivex.ext.auth.authorization.WildcardPermissionBasedAuthorization
return the value of the wildcard permission
getPreparedQuery(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns an existing prepared query
getQuery() - Method in class io.vertx.reactivex.openapi.validation.ValidatedRequest
 
getrange(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get a substring of the string stored at a key.
getRawContract() - Method in class io.vertx.reactivex.openapi.contract.OpenAPIContract
 
getRawMessage() - Method in class io.vertx.reactivex.ext.bridge.BaseBridgeEvent
Get the raw JSON message for the event.
getReadLength() - Method in class io.vertx.reactivex.core.file.AsyncFile
 
getRecord(JsonObject) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
Lookups for a single record.
getRecord(String) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
Looks up for a single record by its registration id.
getRecord(Function<Record, Boolean>) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
Lookups for a single record.
getRecord(Function<Record, Boolean>, boolean) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
Lookups for a single record.
getRecords(JsonObject) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
Lookups for a set of records.
getRecords(Function<Record, Boolean>) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
Lookups for a set of records.
getRecords(Function<Record, Boolean>, boolean) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
Lookups for a set of records.
getRedisClient(ServiceDiscovery, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.RedisDataSource
Convenient method that looks for a Redis data source and provides the configured Redis.
getRedisClient(ServiceDiscovery, JsonObject, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.RedisDataSource
Convenient method that looks for a Redis data source and provides the configured Redis.
getRedisClient(ServiceDiscovery, Function<Record, Boolean>) - Static method in class io.vertx.reactivex.servicediscovery.types.RedisDataSource
Convenient method that looks for a Redis data source and provides the configured Redis.
getRedisClient(ServiceDiscovery, Function<Record, Boolean>, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.RedisDataSource
Convenient method that looks for a Redis data source and provides the configured Redis.
getReference(Record) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
Gets a service reference from the given record.
getReferenceWithConfiguration(Record, JsonObject) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
Gets a service reference from the given record, the reference is configured with the given json object.
getRefreshUrl() - Method in class io.vertx.reactivex.openapi.contract.OAuthFlow
The URL to be used for obtaining refresh tokens.
getRequestBody() - Method in class io.vertx.reactivex.openapi.contract.Operation
 
getResource() - Method in class io.vertx.reactivex.ext.auth.authorization.PermissionBasedAuthorization
returns an optional resource that the permission is assigned-on
getResource() - Method in class io.vertx.reactivex.ext.auth.authorization.RoleBasedAuthorization
returns an optional resource that the role is assigned-on
getResource() - Method in class io.vertx.reactivex.ext.auth.authorization.WildcardPermissionBasedAuthorization
returns an optional resource that the permission is assigned-on
getResponse(int) - Method in class io.vertx.reactivex.openapi.contract.Operation
Returns the response to the passed response code or null.
getRole() - Method in class io.vertx.reactivex.ext.auth.authorization.RoleBasedAuthorization
returns the role
getRoute(String) - Method in class io.vertx.reactivex.ext.web.openapi.router.RouterBuilder
Access to a route defined in the contract with operationId
getRoutes() - Method in class io.vertx.reactivex.ext.web.openapi.router.RouterBuilder
 
getRoutes() - Method in class io.vertx.reactivex.ext.web.Router
 
getSchema() - Method in class io.vertx.reactivex.openapi.contract.MediaType
This method returns the schema defined in the media type.
getSchema() - Method in class io.vertx.reactivex.openapi.contract.Parameter
 
getSchemaRepository() - Method in class io.vertx.reactivex.openapi.contract.OpenAPIContract
 
getSchemaType() - Method in class io.vertx.reactivex.openapi.contract.Parameter
 
getScheme() - Method in class io.vertx.reactivex.openapi.contract.SecurityScheme
The name of the HTTP Authorization scheme to be used in the Authorization header as defined in [RFC7235].
getScopes() - Method in class io.vertx.reactivex.openapi.contract.OAuthFlow
The available scopes for the OAuth2 security scheme.
getScopes(String) - Method in class io.vertx.reactivex.openapi.contract.SecurityRequirement
Return the scopes for a given name
getSecurityRequirements() - Method in class io.vertx.reactivex.openapi.contract.OpenAPIContract
Returns the applicable list of global security requirements (scopes) or empty list.
getSecurityRequirements() - Method in class io.vertx.reactivex.openapi.contract.Operation
Returns the applicable list of security requirements (scopes) or empty list.
getServers() - Method in class io.vertx.reactivex.openapi.contract.OpenAPIContract
 
getServiceProxy(ServiceDiscovery, Function<Record, Boolean>, Class<T>) - Static method in class io.vertx.reactivex.servicediscovery.types.EventBusService
Lookup for a service record and if found, retrieve it and return the service object (used to consume the service).
getServiceProxy(ServiceDiscovery, Function<Record, Boolean>, Class<T>, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.EventBusService
Lookup for a service record and if found, retrieve it and return the service object (used to consume the service).
getServiceProxyWithJsonFilter(ServiceDiscovery, JsonObject, Class<T>) - Static method in class io.vertx.reactivex.servicediscovery.types.EventBusService
Lookup for a service record and if found, retrieve it and return the service object (used to consume the service).
getServiceProxyWithJsonFilter(ServiceDiscovery, JsonObject, Class<T>, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.EventBusService
Lookup for a service record and if found, retrieve it and return the service object (used to consume the service).
getset(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Deprecated.
getShort(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get a short value at pos.
getShort(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get a short value for the given column.
getSingle(String) - Method in class io.vertx.reactivex.uritemplate.Variables
 
getSize() - Method in class io.vertx.reactivex.ext.mail.MailAttachment
Gets the size of the attachment.
getStatusCode() - Method in class io.vertx.reactivex.core.http.HttpServerResponse
 
getStatusCode() - Method in class io.vertx.reactivex.openapi.validation.ValidatableResponse
 
getStatusMessage() - Method in class io.vertx.reactivex.core.http.HttpServerResponse
 
getStream() - Method in class io.vertx.reactivex.ext.mail.MailAttachment
Gets the data stream.
getStreamPriority() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
 
getString() - Method in class io.vertx.reactivex.ext.web.validation.RequestParameter
 
getString() - Method in interface io.vertx.reactivex.openapi.validation.Parameter
 
getString() - Method in class io.vertx.reactivex.openapi.validation.RequestParameter
 
getString() - Method in class io.vertx.reactivex.openapi.validation.ResponseParameter
 
getString(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get a string value at pos.
getString(String) - Method in interface io.vertx.reactivex.openapi.validation.Parameter
 
getString(String) - Method in class io.vertx.reactivex.openapi.validation.RequestParameter
 
getString(String) - Method in class io.vertx.reactivex.openapi.validation.ResponseParameter
 
getString(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get a string value for the given column.
getStyle() - Method in class io.vertx.reactivex.openapi.contract.Parameter
 
getSubRouter() - Method in class io.vertx.reactivex.ext.web.Route
 
getSubscriptions(StompServerConnection) - Method in class io.vertx.reactivex.ext.stomp.Destination
Gets all subscription ids for the given destination hold by the given client
getTags() - Method in class io.vertx.reactivex.openapi.contract.Operation
 
getTemporal(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get a Temporal value at pos.
getTemporal(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get a temporal value for the given column.
getTokenUrl() - Method in class io.vertx.reactivex.openapi.contract.OAuthFlow
The token URL to be used for this flow.
getTrailer(String) - Method in class io.vertx.reactivex.core.http.HttpClientResponse
Return the first trailer value with the specified name
getTrailer(String) - Method in class io.vertx.reactivex.ext.web.client.HttpResponse
Return the first trailer value with the specified name
getTransactionIsolation() - Method in class io.vertx.reactivex.jdbcclient.JDBCConnection
 
getType() - Method in class io.vertx.reactivex.openapi.contract.SecurityScheme
The type of the security scheme.
getURI() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
 
getURIWithoutFragment() - Method in class io.vertx.reactivex.core.json.pointer.JsonPointer
Return the underlying URI without the fragment
getURL() - Method in class io.vertx.reactivex.openapi.contract.Server
 
getUser() - Method in class io.vertx.reactivex.ext.web.client.OAuth2WebClient
Get the authenticated user (if any) that is associated with this client.
getUserBySession(String) - Method in class io.vertx.reactivex.ext.stomp.StompServerHandler
Provides for authorization matches on a destination level, this will return the User created by the .
getUUID(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get UUID value at pos.
getUUID(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get UUID value for the given column.
getValue(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
Get an object value at pos.
getValue(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns key/value pair that corresponding to the specified key.
getValue(String) - Method in class io.vertx.reactivex.sqlclient.Row
Get a value for the given column.
getValues(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the list of key/value pairs that corresponding to the specified key prefix.
getValuesWithOptions(String, BlockingQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the list of key/value pairs that corresponding to the specified key prefix.
getValueWithOptions(String, BlockingQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns key/value pair that corresponding to the specified key.
getVersion() - Method in class io.vertx.reactivex.openapi.contract.OpenAPIContract
 
getWebClient(ServiceDiscovery, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.HttpEndpoint
Convenient method that looks for a HTTP endpoint and provides the configured .
getWebClient(ServiceDiscovery, JsonObject, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.HttpEndpoint
Convenient method that looks for a HTTP endpoint and provides the configured .
getWebClient(ServiceDiscovery, Function<Record, Boolean>) - Static method in class io.vertx.reactivex.servicediscovery.types.HttpEndpoint
Convenient method that looks for a HTTP endpoint and provides the configured .
getWebClient(ServiceDiscovery, Function<Record, Boolean>, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.HttpEndpoint
Convenient method that looks for a HTTP endpoint and provides the configured .
getWindowSize() - Method in class io.vertx.reactivex.core.http.HttpConnection
 
getWithRegex(String) - Method in class io.vertx.reactivex.ext.web.Router
Add a route that matches a HTTP GET request and the specified path regex
getWritePos() - Method in class io.vertx.reactivex.core.file.AsyncFile
 
GiteeAuth - Class in io.vertx.reactivex.ext.auth.oauth2.providers
Simplified factory to create an for Gitee.
GiteeAuth(GiteeAuth) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.GiteeAuth
 
GiteeAuth(Object) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.GiteeAuth
 
GithubAuth - Class in io.vertx.reactivex.ext.auth.oauth2.providers
Simplified factory to create an for Github.
GithubAuth(GithubAuth) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.GithubAuth
 
GithubAuth(Object) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.GithubAuth
 
GitLabAuth - Class in io.vertx.reactivex.ext.auth.oauth2.providers
Simplified factory to create an for GitLab.com.
GitLabAuth(GitLabAuth) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.GitLabAuth
 
GitLabAuth(Object) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.GitLabAuth
 
goAway(long) - Method in class io.vertx.reactivex.core.http.HttpConnection
Like HttpConnection.goAway(long) with a last stream id -1 which means to disallow any new stream creation.
goAway(long, int) - Method in class io.vertx.reactivex.core.http.HttpConnection
Like HttpConnection.goAway(long) with no buffer.
goAway(long, int, Buffer) - Method in class io.vertx.reactivex.core.http.HttpConnection
Send a go away frame to the remote endpoint of the connection.
goAwayHandler(Handler<GoAway>) - Method in class io.vertx.reactivex.core.http.HttpConnection
Set an handler called when a frame is received.
GoogleAuth - Class in io.vertx.reactivex.ext.auth.oauth2.providers
Simplified factory to create an OAuth2Auth for Google.
GoogleAuth(GoogleAuth) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.GoogleAuth
 
GoogleAuth(Object) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.GoogleAuth
 
grantedQoSLevels() - Method in class io.vertx.reactivex.mqtt.messages.MqttSubAckMessage
 
graphBulk(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command GRAPH.BULK.
graphConfig(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command GRAPH.CONFIG.
graphDebug(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command GRAPH.DEBUG.
graphDelete(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command GRAPH.DELETE.
graphExplain(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command GRAPH.EXPLAIN.
GraphiQLHandler - Class in io.vertx.reactivex.ext.web.handler.graphql
A handler for GraphiQL resources.
GraphiQLHandler(GraphiQLHandler) - Constructor for class io.vertx.reactivex.ext.web.handler.graphql.GraphiQLHandler
 
GraphiQLHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.graphql.GraphiQLHandler
 
GraphiQLHandlerBuilder - Class in io.vertx.reactivex.ext.web.handler.graphql
A builder for GraphiQLHandler instances.
GraphiQLHandlerBuilder(GraphiQLHandlerBuilder) - Constructor for class io.vertx.reactivex.ext.web.handler.graphql.GraphiQLHandlerBuilder
 
GraphiQLHandlerBuilder(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.graphql.GraphiQLHandlerBuilder
 
graphList(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command GRAPH.LIST.
graphProfile(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command GRAPH.PROFILE.
GraphQLHandler - Class in io.vertx.reactivex.ext.web.handler.graphql
A Route handler for GraphQL requests.
GraphQLHandler(GraphQLHandler) - Constructor for class io.vertx.reactivex.ext.web.handler.graphql.GraphQLHandler
 
GraphQLHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.graphql.GraphQLHandler
 
GraphQLHandlerBuilder - Class in io.vertx.reactivex.ext.web.handler.graphql
A builder for GraphQLHandler instances.
GraphQLHandlerBuilder(GraphQLHandlerBuilder) - Constructor for class io.vertx.reactivex.ext.web.handler.graphql.GraphQLHandlerBuilder
 
GraphQLHandlerBuilder(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.graphql.GraphQLHandlerBuilder
 
GraphQLWSHandler - Class in io.vertx.reactivex.ext.web.handler.graphql.ws
GraphQLWSHandler(GraphQLWSHandler) - Constructor for class io.vertx.reactivex.ext.web.handler.graphql.ws.GraphQLWSHandler
 
GraphQLWSHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.graphql.ws.GraphQLWSHandler
 
GraphQLWSHandlerBuilder - Class in io.vertx.reactivex.ext.web.handler.graphql.ws
A builder for GraphQLWSHandler instances.
GraphQLWSHandlerBuilder(GraphQLWSHandlerBuilder) - Constructor for class io.vertx.reactivex.ext.web.handler.graphql.ws.GraphQLWSHandlerBuilder
 
GraphQLWSHandlerBuilder(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.graphql.ws.GraphQLWSHandlerBuilder
 
graphQuery(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command GRAPH.QUERY.
graphRoQuery(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command GRAPH.RO_QUERY.
graphSlowlog(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command GRAPH.SLOWLOG.
groupByNodes(List<Request>) - Method in class io.vertx.reactivex.redis.client.RedisCluster
Groups the requests into a RequestGrouping, which contains: keyed requests: requests that include a key and it is therefore possible to determine to which master node they should be sent; all requests in each inner list in the keyed collection are guaranteed to be sent to the same master node; unkeyed requests: requests that do not include a key and it is therefore not possible to determine to which master node they should be sent. If any of the requests includes multiple keys that belong to different master nodes, the resulting future will fail.
groupId() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
groupId(String) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
groupSequence() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
GrpcClient - Class in io.vertx.reactivex.grpc.client
A gRPC client for Vert.x
GrpcClient(GrpcClient) - Constructor for class io.vertx.reactivex.grpc.client.GrpcClient
 
GrpcClient(Object) - Constructor for class io.vertx.reactivex.grpc.client.GrpcClient
 
GrpcClientBuilder<C> - Class in io.vertx.reactivex.grpc.client
A builder for GrpcClient.
GrpcClientBuilder(GrpcClientBuilder) - Constructor for class io.vertx.reactivex.grpc.client.GrpcClientBuilder
 
GrpcClientBuilder(Object, TypeArg<C>) - Constructor for class io.vertx.reactivex.grpc.client.GrpcClientBuilder
 
GrpcClientRequest<Req,​Resp> - Class in io.vertx.reactivex.grpc.client
A request to a gRPC server.
GrpcClientRequest(GrpcClientRequest) - Constructor for class io.vertx.reactivex.grpc.client.GrpcClientRequest
 
GrpcClientRequest(Object, TypeArg<Req>, TypeArg<Resp>) - Constructor for class io.vertx.reactivex.grpc.client.GrpcClientRequest
 
GrpcClientResponse<Req,​Resp> - Class in io.vertx.reactivex.grpc.client
A response from a gRPC server.
GrpcClientResponse(GrpcClientResponse) - Constructor for class io.vertx.reactivex.grpc.client.GrpcClientResponse
 
GrpcClientResponse(Object, TypeArg<Req>, TypeArg<Resp>) - Constructor for class io.vertx.reactivex.grpc.client.GrpcClientResponse
 
GrpcReadStream<T> - Class in io.vertx.reactivex.grpc.common
 
GrpcReadStream(GrpcReadStream) - Constructor for class io.vertx.reactivex.grpc.common.GrpcReadStream
 
GrpcReadStream(Object, TypeArg<T>) - Constructor for class io.vertx.reactivex.grpc.common.GrpcReadStream
 
GrpcServer - Class in io.vertx.reactivex.grpc.server
A gRPC server based on Vert.x HTTP server.
GrpcServer(GrpcServer) - Constructor for class io.vertx.reactivex.grpc.server.GrpcServer
 
GrpcServer(Object) - Constructor for class io.vertx.reactivex.grpc.server.GrpcServer
 
GrpcServerRequest<Req,​Resp> - Class in io.vertx.reactivex.grpc.server
 
GrpcServerRequest(GrpcServerRequest) - Constructor for class io.vertx.reactivex.grpc.server.GrpcServerRequest
 
GrpcServerRequest(Object, TypeArg<Req>, TypeArg<Resp>) - Constructor for class io.vertx.reactivex.grpc.server.GrpcServerRequest
 
GrpcServerResponse<Req,​Resp> - Class in io.vertx.reactivex.grpc.server
 
GrpcServerResponse(GrpcServerResponse) - Constructor for class io.vertx.reactivex.grpc.server.GrpcServerResponse
 
GrpcServerResponse(Object, TypeArg<Req>, TypeArg<Resp>) - Constructor for class io.vertx.reactivex.grpc.server.GrpcServerResponse
 
GrpcWriteStream<T> - Class in io.vertx.reactivex.grpc.common
 
GrpcWriteStream(GrpcWriteStream) - Constructor for class io.vertx.reactivex.grpc.common.GrpcWriteStream
 
GrpcWriteStream(Object, TypeArg<T>) - Constructor for class io.vertx.reactivex.grpc.common.GrpcWriteStream
 

H

halfOpenHandler(Handler<Void>) - Method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
Sets a to be invoked when the circuit breaker state switches to half-open.
handle(AsyncResult<Boolean>) - Method in class io.vertx.reactivex.ext.bridge.BaseBridgeEvent
Succeed or fail this promise with the event.
handle(AsyncResult<Boolean>) - Method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.BridgeEvent
Succeed or fail this promise with the event.
handle(AsyncResult<Boolean>) - Method in class io.vertx.reactivex.ext.web.handler.sockjs.BridgeEvent
Succeed or fail this promise with the event.
handle(AsyncResult<Object>) - Method in class io.vertx.reactivex.ext.web.handler.graphql.ws.ConnectionInitEvent
Succeed or fail this promise with the event.
handle(Buffer) - Method in class io.vertx.reactivex.core.parsetools.JsonParser
Something has happened, so handle it.
handle(Buffer) - Method in class io.vertx.reactivex.core.parsetools.RecordParser
This method is called to provide the parser with data.
handle(HttpServerRequest) - Method in class io.vertx.reactivex.ext.web.Router
Something has happened, so handle it.
handle(HttpServerRequest) - Method in class io.vertx.reactivex.grpc.server.GrpcServer
Something has happened, so handle it.
handle(ServerFrame) - Method in class io.vertx.reactivex.ext.stomp.StompServerHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.APIKeyHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in interface io.vertx.reactivex.ext.web.handler.AuthenticationHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.AuthorizationHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.BasicAuthHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.BodyHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.ChainAuthHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.CorsHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.CSPHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.CSRFHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.DigestAuthHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.ErrorHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.FaviconHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.FormLoginHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.graphql.GraphQLHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.graphql.ws.GraphQLWSHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.HSTSHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in interface io.vertx.reactivex.ext.web.handler.InputTrustHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.JWTAuthHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.LoggerHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.MethodOverrideHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.MultiTenantHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.OAuth2AuthHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.OtpAuthHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in interface io.vertx.reactivex.ext.web.handler.PlatformHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in interface io.vertx.reactivex.ext.web.handler.ProtocolUpgradeHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.RedirectAuthHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.ResponseContentTypeHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.ResponseTimeHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.SecurityAuditLoggerHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in interface io.vertx.reactivex.ext.web.handler.SecurityPolicyHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.SessionHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.SimpleAuthenticationHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.StaticHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.TemplateHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.TimeoutHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.WebAuthn4JHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.XFrameHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in class io.vertx.reactivex.ext.web.healthchecks.HealthCheckHandler
Something has happened, so handle it.
handle(RoutingContext) - Method in class io.vertx.reactivex.ext.web.validation.ValidationHandler
Something has happened, so handle it.
HandlebarsTemplateEngine - Class in io.vertx.reactivex.ext.web.templ.handlebars
A template engine that uses the Handlebars library.
HandlebarsTemplateEngine(HandlebarsTemplateEngine) - Constructor for class io.vertx.reactivex.ext.web.templ.handlebars.HandlebarsTemplateEngine
 
HandlebarsTemplateEngine(Object) - Constructor for class io.vertx.reactivex.ext.web.templ.handlebars.HandlebarsTemplateEngine
 
handleContext(RoutingContext) - Method in class io.vertx.reactivex.ext.web.Router
Used to route a context to the router.
handleFailure(RoutingContext) - Method in class io.vertx.reactivex.ext.web.Router
Used to route a failure to the router.
handler() - Method in class io.vertx.reactivex.ext.stomp.StompServerConnection
 
handler(Handler<Row>) - Method in class io.vertx.reactivex.cassandra.CassandraRowStream
 
handler(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.unit.Async
Completion handler to receive a completion signal when this completions completes.
handler(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.unit.TestCompletion
Completion handler to receive a completion signal when this completions completes.
handler(Handler<AsyncResult<T>>) - Method in class io.vertx.reactivex.ext.unit.Completion
Completion handler to receive a completion signal when this completions completes.
handler(Handler<Buffer>) - Method in class io.vertx.reactivex.core.file.AsyncFile
 
handler(Handler<Buffer>) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
 
handler(Handler<Buffer>) - Method in class io.vertx.reactivex.core.http.HttpClientResponse
 
handler(Handler<Buffer>) - Method in class io.vertx.reactivex.core.http.HttpServerFileUpload
 
handler(Handler<Buffer>) - Method in class io.vertx.reactivex.core.http.HttpServerRequest
 
handler(Handler<Buffer>) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
 
handler(Handler<Buffer>) - Method in class io.vertx.reactivex.core.http.WebSocket
 
handler(Handler<Buffer>) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
 
handler(Handler<Buffer>) - Method in class io.vertx.reactivex.core.net.NetSocket
 
handler(Handler<Buffer>) - Method in class io.vertx.reactivex.core.parsetools.RecordParser
 
handler(Handler<Buffer>) - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
 
handler(Handler<DatagramPacket>) - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
 
handler(Handler<JsonEvent>) - Method in class io.vertx.reactivex.core.parsetools.JsonParser
 
handler(Handler<AmqpMessage>) - Method in class io.vertx.reactivex.amqp.AmqpReceiver
 
handler(Handler<Message<T>>) - Method in class io.vertx.reactivex.core.eventbus.MessageConsumer
 
handler(Handler<TestCaseReport>) - Method in class io.vertx.reactivex.ext.unit.report.TestSuiteReport
 
handler(Handler<RoutingContext>) - Method in class io.vertx.reactivex.ext.web.Route
Append a request handler to the route handlers list.
handler(Handler<KafkaConsumerRecord<K, V>>) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
 
handler(Handler<RabbitMQMessage>) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQConsumer
Set a message handler.
handler(Handler<Response>) - Method in class io.vertx.reactivex.redis.client.RedisConnection
 
handler(Handler<String>) - Method in class io.vertx.reactivex.pgclient.pubsub.PgChannel
Set or unset an handler to be called when a the channel is notified by Postgres.
handler(Handler<Req>) - Method in class io.vertx.reactivex.grpc.server.GrpcServerRequest
 
handler(Handler<Resp>) - Method in class io.vertx.reactivex.grpc.client.GrpcClientResponse
 
handler(Handler<T>) - Method in interface io.vertx.reactivex.core.streams.ReadStream
Set a data handler.
handler(Handler<T>) - Method in class io.vertx.reactivex.grpc.common.GrpcReadStream
 
handler(Handler<T>) - Method in class io.vertx.reactivex.sqlclient.RowStream
 
handler(StompServerHandler) - Method in class io.vertx.reactivex.ext.stomp.StompServer
Configures the StompServerHandler.
handleReceipt(Frame, StompServerConnection) - Static method in class io.vertx.reactivex.ext.stomp.Frames
 
has(String, Object) - Static method in class io.vertx.reactivex.ext.auth.abac.Attribute
Verifies whether the attribute matches the specified.
hasAmr(String) - Method in class io.vertx.reactivex.ext.auth.User
The "amr" (Authentication Methods References) returns a unique list of claims as defined and registered in the IANA "JSON Web Token Claims" registry.
hash(String, String, String) - Method in class io.vertx.reactivex.ext.auth.sqlclient.SqlAuthentication
Hashes a password to be stored.
hash(String, Map<String, String>, String, String) - Method in class io.vertx.reactivex.ext.auth.hashing.HashingStrategy
Hashes a password.
hash(String, Map<String, String>, String, String) - Method in class io.vertx.reactivex.ext.auth.sqlclient.SqlAuthentication
Hashes a password to be stored.
hashCode() - Method in class io.vertx.reactivex.amqp.AmqpClient
 
hashCode() - Method in class io.vertx.reactivex.amqp.AmqpConnection
 
hashCode() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
hashCode() - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
hashCode() - Method in class io.vertx.reactivex.amqp.AmqpReceiver
 
hashCode() - Method in class io.vertx.reactivex.amqp.AmqpSender
 
hashCode() - Method in class io.vertx.reactivex.cassandra.CassandraClient
 
hashCode() - Method in class io.vertx.reactivex.cassandra.CassandraRowStream
 
hashCode() - Method in class io.vertx.reactivex.cassandra.ResultSet
 
hashCode() - Method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
 
hashCode() - Method in class io.vertx.reactivex.circuitbreaker.FailurePolicy
 
hashCode() - Method in class io.vertx.reactivex.circuitbreaker.RetryPolicy
 
hashCode() - Method in class io.vertx.reactivex.config.ConfigRetriever
 
hashCode() - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
 
hashCode() - Method in class io.vertx.reactivex.core.dns.DnsClient
 
hashCode() - Method in class io.vertx.reactivex.core.eventbus.DeliveryContext
 
hashCode() - Method in class io.vertx.reactivex.core.eventbus.EventBus
 
hashCode() - Method in class io.vertx.reactivex.core.eventbus.Message
 
hashCode() - Method in class io.vertx.reactivex.core.eventbus.MessageConsumer
 
hashCode() - Method in class io.vertx.reactivex.core.eventbus.MessageProducer
 
hashCode() - Method in class io.vertx.reactivex.core.file.AsyncFile
 
hashCode() - Method in class io.vertx.reactivex.core.file.AsyncFileLock
 
hashCode() - Method in class io.vertx.reactivex.core.file.FileSystem
 
hashCode() - Method in class io.vertx.reactivex.core.http.ClientWebSocket
 
hashCode() - Method in class io.vertx.reactivex.core.http.HttpClientAgent
 
hashCode() - Method in class io.vertx.reactivex.core.http.HttpClientBuilder
 
hashCode() - Method in class io.vertx.reactivex.core.http.HttpClientConnection
 
hashCode() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
 
hashCode() - Method in class io.vertx.reactivex.core.http.HttpClientResponse
 
hashCode() - Method in class io.vertx.reactivex.core.http.HttpConnection
 
hashCode() - Method in class io.vertx.reactivex.core.http.HttpHeaders
 
hashCode() - Method in class io.vertx.reactivex.core.http.HttpRequestHead
 
hashCode() - Method in class io.vertx.reactivex.core.http.HttpServer
 
hashCode() - Method in class io.vertx.reactivex.core.http.HttpServerFileUpload
 
hashCode() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
 
hashCode() - Method in class io.vertx.reactivex.core.http.HttpServerResponse
 
hashCode() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
 
hashCode() - Method in class io.vertx.reactivex.core.http.ServerWebSocketHandshake
 
hashCode() - Method in class io.vertx.reactivex.core.http.WebSocket
 
hashCode() - Method in class io.vertx.reactivex.core.http.WebSocketClient
 
hashCode() - Method in class io.vertx.reactivex.core.json.pointer.JsonPointer
 
hashCode() - Method in class io.vertx.reactivex.core.json.pointer.JsonPointerIterator
 
hashCode() - Method in class io.vertx.reactivex.core.net.endpoint.Endpoint
 
hashCode() - Method in class io.vertx.reactivex.core.net.endpoint.EndpointResolver
 
hashCode() - Method in class io.vertx.reactivex.core.net.endpoint.ServerEndpoint
 
hashCode() - Method in class io.vertx.reactivex.core.net.endpoint.ServerInteraction
 
hashCode() - Method in class io.vertx.reactivex.core.net.NetClient
 
hashCode() - Method in class io.vertx.reactivex.core.net.NetServer
 
hashCode() - Method in class io.vertx.reactivex.core.net.NetSocket
 
hashCode() - Method in class io.vertx.reactivex.core.parsetools.JsonParser
 
hashCode() - Method in class io.vertx.reactivex.core.parsetools.RecordParser
 
hashCode() - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
 
hashCode() - Method in class io.vertx.reactivex.core.shareddata.Counter
 
hashCode() - Method in class io.vertx.reactivex.core.shareddata.LocalMap
 
hashCode() - Method in class io.vertx.reactivex.core.shareddata.Lock
 
hashCode() - Method in class io.vertx.reactivex.core.shareddata.SharedData
 
hashCode() - Method in class io.vertx.reactivex.core.streams.Pipe
 
hashCode() - Method in class io.vertx.reactivex.db2client.DB2Builder
 
hashCode() - Method in class io.vertx.reactivex.db2client.DB2Connection
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.abac.Attribute
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.abac.PolicyBasedAuthorizationProvider
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.audit.SecurityAudit
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.authentication.AuthenticationProvider
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.authorization.AndAuthorization
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.authorization.AuthorizationContext
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.authorization.Authorizations
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.authorization.NotAuthorization
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.authorization.OrAuthorization
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.authorization.PermissionBasedAuthorization
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.authorization.RoleBasedAuthorization
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.authorization.WildcardPermissionBasedAuthorization
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.ChainAuth
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.hashing.HashingAlgorithm
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.hashing.HashingStrategy
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.htdigest.HtdigestAuth
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.htpasswd.HtpasswdAuth
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.jwt.authorization.JWTAuthorization
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.jwt.authorization.MicroProfileAuthorization
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.jwt.JWTAuth
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.ldap.LdapAuthentication
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.oauth2.authorization.KeycloakAuthorization
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.oauth2.authorization.ScopeAuthorization
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.AmazonCognitoAuth
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.AppleIdAuth
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.AzureADAuth
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.BoxAuth
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.CloudFoundryAuth
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.DropboxAuth
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.FacebookAuth
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.FoursquareAuth
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.GiteeAuth
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.GithubAuth
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.GitLabAuth
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.GoogleAuth
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.HerokuAuth
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.IBMCloudAuth
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.InstagramAuth
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.KeycloakAuth
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.LinkedInAuth
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.LiveAuth
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.MailchimpAuth
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.OpenIDConnectAuth
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.SalesforceAuth
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.ShopifyAuth
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.SoundcloudAuth
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.StripeAuth
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.TwitterAuth
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.otp.hotp.HotpAuth
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.otp.OtpKeyGenerator
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.otp.totp.TotpAuth
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.prng.VertxContextPRNG
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.properties.PropertyFileAuthentication
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.properties.PropertyFileAuthorization
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.sqlclient.SqlAuthentication
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.sqlclient.SqlAuthorization
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.sqlclient.SqlUserUtil
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.User
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.webauthn4j.CredentialStorage
 
hashCode() - Method in class io.vertx.reactivex.ext.auth.webauthn4j.WebAuthn4J
 
hashCode() - Method in class io.vertx.reactivex.ext.bridge.BaseBridgeEvent
 
hashCode() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
 
hashCode() - Method in class io.vertx.reactivex.ext.consul.Watch
 
hashCode() - Method in class io.vertx.reactivex.ext.consul.WatchResult
 
hashCode() - Method in class io.vertx.reactivex.ext.dropwizard.MetricsService
 
hashCode() - Method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.BridgeEvent
 
hashCode() - Method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.TcpEventBusBridge
 
hashCode() - Method in class io.vertx.reactivex.ext.healthchecks.HealthChecks
 
hashCode() - Method in class io.vertx.reactivex.ext.mail.MailAttachment
 
hashCode() - Method in class io.vertx.reactivex.ext.mail.MailClient
 
hashCode() - Method in class io.vertx.reactivex.ext.mongo.MongoClient
 
hashCode() - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
 
hashCode() - Method in class io.vertx.reactivex.ext.stomp.Acknowledgement
 
hashCode() - Method in class io.vertx.reactivex.ext.stomp.Destination
 
hashCode() - Method in class io.vertx.reactivex.ext.stomp.DestinationFactory
 
hashCode() - Method in class io.vertx.reactivex.ext.stomp.Frames
 
hashCode() - Method in class io.vertx.reactivex.ext.stomp.ServerFrame
 
hashCode() - Method in class io.vertx.reactivex.ext.stomp.StompClient
 
hashCode() - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
 
hashCode() - Method in class io.vertx.reactivex.ext.stomp.StompServer
 
hashCode() - Method in class io.vertx.reactivex.ext.stomp.StompServerConnection
 
hashCode() - Method in class io.vertx.reactivex.ext.stomp.StompServerHandler
 
hashCode() - Method in class io.vertx.reactivex.ext.unit.Async
 
hashCode() - Method in class io.vertx.reactivex.ext.unit.collect.EventBusCollector
 
hashCode() - Method in class io.vertx.reactivex.ext.unit.Completion
 
hashCode() - Method in class io.vertx.reactivex.ext.unit.report.Failure
 
hashCode() - Method in class io.vertx.reactivex.ext.unit.report.TestCaseReport
 
hashCode() - Method in class io.vertx.reactivex.ext.unit.report.TestResult
 
hashCode() - Method in class io.vertx.reactivex.ext.unit.report.TestSuiteReport
 
hashCode() - Method in class io.vertx.reactivex.ext.unit.TestCase
 
hashCode() - Method in class io.vertx.reactivex.ext.unit.TestCompletion
 
hashCode() - Method in class io.vertx.reactivex.ext.unit.TestContext
 
hashCode() - Method in class io.vertx.reactivex.ext.unit.TestSuite
 
hashCode() - Method in class io.vertx.reactivex.ext.web.client.CachingWebClient
 
hashCode() - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
 
hashCode() - Method in class io.vertx.reactivex.ext.web.client.HttpResponse
 
hashCode() - Method in class io.vertx.reactivex.ext.web.client.OAuth2WebClient
 
hashCode() - Method in class io.vertx.reactivex.ext.web.client.WebClient
 
hashCode() - Method in class io.vertx.reactivex.ext.web.client.WebClientSession
 
hashCode() - Method in class io.vertx.reactivex.ext.web.codec.BodyCodec
 
hashCode() - Method in class io.vertx.reactivex.ext.web.common.template.TemplateEngine
 
hashCode() - Method in class io.vertx.reactivex.ext.web.common.WebEnvironment
 
hashCode() - Method in class io.vertx.reactivex.ext.web.FileUpload
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.APIKeyHandler
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.AuthorizationHandler
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.BasicAuthHandler
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.BodyHandler
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.ChainAuthHandler
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.CorsHandler
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.CSPHandler
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.CSRFHandler
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.DigestAuthHandler
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.ErrorHandler
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.FaviconHandler
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.FormLoginHandler
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.graphql.ExecutionInputBuilderWithContext
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.graphql.GraphiQLHandler
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.graphql.GraphiQLHandlerBuilder
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.graphql.GraphQLHandler
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.graphql.GraphQLHandlerBuilder
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.graphql.UploadScalar
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.graphql.ws.ConnectionInitEvent
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.graphql.ws.GraphQLWSHandler
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.graphql.ws.GraphQLWSHandlerBuilder
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.graphql.ws.Message
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.HSTSHandler
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.JWTAuthHandler
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.LoggerFormatter
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.LoggerHandler
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.MethodOverrideHandler
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.MultiTenantHandler
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.OAuth2AuthHandler
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.OtpAuthHandler
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.RedirectAuthHandler
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.ResponseContentTypeHandler
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.ResponseTimeHandler
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.SecurityAuditLoggerHandler
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.SessionHandler
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.SimpleAuthenticationHandler
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.sockjs.BridgeEvent
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSHandler
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.StaticHandler
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.TemplateHandler
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.TimeoutHandler
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.WebAuthn4JHandler
 
hashCode() - Method in class io.vertx.reactivex.ext.web.handler.XFrameHandler
 
hashCode() - Method in class io.vertx.reactivex.ext.web.healthchecks.HealthCheckHandler
 
hashCode() - Method in class io.vertx.reactivex.ext.web.LanguageHeader
 
hashCode() - Method in class io.vertx.reactivex.ext.web.MIMEHeader
 
hashCode() - Method in class io.vertx.reactivex.ext.web.multipart.FormDataPart
 
hashCode() - Method in class io.vertx.reactivex.ext.web.multipart.MultipartForm
 
hashCode() - Method in class io.vertx.reactivex.ext.web.openapi.router.OpenAPIRoute
 
hashCode() - Method in class io.vertx.reactivex.ext.web.openapi.router.RequestExtractor
 
hashCode() - Method in class io.vertx.reactivex.ext.web.openapi.router.RouterBuilder
 
hashCode() - Method in class io.vertx.reactivex.ext.web.openapi.router.Security
 
hashCode() - Method in class io.vertx.reactivex.ext.web.ParsedHeaderValues
 
hashCode() - Method in class io.vertx.reactivex.ext.web.RequestBody
 
hashCode() - Method in class io.vertx.reactivex.ext.web.Route
 
hashCode() - Method in class io.vertx.reactivex.ext.web.Router
 
hashCode() - Method in class io.vertx.reactivex.ext.web.RoutingContext
 
hashCode() - Method in class io.vertx.reactivex.ext.web.Session
 
hashCode() - Method in class io.vertx.reactivex.ext.web.sstore.ClusteredSessionStore
 
hashCode() - Method in class io.vertx.reactivex.ext.web.sstore.cookie.CookieSessionStore
 
hashCode() - Method in class io.vertx.reactivex.ext.web.sstore.infinispan.InfinispanSessionStore
 
hashCode() - Method in class io.vertx.reactivex.ext.web.sstore.LocalSessionStore
 
hashCode() - Method in class io.vertx.reactivex.ext.web.sstore.redis.RedisSessionStore
 
hashCode() - Method in class io.vertx.reactivex.ext.web.sstore.SessionStore
 
hashCode() - Method in class io.vertx.reactivex.ext.web.templ.freemarker.FreeMarkerTemplateEngine
 
hashCode() - Method in class io.vertx.reactivex.ext.web.templ.handlebars.HandlebarsTemplateEngine
 
hashCode() - Method in class io.vertx.reactivex.ext.web.templ.mvel.MVELTemplateEngine
 
hashCode() - Method in class io.vertx.reactivex.ext.web.templ.pebble.PebbleTemplateEngine
 
hashCode() - Method in class io.vertx.reactivex.ext.web.templ.pug.PugTemplateEngine
 
hashCode() - Method in class io.vertx.reactivex.ext.web.templ.rocker.RockerTemplateEngine
 
hashCode() - Method in class io.vertx.reactivex.ext.web.templ.thymeleaf.ThymeleafTemplateEngine
 
hashCode() - Method in class io.vertx.reactivex.ext.web.UserContext
 
hashCode() - Method in class io.vertx.reactivex.ext.web.validation.builder.ArrayParserFactory
 
hashCode() - Method in class io.vertx.reactivex.ext.web.validation.builder.Bodies
 
hashCode() - Method in class io.vertx.reactivex.ext.web.validation.builder.BodyProcessorFactory
 
hashCode() - Method in class io.vertx.reactivex.ext.web.validation.builder.ObjectParserFactory
 
hashCode() - Method in class io.vertx.reactivex.ext.web.validation.builder.ParameterProcessorFactory
 
hashCode() - Method in class io.vertx.reactivex.ext.web.validation.builder.Parameters
 
hashCode() - Method in class io.vertx.reactivex.ext.web.validation.builder.Parsers
 
hashCode() - Method in class io.vertx.reactivex.ext.web.validation.builder.StyledParameterProcessorFactory
 
hashCode() - Method in class io.vertx.reactivex.ext.web.validation.builder.TupleParserFactory
 
hashCode() - Method in class io.vertx.reactivex.ext.web.validation.builder.ValidationHandlerBuilder
 
hashCode() - Method in class io.vertx.reactivex.ext.web.validation.RequestParameter
 
hashCode() - Method in class io.vertx.reactivex.ext.web.validation.RequestParameters
 
hashCode() - Method in class io.vertx.reactivex.ext.web.validation.RequestPredicate
 
hashCode() - Method in class io.vertx.reactivex.ext.web.validation.RequestPredicateResult
 
hashCode() - Method in class io.vertx.reactivex.ext.web.validation.ValidationHandler
 
hashCode() - Method in class io.vertx.reactivex.grpc.client.GrpcClient
 
hashCode() - Method in class io.vertx.reactivex.grpc.client.GrpcClientBuilder
 
hashCode() - Method in class io.vertx.reactivex.grpc.client.GrpcClientRequest
 
hashCode() - Method in class io.vertx.reactivex.grpc.client.GrpcClientResponse
 
hashCode() - Method in class io.vertx.reactivex.grpc.common.GrpcReadStream
 
hashCode() - Method in class io.vertx.reactivex.grpc.common.GrpcWriteStream
 
hashCode() - Method in class io.vertx.reactivex.grpc.server.GrpcServer
 
hashCode() - Method in class io.vertx.reactivex.grpc.server.GrpcServerRequest
 
hashCode() - Method in class io.vertx.reactivex.grpc.server.GrpcServerResponse
 
hashCode() - Method in class io.vertx.reactivex.jdbcclient.JDBCConnection
 
hashCode() - Method in class io.vertx.reactivex.jdbcclient.JDBCPool
 
hashCode() - Method in class io.vertx.reactivex.jdbcclient.SqlOutParam
 
hashCode() - Method in class io.vertx.reactivex.json.schema.JsonFormatValidator
 
hashCode() - Method in class io.vertx.reactivex.json.schema.JsonSchema
 
hashCode() - Method in class io.vertx.reactivex.json.schema.Ref
 
hashCode() - Method in class io.vertx.reactivex.json.schema.SchemaRepository
 
hashCode() - Method in class io.vertx.reactivex.json.schema.Validator
 
hashCode() - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
 
hashCode() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
 
hashCode() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumerRecord
 
hashCode() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumerRecords
 
hashCode() - Method in class io.vertx.reactivex.kafka.client.producer.KafkaHeader
 
hashCode() - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
 
hashCode() - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducerRecord
 
hashCode() - Method in class io.vertx.reactivex.micrometer.MetricsService
 
hashCode() - Method in class io.vertx.reactivex.micrometer.PrometheusRequestHandler
 
hashCode() - Method in class io.vertx.reactivex.micrometer.PrometheusScrapingHandler
 
hashCode() - Method in class io.vertx.reactivex.mqtt.messages.MqttAuthenticationExchangeMessage
 
hashCode() - Method in class io.vertx.reactivex.mqtt.messages.MqttConnAckMessage
 
hashCode() - Method in class io.vertx.reactivex.mqtt.messages.MqttDisconnectMessage
 
hashCode() - Method in class io.vertx.reactivex.mqtt.messages.MqttPubAckMessage
 
hashCode() - Method in class io.vertx.reactivex.mqtt.messages.MqttPubCompMessage
 
hashCode() - Method in class io.vertx.reactivex.mqtt.messages.MqttPublishMessage
 
hashCode() - Method in class io.vertx.reactivex.mqtt.messages.MqttPubRecMessage
 
hashCode() - Method in class io.vertx.reactivex.mqtt.messages.MqttPubRelMessage
 
hashCode() - Method in class io.vertx.reactivex.mqtt.messages.MqttSubAckMessage
 
hashCode() - Method in class io.vertx.reactivex.mqtt.messages.MqttSubscribeMessage
 
hashCode() - Method in class io.vertx.reactivex.mqtt.messages.MqttUnsubscribeMessage
 
hashCode() - Method in class io.vertx.reactivex.mqtt.MqttClient
 
hashCode() - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
 
hashCode() - Method in class io.vertx.reactivex.mqtt.MqttServer
 
hashCode() - Method in class io.vertx.reactivex.mqtt.MqttTopicSubscription
 
hashCode() - Method in class io.vertx.reactivex.mssqlclient.MSSQLBuilder
 
hashCode() - Method in class io.vertx.reactivex.mssqlclient.MSSQLConnection
 
hashCode() - Method in class io.vertx.reactivex.mysqlclient.MySQLBuilder
 
hashCode() - Method in class io.vertx.reactivex.mysqlclient.MySQLClient
 
hashCode() - Method in class io.vertx.reactivex.mysqlclient.MySQLConnection
 
hashCode() - Method in class io.vertx.reactivex.openapi.contract.MediaType
 
hashCode() - Method in class io.vertx.reactivex.openapi.contract.OAuthFlow
 
hashCode() - Method in class io.vertx.reactivex.openapi.contract.OAuthFlows
 
hashCode() - Method in class io.vertx.reactivex.openapi.contract.OpenAPIContract
 
hashCode() - Method in class io.vertx.reactivex.openapi.contract.Operation
 
hashCode() - Method in class io.vertx.reactivex.openapi.contract.Parameter
 
hashCode() - Method in class io.vertx.reactivex.openapi.contract.Path
 
hashCode() - Method in class io.vertx.reactivex.openapi.contract.RequestBody
 
hashCode() - Method in class io.vertx.reactivex.openapi.contract.Response
 
hashCode() - Method in class io.vertx.reactivex.openapi.contract.SecurityRequirement
 
hashCode() - Method in class io.vertx.reactivex.openapi.contract.SecurityScheme
 
hashCode() - Method in class io.vertx.reactivex.openapi.contract.Server
 
hashCode() - Method in class io.vertx.reactivex.openapi.validation.RequestParameter
 
hashCode() - Method in class io.vertx.reactivex.openapi.validation.RequestValidator
 
hashCode() - Method in class io.vertx.reactivex.openapi.validation.ResponseParameter
 
hashCode() - Method in class io.vertx.reactivex.openapi.validation.ValidatableRequest
 
hashCode() - Method in class io.vertx.reactivex.openapi.validation.ValidatableResponse
 
hashCode() - Method in class io.vertx.reactivex.openapi.validation.ValidatedRequest
 
hashCode() - Method in class io.vertx.reactivex.openapi.validation.ValidatedResponse
 
hashCode() - Method in class io.vertx.reactivex.oracleclient.OracleBuilder
 
hashCode() - Method in class io.vertx.reactivex.oracleclient.OracleClient
 
hashCode() - Method in class io.vertx.reactivex.oracleclient.OracleConnection
 
hashCode() - Method in class io.vertx.reactivex.pgclient.PgBuilder
 
hashCode() - Method in class io.vertx.reactivex.pgclient.PgConnection
 
hashCode() - Method in class io.vertx.reactivex.pgclient.pubsub.PgChannel
 
hashCode() - Method in class io.vertx.reactivex.pgclient.pubsub.PgSubscriber
 
hashCode() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
 
hashCode() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQConsumer
 
hashCode() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQMessage
 
hashCode() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQPublisher
 
hashCode() - Method in class io.vertx.reactivex.redis.client.Redis
 
hashCode() - Method in class io.vertx.reactivex.redis.client.RedisAPI
 
hashCode() - Method in class io.vertx.reactivex.redis.client.RedisCluster
 
hashCode() - Method in class io.vertx.reactivex.redis.client.RedisConnection
 
hashCode() - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
 
hashCode() - Method in class io.vertx.reactivex.servicediscovery.ServiceReference
 
hashCode() - Method in class io.vertx.reactivex.servicediscovery.spi.ServiceExporter
 
hashCode() - Method in class io.vertx.reactivex.servicediscovery.spi.ServiceImporter
 
hashCode() - Method in class io.vertx.reactivex.servicediscovery.spi.ServicePublisher
 
hashCode() - Method in class io.vertx.reactivex.servicediscovery.types.EventBusService
 
hashCode() - Method in class io.vertx.reactivex.servicediscovery.types.HttpEndpoint
 
hashCode() - Method in class io.vertx.reactivex.servicediscovery.types.MessageSource
 
hashCode() - Method in class io.vertx.reactivex.servicediscovery.types.MongoDataSource
 
hashCode() - Method in class io.vertx.reactivex.servicediscovery.types.RedisDataSource
 
hashCode() - Method in class io.vertx.reactivex.sqlclient.ClientBuilder
 
hashCode() - Method in class io.vertx.reactivex.sqlclient.Cursor
 
hashCode() - Method in class io.vertx.reactivex.sqlclient.desc.ColumnDescriptor
 
hashCode() - Method in class io.vertx.reactivex.sqlclient.Pool
 
hashCode() - Method in class io.vertx.reactivex.sqlclient.PreparedQuery
 
hashCode() - Method in class io.vertx.reactivex.sqlclient.PreparedStatement
 
hashCode() - Method in class io.vertx.reactivex.sqlclient.PropertyKind
 
hashCode() - Method in class io.vertx.reactivex.sqlclient.Query
 
hashCode() - Method in class io.vertx.reactivex.sqlclient.Row
 
hashCode() - Method in class io.vertx.reactivex.sqlclient.RowIterator
 
hashCode() - Method in class io.vertx.reactivex.sqlclient.RowSet
 
hashCode() - Method in class io.vertx.reactivex.sqlclient.RowStream
 
hashCode() - Method in class io.vertx.reactivex.sqlclient.spi.DatabaseMetadata
 
hashCode() - Method in class io.vertx.reactivex.sqlclient.SqlClient
 
hashCode() - Method in class io.vertx.reactivex.sqlclient.SqlConnection
 
hashCode() - Method in class io.vertx.reactivex.sqlclient.SqlResult
 
hashCode() - Method in class io.vertx.reactivex.sqlclient.templates.RowMapper
 
hashCode() - Method in class io.vertx.reactivex.sqlclient.templates.SqlTemplate
 
hashCode() - Method in class io.vertx.reactivex.sqlclient.templates.TupleMapper
 
hashCode() - Method in class io.vertx.reactivex.sqlclient.Transaction
 
hashCode() - Method in class io.vertx.reactivex.sqlclient.Tuple
 
hashCode() - Method in class io.vertx.reactivex.uritemplate.UriTemplate
 
hashCode() - Method in class io.vertx.reactivex.uritemplate.Variables
 
HashingAlgorithm - Class in io.vertx.reactivex.ext.auth.hashing
Hashing Algorithm.
HashingAlgorithm(HashingAlgorithm) - Constructor for class io.vertx.reactivex.ext.auth.hashing.HashingAlgorithm
 
HashingAlgorithm(Object) - Constructor for class io.vertx.reactivex.ext.auth.hashing.HashingAlgorithm
 
HashingStrategy - Class in io.vertx.reactivex.ext.auth.hashing
Hashing Strategy manager.
HashingStrategy(HashingStrategy) - Constructor for class io.vertx.reactivex.ext.auth.hashing.HashingStrategy
 
HashingStrategy(Object) - Constructor for class io.vertx.reactivex.ext.auth.hashing.HashingStrategy
 
hasMore() - Method in class io.vertx.reactivex.sqlclient.Cursor
Returns true when the cursor has results in progress and the Cursor.read(int) should be called to retrieve them.
hasMorePages() - Method in class io.vertx.reactivex.cassandra.ResultSet
 
hasNext() - Method in class io.vertx.reactivex.sqlclient.RowIterator
 
hdel(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Delete one or more hash fields.
head() - Method in class io.vertx.reactivex.ext.web.Router
Add a route that matches any HTTP HEAD request
head(int, String, UriTemplate) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP HEAD request to send to the server at the specified host and port.
head(int, String, String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP HEAD request to send to the server at the specified host and port.
head(UriTemplate) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP HEAD request to send to the server at the default host and port.
head(String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP HEAD request to send to the server at the default host and port.
head(String) - Method in class io.vertx.reactivex.ext.web.Router
Add a route that matches a HTTP HEAD request and the specified path
head(String, UriTemplate) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP HEAD request to send to the server at the specified host and default port.
head(String, String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP HEAD request to send to the server at the specified host and default port.
headAbs(UriTemplate) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP HEAD request to send to the server using an absolute URI, specifying a response handler to receive the response
headAbs(String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP HEAD request to send to the server using an absolute URI, specifying a response handler to receive the response
header(String) - Method in class io.vertx.reactivex.ext.web.handler.APIKeyHandler
Specify the source for the api key extraction as an HTTP header with the given name.
header(String, Buffer) - Static method in class io.vertx.reactivex.kafka.client.producer.KafkaHeader
 
header(String, String) - Static method in class io.vertx.reactivex.kafka.client.producer.KafkaHeader
 
headerParameter(ParameterProcessorFactory) - Method in class io.vertx.reactivex.ext.web.validation.builder.ValidationHandlerBuilder
 
headerParameter(String) - Method in class io.vertx.reactivex.ext.web.validation.RequestParameters
Get header parameter by name.
headerParametersNames() - Method in class io.vertx.reactivex.ext.web.validation.RequestParameters
Get list of all parameter names inside header
headers() - Method in class io.vertx.reactivex.core.eventbus.Message
Multi-map of message headers.
headers() - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Returns the HTTP headers.
headers() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
 
headers() - Method in class io.vertx.reactivex.core.http.HttpClientResponse
 
headers() - Static method in class io.vertx.reactivex.core.http.HttpHeaders
 
headers() - Method in class io.vertx.reactivex.core.http.HttpRequestHead
 
headers() - Method in interface io.vertx.reactivex.core.http.HttpResponseHead
 
headers() - Method in class io.vertx.reactivex.core.http.HttpServerResponse
 
headers() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Returns the HTTP headers.
headers() - Method in class io.vertx.reactivex.core.http.ServerWebSocketHandshake
Returns the HTTP headers.
headers() - Method in class io.vertx.reactivex.core.http.WebSocket
Returns the HTTP headers.
headers() - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Returns the HTTP headers.
headers() - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
 
headers() - Method in class io.vertx.reactivex.ext.web.client.HttpResponse
 
headers() - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
Return the headers corresponding to the last request for this socket or the websocket handshake Any cookie headers will be removed for security reasons
headers() - Method in class io.vertx.reactivex.grpc.common.GrpcReadStream
 
headers() - Method in class io.vertx.reactivex.grpc.common.GrpcWriteStream
 
headers() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumerRecord
 
headers() - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducerRecord
 
headers(HttpVersion) - Static method in class io.vertx.reactivex.core.http.HttpHeaders
 
headersEndHandler(Handler<Void>) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Provide a handler that will be called just before the headers are written to the wire.
headWithRegex(String) - Method in class io.vertx.reactivex.ext.web.Router
Add a route that matches a HTTP HEAD request and the specified path regex
headWritten() - Method in class io.vertx.reactivex.core.http.HttpServerResponse
 
HealthCheckHandler - Class in io.vertx.reactivex.ext.web.healthchecks
A Vert.x Web handler on which you register health check procedure.
HealthCheckHandler(HealthCheckHandler) - Constructor for class io.vertx.reactivex.ext.web.healthchecks.HealthCheckHandler
 
HealthCheckHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.healthchecks.HealthCheckHandler
 
healthChecks(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the checks associated with the service
HealthChecks - Class in io.vertx.reactivex.ext.healthchecks
NOTE: This class has been automatically generated from the original non RX-ified interface using Vert.x codegen.
HealthChecks(HealthChecks) - Constructor for class io.vertx.reactivex.ext.healthchecks.HealthChecks
 
HealthChecks(Object) - Constructor for class io.vertx.reactivex.ext.healthchecks.HealthChecks
 
healthChecksWithOptions(String, CheckQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the checks associated with the service
healthNodesWithOptions(String, CheckQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the checks specific to the node provided on the path.
healthServiceNodes(String, boolean) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the nodes providing the service.
healthServiceNodesWithOptions(String, boolean, ServiceQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the nodes providing the service.
healthState(HealthState) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the checks in the specified status
healthStateWithOptions(HealthState, CheckQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the checks in the specified status
hello(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Handshake with Redis.
HerokuAuth - Class in io.vertx.reactivex.ext.auth.oauth2.providers
Simplified factory to create an for Heroku.
HerokuAuth(HerokuAuth) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.HerokuAuth
 
HerokuAuth(Object) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.HerokuAuth
 
hexists(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Determine if a hash field exists.
hget(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the value of a hash field.
hgetall(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get all the fields and values in a hash.
hincrby(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Increment the integer value of a hash field by the given number.
hincrbyfloat(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Increment the float value of a hash field by the given amount.
hkeys(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get all the fields in a hash.
hlen(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the number of fields in a hash.
hmget(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the values of all the given hash fields.
hmset(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Deprecated.
host() - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
 
host(String) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Configure the request to use a new host value.
HOST - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Host header name
HotpAuth - Class in io.vertx.reactivex.ext.auth.otp.hotp
An extension of AuthProvider which uses the one time passwords based on counter to perform authentication.
HotpAuth(HotpAuth) - Constructor for class io.vertx.reactivex.ext.auth.otp.hotp.HotpAuth
 
HotpAuth(Object) - Constructor for class io.vertx.reactivex.ext.auth.otp.hotp.HotpAuth
 
hrandfield(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get one or multiple random fields from a hash.
hscan(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Incrementally iterate hash fields and associated values.
hset(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Set the string value of a hash field.
hsetnx(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Set the value of a hash field, only if the field does not exist.
hstrlen(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the length of the value of a hash field.
HSTSHandler - Class in io.vertx.reactivex.ext.web.handler
HTTP Strict Transport Security (HSTS) RFC6797.
HSTSHandler(HSTSHandler) - Constructor for class io.vertx.reactivex.ext.web.handler.HSTSHandler
 
HSTSHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.HSTSHandler
 
HTDIGEST_FILE - Static variable in class io.vertx.reactivex.ext.auth.htdigest.HtdigestAuth
The property name to be used to set the name of the collection inside the config
HtdigestAuth - Class in io.vertx.reactivex.ext.auth.htdigest
An extension of AuthProvider which is using .htdigest file as store
HtdigestAuth(HtdigestAuth) - Constructor for class io.vertx.reactivex.ext.auth.htdigest.HtdigestAuth
 
HtdigestAuth(Object) - Constructor for class io.vertx.reactivex.ext.auth.htdigest.HtdigestAuth
 
HtpasswdAuth - Class in io.vertx.reactivex.ext.auth.htpasswd
An extension of AuthProvider which is using htpasswd file as store
HtpasswdAuth(HtpasswdAuth) - Constructor for class io.vertx.reactivex.ext.auth.htpasswd.HtpasswdAuth
 
HtpasswdAuth(Object) - Constructor for class io.vertx.reactivex.ext.auth.htpasswd.HtpasswdAuth
 
HttpClient - Interface in io.vertx.reactivex.core.http
The API to interacts with an HTTP server.
HttpClientAgent - Class in io.vertx.reactivex.core.http
An asynchronous HTTP client.
HttpClientAgent(HttpClientAgent) - Constructor for class io.vertx.reactivex.core.http.HttpClientAgent
 
HttpClientAgent(Object) - Constructor for class io.vertx.reactivex.core.http.HttpClientAgent
 
HttpClientBuilder - Class in io.vertx.reactivex.core.http
A builder for HttpClient.
HttpClientBuilder(HttpClientBuilder) - Constructor for class io.vertx.reactivex.core.http.HttpClientBuilder
 
HttpClientBuilder(Object) - Constructor for class io.vertx.reactivex.core.http.HttpClientBuilder
 
HttpClientConnection - Class in io.vertx.reactivex.core.http
Represents an HTTP client connection.
HttpClientConnection(HttpClientConnection) - Constructor for class io.vertx.reactivex.core.http.HttpClientConnection
 
HttpClientConnection(Object) - Constructor for class io.vertx.reactivex.core.http.HttpClientConnection
 
HttpClientRequest - Class in io.vertx.reactivex.core.http
Represents a client-side HTTP request.
HttpClientRequest(HttpClientRequest) - Constructor for class io.vertx.reactivex.core.http.HttpClientRequest
 
HttpClientRequest(Object) - Constructor for class io.vertx.reactivex.core.http.HttpClientRequest
 
HttpClientResponse - Class in io.vertx.reactivex.core.http
Represents a client-side HTTP response.
HttpClientResponse(HttpClientResponse) - Constructor for class io.vertx.reactivex.core.http.HttpClientResponse
 
HttpClientResponse(Object) - Constructor for class io.vertx.reactivex.core.http.HttpClientResponse
 
HttpConnection - Class in io.vertx.reactivex.core.http
Represents an HTTP connection.
HttpConnection(HttpConnection) - Constructor for class io.vertx.reactivex.core.http.HttpConnection
 
HttpConnection(Object) - Constructor for class io.vertx.reactivex.core.http.HttpConnection
 
HttpEndpoint - Class in io.vertx.reactivex.servicediscovery.types
for HTTP endpoint (REST api).
HttpEndpoint(HttpEndpoint) - Constructor for class io.vertx.reactivex.servicediscovery.types.HttpEndpoint
 
HttpEndpoint(Object) - Constructor for class io.vertx.reactivex.servicediscovery.types.HttpEndpoint
 
httpHandler(BasicAuthHandler) - Method in class io.vertx.reactivex.ext.web.openapi.router.Security
Configure the to be used when creating the router.
httpHandler(DigestAuthHandler) - Method in class io.vertx.reactivex.ext.web.openapi.router.Security
Configure the to be used when creating the router.
httpHandler(JWTAuthHandler) - Method in class io.vertx.reactivex.ext.web.openapi.router.Security
Configure the to be used when creating the router.
httpHeaders() - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Returns the HTTP headers sent by the client when a WebSocket transport is used otherwise null
HttpHeaders - Class in io.vertx.reactivex.core.http
Contains a bunch of useful HTTP headers stuff: methods for creating instances often used Header names method to create optimized CharSequence which can be used as header name and value
HttpHeaders(HttpHeaders) - Constructor for class io.vertx.reactivex.core.http.HttpHeaders
 
HttpHeaders(Object) - Constructor for class io.vertx.reactivex.core.http.HttpHeaders
 
HttpRequest<T> - Class in io.vertx.reactivex.ext.web.client
A client-side HTTP request.
HttpRequest(HttpRequest) - Constructor for class io.vertx.reactivex.ext.web.client.HttpRequest
 
HttpRequest(Object, TypeArg<T>) - Constructor for class io.vertx.reactivex.ext.web.client.HttpRequest
 
HttpRequestHead - Class in io.vertx.reactivex.core.http
The state of the HTTP request head: Method / URI Headers
HttpRequestHead(HttpRequestHead) - Constructor for class io.vertx.reactivex.core.http.HttpRequestHead
 
HttpRequestHead(Object) - Constructor for class io.vertx.reactivex.core.http.HttpRequestHead
 
httpRequestURI() - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Returns the HTTP request URI sent by the client when a WebSocket transport is used otherwise null
HttpResponse<T> - Class in io.vertx.reactivex.ext.web.client
An HTTP response.
HttpResponse(HttpResponse) - Constructor for class io.vertx.reactivex.ext.web.client.HttpResponse
 
HttpResponse(Object, TypeArg<T>) - Constructor for class io.vertx.reactivex.ext.web.client.HttpResponse
 
HttpResponseExpectation - Class in io.vertx.reactivex.core.http
Common expectations for HTTP responses.
HttpResponseHead - Interface in io.vertx.reactivex.core.http
The state of the HTTP response head: Status code / Message Headers
HttpServer - Class in io.vertx.reactivex.core.http
An HTTP and WebSockets server.
HttpServer(HttpServer) - Constructor for class io.vertx.reactivex.core.http.HttpServer
 
HttpServer(Object) - Constructor for class io.vertx.reactivex.core.http.HttpServer
 
HttpServerFileUpload - Class in io.vertx.reactivex.core.http
Represents an file upload from an HTML FORM.
HttpServerFileUpload(HttpServerFileUpload) - Constructor for class io.vertx.reactivex.core.http.HttpServerFileUpload
 
HttpServerFileUpload(Object) - Constructor for class io.vertx.reactivex.core.http.HttpServerFileUpload
 
HttpServerRequest - Class in io.vertx.reactivex.core.http
Represents a server-side HTTP request.
HttpServerRequest(HttpServerRequest) - Constructor for class io.vertx.reactivex.core.http.HttpServerRequest
 
HttpServerRequest(Object) - Constructor for class io.vertx.reactivex.core.http.HttpServerRequest
 
HttpServerResponse - Class in io.vertx.reactivex.core.http
Represents a server-side HTTP response.
HttpServerResponse(HttpServerResponse) - Constructor for class io.vertx.reactivex.core.http.HttpServerResponse
 
HttpServerResponse(Object) - Constructor for class io.vertx.reactivex.core.http.HttpServerResponse
 
hvals(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get all the values in a hash.

I

IBMCloudAuth - Class in io.vertx.reactivex.ext.auth.oauth2.providers
Simplified factory to create an for IBM Cloud.
IBMCloudAuth(IBMCloudAuth) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.IBMCloudAuth
 
IBMCloudAuth(Object) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.IBMCloudAuth
 
id() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
id() - Method in class io.vertx.reactivex.ext.auth.hashing.HashingAlgorithm
return the symbolic name for the algorithm
id() - Method in class io.vertx.reactivex.ext.web.Session
 
id(String) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
IDENTITY - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
identity header value
idleTimeout() - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
 
idleTimeout(long) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Sets the amount of time after which, if the request does not return any data within the timeout period, the request/response is closed and the related futures are failed with a TimeoutException, e.g.
idleTimeout(long) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Sets the amount of time after which, if the request does not return any data within the timeout period, the request/response is closed and the related futures are failed with a TimeoutException.
idleTimeout(long) - Method in class io.vertx.reactivex.grpc.client.GrpcClientRequest
Sets the amount of time after which, if the request does not return any data within the timeout period, the request/response is cancelled and the related futures.
IF_MATCH - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
If-Match header name
IF_MODIFIED_SINCE - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
If-Modified-Since header name
IF_NONE_MATCH - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
If-None-Match header name
impersonate() - Method in class io.vertx.reactivex.ext.web.UserContext
Impersonates a second identity.
impersonate(String) - Method in class io.vertx.reactivex.ext.web.UserContext
Impersonates a second identity.
in() - Method in class io.vertx.reactivex.jdbcclient.SqlOutParam
Is this marker IN?
incr(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Increment the integer value of a key by one.
incrby(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Increment the integer value of a key by the given amount.
incrbyfloat(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Increment the float value of a key by the given amount.
incrementAndGet() - Method in class io.vertx.reactivex.core.shareddata.Counter
Increment the counter atomically and return the new count
indicatedServerName() - Method in class io.vertx.reactivex.core.http.HttpConnection
Returns the SNI server name presented during the SSL handshake by the client.
indicatedServerName() - Method in class io.vertx.reactivex.core.net.NetSocket
Returns the SNI server name presented during the SSL handshake by the client.
InfinispanSessionStore - Class in io.vertx.reactivex.ext.web.sstore.infinispan
An implementation of that relies on the Infinispan Java Client.
InfinispanSessionStore(InfinispanSessionStore) - Constructor for class io.vertx.reactivex.ext.web.sstore.infinispan.InfinispanSessionStore
 
InfinispanSessionStore(Object) - Constructor for class io.vertx.reactivex.ext.web.sstore.infinispan.InfinispanSessionStore
 
info(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get information and statistics about the server.
infoHandler(Handler<MSSQLInfo>) - Method in class io.vertx.reactivex.mssqlclient.MSSQLConnection
Set a handler called when the connection receives an informational message from the server.
infoSession(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the requested session information
infoSessionWithOptions(String, BlockingQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the requested session information This is blocking query unlike ConsulClient.infoSession(java.lang.String)
init(Vertx, JsonObject) - Method in class io.vertx.reactivex.ext.web.sstore.SessionStore
Initialize this store.
init(Vertx, ServicePublisher, JsonObject, Promise<Void>) - Method in class io.vertx.reactivex.servicediscovery.spi.ServiceExporter
Starts the exporter.
initTransactions() - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
Initializes the underlying kafka transactional producer.
INOUT(Object, int) - Static method in class io.vertx.reactivex.jdbcclient.SqlOutParam
Factory for a INOUT parameter of type out.
INOUT(Object, String) - Static method in class io.vertx.reactivex.jdbcclient.SqlOutParam
Factory for a INOUT parameter of type out.
INOUT(Object, JDBCType) - Static method in class io.vertx.reactivex.jdbcclient.SqlOutParam
Factory for a INOUT parameter of type out.
InputTrustHandler - Interface in io.vertx.reactivex.ext.web.handler
Base input trust interface for handlers that verify the trust of the request.
insert(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Insert a document in the specified collection
insertWithOptions(String, JsonObject, WriteOption) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Insert a document in the specified collection with the specified write option
InstagramAuth - Class in io.vertx.reactivex.ext.auth.oauth2.providers
Simplified factory to create an for Instagram.
InstagramAuth(InstagramAuth) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.InstagramAuth
 
InstagramAuth(Object) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.InstagramAuth
 
invalidMessageHandler(Handler<InvalidMessageException>) - Method in class io.vertx.reactivex.grpc.client.GrpcClientResponse
Set a message handler that is reported with invalid message errors.
invalidMessageHandler(Handler<InvalidMessageException>) - Method in class io.vertx.reactivex.grpc.common.GrpcReadStream
Set a message handler that is reported with invalid message errors.
invalidMessageHandler(Handler<InvalidMessageException>) - Method in class io.vertx.reactivex.grpc.server.GrpcServerRequest
Set a message handler that is reported with invalid message errors.
invalidRequestHandler(Handler<HttpServerRequest>) - Method in class io.vertx.reactivex.core.http.HttpServer
Set a handler for handling invalid requests.
invoke(Handler<JsonObject>) - Method in class io.vertx.reactivex.ext.healthchecks.HealthChecks
Invokes the registered procedures and computes the outcome.
invoke(String) - Method in class io.vertx.reactivex.ext.healthchecks.HealthChecks
Invokes the registered procedure with the given name and sub-procedures.
io.vertx.reactivex.amqp - package io.vertx.reactivex.amqp
 
io.vertx.reactivex.cassandra - package io.vertx.reactivex.cassandra
 
io.vertx.reactivex.circuitbreaker - package io.vertx.reactivex.circuitbreaker
 
io.vertx.reactivex.config - package io.vertx.reactivex.config
 
io.vertx.reactivex.core.datagram - package io.vertx.reactivex.core.datagram
 
io.vertx.reactivex.core.dns - package io.vertx.reactivex.core.dns
 
io.vertx.reactivex.core.eventbus - package io.vertx.reactivex.core.eventbus
 
io.vertx.reactivex.core.file - package io.vertx.reactivex.core.file
 
io.vertx.reactivex.core.http - package io.vertx.reactivex.core.http
 
io.vertx.reactivex.core.json.pointer - package io.vertx.reactivex.core.json.pointer
 
io.vertx.reactivex.core.metrics - package io.vertx.reactivex.core.metrics
 
io.vertx.reactivex.core.net - package io.vertx.reactivex.core.net
 
io.vertx.reactivex.core.net.endpoint - package io.vertx.reactivex.core.net.endpoint
 
io.vertx.reactivex.core.parsetools - package io.vertx.reactivex.core.parsetools
 
io.vertx.reactivex.core.shareddata - package io.vertx.reactivex.core.shareddata
 
io.vertx.reactivex.core.streams - package io.vertx.reactivex.core.streams
 
io.vertx.reactivex.db2client - package io.vertx.reactivex.db2client
 
io.vertx.reactivex.ext.auth - package io.vertx.reactivex.ext.auth
 
io.vertx.reactivex.ext.auth.abac - package io.vertx.reactivex.ext.auth.abac
 
io.vertx.reactivex.ext.auth.audit - package io.vertx.reactivex.ext.auth.audit
 
io.vertx.reactivex.ext.auth.authentication - package io.vertx.reactivex.ext.auth.authentication
 
io.vertx.reactivex.ext.auth.authorization - package io.vertx.reactivex.ext.auth.authorization
 
io.vertx.reactivex.ext.auth.hashing - package io.vertx.reactivex.ext.auth.hashing
 
io.vertx.reactivex.ext.auth.htdigest - package io.vertx.reactivex.ext.auth.htdigest
 
io.vertx.reactivex.ext.auth.htpasswd - package io.vertx.reactivex.ext.auth.htpasswd
 
io.vertx.reactivex.ext.auth.jwt - package io.vertx.reactivex.ext.auth.jwt
 
io.vertx.reactivex.ext.auth.jwt.authorization - package io.vertx.reactivex.ext.auth.jwt.authorization
 
io.vertx.reactivex.ext.auth.ldap - package io.vertx.reactivex.ext.auth.ldap
 
io.vertx.reactivex.ext.auth.oauth2 - package io.vertx.reactivex.ext.auth.oauth2
 
io.vertx.reactivex.ext.auth.oauth2.authorization - package io.vertx.reactivex.ext.auth.oauth2.authorization
 
io.vertx.reactivex.ext.auth.oauth2.providers - package io.vertx.reactivex.ext.auth.oauth2.providers
 
io.vertx.reactivex.ext.auth.otp - package io.vertx.reactivex.ext.auth.otp
 
io.vertx.reactivex.ext.auth.otp.hotp - package io.vertx.reactivex.ext.auth.otp.hotp
 
io.vertx.reactivex.ext.auth.otp.totp - package io.vertx.reactivex.ext.auth.otp.totp
 
io.vertx.reactivex.ext.auth.prng - package io.vertx.reactivex.ext.auth.prng
 
io.vertx.reactivex.ext.auth.properties - package io.vertx.reactivex.ext.auth.properties
 
io.vertx.reactivex.ext.auth.sqlclient - package io.vertx.reactivex.ext.auth.sqlclient
 
io.vertx.reactivex.ext.auth.webauthn4j - package io.vertx.reactivex.ext.auth.webauthn4j
 
io.vertx.reactivex.ext.bridge - package io.vertx.reactivex.ext.bridge
 
io.vertx.reactivex.ext.consul - package io.vertx.reactivex.ext.consul
 
io.vertx.reactivex.ext.dropwizard - package io.vertx.reactivex.ext.dropwizard
 
io.vertx.reactivex.ext.eventbus.bridge.tcp - package io.vertx.reactivex.ext.eventbus.bridge.tcp
 
io.vertx.reactivex.ext.healthchecks - package io.vertx.reactivex.ext.healthchecks
 
io.vertx.reactivex.ext.mail - package io.vertx.reactivex.ext.mail
 
io.vertx.reactivex.ext.mongo - package io.vertx.reactivex.ext.mongo
 
io.vertx.reactivex.ext.stomp - package io.vertx.reactivex.ext.stomp
 
io.vertx.reactivex.ext.unit - package io.vertx.reactivex.ext.unit
 
io.vertx.reactivex.ext.unit.collect - package io.vertx.reactivex.ext.unit.collect
 
io.vertx.reactivex.ext.unit.report - package io.vertx.reactivex.ext.unit.report
 
io.vertx.reactivex.ext.web - package io.vertx.reactivex.ext.web
 
io.vertx.reactivex.ext.web.client - package io.vertx.reactivex.ext.web.client
 
io.vertx.reactivex.ext.web.codec - package io.vertx.reactivex.ext.web.codec
 
io.vertx.reactivex.ext.web.common - package io.vertx.reactivex.ext.web.common
 
io.vertx.reactivex.ext.web.common.template - package io.vertx.reactivex.ext.web.common.template
 
io.vertx.reactivex.ext.web.handler - package io.vertx.reactivex.ext.web.handler
 
io.vertx.reactivex.ext.web.handler.graphql - package io.vertx.reactivex.ext.web.handler.graphql
 
io.vertx.reactivex.ext.web.handler.graphql.ws - package io.vertx.reactivex.ext.web.handler.graphql.ws
 
io.vertx.reactivex.ext.web.handler.sockjs - package io.vertx.reactivex.ext.web.handler.sockjs
 
io.vertx.reactivex.ext.web.healthchecks - package io.vertx.reactivex.ext.web.healthchecks
 
io.vertx.reactivex.ext.web.multipart - package io.vertx.reactivex.ext.web.multipart
 
io.vertx.reactivex.ext.web.openapi.router - package io.vertx.reactivex.ext.web.openapi.router
 
io.vertx.reactivex.ext.web.sstore - package io.vertx.reactivex.ext.web.sstore
 
io.vertx.reactivex.ext.web.sstore.cookie - package io.vertx.reactivex.ext.web.sstore.cookie
 
io.vertx.reactivex.ext.web.sstore.infinispan - package io.vertx.reactivex.ext.web.sstore.infinispan
 
io.vertx.reactivex.ext.web.sstore.redis - package io.vertx.reactivex.ext.web.sstore.redis
 
io.vertx.reactivex.ext.web.templ.freemarker - package io.vertx.reactivex.ext.web.templ.freemarker
 
io.vertx.reactivex.ext.web.templ.handlebars - package io.vertx.reactivex.ext.web.templ.handlebars
 
io.vertx.reactivex.ext.web.templ.mvel - package io.vertx.reactivex.ext.web.templ.mvel
 
io.vertx.reactivex.ext.web.templ.pebble - package io.vertx.reactivex.ext.web.templ.pebble
 
io.vertx.reactivex.ext.web.templ.pug - package io.vertx.reactivex.ext.web.templ.pug
 
io.vertx.reactivex.ext.web.templ.rocker - package io.vertx.reactivex.ext.web.templ.rocker
 
io.vertx.reactivex.ext.web.templ.thymeleaf - package io.vertx.reactivex.ext.web.templ.thymeleaf
 
io.vertx.reactivex.ext.web.validation - package io.vertx.reactivex.ext.web.validation
 
io.vertx.reactivex.ext.web.validation.builder - package io.vertx.reactivex.ext.web.validation.builder
 
io.vertx.reactivex.grpc.client - package io.vertx.reactivex.grpc.client
 
io.vertx.reactivex.grpc.common - package io.vertx.reactivex.grpc.common
 
io.vertx.reactivex.grpc.server - package io.vertx.reactivex.grpc.server
 
io.vertx.reactivex.jdbcclient - package io.vertx.reactivex.jdbcclient
 
io.vertx.reactivex.json.schema - package io.vertx.reactivex.json.schema
 
io.vertx.reactivex.kafka.admin - package io.vertx.reactivex.kafka.admin
 
io.vertx.reactivex.kafka.client.consumer - package io.vertx.reactivex.kafka.client.consumer
 
io.vertx.reactivex.kafka.client.producer - package io.vertx.reactivex.kafka.client.producer
 
io.vertx.reactivex.micrometer - package io.vertx.reactivex.micrometer
 
io.vertx.reactivex.mqtt - package io.vertx.reactivex.mqtt
 
io.vertx.reactivex.mqtt.messages - package io.vertx.reactivex.mqtt.messages
 
io.vertx.reactivex.mssqlclient - package io.vertx.reactivex.mssqlclient
 
io.vertx.reactivex.mysqlclient - package io.vertx.reactivex.mysqlclient
 
io.vertx.reactivex.openapi.contract - package io.vertx.reactivex.openapi.contract
 
io.vertx.reactivex.openapi.validation - package io.vertx.reactivex.openapi.validation
 
io.vertx.reactivex.oracleclient - package io.vertx.reactivex.oracleclient
 
io.vertx.reactivex.pgclient - package io.vertx.reactivex.pgclient
 
io.vertx.reactivex.pgclient.pubsub - package io.vertx.reactivex.pgclient.pubsub
 
io.vertx.reactivex.rabbitmq - package io.vertx.reactivex.rabbitmq
 
io.vertx.reactivex.redis.client - package io.vertx.reactivex.redis.client
 
io.vertx.reactivex.servicediscovery - package io.vertx.reactivex.servicediscovery
 
io.vertx.reactivex.servicediscovery.spi - package io.vertx.reactivex.servicediscovery.spi
 
io.vertx.reactivex.servicediscovery.types - package io.vertx.reactivex.servicediscovery.types
 
io.vertx.reactivex.sqlclient - package io.vertx.reactivex.sqlclient
 
io.vertx.reactivex.sqlclient.desc - package io.vertx.reactivex.sqlclient.desc
 
io.vertx.reactivex.sqlclient.spi - package io.vertx.reactivex.sqlclient.spi
 
io.vertx.reactivex.sqlclient.templates - package io.vertx.reactivex.sqlclient.templates
 
io.vertx.reactivex.uritemplate - package io.vertx.reactivex.uritemplate
 
is(String) - Method in class io.vertx.reactivex.ext.web.RoutingContext
Check if the incoming request contains the "Content-Type" get field, and it contains the give mime `type`.
isArray() - Method in class io.vertx.reactivex.sqlclient.desc.ColumnDescriptor
 
isArray(Object) - Method in class io.vertx.reactivex.core.json.pointer.JsonPointerIterator
 
isAttribute() - Method in class io.vertx.reactivex.ext.web.multipart.FormDataPart
 
isAutoKeepAlive() - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
 
isBodyNull() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
isBoolean() - Method in class io.vertx.reactivex.ext.web.validation.RequestParameter
 
isBoolean() - Method in interface io.vertx.reactivex.openapi.validation.Parameter
 
isBoolean() - Method in class io.vertx.reactivex.openapi.validation.RequestParameter
 
isBoolean() - Method in class io.vertx.reactivex.openapi.validation.ResponseParameter
 
isBuffer() - Method in class io.vertx.reactivex.ext.web.validation.RequestParameter
 
isBuffer() - Method in interface io.vertx.reactivex.openapi.validation.Parameter
 
isBuffer() - Method in class io.vertx.reactivex.openapi.validation.RequestParameter
 
isBuffer() - Method in class io.vertx.reactivex.openapi.validation.ResponseParameter
 
isCancelled() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQConsumer
Return true if cancel() has been called.
isChunked() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
 
isChunked() - Method in class io.vertx.reactivex.core.http.HttpServerResponse
 
isCleanSession() - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
 
isClosed() - Method in class io.vertx.reactivex.core.http.ClientWebSocket
 
isClosed() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
 
isClosed() - Method in class io.vertx.reactivex.core.http.WebSocket
 
isClosed() - Method in interface io.vertx.reactivex.core.http.WebSocketBase
 
isClosed() - Method in class io.vertx.reactivex.ext.stomp.StompClient
 
isClosed() - Method in class io.vertx.reactivex.sqlclient.Cursor
 
isCompleted() - Method in class io.vertx.reactivex.ext.unit.Completion
 
isConnected() - Method in class io.vertx.reactivex.cassandra.CassandraClient
 
isConnected() - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Returns whether or not the `CONNECTED` frame has been receive meaning that the Stomp connection is established.
isConnected() - Method in class io.vertx.reactivex.mqtt.MqttClient
 
isConnected() - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
 
isConnected() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Check if a connection is open
isDestroyed() - Method in class io.vertx.reactivex.ext.web.Session
 
isDisconnected() - Method in class io.vertx.reactivex.amqp.AmqpConnection
 
isDup() - Method in class io.vertx.reactivex.mqtt.messages.MqttPublishMessage
 
isDurable() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
isEmpty() - Method in class io.vertx.reactivex.core.shareddata.LocalMap
 
isEmpty() - Method in class io.vertx.reactivex.ext.auth.authorization.Authorizations
true if the authorizations contains at least one provider.
isEmpty() - Method in class io.vertx.reactivex.ext.web.RequestBody
A body can be empty if it is not available, or its length is 0.
isEmpty() - Method in class io.vertx.reactivex.ext.web.Session
 
isEmpty() - Method in class io.vertx.reactivex.ext.web.validation.RequestParameter
 
isEmpty() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumerRecords
 
isEmpty() - Method in class io.vertx.reactivex.openapi.contract.SecurityRequirement
 
isEmpty() - Method in interface io.vertx.reactivex.openapi.validation.Parameter
 
isEmpty() - Method in class io.vertx.reactivex.openapi.validation.RequestParameter
 
isEmpty() - Method in class io.vertx.reactivex.openapi.validation.ResponseParameter
 
isEnded() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
Has the request ended?
isError() - Method in class io.vertx.reactivex.ext.unit.report.Failure
 
isExactPath() - Method in class io.vertx.reactivex.ext.web.Route
Returns true of the path doesn't end with a wildcard * or is null.
isExpectMultipart() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
 
isExplode() - Method in class io.vertx.reactivex.openapi.contract.Parameter
 
isFailed() - Method in class io.vertx.reactivex.ext.unit.Completion
 
isFileUpload() - Method in class io.vertx.reactivex.ext.web.multipart.FormDataPart
 
isFirstAcquirer() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
isFollowRedirects() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
 
isFresh() - Method in class io.vertx.reactivex.ext.web.RoutingContext
Check if the request is fresh, aka Last-Modified and/or the ETag still match.
isHolding(Object) - Method in class io.vertx.reactivex.servicediscovery.ServiceReference
Checks whether or not the service reference has the given service object.
isJsonArray() - Method in class io.vertx.reactivex.ext.web.validation.RequestParameter
 
isJsonArray() - Method in interface io.vertx.reactivex.openapi.validation.Parameter
 
isJsonArray() - Method in class io.vertx.reactivex.openapi.validation.RequestParameter
 
isJsonArray() - Method in class io.vertx.reactivex.openapi.validation.ResponseParameter
 
isJsonObject() - Method in class io.vertx.reactivex.ext.web.validation.RequestParameter
 
isJsonObject() - Method in interface io.vertx.reactivex.openapi.validation.Parameter
 
isJsonObject() - Method in class io.vertx.reactivex.openapi.validation.RequestParameter
 
isJsonObject() - Method in class io.vertx.reactivex.openapi.validation.ResponseParameter
 
isListening() - Method in class io.vertx.reactivex.ext.stomp.StompServer
Checks whether or not the server is listening.
isLocalPointer() - Method in class io.vertx.reactivex.core.json.pointer.JsonPointer
Return true if the pointer is local (URI with only fragment)
isMatchedBy(ParsedHeaderValue) - Method in class io.vertx.reactivex.ext.web.LanguageHeader
Test if this header is matched by matchTry header
isMatchedBy(ParsedHeaderValue) - Method in class io.vertx.reactivex.ext.web.MIMEHeader
Test if this header is matched by matchTry header
isMatchedBy(ParsedHeaderValue) - Method in interface io.vertx.reactivex.ext.web.ParsedHeaderValue
Test if this header is matched by matchTry header
isMediaTypeSupported(String) - Static method in class io.vertx.reactivex.openapi.contract.MediaType
 
isMetricsEnabled() - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
Whether the metrics are enabled for this measured object
isMetricsEnabled() - Method in class io.vertx.reactivex.core.eventbus.EventBus
Whether the metrics are enabled for this measured object
isMetricsEnabled() - Method in class io.vertx.reactivex.core.http.HttpClientAgent
Whether the metrics are enabled for this measured object
isMetricsEnabled() - Method in class io.vertx.reactivex.core.http.HttpServer
Whether the metrics are enabled for this measured object
isMetricsEnabled() - Method in class io.vertx.reactivex.core.http.WebSocketClient
Whether the metrics are enabled for this measured object
isMetricsEnabled() - Method in interface io.vertx.reactivex.core.metrics.Measured
Whether the metrics are enabled for this measured object
isMetricsEnabled() - Method in class io.vertx.reactivex.core.net.NetClient
Whether the metrics are enabled for this measured object
isMetricsEnabled() - Method in class io.vertx.reactivex.core.net.NetServer
Whether the metrics are enabled for this measured object
isNull() - Method in class io.vertx.reactivex.ext.web.validation.RequestParameter
 
isNull() - Method in interface io.vertx.reactivex.openapi.validation.Parameter
 
isNull() - Method in class io.vertx.reactivex.openapi.validation.RequestParameter
 
isNull() - Method in class io.vertx.reactivex.openapi.validation.ResponseParameter
 
isNull(Object) - Method in class io.vertx.reactivex.core.json.pointer.JsonPointerIterator
 
isNumber() - Method in class io.vertx.reactivex.ext.web.validation.RequestParameter
 
isNumber() - Method in interface io.vertx.reactivex.openapi.validation.Parameter
 
isNumber() - Method in class io.vertx.reactivex.openapi.validation.RequestParameter
 
isNumber() - Method in class io.vertx.reactivex.openapi.validation.ResponseParameter
 
isObject(Object) - Method in class io.vertx.reactivex.core.json.pointer.JsonPointerIterator
 
isOpenChannel() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Check if a channel is open
isParent(JsonPointer) - Method in class io.vertx.reactivex.core.json.pointer.JsonPointer
Return true if this pointer is a parent pointer of child.
isPaused() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQConsumer
 
isPermitted() - Method in class io.vertx.reactivex.ext.web.LanguageHeader
Is this an allowed operation as specified by the corresponding header?
isPermitted() - Method in class io.vertx.reactivex.ext.web.MIMEHeader
Is this an allowed operation as specified by the corresponding header?
isPermitted() - Method in interface io.vertx.reactivex.ext.web.ParsedHeaderValue
Is this an allowed operation as specified by the corresponding header?
isPublishAutoAck() - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
 
isRegenerated() - Method in class io.vertx.reactivex.ext.web.Session
 
isRegexPath() - Method in class io.vertx.reactivex.ext.web.Route
Returns true of the path is a regular expression, this includes expression paths.
isRegistered() - Method in class io.vertx.reactivex.core.eventbus.MessageConsumer
 
isRequired() - Method in class io.vertx.reactivex.openapi.contract.Parameter
 
isRequired() - Method in class io.vertx.reactivex.openapi.contract.RequestBody
 
isRetain() - Method in class io.vertx.reactivex.mqtt.messages.MqttPublishMessage
 
isRootPointer() - Method in class io.vertx.reactivex.core.json.pointer.JsonPointer
Return true if the pointer is a root pointer
isSend() - Method in class io.vertx.reactivex.core.eventbus.Message
Signals if this message represents a send or publish event.
isSessionAccessed() - Method in class io.vertx.reactivex.ext.web.RoutingContext
Whether the RoutingContext.session() has been already called or not.
isSessionPresent() - Method in class io.vertx.reactivex.mqtt.messages.MqttConnAckMessage
 
isShared() - Method in class io.vertx.reactivex.core.file.AsyncFileLock
 
isSizeAvailable() - Method in class io.vertx.reactivex.core.http.HttpServerFileUpload
 
isSsl() - Method in class io.vertx.reactivex.core.http.ClientWebSocket
 
isSsl() - Method in class io.vertx.reactivex.core.http.HttpConnection
 
isSsl() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
 
isSsl() - Method in class io.vertx.reactivex.core.http.ServerWebSocketHandshake
 
isSsl() - Method in class io.vertx.reactivex.core.http.WebSocket
 
isSsl() - Method in interface io.vertx.reactivex.core.http.WebSocketBase
 
isSsl() - Method in class io.vertx.reactivex.core.net.NetSocket
 
isSsl() - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
 
isSSL() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
 
isSSL() - Method in class io.vertx.reactivex.sqlclient.SqlConnection
 
isString() - Method in class io.vertx.reactivex.ext.web.validation.RequestParameter
 
isString() - Method in interface io.vertx.reactivex.openapi.validation.Parameter
 
isString() - Method in class io.vertx.reactivex.openapi.validation.RequestParameter
 
isString() - Method in class io.vertx.reactivex.openapi.validation.ResponseParameter
 
isSubscriptionAutoAck() - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
 
isSucceeded() - Method in class io.vertx.reactivex.ext.unit.Completion
 
issuer(String) - Method in class io.vertx.reactivex.ext.web.handler.OtpAuthHandler
Configure the issuer value to be shown in the authenticator URL.
isText() - Method in class io.vertx.reactivex.ext.web.multipart.FormDataPart
 
isValid() - Method in class io.vertx.reactivex.core.file.AsyncFileLock
A lock remains valid until it is released or the file corresponding AsyncFile is closed.
isValidBlocking() - Method in class io.vertx.reactivex.core.file.AsyncFileLock
Like AsyncFileLock.isValid() but blocking.
isVendorSpecificJson(String) - Static method in class io.vertx.reactivex.openapi.contract.MediaType
 
iterator() - Method in class io.vertx.reactivex.ext.web.multipart.MultipartForm
 
iterator() - Method in class io.vertx.reactivex.sqlclient.RowSet
 

J

JDBCConnection - Class in io.vertx.reactivex.jdbcclient
 
JDBCConnection(JDBCConnection) - Constructor for class io.vertx.reactivex.jdbcclient.JDBCConnection
 
JDBCConnection(Object) - Constructor for class io.vertx.reactivex.jdbcclient.JDBCConnection
 
JDBCPool - Class in io.vertx.reactivex.jdbcclient
JDBCPool is the interface that allows using the Sql Client API with plain JDBC.
JDBCPool(JDBCPool) - Constructor for class io.vertx.reactivex.jdbcclient.JDBCPool
 
JDBCPool(Object) - Constructor for class io.vertx.reactivex.jdbcclient.JDBCPool
 
jdbcType() - Method in class io.vertx.reactivex.sqlclient.desc.ColumnDescriptor
 
json(SchemaBuilder) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Bodies
Create a json body processor
json(Class<U>) - Static method in class io.vertx.reactivex.ext.web.codec.BodyCodec
Create and return a codec for Java objects encoded using Jackson mapper.
json(Object) - Method in class io.vertx.reactivex.ext.web.RoutingContext
Encode an Object to JSON and end the request.
JSON_ITERATOR - Static variable in class io.vertx.reactivex.core.json.pointer.JsonPointerIterator
Instance of a JsonPointerIterator to query Vert.x Json structures
JSON_NULL - Static variable in class io.vertx.reactivex.sqlclient.Row
The JSON null literal value.
JSON_NULL - Static variable in class io.vertx.reactivex.sqlclient.Tuple
The JSON null literal value.
jsonArrappend(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.ARRAPPEND.
jsonArray() - Static method in class io.vertx.reactivex.ext.web.codec.BodyCodec
 
jsonArrindex(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.ARRINDEX.
jsonArrinsert(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.ARRINSERT.
jsonArrlen(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.ARRLEN.
jsonArrpop(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.ARRPOP.
jsonArrtrim(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.ARRTRIM.
jsonClear(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.CLEAR.
jsonDebug(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.DEBUG.
jsonDel(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.DEL.
jsonForget(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.FORGET.
JsonFormatValidator - Class in io.vertx.reactivex.json.schema
 
JsonFormatValidator(JsonFormatValidator) - Constructor for class io.vertx.reactivex.json.schema.JsonFormatValidator
 
JsonFormatValidator(Object) - Constructor for class io.vertx.reactivex.json.schema.JsonFormatValidator
 
jsonGet(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.GET.
jsonMget(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.MGET.
jsonNumincrby(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.NUMINCRBY.
jsonNummultby(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.NUMMULTBY.
jsonNumpowby(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.NUMPOWBY.
jsonObject() - Static method in class io.vertx.reactivex.ext.web.codec.BodyCodec
 
jsonObject() - Static method in class io.vertx.reactivex.sqlclient.templates.TupleMapper
Map a to a .
jsonObjkeys(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.OBJKEYS.
jsonObjlen(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.OBJLEN.
jsonParam(String, SchemaBuilder) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Parameters
Creates a required parameter serialized as valid json
JsonParser - Class in io.vertx.reactivex.core.parsetools
A parser class which allows to incrementally parse json elements and emit json parse events instead of parsing a json element fully.
JsonParser(JsonParser) - Constructor for class io.vertx.reactivex.core.parsetools.JsonParser
 
JsonParser(Object) - Constructor for class io.vertx.reactivex.core.parsetools.JsonParser
 
JsonPointer - Class in io.vertx.reactivex.core.json.pointer
Implementation of RFC6901 Json Pointers.
JsonPointer(JsonPointer) - Constructor for class io.vertx.reactivex.core.json.pointer.JsonPointer
 
JsonPointer(Object) - Constructor for class io.vertx.reactivex.core.json.pointer.JsonPointer
 
JsonPointerIterator - Class in io.vertx.reactivex.core.json.pointer
The JsonPointerIterator is used by the read/write algorithms of the JsonPointer to read/write the querying data structure
Every method takes the currentValue as parameter, representing the actual value held by the query algorithm.
Implementations of this interface should be stateless, so they can be reused
You can implement this interface to query the structure you want using json pointers
JsonPointerIterator(JsonPointerIterator) - Constructor for class io.vertx.reactivex.core.json.pointer.JsonPointerIterator
 
JsonPointerIterator(Object) - Constructor for class io.vertx.reactivex.core.json.pointer.JsonPointerIterator
 
jsonResp(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.RESP.
JsonSchema - Class in io.vertx.reactivex.json.schema
A Json-Schema holder.
JsonSchema(JsonSchema) - Constructor for class io.vertx.reactivex.json.schema.JsonSchema
 
JsonSchema(Object) - Constructor for class io.vertx.reactivex.json.schema.JsonSchema
 
jsonSet(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.SET.
jsonStrappend(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.STRAPPEND.
jsonStream(JsonParser) - Static method in class io.vertx.reactivex.ext.web.codec.BodyCodec
A body codec that parse the response as a JSON stream.
jsonStrlen(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.STRLEN.
jsonToggle(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.TOGGLE.
jsonType(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.TYPE.
jWKSet() - Method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
Retrieve the public server JSON Web Key (JWK) required to verify the authenticity of issued ID and access tokens.
JWTAuth - Class in io.vertx.reactivex.ext.auth.jwt
Factory interface for creating JWT based AuthenticationProvider instances.
JWTAuth(JWTAuth) - Constructor for class io.vertx.reactivex.ext.auth.jwt.JWTAuth
 
JWTAuth(Object) - Constructor for class io.vertx.reactivex.ext.auth.jwt.JWTAuth
 
JWTAuthHandler - Class in io.vertx.reactivex.ext.web.handler
An auth handler that provides JWT Authentication support.
JWTAuthHandler(JWTAuthHandler) - Constructor for class io.vertx.reactivex.ext.web.handler.JWTAuthHandler
 
JWTAuthHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.JWTAuthHandler
 
JWTAuthorization - Class in io.vertx.reactivex.ext.auth.jwt.authorization
Implementation of the JWT authorization provider.
JWTAuthorization(JWTAuthorization) - Constructor for class io.vertx.reactivex.ext.auth.jwt.authorization.JWTAuthorization
 
JWTAuthorization(Object) - Constructor for class io.vertx.reactivex.ext.auth.jwt.authorization.JWTAuthorization
 

K

KafkaAdminClient - Class in io.vertx.reactivex.kafka.admin
Vert.x Kafka Admin client implementation
KafkaAdminClient(KafkaAdminClient) - Constructor for class io.vertx.reactivex.kafka.admin.KafkaAdminClient
 
KafkaAdminClient(Object) - Constructor for class io.vertx.reactivex.kafka.admin.KafkaAdminClient
 
KafkaConsumer<K,​V> - Class in io.vertx.reactivex.kafka.client.consumer
Vert.x Kafka consumer.
KafkaConsumer(KafkaConsumer) - Constructor for class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
 
KafkaConsumer(Object, TypeArg<K>, TypeArg<V>) - Constructor for class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
 
KafkaConsumerRecord<K,​V> - Class in io.vertx.reactivex.kafka.client.consumer
Vert.x Kafka consumer record
KafkaConsumerRecord(KafkaConsumerRecord) - Constructor for class io.vertx.reactivex.kafka.client.consumer.KafkaConsumerRecord
 
KafkaConsumerRecord(Object, TypeArg<K>, TypeArg<V>) - Constructor for class io.vertx.reactivex.kafka.client.consumer.KafkaConsumerRecord
 
KafkaConsumerRecords<K,​V> - Class in io.vertx.reactivex.kafka.client.consumer
Vert.x Kafka consumer records
KafkaConsumerRecords(KafkaConsumerRecords) - Constructor for class io.vertx.reactivex.kafka.client.consumer.KafkaConsumerRecords
 
KafkaConsumerRecords(Object, TypeArg<K>, TypeArg<V>) - Constructor for class io.vertx.reactivex.kafka.client.consumer.KafkaConsumerRecords
 
KafkaHeader - Class in io.vertx.reactivex.kafka.client.producer
Vert.x Kafka producer record header.
KafkaHeader(KafkaHeader) - Constructor for class io.vertx.reactivex.kafka.client.producer.KafkaHeader
 
KafkaHeader(Object) - Constructor for class io.vertx.reactivex.kafka.client.producer.KafkaHeader
 
KafkaProducer<K,​V> - Class in io.vertx.reactivex.kafka.client.producer
Vert.x Kafka producer.
KafkaProducer(KafkaProducer) - Constructor for class io.vertx.reactivex.kafka.client.producer.KafkaProducer
 
KafkaProducer(Object, TypeArg<K>, TypeArg<V>) - Constructor for class io.vertx.reactivex.kafka.client.producer.KafkaProducer
 
KafkaProducerRecord<K,​V> - Class in io.vertx.reactivex.kafka.client.producer
Vert.x Kafka producer record.
KafkaProducerRecord(KafkaProducerRecord) - Constructor for class io.vertx.reactivex.kafka.client.producer.KafkaProducerRecord
 
KafkaProducerRecord(Object, TypeArg<K>, TypeArg<V>) - Constructor for class io.vertx.reactivex.kafka.client.producer.KafkaProducerRecord
 
KEEP_ALIVE - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
keep-alive header value
keepAliveTimeSeconds() - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
 
key() - Method in class io.vertx.reactivex.core.net.endpoint.ServerEndpoint
 
key() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumerRecord
 
key() - Method in class io.vertx.reactivex.kafka.client.producer.KafkaHeader
 
key() - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducerRecord
 
key(String, Vertx) - Static method in class io.vertx.reactivex.ext.consul.Watch
Creates Watch to monitoring a specific key in the KV store.
key(String, Vertx, ConsulClientOptions) - Static method in class io.vertx.reactivex.ext.consul.Watch
Creates Watch to monitoring a specific key in the KV store.
KEY_META_DATA_OPERATION - Static variable in class io.vertx.reactivex.ext.web.openapi.router.RouterBuilder
 
KEY_META_DATA_VALIDATED_REQUEST - Static variable in class io.vertx.reactivex.ext.web.openapi.router.RouterBuilder
 
KeycloakAuth - Class in io.vertx.reactivex.ext.auth.oauth2.providers
Simplified factory to create an for Keycloak.
KeycloakAuth(KeycloakAuth) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.KeycloakAuth
 
KeycloakAuth(Object) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.KeycloakAuth
 
KeycloakAuthorization - Class in io.vertx.reactivex.ext.auth.oauth2.authorization
Implementation of the Keycloak Authorization Provider.
KeycloakAuthorization(KeycloakAuthorization) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.authorization.KeycloakAuthorization
 
KeycloakAuthorization(Object) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.authorization.KeycloakAuthorization
 
keyPrefix(String, Vertx) - Static method in class io.vertx.reactivex.ext.consul.Watch
Creates Watch to monitoring a prefix of keys in the KV store.
keyPrefix(String, Vertx, ConsulClientOptions) - Static method in class io.vertx.reactivex.ext.consul.Watch
Creates Watch to monitoring a prefix of keys in the KV store.
keys() - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
Get the keys of the map, asynchronously.
keys(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Find all keys matching the given pattern.

L

label(String) - Method in class io.vertx.reactivex.ext.web.handler.OtpAuthHandler
Configure the label value to be shown in the authenticator URL.
LanguageHeader - Class in io.vertx.reactivex.ext.web
A parsed language header.
LanguageHeader(LanguageHeader) - Constructor for class io.vertx.reactivex.ext.web.LanguageHeader
 
LanguageHeader(Object) - Constructor for class io.vertx.reactivex.ext.web.LanguageHeader
 
last() - Method in class io.vertx.reactivex.ext.web.Route
Specify this is the last route for the router.
last() - Method in class io.vertx.reactivex.grpc.client.GrpcClientResponse
 
last() - Method in class io.vertx.reactivex.grpc.common.GrpcReadStream
 
last() - Method in class io.vertx.reactivex.grpc.server.GrpcServerRequest
 
LAST_INSERTED_ID - Static variable in class io.vertx.reactivex.mysqlclient.MySQLClient
SqlResult for MySQL last_insert_id.
The property kind can be used to fetch the auto incremented id of the last row when executing inserting or updating operations.
LAST_MODIFIED - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Last-Modified header name
lastAccessed() - Method in class io.vertx.reactivex.ext.web.Session
 
lastMessageId() - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
 
lastModified(String) - Method in class io.vertx.reactivex.ext.web.RoutingContext
Set the Last-Modified date using a String.
lastModified(Instant) - Method in class io.vertx.reactivex.ext.web.RoutingContext
Set the Last-Modified date using a Instant.
lastsave() - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the UNIX time stamp of the last successful save to disk.
latency(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
A container for latency diagnostics commands.
lcs(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Find longest common substring.
LdapAuthentication - Class in io.vertx.reactivex.ext.auth.ldap
Factory interface for creating a LDAP AuthenticationProvider.
LdapAuthentication(LdapAuthentication) - Constructor for class io.vertx.reactivex.ext.auth.ldap.LdapAuthentication
 
LdapAuthentication(Object) - Constructor for class io.vertx.reactivex.ext.auth.ldap.LdapAuthentication
 
leaderStatus() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Get the Raft leader for the datacenter in which the agent is running.
length() - Method in class io.vertx.reactivex.ext.web.RequestBody
Returns the total length of the body buffer.
lindex(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get an element from a list by its index.
linearDelay(long, long) - Static method in class io.vertx.reactivex.circuitbreaker.RetryPolicy
Create a linear delay retry policy.
link(String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
Create a hard link on the file system from link to existing, asynchronously.
linkBlocking(String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
LinkedInAuth - Class in io.vertx.reactivex.ext.auth.oauth2.providers
Simplified factory to create an for LinkedIn.
LinkedInAuth(LinkedInAuth) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.LinkedInAuth
 
LinkedInAuth(Object) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.LinkedInAuth
 
linsert(String, String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Insert an element before or after another element in a list.
listConsumerGroups() - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
Get the the consumer groups available in the cluster with the default options
listen() - Method in class io.vertx.reactivex.core.http.HttpServer
Tell the server to start listening.
listen() - Method in class io.vertx.reactivex.core.net.NetServer
Start listening on the port and host as configured in the NetServerOptions used when creating the server.
listen() - Method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.TcpEventBusBridge
Start listening on the port and host as configured in the NetServerOptions used when creating the server.
listen() - Method in class io.vertx.reactivex.ext.stomp.StompServer
Connects the STOMP server default port (61613) and network interface (0.0.0.0).
listen() - Method in class io.vertx.reactivex.mqtt.MqttServer
Start the server listening for incoming connections using the specified options through the constructor
listen(int) - Method in class io.vertx.reactivex.core.http.HttpServer
Like HttpServer.listen() but the server will listen on host "0.0.0.0" and port specified here ignoring any value in the HttpServerOptions that was used when creating the server.
listen(int) - Method in class io.vertx.reactivex.core.net.NetServer
Start listening on the specified port and host "0.0.0.0", ignoring port and host configured in the NetServerOptions used when creating the server.
listen(int) - Method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.TcpEventBusBridge
Start listening on the specified port and host "0.0.0.0", ignoring port and host configured in the NetServerOptions used when creating the server.
listen(int) - Method in class io.vertx.reactivex.ext.stomp.StompServer
Connects the STOMP server to the given port.
listen(int) - Method in class io.vertx.reactivex.mqtt.MqttServer
Start the server listening for incoming connections on the port specified but on "0.0.0.0" as host.
listen(int, String) - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
Start listening on the given port and host.
listen(int, String) - Method in class io.vertx.reactivex.core.http.HttpServer
Tell the server to start listening.
listen(int, String) - Method in class io.vertx.reactivex.core.net.NetServer
Start listening on the specified port and host, ignoring port and host configured in the NetServerOptions used when creating the server.
listen(int, String) - Method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.TcpEventBusBridge
Start listening on the specified port and host, ignoring port and host configured in the NetServerOptions used when creating the server.
listen(int, String) - Method in class io.vertx.reactivex.ext.stomp.StompServer
Connects the STOMP server to the given port / interface.
listen(int, String) - Method in class io.vertx.reactivex.mqtt.MqttServer
Start the server listening for incoming connections on the port and host specified
listen(Handler<ConfigChange>) - Method in class io.vertx.reactivex.config.ConfigRetriever
Registers a listener receiving configuration changes.
listen(SocketAddress) - Method in class io.vertx.reactivex.core.http.HttpServer
Tell the server to start listening on the given address supplying a handler that will be called when the server is actually listening (or has failed).
listen(SocketAddress) - Method in class io.vertx.reactivex.core.net.NetServer
Start listening on the specified local address, ignoring port and host configured in the NetServerOptions used when creating the server.
listen(SocketAddress) - Method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.TcpEventBusBridge
Start listening on the specified local address, ignoring port and host configured in the used when creating the server.
listenMulticastGroup(String) - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
Joins a multicast group and listens for packets send to it.
listenMulticastGroup(String, String, String) - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
Joins a multicast group and listens for packets send to it on the given network interface.
listEvents() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the most recent events known by the agent
listEventsWithOptions(EventListOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the most recent events known by the agent.
listIndexes(String) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Get all the indexes in this collection.
listNodeSessions(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the active sessions for a given node
listNodeSessionsWithOptions(String, BlockingQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the active sessions for a given node This is blocking query unlike ConsulClient.listNodeSessions(java.lang.String)
listSessions() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the active sessions
listSessionsWithOptions(BlockingQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the active sessions This is blocking query unlike ConsulClient.listSessions()
listTopics() - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
List the topics available in the cluster with the default options.
LiveAuth - Class in io.vertx.reactivex.ext.auth.oauth2.providers
Simplified factory to create an for live.com Services.
LiveAuth(LiveAuth) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.LiveAuth
 
LiveAuth(Object) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.LiveAuth
 
llen(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the length of a list.
lmove(String, String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Pop an element from a list, push it to another list and return it.
lmpop(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Pop elements from a list.
load() - Static method in class io.vertx.reactivex.ext.auth.hashing.HashingStrategy
Factory method to load the algorithms from the system
localAddress() - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
Return the SocketAddress to which this DatagramSocket is bound.
localAddress() - Method in class io.vertx.reactivex.core.http.ClientWebSocket
 
localAddress() - Method in class io.vertx.reactivex.core.http.HttpConnection
 
localAddress() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
 
localAddress() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
 
localAddress() - Method in class io.vertx.reactivex.core.http.ServerWebSocketHandshake
 
localAddress() - Method in class io.vertx.reactivex.core.http.WebSocket
 
localAddress() - Method in interface io.vertx.reactivex.core.http.WebSocketBase
 
localAddress() - Method in class io.vertx.reactivex.core.net.NetSocket
 
localAddress() - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
Return the local address for this socket
localAddress() - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
 
localAddress(boolean) - Method in class io.vertx.reactivex.core.http.HttpConnection
Like HttpConnection.localAddress() ()} but returns the server local address when real is true
localAddress(boolean) - Method in class io.vertx.reactivex.core.net.NetSocket
Like NetSocket.localAddress() ()} but returns the server local address when real is true
localChecks() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Return all the checks that are registered with the local agent.
localConsumer(String) - Method in class io.vertx.reactivex.core.eventbus.EventBus
Like EventBus.consumer(io.vertx.core.eventbus.MessageConsumerOptions) but the address won't be propagated across the cluster.
localConsumer(String, Handler<Message<T>>) - Method in class io.vertx.reactivex.core.eventbus.EventBus
Like EventBus.consumer(io.vertx.core.eventbus.MessageConsumerOptions) but the address won't be propagated across the cluster.
LocalMap<K,​V> - Class in io.vertx.reactivex.core.shareddata
Local maps can be used to share data safely in a single Vert.x instance.
LocalMap(LocalMap) - Constructor for class io.vertx.reactivex.core.shareddata.LocalMap
 
LocalMap(Object, TypeArg<K>, TypeArg<V>) - Constructor for class io.vertx.reactivex.core.shareddata.LocalMap
 
localServices() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns list of services registered with the local agent.
LocalSessionStore - Class in io.vertx.reactivex.ext.web.sstore
A session store which is only available on a single node.
LocalSessionStore(LocalSessionStore) - Constructor for class io.vertx.reactivex.ext.web.sstore.LocalSessionStore
 
LocalSessionStore(Object) - Constructor for class io.vertx.reactivex.ext.web.sstore.LocalSessionStore
 
LOCATION - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Location header name
lock() - Method in class io.vertx.reactivex.core.file.AsyncFile
Acquire a non-shared lock on the entire file.
lock(long, long, boolean) - Method in class io.vertx.reactivex.core.file.AsyncFile
Acquire a lock on a portion of this file.
Lock - Class in io.vertx.reactivex.core.shareddata
An asynchronous exclusive lock which can be obtained from any node in the cluster.
Lock(Lock) - Constructor for class io.vertx.reactivex.core.shareddata.Lock
 
Lock(Object) - Constructor for class io.vertx.reactivex.core.shareddata.Lock
 
LoggerFormatter - Class in io.vertx.reactivex.ext.web.handler
Implement to format the output of the LoggerHandler
LoggerFormatter(LoggerFormatter) - Constructor for class io.vertx.reactivex.ext.web.handler.LoggerFormatter
 
LoggerFormatter(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.LoggerFormatter
 
LoggerHandler - Class in io.vertx.reactivex.ext.web.handler
A handler which logs request information to the Vert.x logger.
LoggerHandler(LoggerHandler) - Constructor for class io.vertx.reactivex.ext.web.handler.LoggerHandler
 
LoggerHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.LoggerHandler
 
loginHint(String) - Method in class io.vertx.reactivex.ext.web.UserContext
When performing a web identity operation, hint if possible to the identity provider to use the given login.
logout() - Method in class io.vertx.reactivex.ext.web.UserContext
Logout can be called from any route handler which needs to terminate a login session.
logout(String) - Method in class io.vertx.reactivex.ext.web.UserContext
Logout can be called from any route handler which needs to terminate a login session.
lolwut(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Display some computer art and the Redis version.
lookup(String) - Method in class io.vertx.reactivex.core.dns.DnsClient
Try to lookup the A (ipv4) or AAAA (ipv6) record for the given name.
lookup4(String) - Method in class io.vertx.reactivex.core.dns.DnsClient
Try to lookup the A (ipv4) record for the given name.
lookup6(String) - Method in class io.vertx.reactivex.core.dns.DnsClient
Try to lookup the AAAA (ipv6) record for the given name.
lpop(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove and get the first elements in a list.
lpos(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Return the index of matching elements on a list.
lprops(String) - Method in class io.vertx.reactivex.core.file.FileSystem
Obtain properties for the link represented by path, asynchronously.
lpropsBlocking(String) - Method in class io.vertx.reactivex.core.file.FileSystem
lpush(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Prepend one or multiple elements to a list.
lpushx(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Prepend an element to a list, only if the list exists.
lrange(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get a range of elements from a list.
lrem(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove elements from a list.
lset(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Set the value of an element in a list by its index.
ltrim(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Trim a list to the specified range.

M

MailAttachment - Class in io.vertx.reactivex.ext.mail
Represent a mail attachment that can be used in a MailMessage.
MailAttachment(MailAttachment) - Constructor for class io.vertx.reactivex.ext.mail.MailAttachment
 
MailAttachment(Object) - Constructor for class io.vertx.reactivex.ext.mail.MailAttachment
 
MailchimpAuth - Class in io.vertx.reactivex.ext.auth.oauth2.providers
Simplified factory to create an for Mailchimp.
MailchimpAuth(MailchimpAuth) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.MailchimpAuth
 
MailchimpAuth(Object) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.MailchimpAuth
 
MailClient - Class in io.vertx.reactivex.ext.mail
SMTP mail client for Vert.x
MailClient(MailClient) - Constructor for class io.vertx.reactivex.ext.mail.MailClient
 
MailClient(Object) - Constructor for class io.vertx.reactivex.ext.mail.MailClient
 
maintenanceService(MaintenanceOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Places a given service into "maintenance mode"
majorVersion() - Method in class io.vertx.reactivex.sqlclient.spi.DatabaseMetadata
 
map(Row) - Method in class io.vertx.reactivex.sqlclient.templates.RowMapper
Build a T representation of the given row
map(Function<Integer, String>, int, T) - Method in class io.vertx.reactivex.sqlclient.templates.TupleMapper
The internal mapper contract that builds a tuple.
mapFrom(TupleMapper<T>) - Method in class io.vertx.reactivex.sqlclient.templates.SqlTemplate
Set a parameters user defined mapping function.
mapFrom(Class<T>) - Method in class io.vertx.reactivex.sqlclient.templates.SqlTemplate
Set a parameters user defined class mapping.
mapper(Function<T, Map<String, Object>>) - Static method in class io.vertx.reactivex.sqlclient.templates.TupleMapper
Create a mapper that associates a parameters object to a map of named parameters to their respective value.
mapping(Function<Row, U>) - Method in class io.vertx.reactivex.sqlclient.PreparedQuery
Use the specified mapper for mapping Row to .
mapping(Function<Row, U>) - Method in class io.vertx.reactivex.sqlclient.Query
Use the specified mapper for mapping Row to .
mapTo(RowMapper<U>) - Method in class io.vertx.reactivex.sqlclient.templates.SqlTemplate
Set a row user defined mapping function.
mapTo(Class<U>) - Method in class io.vertx.reactivex.sqlclient.templates.SqlTemplate
Set a row user defined mapping function.
match(AuthorizationContext) - Method in class io.vertx.reactivex.ext.auth.authorization.AndAuthorization
this methods verifies whether or not the authorization match the specified context.
match(AuthorizationContext) - Method in interface io.vertx.reactivex.ext.auth.authorization.Authorization
this methods verifies whether or not the authorization match the specified context.
match(AuthorizationContext) - Method in class io.vertx.reactivex.ext.auth.authorization.NotAuthorization
this methods verifies whether or not the authorization match the specified context.
match(AuthorizationContext) - Method in class io.vertx.reactivex.ext.auth.authorization.OrAuthorization
this methods verifies whether or not the authorization match the specified context.
match(AuthorizationContext) - Method in class io.vertx.reactivex.ext.auth.authorization.PermissionBasedAuthorization
this methods verifies whether or not the authorization match the specified context.
match(AuthorizationContext) - Method in class io.vertx.reactivex.ext.auth.authorization.RoleBasedAuthorization
this methods verifies whether or not the authorization match the specified context.
match(AuthorizationContext) - Method in class io.vertx.reactivex.ext.auth.authorization.WildcardPermissionBasedAuthorization
this methods verifies whether or not the authorization match the specified context.
match(User) - Method in class io.vertx.reactivex.ext.auth.abac.Attribute
Verifies whether the attribute matches the specified user.
match(User) - Method in class io.vertx.reactivex.ext.auth.authorization.AndAuthorization
this methods verifies whether or not the authorization match the specified user.
match(User) - Method in class io.vertx.reactivex.ext.auth.authorization.NotAuthorization
this methods verifies whether or not the authorization match the specified user.
match(User) - Method in class io.vertx.reactivex.ext.auth.authorization.OrAuthorization
this methods verifies whether or not the authorization match the specified user.
match(User) - Method in class io.vertx.reactivex.ext.auth.authorization.PermissionBasedAuthorization
this methods verifies whether or not the authorization match the specified user.
match(User) - Method in class io.vertx.reactivex.ext.auth.authorization.RoleBasedAuthorization
this methods verifies whether or not the authorization match the specified user.
match(User) - Method in class io.vertx.reactivex.ext.auth.authorization.WildcardPermissionBasedAuthorization
this methods verifies whether or not the authorization match the specified user.
matches(String) - Method in class io.vertx.reactivex.ext.stomp.Destination
Checks whether or not the given address matches with the current destination.
maxActiveStreams() - Method in class io.vertx.reactivex.core.http.HttpClientConnection
 
maxAgeSeconds(int) - Method in class io.vertx.reactivex.ext.web.handler.CorsHandler
Set how long the browser should cache the information
maxRecordSize(int) - Method in class io.vertx.reactivex.core.parsetools.RecordParser
Set the maximum allowed size for a record when using the delimited mode.
Measured - Interface in io.vertx.reactivex.core.metrics
NOTE: This class has been automatically generated from the original non RX-ified interface using Vert.x codegen.
mediaType() - Method in class io.vertx.reactivex.ext.web.MIMEHeader
Gets the MIME media type string.
mediaType() - Method in class io.vertx.reactivex.ext.web.multipart.FormDataPart
 
MediaType - Class in io.vertx.reactivex.openapi.contract
This interface represents the most important attributes of an OpenAPI Operation.
MediaType(MediaType) - Constructor for class io.vertx.reactivex.openapi.contract.MediaType
 
MediaType(Object) - Constructor for class io.vertx.reactivex.openapi.contract.MediaType
 
mediaTypeWithParams() - Method in class io.vertx.reactivex.ext.web.MIMEHeader
Gets the MIME media type string with parameters attached.
memory(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
A container for memory diagnostics commands.
merge(User) - Method in class io.vertx.reactivex.ext.auth.User
Merge the principal and attributes of a second user into this object properties.
message() - Method in class io.vertx.reactivex.core.eventbus.DeliveryContext
 
message() - Method in class io.vertx.reactivex.ext.unit.report.Failure
 
message() - Method in class io.vertx.reactivex.ext.web.handler.graphql.ws.ConnectionInitEvent
Provides message content.
message() - Method in class io.vertx.reactivex.ext.web.handler.graphql.ws.Message
 
Message<T> - Class in io.vertx.reactivex.core.eventbus
Represents a message that is received from the event bus in a handler.
Message - Class in io.vertx.reactivex.ext.web.handler.graphql.ws
Message(Message) - Constructor for class io.vertx.reactivex.core.eventbus.Message
 
Message(Message) - Constructor for class io.vertx.reactivex.ext.web.handler.graphql.ws.Message
 
Message(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.graphql.ws.Message
 
Message(Object, TypeArg<T>) - Constructor for class io.vertx.reactivex.core.eventbus.Message
 
MessageConsumer<T> - Class in io.vertx.reactivex.core.eventbus
An event bus consumer object representing a stream of message to an EventBus address that can be read from.
MessageConsumer(MessageConsumer) - Constructor for class io.vertx.reactivex.core.eventbus.MessageConsumer
 
MessageConsumer(Object, TypeArg<T>) - Constructor for class io.vertx.reactivex.core.eventbus.MessageConsumer
 
messageCount() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQMessage
 
messageCount(String) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Returns the number of messages in a queue ready to be delivered.
messageHandler(Handler<GrpcMessage>) - Method in class io.vertx.reactivex.grpc.client.GrpcClientResponse
 
messageHandler(Handler<GrpcMessage>) - Method in class io.vertx.reactivex.grpc.common.GrpcReadStream
Set a handler to be notified with incoming encoded messages.
messageHandler(Handler<GrpcMessage>) - Method in class io.vertx.reactivex.grpc.server.GrpcServerRequest
 
messageId() - Method in interface io.vertx.reactivex.mqtt.messages.MqttMessage
 
messageId() - Method in class io.vertx.reactivex.mqtt.messages.MqttPubAckMessage
 
messageId() - Method in class io.vertx.reactivex.mqtt.messages.MqttPubCompMessage
 
messageId() - Method in class io.vertx.reactivex.mqtt.messages.MqttPublishMessage
 
messageId() - Method in class io.vertx.reactivex.mqtt.messages.MqttPubRecMessage
 
messageId() - Method in class io.vertx.reactivex.mqtt.messages.MqttPubRelMessage
 
messageId() - Method in class io.vertx.reactivex.mqtt.messages.MqttSubAckMessage
 
messageId() - Method in class io.vertx.reactivex.mqtt.messages.MqttSubscribeMessage
 
messageId() - Method in class io.vertx.reactivex.mqtt.messages.MqttUnsubscribeMessage
 
MessageProducer<T> - Class in io.vertx.reactivex.core.eventbus
Represents a stream of message that can be written to.
MessageProducer(MessageProducer) - Constructor for class io.vertx.reactivex.core.eventbus.MessageProducer
 
MessageProducer(Object, TypeArg<T>) - Constructor for class io.vertx.reactivex.core.eventbus.MessageProducer
 
MessageSource - Class in io.vertx.reactivex.servicediscovery.types
Service type for data producer.
MessageSource(MessageSource) - Constructor for class io.vertx.reactivex.servicediscovery.types.MessageSource
 
MessageSource(Object) - Constructor for class io.vertx.reactivex.servicediscovery.types.MessageSource
 
metadata() - Method in class io.vertx.reactivex.cassandra.CassandraClient
Get for the session.
metadata() - Method in class io.vertx.reactivex.ext.web.Route
 
metadata() - Method in class io.vertx.reactivex.ext.web.Router
 
method() - Method in class io.vertx.reactivex.core.http.HttpRequestHead
 
method() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
 
method() - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
 
method(HttpMethod) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Configure the request to use a new method value.
method(HttpMethod) - Method in class io.vertx.reactivex.ext.web.Route
Add an HTTP method for this route.
methodName() - Method in class io.vertx.reactivex.grpc.server.GrpcServerRequest
 
methodName(String) - Method in class io.vertx.reactivex.grpc.client.GrpcClientRequest
Set the method name to call.
MethodOverrideHandler - Class in io.vertx.reactivex.ext.web.handler
NOTE: This class has been automatically generated from the original non RX-ified interface using Vert.x codegen.
MethodOverrideHandler(MethodOverrideHandler) - Constructor for class io.vertx.reactivex.ext.web.handler.MethodOverrideHandler
 
MethodOverrideHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.MethodOverrideHandler
 
methods() - Method in class io.vertx.reactivex.ext.web.Route
 
metricsNames() - Method in class io.vertx.reactivex.ext.dropwizard.MetricsService
 
metricsNames() - Method in class io.vertx.reactivex.micrometer.MetricsService
 
MetricsService - Class in io.vertx.reactivex.ext.dropwizard
The metrics service mainly allows to return a snapshot of measured objects.
MetricsService - Class in io.vertx.reactivex.micrometer
The metrics service mainly allows to return a snapshot of measured objects.
This service is derived and adapted from MetricsService in the vertx-dropwizard-metrics module.
MetricsService(MetricsService) - Constructor for class io.vertx.reactivex.ext.dropwizard.MetricsService
 
MetricsService(MetricsService) - Constructor for class io.vertx.reactivex.micrometer.MetricsService
 
MetricsService(Object) - Constructor for class io.vertx.reactivex.ext.dropwizard.MetricsService
 
MetricsService(Object) - Constructor for class io.vertx.reactivex.micrometer.MetricsService
 
mget(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the values of all the given keys.
MicroProfileAuthorization - Class in io.vertx.reactivex.ext.auth.jwt.authorization
Implementation of the Microprofile MP-JWT 1.1 RBAC based on the access token groups key.
MicroProfileAuthorization(MicroProfileAuthorization) - Constructor for class io.vertx.reactivex.ext.auth.jwt.authorization.MicroProfileAuthorization
 
MicroProfileAuthorization(Object) - Constructor for class io.vertx.reactivex.ext.auth.jwt.authorization.MicroProfileAuthorization
 
migrate(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Atomically transfer a key from a Redis instance to another one.
MIMEHeader - Class in io.vertx.reactivex.ext.web
 
MIMEHeader(MIMEHeader) - Constructor for class io.vertx.reactivex.ext.web.MIMEHeader
 
MIMEHeader(Object) - Constructor for class io.vertx.reactivex.ext.web.MIMEHeader
 
minorVersion() - Method in class io.vertx.reactivex.sqlclient.spi.DatabaseMetadata
 
missingKeyHandler(Handler<String>) - Method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
Handled to be called when a key (mentioned on a JWT) is missing from the current config.
mkdir(String) - Method in class io.vertx.reactivex.core.file.FileSystem
Create the directory represented by path, asynchronously.
mkdir(String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
Create the directory represented by path, asynchronously.
mkdirBlocking(String) - Method in class io.vertx.reactivex.core.file.FileSystem
mkdirBlocking(String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
mkdirs(String) - Method in class io.vertx.reactivex.core.file.FileSystem
Create the directory represented by path and any non existent parents, asynchronously.
mkdirs(String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
Create the directory represented by path and any non existent parents, asynchronously.
mkdirsBlocking(String) - Method in class io.vertx.reactivex.core.file.FileSystem
mkdirsBlocking(String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
mode() - Static method in class io.vertx.reactivex.ext.web.common.WebEnvironment
The current mode from the system properties with fallback to environment variables
modified(boolean, boolean) - Method in class io.vertx.reactivex.amqp.AmqpMessage
When receiving a message, and when auto-acknowledgement is disabled, this method is used to acknowledge the incoming message as modified.
modifiedHandler(Handler<Router>) - Method in class io.vertx.reactivex.ext.web.Router
When a Router routes are changed this handler is notified.
module(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
A container for module commands.
MongoClient - Class in io.vertx.reactivex.ext.mongo
A Vert.x service used to interact with MongoDB server instances.
MongoClient(MongoClient) - Constructor for class io.vertx.reactivex.ext.mongo.MongoClient
 
MongoClient(Object) - Constructor for class io.vertx.reactivex.ext.mongo.MongoClient
 
MongoDataSource - Class in io.vertx.reactivex.servicediscovery.types
NOTE: This class has been automatically generated from the original non RX-ified interface using Vert.x codegen.
MongoDataSource(MongoDataSource) - Constructor for class io.vertx.reactivex.servicediscovery.types.MongoDataSource
 
MongoDataSource(Object) - Constructor for class io.vertx.reactivex.servicediscovery.types.MongoDataSource
 
MongoGridFsClient - Class in io.vertx.reactivex.ext.mongo
 
MongoGridFsClient(MongoGridFsClient) - Constructor for class io.vertx.reactivex.ext.mongo.MongoGridFsClient
 
MongoGridFsClient(Object) - Constructor for class io.vertx.reactivex.ext.mongo.MongoGridFsClient
 
monitor() - Method in class io.vertx.reactivex.redis.client.RedisAPI
Listen for all requests received by the server in real time.
mountPoint() - Method in class io.vertx.reactivex.ext.web.RoutingContext
 
move(String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
Move a file from the path from to path to, asynchronously.
move(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Move a key to another database.
move(String, String, CopyOptions) - Method in class io.vertx.reactivex.core.file.FileSystem
Move a file from the path from to path to, asynchronously.
moveBlocking(String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
MqttAuthenticationExchangeMessage - Class in io.vertx.reactivex.mqtt.messages
Represents an MQTT AUTH message
MqttAuthenticationExchangeMessage(MqttAuthenticationExchangeMessage) - Constructor for class io.vertx.reactivex.mqtt.messages.MqttAuthenticationExchangeMessage
 
MqttAuthenticationExchangeMessage(Object) - Constructor for class io.vertx.reactivex.mqtt.messages.MqttAuthenticationExchangeMessage
 
MqttClient - Class in io.vertx.reactivex.mqtt
An MQTT client
MqttClient(MqttClient) - Constructor for class io.vertx.reactivex.mqtt.MqttClient
 
MqttClient(Object) - Constructor for class io.vertx.reactivex.mqtt.MqttClient
 
MqttConnAckMessage - Class in io.vertx.reactivex.mqtt.messages
Represents an MQTT CONNACK message
MqttConnAckMessage(MqttConnAckMessage) - Constructor for class io.vertx.reactivex.mqtt.messages.MqttConnAckMessage
 
MqttConnAckMessage(Object) - Constructor for class io.vertx.reactivex.mqtt.messages.MqttConnAckMessage
 
MqttDisconnectMessage - Class in io.vertx.reactivex.mqtt.messages
Represents an MQTT CONNACK message
MqttDisconnectMessage(MqttDisconnectMessage) - Constructor for class io.vertx.reactivex.mqtt.messages.MqttDisconnectMessage
 
MqttDisconnectMessage(Object) - Constructor for class io.vertx.reactivex.mqtt.messages.MqttDisconnectMessage
 
MqttEndpoint - Class in io.vertx.reactivex.mqtt
Represents an MQTT endpoint for point-to-point communication with the remote MQTT client
MqttEndpoint(MqttEndpoint) - Constructor for class io.vertx.reactivex.mqtt.MqttEndpoint
 
MqttEndpoint(Object) - Constructor for class io.vertx.reactivex.mqtt.MqttEndpoint
 
MqttMessage - Interface in io.vertx.reactivex.mqtt.messages
Represent the interface for each MQTT message
MqttPubAckMessage - Class in io.vertx.reactivex.mqtt.messages
Represents an MQTT PUBACK message
MqttPubAckMessage(MqttPubAckMessage) - Constructor for class io.vertx.reactivex.mqtt.messages.MqttPubAckMessage
 
MqttPubAckMessage(Object) - Constructor for class io.vertx.reactivex.mqtt.messages.MqttPubAckMessage
 
MqttPubCompMessage - Class in io.vertx.reactivex.mqtt.messages
Represents an MQTT PUBCOMP message
MqttPubCompMessage(MqttPubCompMessage) - Constructor for class io.vertx.reactivex.mqtt.messages.MqttPubCompMessage
 
MqttPubCompMessage(Object) - Constructor for class io.vertx.reactivex.mqtt.messages.MqttPubCompMessage
 
MqttPublishMessage - Class in io.vertx.reactivex.mqtt.messages
Represents an MQTT PUBLISH message
MqttPublishMessage(MqttPublishMessage) - Constructor for class io.vertx.reactivex.mqtt.messages.MqttPublishMessage
 
MqttPublishMessage(Object) - Constructor for class io.vertx.reactivex.mqtt.messages.MqttPublishMessage
 
MqttPubRecMessage - Class in io.vertx.reactivex.mqtt.messages
Represents an MQTT PUBREC message
MqttPubRecMessage(MqttPubRecMessage) - Constructor for class io.vertx.reactivex.mqtt.messages.MqttPubRecMessage
 
MqttPubRecMessage(Object) - Constructor for class io.vertx.reactivex.mqtt.messages.MqttPubRecMessage
 
MqttPubRelMessage - Class in io.vertx.reactivex.mqtt.messages
Represents an MQTT PUBREL message
MqttPubRelMessage(MqttPubRelMessage) - Constructor for class io.vertx.reactivex.mqtt.messages.MqttPubRelMessage
 
MqttPubRelMessage(Object) - Constructor for class io.vertx.reactivex.mqtt.messages.MqttPubRelMessage
 
MqttServer - Class in io.vertx.reactivex.mqtt
An MQTT server
MqttServer(MqttServer) - Constructor for class io.vertx.reactivex.mqtt.MqttServer
 
MqttServer(Object) - Constructor for class io.vertx.reactivex.mqtt.MqttServer
 
MqttSubAckMessage - Class in io.vertx.reactivex.mqtt.messages
Represents an MQTT SUBACK message
MqttSubAckMessage(MqttSubAckMessage) - Constructor for class io.vertx.reactivex.mqtt.messages.MqttSubAckMessage
 
MqttSubAckMessage(Object) - Constructor for class io.vertx.reactivex.mqtt.messages.MqttSubAckMessage
 
MqttSubscribeMessage - Class in io.vertx.reactivex.mqtt.messages
Represents an MQTT SUBSCRIBE message
MqttSubscribeMessage(MqttSubscribeMessage) - Constructor for class io.vertx.reactivex.mqtt.messages.MqttSubscribeMessage
 
MqttSubscribeMessage(Object) - Constructor for class io.vertx.reactivex.mqtt.messages.MqttSubscribeMessage
 
MqttTopicSubscription - Class in io.vertx.reactivex.mqtt
Represents a subscription to a topic
MqttTopicSubscription(MqttTopicSubscription) - Constructor for class io.vertx.reactivex.mqtt.MqttTopicSubscription
 
MqttTopicSubscription(Object) - Constructor for class io.vertx.reactivex.mqtt.MqttTopicSubscription
 
MqttUnsubscribeMessage - Class in io.vertx.reactivex.mqtt.messages
Represents an MQTT UNSUBSCRIBE message
MqttUnsubscribeMessage(MqttUnsubscribeMessage) - Constructor for class io.vertx.reactivex.mqtt.messages.MqttUnsubscribeMessage
 
MqttUnsubscribeMessage(Object) - Constructor for class io.vertx.reactivex.mqtt.messages.MqttUnsubscribeMessage
 
mset(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Set multiple keys to multiple values.
msetnx(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Set multiple keys to multiple values, only if none of the keys exist.
MSSQLBuilder - Class in io.vertx.reactivex.mssqlclient
Entry point for building MSSQL clients.
MSSQLBuilder(MSSQLBuilder) - Constructor for class io.vertx.reactivex.mssqlclient.MSSQLBuilder
 
MSSQLBuilder(Object) - Constructor for class io.vertx.reactivex.mssqlclient.MSSQLBuilder
 
MSSQLConnection - Class in io.vertx.reactivex.mssqlclient
A connection to Microsoft SQL Server.
MSSQLConnection(MSSQLConnection) - Constructor for class io.vertx.reactivex.mssqlclient.MSSQLConnection
 
MSSQLConnection(Object) - Constructor for class io.vertx.reactivex.mssqlclient.MSSQLConnection
 
multi() - Method in class io.vertx.reactivex.redis.client.RedisAPI
Mark the start of a transaction block.
MULTIPART_FORM_DATA - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
multipart/form-data header value
MULTIPART_FORM_DATA - Static variable in class io.vertx.reactivex.openapi.contract.MediaType
 
multipartFileUploadExists(String, String) - Static method in class io.vertx.reactivex.ext.web.validation.RequestPredicate
Generate request predicate that checks if a particular multipart file upload with propertyName and matching contentTypePattern exists
MultipartForm - Class in io.vertx.reactivex.ext.web.multipart
A multipart form.
MultipartForm(MultipartForm) - Constructor for class io.vertx.reactivex.ext.web.multipart.MultipartForm
 
MultipartForm(Object) - Constructor for class io.vertx.reactivex.ext.web.multipart.MultipartForm
 
multipartFormData(ObjectSchemaBuilder) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Bodies
Create a form multipart/form-data processor
multipartMixed() - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
 
multipartMixed(boolean) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Allow or disallow multipart mixed encoding when sending having files sharing the same file name.
MultiTenantHandler - Class in io.vertx.reactivex.ext.web.handler
A handler which selectively executes another handler if a precondition is met.
MultiTenantHandler(MultiTenantHandler) - Constructor for class io.vertx.reactivex.ext.web.handler.MultiTenantHandler
 
MultiTenantHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.MultiTenantHandler
 
MVELTemplateEngine - Class in io.vertx.reactivex.ext.web.templ.mvel
A template engine that uses the Handlebars library.
MVELTemplateEngine(MVELTemplateEngine) - Constructor for class io.vertx.reactivex.ext.web.templ.mvel.MVELTemplateEngine
 
MVELTemplateEngine(Object) - Constructor for class io.vertx.reactivex.ext.web.templ.mvel.MVELTemplateEngine
 
MySQLBuilder - Class in io.vertx.reactivex.mysqlclient
Entry point for building MySQL clients.
MySQLBuilder(MySQLBuilder) - Constructor for class io.vertx.reactivex.mysqlclient.MySQLBuilder
 
MySQLBuilder(Object) - Constructor for class io.vertx.reactivex.mysqlclient.MySQLBuilder
 
MySQLClient - Class in io.vertx.reactivex.mysqlclient
An interface to define MySQL specific constants or behaviors.
MySQLClient(MySQLClient) - Constructor for class io.vertx.reactivex.mysqlclient.MySQLClient
 
MySQLClient(Object) - Constructor for class io.vertx.reactivex.mysqlclient.MySQLClient
 
MySQLConnection - Class in io.vertx.reactivex.mysqlclient
An interface which represents a connection to MySQL server.
MySQLConnection(MySQLConnection) - Constructor for class io.vertx.reactivex.mysqlclient.MySQLConnection
 
MySQLConnection(Object) - Constructor for class io.vertx.reactivex.mysqlclient.MySQLConnection
 

N

nack(StompServerConnection, Frame) - Method in class io.vertx.reactivex.ext.stomp.Destination
Handles a NACK frame.
nack(String) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Sends a non-acknowledgement for the given message.
nack(String, String) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Sends a non-acknowledgement for the given frame.
nackHandler(Handler<ServerFrame>) - Method in class io.vertx.reactivex.ext.stomp.StompServerHandler
Configures the action to execute when a NACK frame is received.
name() - Method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
 
name() - Method in class io.vertx.reactivex.core.http.HttpServerFileUpload
 
name() - Method in class io.vertx.reactivex.ext.unit.report.TestCaseReport
 
name() - Method in class io.vertx.reactivex.ext.unit.report.TestResult
The test description, may be null if none was provided.
name() - Method in class io.vertx.reactivex.ext.unit.report.TestSuiteReport
 
name() - Method in class io.vertx.reactivex.ext.web.FileUpload
 
name() - Method in class io.vertx.reactivex.ext.web.multipart.FormDataPart
 
name() - Method in class io.vertx.reactivex.sqlclient.desc.ColumnDescriptor
 
name() - Method in class io.vertx.reactivex.sqlclient.PropertyKind
 
names() - Method in class io.vertx.reactivex.uritemplate.Variables
 
ne(String, Object) - Static method in class io.vertx.reactivex.ext.auth.abac.Attribute
Verifies whether the attribute matches the specified.
needsSeparator() - Method in class io.vertx.reactivex.ext.auth.hashing.HashingAlgorithm
Should the encoded string use the default separator to split fields.
NetClient - Class in io.vertx.reactivex.core.net
A TCP client.
NetClient(NetClient) - Constructor for class io.vertx.reactivex.core.net.NetClient
 
NetClient(Object) - Constructor for class io.vertx.reactivex.core.net.NetClient
 
NetServer - Class in io.vertx.reactivex.core.net
Represents a TCP server
NetServer(NetServer) - Constructor for class io.vertx.reactivex.core.net.NetServer
 
NetServer(Object) - Constructor for class io.vertx.reactivex.core.net.NetServer
 
netSocket() - Method in class io.vertx.reactivex.core.http.HttpClientResponse
 
NetSocket - Class in io.vertx.reactivex.core.net
Represents a socket-like interface to a TCP connection on either the client or the server side.
NetSocket(NetSocket) - Constructor for class io.vertx.reactivex.core.net.NetSocket
 
NetSocket(Object) - Constructor for class io.vertx.reactivex.core.net.NetSocket
 
newArrayParser(ValueParser<String>) - Method in class io.vertx.reactivex.ext.web.validation.builder.ArrayParserFactory
 
newDelimited(Buffer) - Static method in class io.vertx.reactivex.core.parsetools.RecordParser
Create a new RecordParser instance, initially in delimited mode, and where the delimiter can be represented by the Buffer delim.
newDelimited(Buffer, Flowable<Buffer>) - Static method in class io.vertx.reactivex.core.parsetools.RecordParser
newDelimited(Buffer, Handler<Buffer>) - Static method in class io.vertx.reactivex.core.parsetools.RecordParser
Like RecordParser.newDelimited(java.lang.String, io.vertx.core.Handler<io.vertx.core.buffer.Buffer>) but set the output that will receive whole records which have been parsed.
newDelimited(Buffer, ReadStream<Buffer>) - Static method in class io.vertx.reactivex.core.parsetools.RecordParser
newDelimited(String) - Static method in class io.vertx.reactivex.core.parsetools.RecordParser
Create a new RecordParser instance, initially in delimited mode, and where the delimiter can be represented by the String delim endcoded in latin-1 .
newDelimited(String, Flowable<Buffer>) - Static method in class io.vertx.reactivex.core.parsetools.RecordParser
newDelimited(String, Handler<Buffer>) - Static method in class io.vertx.reactivex.core.parsetools.RecordParser
Like RecordParser.newDelimited(java.lang.String, io.vertx.core.Handler<io.vertx.core.buffer.Buffer>) but set the output that will receive whole records which have been parsed.
newDelimited(String, ReadStream<Buffer>) - Static method in class io.vertx.reactivex.core.parsetools.RecordParser
newFixed(int) - Static method in class io.vertx.reactivex.core.parsetools.RecordParser
Create a new RecordParser instance, initially in fixed size mode, and where the record size is specified by the size parameter.
newFixed(int, Flowable<Buffer>) - Static method in class io.vertx.reactivex.core.parsetools.RecordParser
Like RecordParser.newFixed(int) but wraps the stream.
newFixed(int, Handler<Buffer>) - Static method in class io.vertx.reactivex.core.parsetools.RecordParser
Like RecordParser.newFixed(int) but set the output that will receive whole records which have been parsed.
newFixed(int, ReadStream<Buffer>) - Static method in class io.vertx.reactivex.core.parsetools.RecordParser
Like RecordParser.newFixed(int) but wraps the stream.
newInstance(AmqpClient) - Static method in class io.vertx.reactivex.amqp.AmqpClient
 
newInstance(AmqpConnection) - Static method in class io.vertx.reactivex.amqp.AmqpConnection
 
newInstance(AmqpMessage) - Static method in class io.vertx.reactivex.amqp.AmqpMessage
 
newInstance(AmqpMessageBuilder) - Static method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
newInstance(AmqpReceiver) - Static method in class io.vertx.reactivex.amqp.AmqpReceiver
 
newInstance(AmqpSender) - Static method in class io.vertx.reactivex.amqp.AmqpSender
 
newInstance(CassandraClient) - Static method in class io.vertx.reactivex.cassandra.CassandraClient
 
newInstance(CassandraRowStream) - Static method in class io.vertx.reactivex.cassandra.CassandraRowStream
 
newInstance(ResultSet) - Static method in class io.vertx.reactivex.cassandra.ResultSet
 
newInstance(CircuitBreaker) - Static method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
 
newInstance(FailurePolicy) - Static method in class io.vertx.reactivex.circuitbreaker.FailurePolicy
 
newInstance(FailurePolicy, TypeArg<T>) - Static method in class io.vertx.reactivex.circuitbreaker.FailurePolicy
 
newInstance(RetryPolicy) - Static method in class io.vertx.reactivex.circuitbreaker.RetryPolicy
 
newInstance(ConfigRetriever) - Static method in class io.vertx.reactivex.config.ConfigRetriever
 
newInstance(DatagramSocket) - Static method in class io.vertx.reactivex.core.datagram.DatagramSocket
 
newInstance(DnsClient) - Static method in class io.vertx.reactivex.core.dns.DnsClient
 
newInstance(DeliveryContext) - Static method in class io.vertx.reactivex.core.eventbus.DeliveryContext
 
newInstance(DeliveryContext, TypeArg<T>) - Static method in class io.vertx.reactivex.core.eventbus.DeliveryContext
 
newInstance(EventBus) - Static method in class io.vertx.reactivex.core.eventbus.EventBus
 
newInstance(Message) - Static method in class io.vertx.reactivex.core.eventbus.Message
 
newInstance(MessageConsumer) - Static method in class io.vertx.reactivex.core.eventbus.MessageConsumer
 
newInstance(MessageConsumer, TypeArg<T>) - Static method in class io.vertx.reactivex.core.eventbus.MessageConsumer
 
newInstance(MessageProducer) - Static method in class io.vertx.reactivex.core.eventbus.MessageProducer
 
newInstance(MessageProducer, TypeArg<T>) - Static method in class io.vertx.reactivex.core.eventbus.MessageProducer
 
newInstance(Message, TypeArg<T>) - Static method in class io.vertx.reactivex.core.eventbus.Message
 
newInstance(AsyncFile) - Static method in class io.vertx.reactivex.core.file.AsyncFile
 
newInstance(AsyncFileLock) - Static method in class io.vertx.reactivex.core.file.AsyncFileLock
 
newInstance(FileSystem) - Static method in class io.vertx.reactivex.core.file.FileSystem
 
newInstance(ClientWebSocket) - Static method in class io.vertx.reactivex.core.http.ClientWebSocket
 
newInstance(HttpClient) - Static method in interface io.vertx.reactivex.core.http.HttpClient
 
newInstance(HttpClientAgent) - Static method in class io.vertx.reactivex.core.http.HttpClientAgent
 
newInstance(HttpClientBuilder) - Static method in class io.vertx.reactivex.core.http.HttpClientBuilder
 
newInstance(HttpClientConnection) - Static method in class io.vertx.reactivex.core.http.HttpClientConnection
 
newInstance(HttpClientRequest) - Static method in class io.vertx.reactivex.core.http.HttpClientRequest
 
newInstance(HttpClientResponse) - Static method in class io.vertx.reactivex.core.http.HttpClientResponse
 
newInstance(HttpConnection) - Static method in class io.vertx.reactivex.core.http.HttpConnection
 
newInstance(HttpHeaders) - Static method in class io.vertx.reactivex.core.http.HttpHeaders
 
newInstance(HttpRequestHead) - Static method in class io.vertx.reactivex.core.http.HttpRequestHead
 
newInstance(HttpResponseHead) - Static method in interface io.vertx.reactivex.core.http.HttpResponseHead
 
newInstance(HttpServer) - Static method in class io.vertx.reactivex.core.http.HttpServer
 
newInstance(HttpServerFileUpload) - Static method in class io.vertx.reactivex.core.http.HttpServerFileUpload
 
newInstance(HttpServerRequest) - Static method in class io.vertx.reactivex.core.http.HttpServerRequest
 
newInstance(HttpServerResponse) - Static method in class io.vertx.reactivex.core.http.HttpServerResponse
 
newInstance(ServerWebSocket) - Static method in class io.vertx.reactivex.core.http.ServerWebSocket
 
newInstance(ServerWebSocketHandshake) - Static method in class io.vertx.reactivex.core.http.ServerWebSocketHandshake
 
newInstance(WebSocket) - Static method in class io.vertx.reactivex.core.http.WebSocket
 
newInstance(WebSocketBase) - Static method in interface io.vertx.reactivex.core.http.WebSocketBase
 
newInstance(WebSocketClient) - Static method in class io.vertx.reactivex.core.http.WebSocketClient
 
newInstance(JsonPointer) - Static method in class io.vertx.reactivex.core.json.pointer.JsonPointer
 
newInstance(JsonPointerIterator) - Static method in class io.vertx.reactivex.core.json.pointer.JsonPointerIterator
 
newInstance(Measured) - Static method in interface io.vertx.reactivex.core.metrics.Measured
 
newInstance(Endpoint) - Static method in class io.vertx.reactivex.core.net.endpoint.Endpoint
 
newInstance(EndpointResolver) - Static method in class io.vertx.reactivex.core.net.endpoint.EndpointResolver
 
newInstance(ServerEndpoint) - Static method in class io.vertx.reactivex.core.net.endpoint.ServerEndpoint
 
newInstance(ServerInteraction) - Static method in class io.vertx.reactivex.core.net.endpoint.ServerInteraction
 
newInstance(NetClient) - Static method in class io.vertx.reactivex.core.net.NetClient
 
newInstance(NetServer) - Static method in class io.vertx.reactivex.core.net.NetServer
 
newInstance(NetSocket) - Static method in class io.vertx.reactivex.core.net.NetSocket
 
newInstance(JsonParser) - Static method in class io.vertx.reactivex.core.parsetools.JsonParser
 
newInstance(RecordParser) - Static method in class io.vertx.reactivex.core.parsetools.RecordParser
 
newInstance(AsyncMap) - Static method in class io.vertx.reactivex.core.shareddata.AsyncMap
 
newInstance(AsyncMap, TypeArg<K>, TypeArg<V>) - Static method in class io.vertx.reactivex.core.shareddata.AsyncMap
 
newInstance(Counter) - Static method in class io.vertx.reactivex.core.shareddata.Counter
 
newInstance(LocalMap) - Static method in class io.vertx.reactivex.core.shareddata.LocalMap
 
newInstance(LocalMap, TypeArg<K>, TypeArg<V>) - Static method in class io.vertx.reactivex.core.shareddata.LocalMap
 
newInstance(Lock) - Static method in class io.vertx.reactivex.core.shareddata.Lock
 
newInstance(SharedData) - Static method in class io.vertx.reactivex.core.shareddata.SharedData
 
newInstance(Pipe) - Static method in class io.vertx.reactivex.core.streams.Pipe
 
newInstance(Pipe, TypeArg<T>) - Static method in class io.vertx.reactivex.core.streams.Pipe
 
newInstance(ReadStream) - Static method in interface io.vertx.reactivex.core.streams.ReadStream
 
newInstance(ReadStream, TypeArg<T>) - Static method in interface io.vertx.reactivex.core.streams.ReadStream
 
newInstance(StreamBase) - Static method in interface io.vertx.reactivex.core.streams.StreamBase
 
newInstance(WriteStream) - Static method in interface io.vertx.reactivex.core.streams.WriteStream
 
newInstance(WriteStream, TypeArg<T>) - Static method in interface io.vertx.reactivex.core.streams.WriteStream
 
newInstance(DB2Builder) - Static method in class io.vertx.reactivex.db2client.DB2Builder
 
newInstance(DB2Connection) - Static method in class io.vertx.reactivex.db2client.DB2Connection
 
newInstance(Attribute) - Static method in class io.vertx.reactivex.ext.auth.abac.Attribute
 
newInstance(PolicyBasedAuthorizationProvider) - Static method in class io.vertx.reactivex.ext.auth.abac.PolicyBasedAuthorizationProvider
 
newInstance(SecurityAudit) - Static method in class io.vertx.reactivex.ext.auth.audit.SecurityAudit
 
newInstance(AuthenticationProvider) - Static method in class io.vertx.reactivex.ext.auth.authentication.AuthenticationProvider
 
newInstance(AndAuthorization) - Static method in class io.vertx.reactivex.ext.auth.authorization.AndAuthorization
 
newInstance(Authorization) - Static method in interface io.vertx.reactivex.ext.auth.authorization.Authorization
 
newInstance(AuthorizationContext) - Static method in class io.vertx.reactivex.ext.auth.authorization.AuthorizationContext
 
newInstance(AuthorizationProvider) - Static method in interface io.vertx.reactivex.ext.auth.authorization.AuthorizationProvider
 
newInstance(Authorizations) - Static method in class io.vertx.reactivex.ext.auth.authorization.Authorizations
 
newInstance(NotAuthorization) - Static method in class io.vertx.reactivex.ext.auth.authorization.NotAuthorization
 
newInstance(OrAuthorization) - Static method in class io.vertx.reactivex.ext.auth.authorization.OrAuthorization
 
newInstance(PermissionBasedAuthorization) - Static method in class io.vertx.reactivex.ext.auth.authorization.PermissionBasedAuthorization
 
newInstance(RoleBasedAuthorization) - Static method in class io.vertx.reactivex.ext.auth.authorization.RoleBasedAuthorization
 
newInstance(WildcardPermissionBasedAuthorization) - Static method in class io.vertx.reactivex.ext.auth.authorization.WildcardPermissionBasedAuthorization
 
newInstance(ChainAuth) - Static method in class io.vertx.reactivex.ext.auth.ChainAuth
 
newInstance(HashingAlgorithm) - Static method in class io.vertx.reactivex.ext.auth.hashing.HashingAlgorithm
 
newInstance(HashingStrategy) - Static method in class io.vertx.reactivex.ext.auth.hashing.HashingStrategy
 
newInstance(HtdigestAuth) - Static method in class io.vertx.reactivex.ext.auth.htdigest.HtdigestAuth
 
newInstance(HtpasswdAuth) - Static method in class io.vertx.reactivex.ext.auth.htpasswd.HtpasswdAuth
 
newInstance(JWTAuthorization) - Static method in class io.vertx.reactivex.ext.auth.jwt.authorization.JWTAuthorization
 
newInstance(MicroProfileAuthorization) - Static method in class io.vertx.reactivex.ext.auth.jwt.authorization.MicroProfileAuthorization
 
newInstance(JWTAuth) - Static method in class io.vertx.reactivex.ext.auth.jwt.JWTAuth
 
newInstance(LdapAuthentication) - Static method in class io.vertx.reactivex.ext.auth.ldap.LdapAuthentication
 
newInstance(KeycloakAuthorization) - Static method in class io.vertx.reactivex.ext.auth.oauth2.authorization.KeycloakAuthorization
 
newInstance(ScopeAuthorization) - Static method in class io.vertx.reactivex.ext.auth.oauth2.authorization.ScopeAuthorization
 
newInstance(OAuth2Auth) - Static method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
 
newInstance(AmazonCognitoAuth) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.AmazonCognitoAuth
 
newInstance(AppleIdAuth) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.AppleIdAuth
 
newInstance(AzureADAuth) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.AzureADAuth
 
newInstance(BoxAuth) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.BoxAuth
 
newInstance(CloudFoundryAuth) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.CloudFoundryAuth
 
newInstance(DropboxAuth) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.DropboxAuth
 
newInstance(FacebookAuth) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.FacebookAuth
 
newInstance(FoursquareAuth) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.FoursquareAuth
 
newInstance(GiteeAuth) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.GiteeAuth
 
newInstance(GithubAuth) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.GithubAuth
 
newInstance(GitLabAuth) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.GitLabAuth
 
newInstance(GoogleAuth) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.GoogleAuth
 
newInstance(HerokuAuth) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.HerokuAuth
 
newInstance(IBMCloudAuth) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.IBMCloudAuth
 
newInstance(InstagramAuth) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.InstagramAuth
 
newInstance(KeycloakAuth) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.KeycloakAuth
 
newInstance(LinkedInAuth) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.LinkedInAuth
 
newInstance(LiveAuth) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.LiveAuth
 
newInstance(MailchimpAuth) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.MailchimpAuth
 
newInstance(OpenIDConnectAuth) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.OpenIDConnectAuth
 
newInstance(SalesforceAuth) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.SalesforceAuth
 
newInstance(ShopifyAuth) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.ShopifyAuth
 
newInstance(SoundcloudAuth) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.SoundcloudAuth
 
newInstance(StripeAuth) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.StripeAuth
 
newInstance(TwitterAuth) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.TwitterAuth
 
newInstance(HotpAuth) - Static method in class io.vertx.reactivex.ext.auth.otp.hotp.HotpAuth
 
newInstance(OtpKeyGenerator) - Static method in class io.vertx.reactivex.ext.auth.otp.OtpKeyGenerator
 
newInstance(TotpAuth) - Static method in class io.vertx.reactivex.ext.auth.otp.totp.TotpAuth
 
newInstance(VertxContextPRNG) - Static method in class io.vertx.reactivex.ext.auth.prng.VertxContextPRNG
 
newInstance(PropertyFileAuthentication) - Static method in class io.vertx.reactivex.ext.auth.properties.PropertyFileAuthentication
 
newInstance(PropertyFileAuthorization) - Static method in class io.vertx.reactivex.ext.auth.properties.PropertyFileAuthorization
 
newInstance(SqlAuthentication) - Static method in class io.vertx.reactivex.ext.auth.sqlclient.SqlAuthentication
 
newInstance(SqlAuthorization) - Static method in class io.vertx.reactivex.ext.auth.sqlclient.SqlAuthorization
 
newInstance(SqlUserUtil) - Static method in class io.vertx.reactivex.ext.auth.sqlclient.SqlUserUtil
 
newInstance(User) - Static method in class io.vertx.reactivex.ext.auth.User
 
newInstance(CredentialStorage) - Static method in class io.vertx.reactivex.ext.auth.webauthn4j.CredentialStorage
 
newInstance(WebAuthn4J) - Static method in class io.vertx.reactivex.ext.auth.webauthn4j.WebAuthn4J
 
newInstance(BaseBridgeEvent) - Static method in class io.vertx.reactivex.ext.bridge.BaseBridgeEvent
 
newInstance(ConsulClient) - Static method in class io.vertx.reactivex.ext.consul.ConsulClient
 
newInstance(Watch) - Static method in class io.vertx.reactivex.ext.consul.Watch
 
newInstance(WatchResult) - Static method in class io.vertx.reactivex.ext.consul.WatchResult
 
newInstance(WatchResult, TypeArg<T>) - Static method in class io.vertx.reactivex.ext.consul.WatchResult
 
newInstance(Watch, TypeArg<T>) - Static method in class io.vertx.reactivex.ext.consul.Watch
 
newInstance(MetricsService) - Static method in class io.vertx.reactivex.ext.dropwizard.MetricsService
 
newInstance(BridgeEvent) - Static method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.BridgeEvent
 
newInstance(TcpEventBusBridge) - Static method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.TcpEventBusBridge
 
newInstance(HealthChecks) - Static method in class io.vertx.reactivex.ext.healthchecks.HealthChecks
 
newInstance(MailAttachment) - Static method in class io.vertx.reactivex.ext.mail.MailAttachment
 
newInstance(MailClient) - Static method in class io.vertx.reactivex.ext.mail.MailClient
 
newInstance(MongoClient) - Static method in class io.vertx.reactivex.ext.mongo.MongoClient
 
newInstance(MongoGridFsClient) - Static method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
 
newInstance(Acknowledgement) - Static method in class io.vertx.reactivex.ext.stomp.Acknowledgement
 
newInstance(Destination) - Static method in class io.vertx.reactivex.ext.stomp.Destination
 
newInstance(DestinationFactory) - Static method in class io.vertx.reactivex.ext.stomp.DestinationFactory
 
newInstance(Frames) - Static method in class io.vertx.reactivex.ext.stomp.Frames
 
newInstance(ServerFrame) - Static method in class io.vertx.reactivex.ext.stomp.ServerFrame
 
newInstance(StompClient) - Static method in class io.vertx.reactivex.ext.stomp.StompClient
 
newInstance(StompClientConnection) - Static method in class io.vertx.reactivex.ext.stomp.StompClientConnection
 
newInstance(StompServer) - Static method in class io.vertx.reactivex.ext.stomp.StompServer
 
newInstance(StompServerConnection) - Static method in class io.vertx.reactivex.ext.stomp.StompServerConnection
 
newInstance(StompServerHandler) - Static method in class io.vertx.reactivex.ext.stomp.StompServerHandler
 
newInstance(Async) - Static method in class io.vertx.reactivex.ext.unit.Async
 
newInstance(EventBusCollector) - Static method in class io.vertx.reactivex.ext.unit.collect.EventBusCollector
 
newInstance(Completion) - Static method in class io.vertx.reactivex.ext.unit.Completion
 
newInstance(Completion, TypeArg<T>) - Static method in class io.vertx.reactivex.ext.unit.Completion
 
newInstance(Failure) - Static method in class io.vertx.reactivex.ext.unit.report.Failure
 
newInstance(TestCaseReport) - Static method in class io.vertx.reactivex.ext.unit.report.TestCaseReport
 
newInstance(TestResult) - Static method in class io.vertx.reactivex.ext.unit.report.TestResult
 
newInstance(TestSuiteReport) - Static method in class io.vertx.reactivex.ext.unit.report.TestSuiteReport
 
newInstance(TestCase) - Static method in class io.vertx.reactivex.ext.unit.TestCase
 
newInstance(TestCompletion) - Static method in class io.vertx.reactivex.ext.unit.TestCompletion
 
newInstance(TestContext) - Static method in class io.vertx.reactivex.ext.unit.TestContext
 
newInstance(TestSuite) - Static method in class io.vertx.reactivex.ext.unit.TestSuite
 
newInstance(CachingWebClient) - Static method in class io.vertx.reactivex.ext.web.client.CachingWebClient
 
newInstance(HttpRequest) - Static method in class io.vertx.reactivex.ext.web.client.HttpRequest
 
newInstance(HttpRequest, TypeArg<T>) - Static method in class io.vertx.reactivex.ext.web.client.HttpRequest
 
newInstance(HttpResponse) - Static method in class io.vertx.reactivex.ext.web.client.HttpResponse
 
newInstance(HttpResponse, TypeArg<T>) - Static method in class io.vertx.reactivex.ext.web.client.HttpResponse
 
newInstance(OAuth2WebClient) - Static method in class io.vertx.reactivex.ext.web.client.OAuth2WebClient
 
newInstance(WebClient) - Static method in class io.vertx.reactivex.ext.web.client.WebClient
 
newInstance(WebClientSession) - Static method in class io.vertx.reactivex.ext.web.client.WebClientSession
 
newInstance(BodyCodec) - Static method in class io.vertx.reactivex.ext.web.codec.BodyCodec
 
newInstance(BodyCodec, TypeArg<T>) - Static method in class io.vertx.reactivex.ext.web.codec.BodyCodec
 
newInstance(TemplateEngine) - Static method in class io.vertx.reactivex.ext.web.common.template.TemplateEngine
 
newInstance(WebEnvironment) - Static method in class io.vertx.reactivex.ext.web.common.WebEnvironment
 
newInstance(FileUpload) - Static method in class io.vertx.reactivex.ext.web.FileUpload
 
newInstance(APIKeyHandler) - Static method in class io.vertx.reactivex.ext.web.handler.APIKeyHandler
 
newInstance(AuthenticationHandler) - Static method in interface io.vertx.reactivex.ext.web.handler.AuthenticationHandler
 
newInstance(AuthorizationHandler) - Static method in class io.vertx.reactivex.ext.web.handler.AuthorizationHandler
 
newInstance(BasicAuthHandler) - Static method in class io.vertx.reactivex.ext.web.handler.BasicAuthHandler
 
newInstance(BodyHandler) - Static method in class io.vertx.reactivex.ext.web.handler.BodyHandler
 
newInstance(ChainAuthHandler) - Static method in class io.vertx.reactivex.ext.web.handler.ChainAuthHandler
 
newInstance(CorsHandler) - Static method in class io.vertx.reactivex.ext.web.handler.CorsHandler
 
newInstance(CSPHandler) - Static method in class io.vertx.reactivex.ext.web.handler.CSPHandler
 
newInstance(CSRFHandler) - Static method in class io.vertx.reactivex.ext.web.handler.CSRFHandler
 
newInstance(DigestAuthHandler) - Static method in class io.vertx.reactivex.ext.web.handler.DigestAuthHandler
 
newInstance(ErrorHandler) - Static method in class io.vertx.reactivex.ext.web.handler.ErrorHandler
 
newInstance(FaviconHandler) - Static method in class io.vertx.reactivex.ext.web.handler.FaviconHandler
 
newInstance(FormLoginHandler) - Static method in class io.vertx.reactivex.ext.web.handler.FormLoginHandler
 
newInstance(ExecutionInputBuilderWithContext) - Static method in class io.vertx.reactivex.ext.web.handler.graphql.ExecutionInputBuilderWithContext
 
newInstance(ExecutionInputBuilderWithContext, TypeArg<C>) - Static method in class io.vertx.reactivex.ext.web.handler.graphql.ExecutionInputBuilderWithContext
 
newInstance(GraphiQLHandler) - Static method in class io.vertx.reactivex.ext.web.handler.graphql.GraphiQLHandler
 
newInstance(GraphiQLHandlerBuilder) - Static method in class io.vertx.reactivex.ext.web.handler.graphql.GraphiQLHandlerBuilder
 
newInstance(GraphQLHandler) - Static method in class io.vertx.reactivex.ext.web.handler.graphql.GraphQLHandler
 
newInstance(GraphQLHandlerBuilder) - Static method in class io.vertx.reactivex.ext.web.handler.graphql.GraphQLHandlerBuilder
 
newInstance(UploadScalar) - Static method in class io.vertx.reactivex.ext.web.handler.graphql.UploadScalar
 
newInstance(ConnectionInitEvent) - Static method in class io.vertx.reactivex.ext.web.handler.graphql.ws.ConnectionInitEvent
 
newInstance(GraphQLWSHandler) - Static method in class io.vertx.reactivex.ext.web.handler.graphql.ws.GraphQLWSHandler
 
newInstance(GraphQLWSHandlerBuilder) - Static method in class io.vertx.reactivex.ext.web.handler.graphql.ws.GraphQLWSHandlerBuilder
 
newInstance(Message) - Static method in class io.vertx.reactivex.ext.web.handler.graphql.ws.Message
 
newInstance(HSTSHandler) - Static method in class io.vertx.reactivex.ext.web.handler.HSTSHandler
 
newInstance(InputTrustHandler) - Static method in interface io.vertx.reactivex.ext.web.handler.InputTrustHandler
 
newInstance(JWTAuthHandler) - Static method in class io.vertx.reactivex.ext.web.handler.JWTAuthHandler
 
newInstance(LoggerFormatter) - Static method in class io.vertx.reactivex.ext.web.handler.LoggerFormatter
 
newInstance(LoggerHandler) - Static method in class io.vertx.reactivex.ext.web.handler.LoggerHandler
 
newInstance(MethodOverrideHandler) - Static method in class io.vertx.reactivex.ext.web.handler.MethodOverrideHandler
 
newInstance(MultiTenantHandler) - Static method in class io.vertx.reactivex.ext.web.handler.MultiTenantHandler
 
newInstance(OAuth2AuthHandler) - Static method in class io.vertx.reactivex.ext.web.handler.OAuth2AuthHandler
 
newInstance(OtpAuthHandler) - Static method in class io.vertx.reactivex.ext.web.handler.OtpAuthHandler
 
newInstance(PlatformHandler) - Static method in interface io.vertx.reactivex.ext.web.handler.PlatformHandler
 
newInstance(ProtocolUpgradeHandler) - Static method in interface io.vertx.reactivex.ext.web.handler.ProtocolUpgradeHandler
 
newInstance(RedirectAuthHandler) - Static method in class io.vertx.reactivex.ext.web.handler.RedirectAuthHandler
 
newInstance(ResponseContentTypeHandler) - Static method in class io.vertx.reactivex.ext.web.handler.ResponseContentTypeHandler
 
newInstance(ResponseTimeHandler) - Static method in class io.vertx.reactivex.ext.web.handler.ResponseTimeHandler
 
newInstance(SecurityAuditLoggerHandler) - Static method in class io.vertx.reactivex.ext.web.handler.SecurityAuditLoggerHandler
 
newInstance(SecurityPolicyHandler) - Static method in interface io.vertx.reactivex.ext.web.handler.SecurityPolicyHandler
 
newInstance(SessionHandler) - Static method in class io.vertx.reactivex.ext.web.handler.SessionHandler
 
newInstance(SimpleAuthenticationHandler) - Static method in class io.vertx.reactivex.ext.web.handler.SimpleAuthenticationHandler
 
newInstance(BridgeEvent) - Static method in class io.vertx.reactivex.ext.web.handler.sockjs.BridgeEvent
 
newInstance(SockJSHandler) - Static method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSHandler
 
newInstance(SockJSSocket) - Static method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
 
newInstance(StaticHandler) - Static method in class io.vertx.reactivex.ext.web.handler.StaticHandler
 
newInstance(TemplateHandler) - Static method in class io.vertx.reactivex.ext.web.handler.TemplateHandler
 
newInstance(TimeoutHandler) - Static method in class io.vertx.reactivex.ext.web.handler.TimeoutHandler
 
newInstance(WebAuthn4JHandler) - Static method in class io.vertx.reactivex.ext.web.handler.WebAuthn4JHandler
 
newInstance(XFrameHandler) - Static method in class io.vertx.reactivex.ext.web.handler.XFrameHandler
 
newInstance(HealthCheckHandler) - Static method in class io.vertx.reactivex.ext.web.healthchecks.HealthCheckHandler
 
newInstance(LanguageHeader) - Static method in class io.vertx.reactivex.ext.web.LanguageHeader
 
newInstance(MIMEHeader) - Static method in class io.vertx.reactivex.ext.web.MIMEHeader
 
newInstance(FormDataPart) - Static method in class io.vertx.reactivex.ext.web.multipart.FormDataPart
 
newInstance(MultipartForm) - Static method in class io.vertx.reactivex.ext.web.multipart.MultipartForm
 
newInstance(OpenAPIRoute) - Static method in class io.vertx.reactivex.ext.web.openapi.router.OpenAPIRoute
 
newInstance(RequestExtractor) - Static method in class io.vertx.reactivex.ext.web.openapi.router.RequestExtractor
 
newInstance(RouterBuilder) - Static method in class io.vertx.reactivex.ext.web.openapi.router.RouterBuilder
 
newInstance(Security) - Static method in class io.vertx.reactivex.ext.web.openapi.router.Security
 
newInstance(ParsedHeaderValue) - Static method in interface io.vertx.reactivex.ext.web.ParsedHeaderValue
 
newInstance(ParsedHeaderValues) - Static method in class io.vertx.reactivex.ext.web.ParsedHeaderValues
 
newInstance(RequestBody) - Static method in class io.vertx.reactivex.ext.web.RequestBody
 
newInstance(Route) - Static method in class io.vertx.reactivex.ext.web.Route
 
newInstance(Router) - Static method in class io.vertx.reactivex.ext.web.Router
 
newInstance(RoutingContext) - Static method in class io.vertx.reactivex.ext.web.RoutingContext
 
newInstance(Session) - Static method in class io.vertx.reactivex.ext.web.Session
 
newInstance(ClusteredSessionStore) - Static method in class io.vertx.reactivex.ext.web.sstore.ClusteredSessionStore
 
newInstance(CookieSessionStore) - Static method in class io.vertx.reactivex.ext.web.sstore.cookie.CookieSessionStore
 
newInstance(InfinispanSessionStore) - Static method in class io.vertx.reactivex.ext.web.sstore.infinispan.InfinispanSessionStore
 
newInstance(LocalSessionStore) - Static method in class io.vertx.reactivex.ext.web.sstore.LocalSessionStore
 
newInstance(RedisSessionStore) - Static method in class io.vertx.reactivex.ext.web.sstore.redis.RedisSessionStore
 
newInstance(SessionStore) - Static method in class io.vertx.reactivex.ext.web.sstore.SessionStore
 
newInstance(FreeMarkerTemplateEngine) - Static method in class io.vertx.reactivex.ext.web.templ.freemarker.FreeMarkerTemplateEngine
 
newInstance(HandlebarsTemplateEngine) - Static method in class io.vertx.reactivex.ext.web.templ.handlebars.HandlebarsTemplateEngine
 
newInstance(MVELTemplateEngine) - Static method in class io.vertx.reactivex.ext.web.templ.mvel.MVELTemplateEngine
 
newInstance(PebbleTemplateEngine) - Static method in class io.vertx.reactivex.ext.web.templ.pebble.PebbleTemplateEngine
 
newInstance(PugTemplateEngine) - Static method in class io.vertx.reactivex.ext.web.templ.pug.PugTemplateEngine
 
newInstance(RockerTemplateEngine) - Static method in class io.vertx.reactivex.ext.web.templ.rocker.RockerTemplateEngine
 
newInstance(ThymeleafTemplateEngine) - Static method in class io.vertx.reactivex.ext.web.templ.thymeleaf.ThymeleafTemplateEngine
 
newInstance(UserContext) - Static method in class io.vertx.reactivex.ext.web.UserContext
 
newInstance(ArrayParserFactory) - Static method in class io.vertx.reactivex.ext.web.validation.builder.ArrayParserFactory
 
newInstance(Bodies) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Bodies
 
newInstance(BodyProcessorFactory) - Static method in class io.vertx.reactivex.ext.web.validation.builder.BodyProcessorFactory
 
newInstance(ObjectParserFactory) - Static method in class io.vertx.reactivex.ext.web.validation.builder.ObjectParserFactory
 
newInstance(ParameterProcessorFactory) - Static method in class io.vertx.reactivex.ext.web.validation.builder.ParameterProcessorFactory
 
newInstance(Parameters) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Parameters
 
newInstance(Parsers) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Parsers
 
newInstance(StyledParameterProcessorFactory) - Static method in class io.vertx.reactivex.ext.web.validation.builder.StyledParameterProcessorFactory
 
newInstance(TupleParserFactory) - Static method in class io.vertx.reactivex.ext.web.validation.builder.TupleParserFactory
 
newInstance(ValidationHandlerBuilder) - Static method in class io.vertx.reactivex.ext.web.validation.builder.ValidationHandlerBuilder
 
newInstance(RequestParameter) - Static method in class io.vertx.reactivex.ext.web.validation.RequestParameter
 
newInstance(RequestParameters) - Static method in class io.vertx.reactivex.ext.web.validation.RequestParameters
 
newInstance(RequestPredicate) - Static method in class io.vertx.reactivex.ext.web.validation.RequestPredicate
 
newInstance(RequestPredicateResult) - Static method in class io.vertx.reactivex.ext.web.validation.RequestPredicateResult
 
newInstance(ValidationHandler) - Static method in class io.vertx.reactivex.ext.web.validation.ValidationHandler
 
newInstance(GrpcClient) - Static method in class io.vertx.reactivex.grpc.client.GrpcClient
 
newInstance(GrpcClientBuilder) - Static method in class io.vertx.reactivex.grpc.client.GrpcClientBuilder
 
newInstance(GrpcClientBuilder, TypeArg<C>) - Static method in class io.vertx.reactivex.grpc.client.GrpcClientBuilder
 
newInstance(GrpcClientRequest) - Static method in class io.vertx.reactivex.grpc.client.GrpcClientRequest
 
newInstance(GrpcClientRequest, TypeArg<Req>, TypeArg<Resp>) - Static method in class io.vertx.reactivex.grpc.client.GrpcClientRequest
 
newInstance(GrpcClientResponse) - Static method in class io.vertx.reactivex.grpc.client.GrpcClientResponse
 
newInstance(GrpcClientResponse, TypeArg<Req>, TypeArg<Resp>) - Static method in class io.vertx.reactivex.grpc.client.GrpcClientResponse
 
newInstance(GrpcReadStream) - Static method in class io.vertx.reactivex.grpc.common.GrpcReadStream
 
newInstance(GrpcReadStream, TypeArg<T>) - Static method in class io.vertx.reactivex.grpc.common.GrpcReadStream
 
newInstance(GrpcWriteStream) - Static method in class io.vertx.reactivex.grpc.common.GrpcWriteStream
 
newInstance(GrpcWriteStream, TypeArg<T>) - Static method in class io.vertx.reactivex.grpc.common.GrpcWriteStream
 
newInstance(GrpcServer) - Static method in class io.vertx.reactivex.grpc.server.GrpcServer
 
newInstance(GrpcServerRequest) - Static method in class io.vertx.reactivex.grpc.server.GrpcServerRequest
 
newInstance(GrpcServerRequest, TypeArg<Req>, TypeArg<Resp>) - Static method in class io.vertx.reactivex.grpc.server.GrpcServerRequest
 
newInstance(GrpcServerResponse) - Static method in class io.vertx.reactivex.grpc.server.GrpcServerResponse
 
newInstance(GrpcServerResponse, TypeArg<Req>, TypeArg<Resp>) - Static method in class io.vertx.reactivex.grpc.server.GrpcServerResponse
 
newInstance(JDBCConnection) - Static method in class io.vertx.reactivex.jdbcclient.JDBCConnection
 
newInstance(JDBCPool) - Static method in class io.vertx.reactivex.jdbcclient.JDBCPool
 
newInstance(SqlOutParam) - Static method in class io.vertx.reactivex.jdbcclient.SqlOutParam
 
newInstance(JsonFormatValidator) - Static method in class io.vertx.reactivex.json.schema.JsonFormatValidator
 
newInstance(JsonSchema) - Static method in class io.vertx.reactivex.json.schema.JsonSchema
 
newInstance(Ref) - Static method in class io.vertx.reactivex.json.schema.Ref
 
newInstance(SchemaRepository) - Static method in class io.vertx.reactivex.json.schema.SchemaRepository
 
newInstance(Validator) - Static method in class io.vertx.reactivex.json.schema.Validator
 
newInstance(KafkaAdminClient) - Static method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
 
newInstance(KafkaConsumer) - Static method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
 
newInstance(KafkaConsumerRecord) - Static method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumerRecord
 
newInstance(KafkaConsumerRecord, TypeArg<K>, TypeArg<V>) - Static method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumerRecord
 
newInstance(KafkaConsumerRecords) - Static method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumerRecords
 
newInstance(KafkaConsumerRecords, TypeArg<K>, TypeArg<V>) - Static method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumerRecords
 
newInstance(KafkaConsumer, TypeArg<K>, TypeArg<V>) - Static method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
 
newInstance(KafkaHeader) - Static method in class io.vertx.reactivex.kafka.client.producer.KafkaHeader
 
newInstance(KafkaProducer) - Static method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
 
newInstance(KafkaProducerRecord) - Static method in class io.vertx.reactivex.kafka.client.producer.KafkaProducerRecord
 
newInstance(KafkaProducerRecord, TypeArg<K>, TypeArg<V>) - Static method in class io.vertx.reactivex.kafka.client.producer.KafkaProducerRecord
 
newInstance(KafkaProducer, TypeArg<K>, TypeArg<V>) - Static method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
 
newInstance(MetricsService) - Static method in class io.vertx.reactivex.micrometer.MetricsService
 
newInstance(PrometheusRequestHandler) - Static method in class io.vertx.reactivex.micrometer.PrometheusRequestHandler
 
newInstance(PrometheusScrapingHandler) - Static method in class io.vertx.reactivex.micrometer.PrometheusScrapingHandler
 
newInstance(MqttAuthenticationExchangeMessage) - Static method in class io.vertx.reactivex.mqtt.messages.MqttAuthenticationExchangeMessage
 
newInstance(MqttConnAckMessage) - Static method in class io.vertx.reactivex.mqtt.messages.MqttConnAckMessage
 
newInstance(MqttDisconnectMessage) - Static method in class io.vertx.reactivex.mqtt.messages.MqttDisconnectMessage
 
newInstance(MqttMessage) - Static method in interface io.vertx.reactivex.mqtt.messages.MqttMessage
 
newInstance(MqttPubAckMessage) - Static method in class io.vertx.reactivex.mqtt.messages.MqttPubAckMessage
 
newInstance(MqttPubCompMessage) - Static method in class io.vertx.reactivex.mqtt.messages.MqttPubCompMessage
 
newInstance(MqttPublishMessage) - Static method in class io.vertx.reactivex.mqtt.messages.MqttPublishMessage
 
newInstance(MqttPubRecMessage) - Static method in class io.vertx.reactivex.mqtt.messages.MqttPubRecMessage
 
newInstance(MqttPubRelMessage) - Static method in class io.vertx.reactivex.mqtt.messages.MqttPubRelMessage
 
newInstance(MqttSubAckMessage) - Static method in class io.vertx.reactivex.mqtt.messages.MqttSubAckMessage
 
newInstance(MqttSubscribeMessage) - Static method in class io.vertx.reactivex.mqtt.messages.MqttSubscribeMessage
 
newInstance(MqttUnsubscribeMessage) - Static method in class io.vertx.reactivex.mqtt.messages.MqttUnsubscribeMessage
 
newInstance(MqttClient) - Static method in class io.vertx.reactivex.mqtt.MqttClient
 
newInstance(MqttEndpoint) - Static method in class io.vertx.reactivex.mqtt.MqttEndpoint
 
newInstance(MqttServer) - Static method in class io.vertx.reactivex.mqtt.MqttServer
 
newInstance(MqttTopicSubscription) - Static method in class io.vertx.reactivex.mqtt.MqttTopicSubscription
 
newInstance(MSSQLBuilder) - Static method in class io.vertx.reactivex.mssqlclient.MSSQLBuilder
 
newInstance(MSSQLConnection) - Static method in class io.vertx.reactivex.mssqlclient.MSSQLConnection
 
newInstance(MySQLBuilder) - Static method in class io.vertx.reactivex.mysqlclient.MySQLBuilder
 
newInstance(MySQLClient) - Static method in class io.vertx.reactivex.mysqlclient.MySQLClient
 
newInstance(MySQLConnection) - Static method in class io.vertx.reactivex.mysqlclient.MySQLConnection
 
newInstance(MediaType) - Static method in class io.vertx.reactivex.openapi.contract.MediaType
 
newInstance(OAuthFlow) - Static method in class io.vertx.reactivex.openapi.contract.OAuthFlow
 
newInstance(OAuthFlows) - Static method in class io.vertx.reactivex.openapi.contract.OAuthFlows
 
newInstance(OpenAPIContract) - Static method in class io.vertx.reactivex.openapi.contract.OpenAPIContract
 
newInstance(Operation) - Static method in class io.vertx.reactivex.openapi.contract.Operation
 
newInstance(Parameter) - Static method in class io.vertx.reactivex.openapi.contract.Parameter
 
newInstance(Path) - Static method in class io.vertx.reactivex.openapi.contract.Path
 
newInstance(RequestBody) - Static method in class io.vertx.reactivex.openapi.contract.RequestBody
 
newInstance(Response) - Static method in class io.vertx.reactivex.openapi.contract.Response
 
newInstance(SecurityRequirement) - Static method in class io.vertx.reactivex.openapi.contract.SecurityRequirement
 
newInstance(SecurityScheme) - Static method in class io.vertx.reactivex.openapi.contract.SecurityScheme
 
newInstance(Server) - Static method in class io.vertx.reactivex.openapi.contract.Server
 
newInstance(Parameter) - Static method in interface io.vertx.reactivex.openapi.validation.Parameter
 
newInstance(RequestParameter) - Static method in class io.vertx.reactivex.openapi.validation.RequestParameter
 
newInstance(RequestValidator) - Static method in class io.vertx.reactivex.openapi.validation.RequestValidator
 
newInstance(ResponseParameter) - Static method in class io.vertx.reactivex.openapi.validation.ResponseParameter
 
newInstance(ValidatableRequest) - Static method in class io.vertx.reactivex.openapi.validation.ValidatableRequest
 
newInstance(ValidatableResponse) - Static method in class io.vertx.reactivex.openapi.validation.ValidatableResponse
 
newInstance(ValidatedRequest) - Static method in class io.vertx.reactivex.openapi.validation.ValidatedRequest
 
newInstance(ValidatedResponse) - Static method in class io.vertx.reactivex.openapi.validation.ValidatedResponse
 
newInstance(OracleBuilder) - Static method in class io.vertx.reactivex.oracleclient.OracleBuilder
 
newInstance(OracleClient) - Static method in class io.vertx.reactivex.oracleclient.OracleClient
 
newInstance(OracleConnection) - Static method in class io.vertx.reactivex.oracleclient.OracleConnection
 
newInstance(PgBuilder) - Static method in class io.vertx.reactivex.pgclient.PgBuilder
 
newInstance(PgConnection) - Static method in class io.vertx.reactivex.pgclient.PgConnection
 
newInstance(PgChannel) - Static method in class io.vertx.reactivex.pgclient.pubsub.PgChannel
 
newInstance(PgSubscriber) - Static method in class io.vertx.reactivex.pgclient.pubsub.PgSubscriber
 
newInstance(RabbitMQClient) - Static method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
 
newInstance(RabbitMQConsumer) - Static method in class io.vertx.reactivex.rabbitmq.RabbitMQConsumer
 
newInstance(RabbitMQMessage) - Static method in class io.vertx.reactivex.rabbitmq.RabbitMQMessage
 
newInstance(RabbitMQPublisher) - Static method in class io.vertx.reactivex.rabbitmq.RabbitMQPublisher
 
newInstance(Redis) - Static method in class io.vertx.reactivex.redis.client.Redis
 
newInstance(RedisAPI) - Static method in class io.vertx.reactivex.redis.client.RedisAPI
 
newInstance(RedisCluster) - Static method in class io.vertx.reactivex.redis.client.RedisCluster
 
newInstance(RedisConnection) - Static method in class io.vertx.reactivex.redis.client.RedisConnection
 
newInstance(ServiceDiscovery) - Static method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
 
newInstance(ServiceReference) - Static method in class io.vertx.reactivex.servicediscovery.ServiceReference
 
newInstance(ServiceExporter) - Static method in class io.vertx.reactivex.servicediscovery.spi.ServiceExporter
 
newInstance(ServiceImporter) - Static method in class io.vertx.reactivex.servicediscovery.spi.ServiceImporter
 
newInstance(ServicePublisher) - Static method in class io.vertx.reactivex.servicediscovery.spi.ServicePublisher
 
newInstance(EventBusService) - Static method in class io.vertx.reactivex.servicediscovery.types.EventBusService
 
newInstance(HttpEndpoint) - Static method in class io.vertx.reactivex.servicediscovery.types.HttpEndpoint
 
newInstance(MessageSource) - Static method in class io.vertx.reactivex.servicediscovery.types.MessageSource
 
newInstance(MongoDataSource) - Static method in class io.vertx.reactivex.servicediscovery.types.MongoDataSource
 
newInstance(RedisDataSource) - Static method in class io.vertx.reactivex.servicediscovery.types.RedisDataSource
 
newInstance(ClientBuilder) - Static method in class io.vertx.reactivex.sqlclient.ClientBuilder
 
newInstance(ClientBuilder, TypeArg<C>) - Static method in class io.vertx.reactivex.sqlclient.ClientBuilder
 
newInstance(Cursor) - Static method in class io.vertx.reactivex.sqlclient.Cursor
 
newInstance(ColumnDescriptor) - Static method in class io.vertx.reactivex.sqlclient.desc.ColumnDescriptor
 
newInstance(Pool) - Static method in class io.vertx.reactivex.sqlclient.Pool
 
newInstance(PreparedQuery) - Static method in class io.vertx.reactivex.sqlclient.PreparedQuery
 
newInstance(PreparedQuery, TypeArg<T>) - Static method in class io.vertx.reactivex.sqlclient.PreparedQuery
 
newInstance(PreparedStatement) - Static method in class io.vertx.reactivex.sqlclient.PreparedStatement
 
newInstance(PropertyKind) - Static method in class io.vertx.reactivex.sqlclient.PropertyKind
 
newInstance(PropertyKind, TypeArg<T>) - Static method in class io.vertx.reactivex.sqlclient.PropertyKind
 
newInstance(Query) - Static method in class io.vertx.reactivex.sqlclient.Query
 
newInstance(Query, TypeArg<T>) - Static method in class io.vertx.reactivex.sqlclient.Query
 
newInstance(Row) - Static method in class io.vertx.reactivex.sqlclient.Row
 
newInstance(RowIterator) - Static method in class io.vertx.reactivex.sqlclient.RowIterator
 
newInstance(RowIterator, TypeArg<R>) - Static method in class io.vertx.reactivex.sqlclient.RowIterator
 
newInstance(RowSet) - Static method in class io.vertx.reactivex.sqlclient.RowSet
 
newInstance(RowSet, TypeArg<R>) - Static method in class io.vertx.reactivex.sqlclient.RowSet
 
newInstance(RowStream) - Static method in class io.vertx.reactivex.sqlclient.RowStream
 
newInstance(RowStream, TypeArg<T>) - Static method in class io.vertx.reactivex.sqlclient.RowStream
 
newInstance(DatabaseMetadata) - Static method in class io.vertx.reactivex.sqlclient.spi.DatabaseMetadata
 
newInstance(SqlClient) - Static method in class io.vertx.reactivex.sqlclient.SqlClient
 
newInstance(SqlConnection) - Static method in class io.vertx.reactivex.sqlclient.SqlConnection
 
newInstance(SqlResult) - Static method in class io.vertx.reactivex.sqlclient.SqlResult
 
newInstance(SqlResult, TypeArg<T>) - Static method in class io.vertx.reactivex.sqlclient.SqlResult
 
newInstance(RowMapper) - Static method in class io.vertx.reactivex.sqlclient.templates.RowMapper
 
newInstance(RowMapper, TypeArg<T>) - Static method in class io.vertx.reactivex.sqlclient.templates.RowMapper
 
newInstance(SqlTemplate) - Static method in class io.vertx.reactivex.sqlclient.templates.SqlTemplate
 
newInstance(SqlTemplate, TypeArg<I>, TypeArg<R>) - Static method in class io.vertx.reactivex.sqlclient.templates.SqlTemplate
 
newInstance(TupleMapper) - Static method in class io.vertx.reactivex.sqlclient.templates.TupleMapper
 
newInstance(TupleMapper, TypeArg<T>) - Static method in class io.vertx.reactivex.sqlclient.templates.TupleMapper
 
newInstance(Transaction) - Static method in class io.vertx.reactivex.sqlclient.Transaction
 
newInstance(Tuple) - Static method in class io.vertx.reactivex.sqlclient.Tuple
 
newInstance(UriTemplate) - Static method in class io.vertx.reactivex.uritemplate.UriTemplate
 
newInstance(Variables) - Static method in class io.vertx.reactivex.uritemplate.Variables
 
newInteraction() - Method in class io.vertx.reactivex.core.net.endpoint.ServerEndpoint
Initiate a request/response interaction with the endpoint represented by this node, the returned interaction gathers statistics.
newParser() - Static method in class io.vertx.reactivex.core.parsetools.JsonParser
Create a new JsonParser instance.
newParser(Flowable<Buffer>) - Static method in class io.vertx.reactivex.core.parsetools.JsonParser
Create a new JsonParser instance.
newParser(ReadStream<Buffer>) - Static method in class io.vertx.reactivex.core.parsetools.JsonParser
Create a new JsonParser instance.
newSession(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.SessionHandler
Create a new session
newTupleParser(List<ValueParser<String>>, ValueParser<String>) - Method in class io.vertx.reactivex.ext.web.validation.builder.TupleParserFactory
 
next() - Method in class io.vertx.reactivex.core.eventbus.DeliveryContext
Call the next interceptor
next() - Method in class io.vertx.reactivex.ext.web.RoutingContext
Tell the router to route this context to the next matching route (if any).
next() - Method in class io.vertx.reactivex.sqlclient.RowIterator
 
next() - Method in class io.vertx.reactivex.sqlclient.RowSet
 
next() - Method in class io.vertx.reactivex.sqlclient.SqlResult
Return the next available result or null, e.g for a simple query that executed multiple queries or for a batch result.
nextBoolean() - Method in class io.vertx.reactivex.ext.auth.prng.VertxContextPRNG
Returns a secure random boolean
nextBytes(byte[]) - Method in class io.vertx.reactivex.ext.auth.prng.VertxContextPRNG
Fills the given byte array with random bytes.
nextDouble() - Method in class io.vertx.reactivex.ext.auth.prng.VertxContextPRNG
Returns a secure random double value.
nextFloat() - Method in class io.vertx.reactivex.ext.auth.prng.VertxContextPRNG
Returns a secure random float value.
nextGaussian() - Method in class io.vertx.reactivex.ext.auth.prng.VertxContextPRNG
Returns a secure random double value.
nextInt() - Method in class io.vertx.reactivex.ext.auth.prng.VertxContextPRNG
Returns a secure random int
nextInt(int) - Method in class io.vertx.reactivex.ext.auth.prng.VertxContextPRNG
Returns a secure random int, between 0 (inclusive) and the specified bound (exclusive).
nextLong() - Method in class io.vertx.reactivex.ext.auth.prng.VertxContextPRNG
Returns a secure random long
nextResult() - Method in class io.vertx.reactivex.ext.consul.WatchResult
The next result of the operation.
nextString(int) - Method in class io.vertx.reactivex.ext.auth.prng.VertxContextPRNG
Returns a Base64 url encoded String of random data with the given length.
nodeHealthChecks(String, CheckQueryOptions, Vertx, ConsulClientOptions) - Static method in class io.vertx.reactivex.ext.consul.Watch
Creates Watch to monitoring the health checks of the nodes.
nodes(Vertx) - Static method in class io.vertx.reactivex.ext.consul.Watch
Creates Watch to monitoring the list of available nodes.
nodes(Vertx, ConsulClientOptions) - Static method in class io.vertx.reactivex.ext.consul.Watch
Creates Watch to monitoring the list of available nodes.
none() - Static method in class io.vertx.reactivex.ext.web.codec.BodyCodec
 
NOOP - Static variable in class io.vertx.reactivex.ext.auth.audit.SecurityAudit
 
normalizedPath() - Method in class io.vertx.reactivex.ext.web.RoutingContext
Normalizes a path as per NotAuthorization - Class in io.vertx.reactivex.ext.auth.authorization
Allows to perform a logical 'not' of the specified authorization
NotAuthorization(NotAuthorization) - Constructor for class io.vertx.reactivex.ext.auth.authorization.NotAuthorization
 
NotAuthorization(Object) - Constructor for class io.vertx.reactivex.ext.auth.authorization.NotAuthorization
 
noticeHandler(Handler<PgNotice>) - Method in class io.vertx.reactivex.pgclient.PgConnection
Set a handler called when the connection receives a notice from the server.
notificationHandler(Handler<PgNotification>) - Method in class io.vertx.reactivex.pgclient.PgConnection
Set a handler called when the connection receives notification on a channel.
numberOfRedirections() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
 
numberOfSubscriptions() - Method in class io.vertx.reactivex.ext.stomp.Destination
Gets the number of subscriptions attached to the current Destination.

O

OAuth2Auth - Class in io.vertx.reactivex.ext.auth.oauth2
Factory interface for creating OAuth2 based AuthenticationProvider instances.
OAuth2Auth(OAuth2Auth) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
 
OAuth2Auth(Object) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
 
OAuth2AuthHandler - Class in io.vertx.reactivex.ext.web.handler
An auth handler that provides OAuth2 Authentication support.
OAuth2AuthHandler(OAuth2AuthHandler) - Constructor for class io.vertx.reactivex.ext.web.handler.OAuth2AuthHandler
 
OAuth2AuthHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.OAuth2AuthHandler
 
oauth2Handler(String, Function<SecurityScheme, OAuth2AuthHandler>) - Method in class io.vertx.reactivex.ext.web.openapi.router.Security
Configure the to be used when creating the router.
oauth2Handler(Function<SecurityScheme, OAuth2AuthHandler>) - Method in class io.vertx.reactivex.ext.web.openapi.router.Security
Configure the to be used when creating the router.
OAuth2WebClient - Class in io.vertx.reactivex.ext.web.client
An asynchronous OAuth2/OIDC aware HTTP / HTTP/2 client called WebClientOAuth2.
OAuth2WebClient(OAuth2WebClient) - Constructor for class io.vertx.reactivex.ext.web.client.OAuth2WebClient
 
OAuth2WebClient(Object) - Constructor for class io.vertx.reactivex.ext.web.client.OAuth2WebClient
 
OAuthFlow - Class in io.vertx.reactivex.openapi.contract
Represents an OAuth Flow Object (the configuration).
OAuthFlow(OAuthFlow) - Constructor for class io.vertx.reactivex.openapi.contract.OAuthFlow
 
OAuthFlow(Object) - Constructor for class io.vertx.reactivex.openapi.contract.OAuthFlow
 
OAuthFlows - Class in io.vertx.reactivex.openapi.contract
Represents an OAuth Flows Object.
OAuthFlows(OAuthFlows) - Constructor for class io.vertx.reactivex.openapi.contract.OAuthFlows
 
OAuthFlows(Object) - Constructor for class io.vertx.reactivex.openapi.contract.OAuthFlows
 
object(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
A container for object introspection commands.
objectContainsKey(Object, String) - Method in class io.vertx.reactivex.core.json.pointer.JsonPointerIterator
 
objectEventMode() - Method in class io.vertx.reactivex.core.parsetools.JsonParser
Flip the parser to emit a stream of events for each new json object.
ObjectParserFactory - Class in io.vertx.reactivex.ext.web.validation.builder
This interface is used to create able to parse serialized object structures.
ObjectParserFactory(ObjectParserFactory) - Constructor for class io.vertx.reactivex.ext.web.validation.builder.ObjectParserFactory
 
ObjectParserFactory(Object) - Constructor for class io.vertx.reactivex.ext.web.validation.builder.ObjectParserFactory
 
objectValueMode() - Method in class io.vertx.reactivex.core.parsetools.JsonParser
Flip the parser to emit a single value event for each new json object.
of(boolean) - Static method in class io.vertx.reactivex.json.schema.JsonSchema
Factory method to create a JsonSchema from a Boolean.
of(JsonObject) - Static method in class io.vertx.reactivex.json.schema.JsonSchema
Factory method to create a JsonSchema from a .
of(HttpServerRequest, Operation) - Static method in class io.vertx.reactivex.openapi.validation.ValidatableRequest
Creates a new ValidatableRequest object based on the passed and .
of(Object) - Static method in class io.vertx.reactivex.sqlclient.Tuple
Create a tuple of one element.
of(Object, Object) - Static method in class io.vertx.reactivex.sqlclient.Tuple
Create a tuple of two elements.
of(Object, Object, Object) - Static method in class io.vertx.reactivex.sqlclient.Tuple
Create a tuple of three elements.
of(Object, Object, Object, Object) - Static method in class io.vertx.reactivex.sqlclient.Tuple
Create a tuple of four elements.
of(Object, Object, Object, Object, Object) - Static method in class io.vertx.reactivex.sqlclient.Tuple
Create a tuple of five elements.
of(Object, Object, Object, Object, Object, Object) - Static method in class io.vertx.reactivex.sqlclient.Tuple
Create a tuple of six elements.
of(String) - Static method in class io.vertx.reactivex.uritemplate.UriTemplate
Create a template from a string uri.
of(String, JsonObject) - Static method in class io.vertx.reactivex.json.schema.JsonSchema
Factory method to create a JsonSchema from a .
offset() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumerRecord
 
offsetsForTimes(TopicPartition, Long) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Look up the offset for the given partition by timestamp.
oldId() - Method in class io.vertx.reactivex.ext.web.Session
 
onAck(StompServerConnection, Frame, List<Frame>) - Method in class io.vertx.reactivex.ext.stomp.StompServerHandler
Method called by single message (client-individual policy) or a set of message (client policy) are acknowledged.
onAckHandler(Handler<Acknowledgement>) - Method in class io.vertx.reactivex.ext.stomp.StompServerHandler
Configures the action to execute when messages are acknowledged.
onAllMasterNodes(Request) - Method in class io.vertx.reactivex.redis.client.RedisCluster
Runs the request against all master nodes in the cluster.
onAllNodes(Request) - Method in class io.vertx.reactivex.redis.client.RedisCluster
Runs the request against all nodes in the cluster.
onAuthenticationRequest(StompServerConnection, String, String) - Method in class io.vertx.reactivex.ext.stomp.StompServerHandler
Called when the client connects to a server requiring authentication.
onClose(StompServerConnection) - Method in class io.vertx.reactivex.ext.stomp.StompServerHandler
Called when the connection is closed.
onConnectionInit(Handler<ConnectionInitEvent>) - Method in class io.vertx.reactivex.ext.web.handler.graphql.ws.GraphQLWSHandlerBuilder
Customize the connection init .
one() - Method in class io.vertx.reactivex.cassandra.ResultSet
 
onMessage(Handler<Message>) - Method in class io.vertx.reactivex.ext.web.handler.graphql.ws.GraphQLWSHandlerBuilder
Customize the message .
onNack(StompServerConnection, Frame, List<Frame>) - Method in class io.vertx.reactivex.ext.stomp.StompServerHandler
Method called by single message (client-individual policy) or a set of message (client policy) are not acknowledged.
onNackHandler(Handler<Acknowledgement>) - Method in class io.vertx.reactivex.ext.stomp.StompServerHandler
Configures the action to execute when messages are not acknowledged.
onPublish(Record) - Method in class io.vertx.reactivex.servicediscovery.spi.ServiceExporter
Notify a new record has been published, the record's registration can be used to uniquely identify the record
onServerActivity() - Method in class io.vertx.reactivex.ext.stomp.StompServerConnection
Notifies the connection about server activity (the server has sent a frame).
onSocketEnd(Handler<ServerWebSocket>) - Method in class io.vertx.reactivex.ext.web.handler.graphql.ws.GraphQLWSHandlerBuilder
Customize the end .
onUnpublish(String) - Method in class io.vertx.reactivex.servicediscovery.spi.ServiceExporter
Notify an existing record has been removed
onUpdate(Record) - Method in class io.vertx.reactivex.servicediscovery.spi.ServiceExporter
Notify an existing record has been updated, the record's registration can be used to uniquely identify the record
open() - Method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
Explicitly opens the circuit breaker.
open(String, OpenOptions) - Method in class io.vertx.reactivex.core.file.FileSystem
Open the file represented by path, asynchronously.
OpenAPIContract - Class in io.vertx.reactivex.openapi.contract
 
OpenAPIContract(OpenAPIContract) - Constructor for class io.vertx.reactivex.openapi.contract.OpenAPIContract
 
OpenAPIContract(Object) - Constructor for class io.vertx.reactivex.openapi.contract.OpenAPIContract
 
OpenAPIRoute - Class in io.vertx.reactivex.ext.web.openapi.router
 
OpenAPIRoute(OpenAPIRoute) - Constructor for class io.vertx.reactivex.ext.web.openapi.router.OpenAPIRoute
 
OpenAPIRoute(Object) - Constructor for class io.vertx.reactivex.ext.web.openapi.router.OpenAPIRoute
 
openBlocking(String, OpenOptions) - Method in class io.vertx.reactivex.core.file.FileSystem
openHandler(Handler<Void>) - Method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
Sets a to be invoked when the circuit breaker state switches to open.
OpenIDConnectAuth - Class in io.vertx.reactivex.ext.auth.oauth2.providers
Simplified factory to create an OAuth2Auth for OpenID Connect.
OpenIDConnectAuth(OpenIDConnectAuth) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.OpenIDConnectAuth
 
OpenIDConnectAuth(Object) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.OpenIDConnectAuth
 
openIdConnectHandler(Function<String, Single<OAuth2AuthHandler>>) - Method in class io.vertx.reactivex.ext.web.openapi.router.Security
Configure the to be used when creating the router.
openIdConnectHandler(String, Function<String, Single<OAuth2AuthHandler>>) - Method in class io.vertx.reactivex.ext.web.openapi.router.Security
Configure the to be used when creating the router.
openIdConnectHandler(String, Function<String, Future<OAuth2AuthHandler>>) - Method in class io.vertx.reactivex.ext.web.openapi.router.Security
Configure the to be used when creating the router.
openIdConnectHandler(Function<String, Future<OAuth2AuthHandler>>) - Method in class io.vertx.reactivex.ext.web.openapi.router.Security
Configure the to be used when creating the router.
operation(String) - Method in class io.vertx.reactivex.openapi.contract.OpenAPIContract
Access to an operation defined in the contract with operationId.
Operation - Class in io.vertx.reactivex.openapi.contract
This interface represents the most important attributes of an OpenAPI Operation.
Operation(Operation) - Constructor for class io.vertx.reactivex.openapi.contract.Operation
 
Operation(Object) - Constructor for class io.vertx.reactivex.openapi.contract.Operation
 
operations() - Method in class io.vertx.reactivex.openapi.contract.OpenAPIContract
 
optionalDeepObjectParam(String, ObjectSchemaBuilder) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Parameters
Creates an optional deep object parameter.
optionalExplodedParam(String, ArraySchemaBuilder) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Parameters
Creates an optional exploded array parameter.
optionalExplodedParam(String, ObjectSchemaBuilder) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Parameters
Creates an optional exploded object parameter.
optionalExplodedParam(String, TupleSchemaBuilder) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Parameters
Creates an optional exploded tuple parameter.
optionalJsonParam(String, SchemaBuilder) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Parameters
Creates an optional parameter serialized as valid json
optionalParam(String, ArraySchemaBuilder) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Parameters
Creates a new optional array parameter serialized as comma separated
optionalParam(String, BooleanSchemaBuilder) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Parameters
Creates a new optional boolean parameter
optionalParam(String, NumberSchemaBuilder) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Parameters
Creates a new optional number parameter.
optionalParam(String, ObjectSchemaBuilder) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Parameters
Creates an optional object parameter serialized as comma separated, like key1,value1,key2,value2
optionalParam(String, SchemaBuilder, ValueParser<String>) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Parameters
Creates an optional parameter providing a
optionalParam(String, StringSchemaBuilder) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Parameters
Creates a new optional string parameter
optionalParam(String, TupleSchemaBuilder) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Parameters
Creates a new optional tuple parameter serialized as comma separated
optionalSerializedParam(String, ArrayParserFactory, ArraySchemaBuilder) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Parameters
Creates an optional array parameter deserializable using the provided parser factory.
optionalSerializedParam(String, ObjectParserFactory, ObjectSchemaBuilder) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Parameters
Creates an optional object parameter deserializable using the provided parser factory.
optionalSerializedParam(String, TupleParserFactory, TupleSchemaBuilder) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Parameters
Creates an optional tuple parameter deserializable using the provided parser factory.
options() - Method in class io.vertx.reactivex.ext.stomp.StompClient
 
options() - Method in class io.vertx.reactivex.ext.stomp.StompServer
 
options() - Method in class io.vertx.reactivex.ext.web.Router
Add a route that matches any HTTP OPTIONS request
options() - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
 
options(String) - Method in class io.vertx.reactivex.ext.web.Router
Add a route that matches a HTTP OPTIONS request and the specified path
optionsWithRegex(String) - Method in class io.vertx.reactivex.ext.web.Router
Add a route that matches a HTTP OPTIONS request and the specified path regex
OracleBuilder - Class in io.vertx.reactivex.oracleclient
Entry point for building Oracle clients.
OracleBuilder(OracleBuilder) - Constructor for class io.vertx.reactivex.oracleclient.OracleBuilder
 
OracleBuilder(Object) - Constructor for class io.vertx.reactivex.oracleclient.OracleBuilder
 
OracleClient - Class in io.vertx.reactivex.oracleclient
An interface to define Oracle specific constants or behaviors.
OracleClient(OracleClient) - Constructor for class io.vertx.reactivex.oracleclient.OracleClient
 
OracleClient(Object) - Constructor for class io.vertx.reactivex.oracleclient.OracleClient
 
OracleConnection - Class in io.vertx.reactivex.oracleclient
A connection to Oracle Database.
OracleConnection(OracleConnection) - Constructor for class io.vertx.reactivex.oracleclient.OracleConnection
 
OracleConnection(Object) - Constructor for class io.vertx.reactivex.oracleclient.OracleConnection
 
OrAuthorization - Class in io.vertx.reactivex.ext.auth.authorization
Allows to perform a logical 'or' between several authorizations
OrAuthorization(OrAuthorization) - Constructor for class io.vertx.reactivex.ext.auth.authorization.OrAuthorization
 
OrAuthorization(Object) - Constructor for class io.vertx.reactivex.ext.auth.authorization.OrAuthorization
 
order(int) - Method in class io.vertx.reactivex.ext.web.Route
Specify the order for this route.
ORIGIN - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Origin header name
OtpAuthHandler - Class in io.vertx.reactivex.ext.web.handler
An auth handler that provides One Time Password (Multi-Factor) Authentication support.
OtpAuthHandler(OtpAuthHandler) - Constructor for class io.vertx.reactivex.ext.web.handler.OtpAuthHandler
 
OtpAuthHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.OtpAuthHandler
 
OtpKeyGenerator - Class in io.vertx.reactivex.ext.auth.otp
Otp key generator.
OtpKeyGenerator(OtpKeyGenerator) - Constructor for class io.vertx.reactivex.ext.auth.otp.OtpKeyGenerator
 
OtpKeyGenerator(Object) - Constructor for class io.vertx.reactivex.ext.auth.otp.OtpKeyGenerator
 
OUT(int) - Static method in class io.vertx.reactivex.jdbcclient.SqlOutParam
Factory for a OUT parameter of type out.
OUT(String) - Static method in class io.vertx.reactivex.jdbcclient.SqlOutParam
Factory for a OUT parameter of type out.
OUT(JDBCType) - Static method in class io.vertx.reactivex.jdbcclient.SqlOutParam
Factory for a OUT parameter of type out.
OUTPUT - Static variable in class io.vertx.reactivex.jdbcclient.JDBCPool
The property to be used to retrieve the output of the callable statement
OUTPUT - Static variable in class io.vertx.reactivex.oracleclient.OracleClient
The property to be used to retrieve the output of the callable statement
overlaps(long, long) - Method in class io.vertx.reactivex.core.file.AsyncFileLock
 

P

param(String, ArraySchemaBuilder) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Parameters
Creates a new required array parameter serialized as comma separated
param(String, BooleanSchemaBuilder) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Parameters
Creates a new required boolean parameter
param(String, NumberSchemaBuilder) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Parameters
Creates a new required number parameter.
param(String, ObjectSchemaBuilder) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Parameters
Creates a required object parameter serialized as comma separated, like key1,value1,key2,value2
param(String, SchemaBuilder, ValueParser<String>) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Parameters
Creates a required parameter providing a
param(String, StringSchemaBuilder) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Parameters
Creates a new required string parameter
param(String, TupleSchemaBuilder) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Parameters
Creates a new required tuple parameter serialized as comma separated
parameter(ParameterLocation, ParameterProcessor) - Method in class io.vertx.reactivex.ext.web.validation.builder.ValidationHandlerBuilder
Add a parameter given the location and the processor
parameter(String) - Method in class io.vertx.reactivex.ext.web.handler.APIKeyHandler
Specify the source for the api key extraction as an HTTP query parameter with the given name.
parameter(String) - Method in class io.vertx.reactivex.ext.web.LanguageHeader
The value of the parameter specified by this key.
parameter(String) - Method in class io.vertx.reactivex.ext.web.MIMEHeader
The value of the parameter specified by this key.
parameter(String) - Method in interface io.vertx.reactivex.ext.web.ParsedHeaderValue
The value of the parameter specified by this key.
Parameter - Class in io.vertx.reactivex.openapi.contract
This interface represents the most important attributes of an OpenAPI Parameter.
Parameter - Interface in io.vertx.reactivex.openapi.validation
 
Parameter(Parameter) - Constructor for class io.vertx.reactivex.openapi.contract.Parameter
 
Parameter(Object) - Constructor for class io.vertx.reactivex.openapi.contract.Parameter
 
ParameterProcessorFactory - Class in io.vertx.reactivex.ext.web.validation.builder
This interface is used to build parameter processors supported on every .
ParameterProcessorFactory(ParameterProcessorFactory) - Constructor for class io.vertx.reactivex.ext.web.validation.builder.ParameterProcessorFactory
 
ParameterProcessorFactory(Object) - Constructor for class io.vertx.reactivex.ext.web.validation.builder.ParameterProcessorFactory
 
parameters() - Method in class io.vertx.reactivex.ext.web.LanguageHeader
The parameters specified in this header value.
parameters() - Method in class io.vertx.reactivex.ext.web.MIMEHeader
The parameters specified in this header value.
parameters() - Method in interface io.vertx.reactivex.ext.web.ParsedHeaderValue
The parameters specified in this header value.
Parameters - Class in io.vertx.reactivex.ext.web.validation.builder
In this interface you can find all available ParameterProcessorFactory to use in ValidationHandlerBuilder.
Parameters(Parameters) - Constructor for class io.vertx.reactivex.ext.web.validation.builder.Parameters
 
Parameters(Object) - Constructor for class io.vertx.reactivex.ext.web.validation.builder.Parameters
 
params() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
 
params() - Method in class io.vertx.reactivex.ext.auth.hashing.HashingAlgorithm
return the list of param names required for this algorithm.
params(boolean) - Method in class io.vertx.reactivex.core.http.HttpServerRequest
 
parent() - Method in class io.vertx.reactivex.core.json.pointer.JsonPointer
Remove last reference token of this pointer
parsedHeaders() - Method in class io.vertx.reactivex.ext.web.RoutingContext
The headers: Accept Accept-Charset Accept-Encoding Accept-Language Content-Type Parsed into ParsedHeaderValue
ParsedHeaderValue - Interface in io.vertx.reactivex.ext.web
 
ParsedHeaderValues - Class in io.vertx.reactivex.ext.web
A container with the request's headers that are meaningful enough to be parsed Contains: Accept -> MIME header, parameters and sortable Accept-Charset -> Parameters and sortable Accept-Encoding -> Parameters and sortable Accept-Language -> Parameters and sortable Content-Type -> MIME header and parameters
ParsedHeaderValues(ParsedHeaderValues) - Constructor for class io.vertx.reactivex.ext.web.ParsedHeaderValues
 
ParsedHeaderValues(Object) - Constructor for class io.vertx.reactivex.ext.web.ParsedHeaderValues
 
Parsers - Class in io.vertx.reactivex.ext.web.validation.builder
In this interface you can find all available ArrayParserFactory, ObjectParserFactory & TupleParserFactory
Parsers(Parsers) - Constructor for class io.vertx.reactivex.ext.web.validation.builder.Parsers
 
Parsers(Object) - Constructor for class io.vertx.reactivex.ext.web.validation.builder.Parsers
 
partition() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumerRecord
 
partition() - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducerRecord
 
partitionsAssignedHandler(Handler<Set<TopicPartition>>) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Set the handler called when topic partitions are assigned to the consumer
partitionsFor(String) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Get metadata about the partitions for a given topic.
partitionsFor(String) - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
Get the partition metadata for the give topic.
partitionsRevokedHandler(Handler<Set<TopicPartition>>) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Set the handler called when topic partitions are revoked to the consumer
passCheck(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Set status of the check to "passing".
passCheckWithNote(String, String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Set status of the check to "passing".
patch() - Method in class io.vertx.reactivex.ext.web.Router
Add a route that matches any HTTP PATCH request
patch(int, String, UriTemplate) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP PATCH request to send to the server at the specified host and port.
patch(int, String, String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP PATCH request to send to the server at the specified host and port.
patch(UriTemplate) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP PATCH request to send to the server at the default host and port.
patch(String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP PATCH request to send to the server at the default host and port.
patch(String) - Method in class io.vertx.reactivex.ext.web.Router
Add a route that matches a HTTP PATCH request and the specified path
patch(String, UriTemplate) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP PATCH request to send to the server at the specified host and default port.
patch(String, String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP PATCH request to send to the server at the specified host and default port.
patchAbs(UriTemplate) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP PATCH request to send to the server using an absolute URI, specifying a response handler to receive the response
patchAbs(String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP PATCH request to send to the server using an absolute URI, specifying a response handler to receive the response
patchWithRegex(String) - Method in class io.vertx.reactivex.ext.web.Router
Add a route that matches a HTTP PATCH request and the specified path regex
path() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
 
path() - Method in class io.vertx.reactivex.core.http.HttpRequestHead
 
path() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
 
path() - Method in class io.vertx.reactivex.core.http.ServerWebSocketHandshake
 
path(String) - Method in class io.vertx.reactivex.ext.web.Route
Set the path prefix for this route.
Path - Class in io.vertx.reactivex.openapi.contract
This interface represents the most important attributes of an OpenAPI Parameter.
Path(Path) - Constructor for class io.vertx.reactivex.openapi.contract.Path
 
Path(Object) - Constructor for class io.vertx.reactivex.openapi.contract.Path
 
pathname() - Method in class io.vertx.reactivex.ext.web.multipart.FormDataPart
 
pathParam(String) - Method in class io.vertx.reactivex.ext.web.RoutingContext
Gets the value of a single path parameter
pathParameter(ParameterProcessorFactory) - Method in class io.vertx.reactivex.ext.web.validation.builder.ValidationHandlerBuilder
 
pathParameter(String) - Method in class io.vertx.reactivex.ext.web.validation.RequestParameters
Get path parameter by name
pathParametersNames() - Method in class io.vertx.reactivex.ext.web.validation.RequestParameters
Get list of all parameter names inside path
pathParams() - Method in class io.vertx.reactivex.ext.web.RoutingContext
Returns a map of named parameters as defined in path declaration with their actual values
pathRegex(String) - Method in class io.vertx.reactivex.ext.web.Route
Set the path prefix as a regular expression.
pause() - Method in class io.vertx.reactivex.amqp.AmqpReceiver
 
pause() - Method in class io.vertx.reactivex.cassandra.CassandraRowStream
 
pause() - Method in class io.vertx.reactivex.core.eventbus.MessageConsumer
 
pause() - Method in class io.vertx.reactivex.core.file.AsyncFile
 
pause() - Method in class io.vertx.reactivex.core.http.ClientWebSocket
 
pause() - Method in class io.vertx.reactivex.core.http.HttpClientResponse
 
pause() - Method in class io.vertx.reactivex.core.http.HttpServerFileUpload
 
pause() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
 
pause() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
 
pause() - Method in class io.vertx.reactivex.core.http.WebSocket
 
pause() - Method in interface io.vertx.reactivex.core.http.WebSocketBase
 
pause() - Method in class io.vertx.reactivex.core.net.NetSocket
 
pause() - Method in class io.vertx.reactivex.core.parsetools.JsonParser
 
pause() - Method in class io.vertx.reactivex.core.parsetools.RecordParser
 
pause() - Method in interface io.vertx.reactivex.core.streams.ReadStream
Pause the ReadStream, it sets the buffer in fetch mode and clears the actual demand.
pause() - Method in class io.vertx.reactivex.ext.unit.report.TestSuiteReport
 
pause() - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
 
pause() - Method in class io.vertx.reactivex.grpc.client.GrpcClientResponse
 
pause() - Method in class io.vertx.reactivex.grpc.common.GrpcReadStream
 
pause() - Method in class io.vertx.reactivex.grpc.server.GrpcServerRequest
 
pause() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
 
pause() - Method in class io.vertx.reactivex.pgclient.pubsub.PgChannel
Pause the channel, all notifications are discarded.
pause() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQConsumer
Pause the stream of incoming messages from queue.
pause() - Method in class io.vertx.reactivex.redis.client.RedisConnection
 
pause() - Method in class io.vertx.reactivex.sqlclient.RowStream
 
pause(TopicPartition) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Suspend fetching from the requested partition.
pause(Set<TopicPartition>) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Suspend fetching from the requested partitions.
paused() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Get the set of partitions that were previously paused by a call to pause(Set).
payload() - Method in class io.vertx.reactivex.mqtt.messages.MqttPublishMessage
 
PebbleTemplateEngine - Class in io.vertx.reactivex.ext.web.templ.pebble
A template engine that uses the Pebble library.
PebbleTemplateEngine(PebbleTemplateEngine) - Constructor for class io.vertx.reactivex.ext.web.templ.pebble.PebbleTemplateEngine
 
PebbleTemplateEngine(Object) - Constructor for class io.vertx.reactivex.ext.web.templ.pebble.PebbleTemplateEngine
 
peersStatus() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Retrieves the Raft peers for the datacenter in which the the agent is running.
pendingQueueFull() - Method in class io.vertx.reactivex.redis.client.RedisConnection
Flag to notify if the pending message queue (commands in transit) is full.
PermissionBasedAuthorization - Class in io.vertx.reactivex.ext.auth.authorization
Represents a permission Note that the permission can optionally be assigned to a specific resource
PermissionBasedAuthorization(PermissionBasedAuthorization) - Constructor for class io.vertx.reactivex.ext.auth.authorization.PermissionBasedAuthorization
 
PermissionBasedAuthorization(Object) - Constructor for class io.vertx.reactivex.ext.auth.authorization.PermissionBasedAuthorization
 
persist(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove the expiration from a key.
pexpire(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Set a key's time to live in milliseconds.
pexpireat(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Set the expiration for a key as a UNIX timestamp specified in milliseconds.
pexpiretime(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the expiration Unix timestamp for a key in milliseconds.
pfadd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Adds the specified elements to the specified HyperLogLog.
pfcount(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Return the approximated cardinality of the set(s) observed by the HyperLogLog at key(s).
pfdebug(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Internal commands for debugging HyperLogLog values.
pfmerge(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Merge N different HyperLogLogs into a single one.
pfselftest() - Method in class io.vertx.reactivex.redis.client.RedisAPI
An internal command for testing HyperLogLog values.
PgBuilder - Class in io.vertx.reactivex.pgclient
Entry point for building PostgreSQL clients.
PgBuilder(PgBuilder) - Constructor for class io.vertx.reactivex.pgclient.PgBuilder
 
PgBuilder(Object) - Constructor for class io.vertx.reactivex.pgclient.PgBuilder
 
PgChannel - Class in io.vertx.reactivex.pgclient.pubsub
A channel to Postgres that tracks the subscription to a given Postgres channel using the LISTEN/UNLISTEN commands.
PgChannel(PgChannel) - Constructor for class io.vertx.reactivex.pgclient.pubsub.PgChannel
 
PgChannel(Object) - Constructor for class io.vertx.reactivex.pgclient.pubsub.PgChannel
 
PgConnection - Class in io.vertx.reactivex.pgclient
A connection to Postgres.
PgConnection(PgConnection) - Constructor for class io.vertx.reactivex.pgclient.PgConnection
 
PgConnection(Object) - Constructor for class io.vertx.reactivex.pgclient.PgConnection
 
PgSubscriber - Class in io.vertx.reactivex.pgclient.pubsub
A class for managing subscriptions using LISTEN/UNLISTEN to Postgres channels.
PgSubscriber(PgSubscriber) - Constructor for class io.vertx.reactivex.pgclient.pubsub.PgSubscriber
 
PgSubscriber(Object) - Constructor for class io.vertx.reactivex.pgclient.pubsub.PgSubscriber
 
ping() - Method in class io.vertx.reactivex.db2client.DB2Connection
Send a PING command to check if the server is alive.
ping() - Static method in class io.vertx.reactivex.ext.stomp.Frames
 
ping() - Method in class io.vertx.reactivex.ext.stomp.StompServerConnection
Sends a `PING` frame to the client.
ping() - Method in class io.vertx.reactivex.mqtt.MqttClient
This method is needed by the client in order to avoid server closes the connection due to the keep alive timeout if client has no messages to send
ping() - Method in class io.vertx.reactivex.mysqlclient.MySQLConnection
Send a PING command to check if the server is alive.
ping(Buffer) - Method in class io.vertx.reactivex.core.http.HttpConnection
Send a frame to the remote endpoint.
ping(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Ping the server.
PING - Static variable in class io.vertx.reactivex.ext.stomp.Frames
 
pingHandler(Handler<Buffer>) - Method in class io.vertx.reactivex.core.http.HttpConnection
Set an handler notified when a frame is received from the remote endpoint.
pingHandler(Handler<StompClientConnection>) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Sets a handler that let customize the behavior when a ping needs to be sent to the server.
pingHandler(Handler<StompServerConnection>) - Method in class io.vertx.reactivex.ext.stomp.StompServerHandler
Allows customizing the action to do when the server needs to send a `PING` to the client.
pingHandler(Handler<Void>) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Set the pingreq handler on the MQTT endpoint.
pingResponseHandler(Handler<Void>) - Method in class io.vertx.reactivex.mqtt.MqttClient
Sets handler which will be called after PINGRESP packet receiving
pipe() - Method in class io.vertx.reactivex.amqp.AmqpReceiver
Pause this stream and return a to transfer the elements of this stream to a destination .
pipe() - Method in class io.vertx.reactivex.cassandra.CassandraRowStream
Pause this stream and return a to transfer the elements of this stream to a destination .
pipe() - Method in class io.vertx.reactivex.core.eventbus.MessageConsumer
Pause this stream and return a to transfer the elements of this stream to a destination .
pipe() - Method in class io.vertx.reactivex.core.file.AsyncFile
Pause this stream and return a to transfer the elements of this stream to a destination .
pipe() - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Pause this stream and return a to transfer the elements of this stream to a destination .
pipe() - Method in class io.vertx.reactivex.core.http.HttpClientResponse
Pause this stream and return a to transfer the elements of this stream to a destination .
pipe() - Method in class io.vertx.reactivex.core.http.HttpServerFileUpload
Pause this stream and return a to transfer the elements of this stream to a destination .
pipe() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
Pause this stream and return a to transfer the elements of this stream to a destination .
pipe() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Pause this stream and return a to transfer the elements of this stream to a destination .
pipe() - Method in class io.vertx.reactivex.core.http.WebSocket
Pause this stream and return a to transfer the elements of this stream to a destination .
pipe() - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Pause this stream and return a to transfer the elements of this stream to a destination .
pipe() - Method in class io.vertx.reactivex.core.net.NetSocket
Pause this stream and return a to transfer the elements of this stream to a destination .
pipe() - Method in class io.vertx.reactivex.core.parsetools.JsonParser
Pause this stream and return a to transfer the elements of this stream to a destination .
pipe() - Method in class io.vertx.reactivex.core.parsetools.RecordParser
Pause this stream and return a to transfer the elements of this stream to a destination .
pipe() - Method in interface io.vertx.reactivex.core.streams.ReadStream
Pause this stream and return a Pipe to transfer the elements of this stream to a destination WriteStream.
pipe() - Method in class io.vertx.reactivex.ext.unit.report.TestSuiteReport
Pause this stream and return a to transfer the elements of this stream to a destination .
pipe() - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
Pause this stream and return a to transfer the elements of this stream to a destination .
pipe() - Method in class io.vertx.reactivex.grpc.client.GrpcClientResponse
Pause this stream and return a to transfer the elements of this stream to a destination .
pipe() - Method in class io.vertx.reactivex.grpc.common.GrpcReadStream
Pause this stream and return a to transfer the elements of this stream to a destination .
pipe() - Method in class io.vertx.reactivex.grpc.server.GrpcServerRequest
Pause this stream and return a to transfer the elements of this stream to a destination .
pipe() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Pause this stream and return a to transfer the elements of this stream to a destination .
pipe() - Method in class io.vertx.reactivex.pgclient.pubsub.PgChannel
Pause this stream and return a to transfer the elements of this stream to a destination .
pipe() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQConsumer
Pause this stream and return a to transfer the elements of this stream to a destination .
pipe() - Method in class io.vertx.reactivex.redis.client.RedisConnection
Pause this stream and return a to transfer the elements of this stream to a destination .
pipe() - Method in class io.vertx.reactivex.sqlclient.RowStream
Pause this stream and return a to transfer the elements of this stream to a destination .
pipe(WriteStream<Buffer>) - Static method in class io.vertx.reactivex.ext.web.codec.BodyCodec
A body codec that pipes the body to a write stream.
pipe(WriteStream<Buffer>, boolean) - Static method in class io.vertx.reactivex.ext.web.codec.BodyCodec
A body codec that pipes the body to a write stream.
Pipe<T> - Class in io.vertx.reactivex.core.streams
Pipe data from a ReadStream to a WriteStream and performs flow control where necessary to prevent the write stream buffer from getting overfull.
Pipe(Pipe) - Constructor for class io.vertx.reactivex.core.streams.Pipe
 
Pipe(Object, TypeArg<T>) - Constructor for class io.vertx.reactivex.core.streams.Pipe
 
pipeTo(WriteStream<Row>) - Method in class io.vertx.reactivex.cassandra.CassandraRowStream
 
pipeTo(WriteStream<Buffer>) - Method in class io.vertx.reactivex.core.file.AsyncFile
Pipe this ReadStream to the WriteStream.
pipeTo(WriteStream<Buffer>) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Pipe this ReadStream to the WriteStream.
pipeTo(WriteStream<Buffer>) - Method in class io.vertx.reactivex.core.http.HttpClientResponse
Pipe this ReadStream to the WriteStream.
pipeTo(WriteStream<Buffer>) - Method in class io.vertx.reactivex.core.http.HttpServerFileUpload
Pipe this ReadStream to the WriteStream.
pipeTo(WriteStream<Buffer>) - Method in class io.vertx.reactivex.core.http.HttpServerRequest
Pipe this ReadStream to the WriteStream.
pipeTo(WriteStream<Buffer>) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Pipe this ReadStream to the WriteStream.
pipeTo(WriteStream<Buffer>) - Method in class io.vertx.reactivex.core.http.WebSocket
Pipe this ReadStream to the WriteStream.
pipeTo(WriteStream<Buffer>) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Pipe this ReadStream to the WriteStream.
pipeTo(WriteStream<Buffer>) - Method in class io.vertx.reactivex.core.net.NetSocket
Pipe this ReadStream to the WriteStream.
pipeTo(WriteStream<Buffer>) - Method in class io.vertx.reactivex.core.parsetools.RecordParser
Pipe this ReadStream to the WriteStream.
pipeTo(WriteStream<Buffer>) - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
Pipe this ReadStream to the WriteStream.
pipeTo(WriteStream<JsonEvent>) - Method in class io.vertx.reactivex.core.parsetools.JsonParser
Pipe this ReadStream to the WriteStream.
pipeTo(WriteStream<AmqpMessage>) - Method in class io.vertx.reactivex.amqp.AmqpReceiver
Pipe this ReadStream to the WriteStream.
pipeTo(WriteStream<Message<T>>) - Method in class io.vertx.reactivex.core.eventbus.MessageConsumer
Pipe this ReadStream to the WriteStream.
pipeTo(WriteStream<TestCaseReport>) - Method in class io.vertx.reactivex.ext.unit.report.TestSuiteReport
Pipe this ReadStream to the WriteStream.
pipeTo(WriteStream<KafkaConsumerRecord<K, V>>) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Pipe this ReadStream to the WriteStream.
pipeTo(WriteStream<RabbitMQMessage>) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQConsumer
Pipe this ReadStream to the WriteStream.
pipeTo(WriteStream<Response>) - Method in class io.vertx.reactivex.redis.client.RedisConnection
Pipe this ReadStream to the WriteStream.
pipeTo(WriteStream<String>) - Method in class io.vertx.reactivex.pgclient.pubsub.PgChannel
Pipe this ReadStream to the WriteStream.
pipeTo(WriteStream<Req>) - Method in class io.vertx.reactivex.grpc.server.GrpcServerRequest
Pipe this ReadStream to the WriteStream.
pipeTo(WriteStream<Resp>) - Method in class io.vertx.reactivex.grpc.client.GrpcClientResponse
Pipe this ReadStream to the WriteStream.
pipeTo(WriteStream<T>) - Method in interface io.vertx.reactivex.core.streams.ReadStream
Pipe this ReadStream to the WriteStream.
pipeTo(WriteStream<T>) - Method in class io.vertx.reactivex.grpc.common.GrpcReadStream
Pipe this ReadStream to the WriteStream.
pipeTo(WriteStream<T>) - Method in class io.vertx.reactivex.sqlclient.RowStream
Pipe this ReadStream to the WriteStream.
pkceVerifierLength(int) - Method in class io.vertx.reactivex.ext.web.handler.OAuth2AuthHandler
PKCE (RFC 7636) is an extension to the Authorization Code flow to prevent several attacks and to be able to securely perform the OAuth exchange from public clients.
PlatformHandler - Interface in io.vertx.reactivex.ext.web.handler
Base platform interface for handlers that provide functionality to the application platform.
PolicyBasedAuthorizationProvider - Class in io.vertx.reactivex.ext.auth.abac
 
PolicyBasedAuthorizationProvider(PolicyBasedAuthorizationProvider) - Constructor for class io.vertx.reactivex.ext.auth.abac.PolicyBasedAuthorizationProvider
 
PolicyBasedAuthorizationProvider(Object) - Constructor for class io.vertx.reactivex.ext.auth.abac.PolicyBasedAuthorizationProvider
 
poll(Duration) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Executes a poll for getting messages from Kafka.
pollTimeout(Duration) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Sets the poll timeout for the underlying native Kafka Consumer.
pong() - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Sends the PINGRESP message to the remote MQTT client
pongHandler(Handler<Buffer>) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
 
pongHandler(Handler<Buffer>) - Method in class io.vertx.reactivex.core.http.WebSocket
 
pongHandler(Handler<Buffer>) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Set a pong frame handler on the connection.
pool() - Static method in class io.vertx.reactivex.db2client.DB2Builder
Provide a builder for DB2 pool of connections
pool() - Static method in class io.vertx.reactivex.mssqlclient.MSSQLBuilder
Provide a builder for MSSQL pool of connections
pool() - Static method in class io.vertx.reactivex.mysqlclient.MySQLBuilder
Provide a builder for MySQL pool of connections
pool() - Static method in class io.vertx.reactivex.oracleclient.OracleBuilder
Provide a builder for Oracle pool of connections
pool() - Static method in class io.vertx.reactivex.pgclient.PgBuilder
Provide a builder for PostgreSQL pool of connections
pool(Handler<ClientBuilder<Pool>>) - Static method in class io.vertx.reactivex.db2client.DB2Builder
Build a pool with the specified block argument.
pool(Handler<ClientBuilder<Pool>>) - Static method in class io.vertx.reactivex.mssqlclient.MSSQLBuilder
Build a pool with the specified block argument.
pool(Handler<ClientBuilder<Pool>>) - Static method in class io.vertx.reactivex.mysqlclient.MySQLBuilder
Build a pool with the specified block argument.
pool(Handler<ClientBuilder<Pool>>) - Static method in class io.vertx.reactivex.oracleclient.OracleBuilder
Build a pool with the specified block argument.
pool(Handler<ClientBuilder<Pool>>) - Static method in class io.vertx.reactivex.pgclient.PgBuilder
Build a pool with the specified block argument.
pool(Vertx, JDBCConnectOptions, PoolOptions) - Static method in class io.vertx.reactivex.jdbcclient.JDBCPool
Create a JDBC pool which maintains its own data source.
pool(Vertx, SqlConnectOptions, PoolOptions) - Static method in class io.vertx.reactivex.sqlclient.Pool
Create a connection pool to the database with the given options.
pool(Vertx, DataSource, PoolOptions) - Static method in class io.vertx.reactivex.jdbcclient.JDBCPool
Create a JDBC pool using a pre-initialized data source, note this data source does not need to be a pool.
pool(SqlConnectOptions) - Static method in class io.vertx.reactivex.sqlclient.Pool
pool(SqlConnectOptions, PoolOptions) - Static method in class io.vertx.reactivex.sqlclient.Pool
Like Pool.pool(io.vertx.sqlclient.SqlConnectOptions) with a Vert.x instance created automatically.
Pool - Class in io.vertx.reactivex.sqlclient
A connection pool which reuses a number of SQL connections.
Pool(Pool) - Constructor for class io.vertx.reactivex.sqlclient.Pool
 
Pool(Object) - Constructor for class io.vertx.reactivex.sqlclient.Pool
 
port() - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
 
port(int) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Configure the request to use a new port value.
position() - Method in class io.vertx.reactivex.core.file.AsyncFileLock
 
position(TopicPartition) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Get the offset of the next record that will be fetched (if a record with that offset exists).
post() - Method in class io.vertx.reactivex.ext.web.Router
Add a route that matches any HTTP POST request
post(int, String, UriTemplate) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP POST request to send to the server at the specified host and port.
post(int, String, String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP POST request to send to the server at the specified host and port.
post(UriTemplate) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP POST request to send to the server at the default host and port.
post(String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP POST request to send to the server at the default host and port.
post(String) - Method in class io.vertx.reactivex.ext.web.Router
Add a route that matches a HTTP POST request and the specified path
post(String, UriTemplate) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP POST request to send to the server at the specified host and default port.
post(String, String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP POST request to send to the server at the specified host and default port.
postAbs(UriTemplate) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP POST request to send to the server using an absolute URI, specifying a response handler to receive the response
postAbs(String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP POST request to send to the server using an absolute URI, specifying a response handler to receive the response
postWithRegex(String) - Method in class io.vertx.reactivex.ext.web.Router
Add a route that matches a HTTP POST request and the specified path regex
predicate(RequestPredicate) - Method in class io.vertx.reactivex.ext.web.validation.builder.ValidationHandlerBuilder
 
preferredLanguage() - Method in class io.vertx.reactivex.ext.web.RoutingContext
Helper to return the user preferred language.
preloadMetaSchema(FileSystem) - Method in class io.vertx.reactivex.json.schema.SchemaRepository
Preloads the repository with the meta schemas for the related @link Draft version.
preloadMetaSchema(FileSystem, Draft) - Method in class io.vertx.reactivex.json.schema.SchemaRepository
Preloads the repository with the meta schemas for the related draft version.
prepare(SimpleStatement) - Method in class io.vertx.reactivex.cassandra.CassandraClient
Prepares the provided a .
prepare(String) - Method in class io.vertx.reactivex.cassandra.CassandraClient
Prepares the provided query string.
prepare(String) - Method in class io.vertx.reactivex.sqlclient.SqlConnection
Create a prepared statement using the given sql string.
prepare(String, PrepareOptions) - Method in class io.vertx.reactivex.sqlclient.SqlConnection
Create a prepared statement using the given sql string.
preparedQuery(String) - Method in class io.vertx.reactivex.sqlclient.Pool
A connection is borrowed from the connection pool when the query is executed and then immediately returned to the pool after it completes.
preparedQuery(String) - Method in class io.vertx.reactivex.sqlclient.SqlClient
Create a prepared query, one of the Query.execute() or PreparedQuery.executeBatch(java.util.List<io.vertx.reactivex.sqlclient.Tuple>) methods must be called to execute the query.
preparedQuery(String, PrepareOptions) - Method in class io.vertx.reactivex.sqlclient.SqlClient
Create a prepared query, one of the Query.execute() or PreparedQuery.executeBatch(java.util.List<io.vertx.reactivex.sqlclient.Tuple>) methods must be called to execute the query.
PreparedQuery<T> - Class in io.vertx.reactivex.sqlclient
A query for a prepared statement allowing parameterized execution of the query, this query will use a prepared statement.
PreparedQuery(PreparedQuery) - Constructor for class io.vertx.reactivex.sqlclient.PreparedQuery
 
PreparedQuery(Object, TypeArg<T>) - Constructor for class io.vertx.reactivex.sqlclient.PreparedQuery
 
PreparedStatement - Class in io.vertx.reactivex.sqlclient
A prepared statement, the statement is pre-compiled and it's more efficient to execute the statement for multiple times.
PreparedStatement(PreparedStatement) - Constructor for class io.vertx.reactivex.sqlclient.PreparedStatement
 
PreparedStatement(Object) - Constructor for class io.vertx.reactivex.sqlclient.PreparedStatement
 
prevResult() - Method in class io.vertx.reactivex.ext.consul.WatchResult
The previous result of the operation.
principal() - Method in class io.vertx.reactivex.ext.auth.User
Get the underlying principal for the User.
priority() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
priority(short) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
processId() - Method in class io.vertx.reactivex.pgclient.PgConnection
 
produces(String) - Method in class io.vertx.reactivex.ext.web.Route
Add a content type produced by this route.
productName() - Method in class io.vertx.reactivex.sqlclient.spi.DatabaseMetadata
 
PrometheusRequestHandler - Class in io.vertx.reactivex.micrometer
An interface for creating handlers to expose Prometheus metrics via an HTTP endpoint.
PrometheusRequestHandler(PrometheusRequestHandler) - Constructor for class io.vertx.reactivex.micrometer.PrometheusRequestHandler
 
PrometheusRequestHandler(Object) - Constructor for class io.vertx.reactivex.micrometer.PrometheusRequestHandler
 
PrometheusScrapingHandler - Class in io.vertx.reactivex.micrometer
A Vert.x Web Route handler for Prometheus metrics scraping.
PrometheusScrapingHandler(PrometheusScrapingHandler) - Constructor for class io.vertx.reactivex.micrometer.PrometheusScrapingHandler
 
PrometheusScrapingHandler(Object) - Constructor for class io.vertx.reactivex.micrometer.PrometheusScrapingHandler
 
prompt(String) - Method in class io.vertx.reactivex.ext.web.handler.OAuth2AuthHandler
Indicates the type of user interaction that is required.
properties() - Method in class io.vertx.reactivex.mqtt.messages.MqttAuthenticationExchangeMessage
 
properties() - Method in class io.vertx.reactivex.mqtt.messages.MqttConnAckMessage
 
properties() - Method in class io.vertx.reactivex.mqtt.messages.MqttDisconnectMessage
 
properties() - Method in class io.vertx.reactivex.mqtt.messages.MqttPubAckMessage
 
properties() - Method in class io.vertx.reactivex.mqtt.messages.MqttPubCompMessage
 
properties() - Method in class io.vertx.reactivex.mqtt.messages.MqttPublishMessage
 
properties() - Method in class io.vertx.reactivex.mqtt.messages.MqttPubRecMessage
 
properties() - Method in class io.vertx.reactivex.mqtt.messages.MqttPubRelMessage
 
properties() - Method in class io.vertx.reactivex.mqtt.messages.MqttSubscribeMessage
 
properties() - Method in class io.vertx.reactivex.mqtt.messages.MqttUnsubscribeMessage
 
properties() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQMessage
 
property(PropertyKind<V>) - Method in class io.vertx.reactivex.sqlclient.SqlResult
Get the specific property with the specified PropertyKind.
PropertyFileAuthentication - Class in io.vertx.reactivex.ext.auth.properties
Factory interface for creating property file based AuthenticationProvider instances.
PropertyFileAuthentication(PropertyFileAuthentication) - Constructor for class io.vertx.reactivex.ext.auth.properties.PropertyFileAuthentication
 
PropertyFileAuthentication(Object) - Constructor for class io.vertx.reactivex.ext.auth.properties.PropertyFileAuthentication
 
PropertyFileAuthorization - Class in io.vertx.reactivex.ext.auth.properties
Factory interface for creating property file based AuthenticationProvider instances.
PropertyFileAuthorization(PropertyFileAuthorization) - Constructor for class io.vertx.reactivex.ext.auth.properties.PropertyFileAuthorization
 
PropertyFileAuthorization(Object) - Constructor for class io.vertx.reactivex.ext.auth.properties.PropertyFileAuthorization
 
PropertyKind<T> - Class in io.vertx.reactivex.sqlclient
The kind of the property, this can be used to fetch some specific property of the execution result.
PropertyKind(PropertyKind) - Constructor for class io.vertx.reactivex.sqlclient.PropertyKind
 
PropertyKind(Object, TypeArg<T>) - Constructor for class io.vertx.reactivex.sqlclient.PropertyKind
 
props(String) - Method in class io.vertx.reactivex.core.file.FileSystem
Obtain properties for the file represented by path, asynchronously.
propsBlocking(String) - Method in class io.vertx.reactivex.core.file.FileSystem
protocolName() - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
 
ProtocolUpgradeHandler - Interface in io.vertx.reactivex.ext.web.handler
Base interface for handlers that perform protocol upgrades.
protocolVersion() - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
 
proxy() - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
 
proxy(ProxyOptions) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Configure the request to set a proxy for this request.
PROXY_AUTHENTICATE - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Proxy-Authenticate header name
PROXY_AUTHORIZATION - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Proxy-Authorization header name
psetex(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Set the value and expiration in milliseconds of a key.
PSEUDO_AUTHORITY - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
HTTP/2 :authority pseudo header
PSEUDO_METHOD - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
HTTP/2 :method pseudo hedaer
PSEUDO_PATH - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
HTTP/2 :path pseudo header
PSEUDO_SCHEME - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
HTTP/2 :scheme pseudo header
PSEUDO_STATUS - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
HTTP/2 :status pseudo header
psubscribe(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Listen for messages published to channels matching the given patterns.
psync(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Internal command used for replication.
pttl(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the time to live for a key in milliseconds.
publish(Record) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
Publishes a record.
publish(Record) - Method in class io.vertx.reactivex.servicediscovery.spi.ServicePublisher
Publishes a record.
publish(String, Buffer, MqttQoS, boolean, boolean) - Method in class io.vertx.reactivex.mqtt.MqttClient
Sends the PUBLISH message to the remote MQTT server
publish(String, Buffer, MqttQoS, boolean, boolean) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Sends the PUBLISH message to the remote MQTT client
publish(String, Buffer, MqttQoS, boolean, boolean, int) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Sends the PUBLISH message to the remote MQTT server explicitly specifying the messageId
publish(String, Buffer, MqttQoS, boolean, boolean, int, MqttProperties) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Sends the PUBLISH message to the remote MQTT server explicitly specifying the messageId
publish(String, Object) - Method in class io.vertx.reactivex.core.eventbus.EventBus
Publish a message.
publish(String, Object, DeliveryOptions) - Method in class io.vertx.reactivex.core.eventbus.EventBus
Like EventBus.publish(java.lang.String, java.lang.Object) but specifying options that can be used to configure the delivery.
publish(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Post a message to a channel.
publish(String, String, BasicProperties, Buffer) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQPublisher
Publish a message.
publishAcknowledge(int) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Sends the PUBACK message to the remote MQTT client
publishAcknowledge(int, MqttPubAckReasonCode, MqttProperties) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
 
publishAcknowledgeHandler(Handler<Integer>) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Set the puback handler on the MQTT endpoint.
publishAcknowledgeMessageHandler(Handler<MqttPubAckMessage>) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Set the puback handler on the MQTT endpoint.
publishAutoAck(boolean) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Enable/disable publishing (in/out) auto acknowledge
publishComplete(int) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Sends the PUBCOMP message to the remote MQTT client
publishComplete(int, MqttPubCompReasonCode, MqttProperties) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Sends the PUBCOMP message to the remote MQTT client
publishCompletionExpirationHandler(Handler<Integer>) - Method in class io.vertx.reactivex.mqtt.MqttClient
Sets a handler which will be called when the client does not receive a PUBACK or PUBREC/PUBCOMP for a message published using QoS 1 or 2 respectively.
publishCompletionHandler(Handler<Integer>) - Method in class io.vertx.reactivex.mqtt.MqttClient
Sets a handler which will be called each time the publishing of a message has been completed.
publishCompletionHandler(Handler<Integer>) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Set the pubcomp handler on the MQTT endpoint.
publishCompletionMessageHandler(Handler<MqttPubCompMessage>) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Set the pubcomp handler on the MQTT endpoint.
publishCompletionUnknownPacketIdHandler(Handler<Integer>) - Method in class io.vertx.reactivex.mqtt.MqttClient
Sets a handler which will be called when the client receives a PUBACK/PUBREC/PUBCOMP with an unknown packet ID.
publishConfirm(String, String, BasicProperties, Buffer) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQPublisher
Publish a message and complete when publish confirm has returned.
publisher(String) - Method in class io.vertx.reactivex.core.eventbus.EventBus
Create a message publisher against the specified address.
publisher(String, DeliveryOptions) - Method in class io.vertx.reactivex.core.eventbus.EventBus
Like EventBus.publisher(java.lang.String) but specifying delivery options that will be used for configuring the delivery of the message.
publishHandler(Handler<MqttPublishMessage>) - Method in class io.vertx.reactivex.mqtt.MqttClient
Sets handler which will be called each time server publish something to client
publishHandler(Handler<MqttPublishMessage>) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Set the publish handler on the MQTT endpoint.
publishReceived(int) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Sends the PUBREC message to the remote MQTT client
publishReceived(int, MqttPubRecReasonCode, MqttProperties) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Sends the PUBREC message to the remote MQTT client
publishReceivedHandler(Handler<Integer>) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Set the pubrec handler on the MQTT endpoint.
publishReceivedMessageHandler(Handler<MqttPubRecMessage>) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Set the pubrec handler on the MQTT endpoint.
publishRelease(int) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Sends the PUBREL message to the remote MQTT client
publishRelease(int, MqttPubRelReasonCode, MqttProperties) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Sends the PUBREL message to the remote MQTT client
publishReleaseHandler(Handler<Integer>) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Set the pubrel handler on the MQTT endpoint.
publishReleaseMessageHandler(Handler<MqttPubRelMessage>) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Set the pubrel handler on the MQTT endpoint.
pubsub(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
A container for Pub/Sub commands.
PugTemplateEngine - Class in io.vertx.reactivex.ext.web.templ.pug
A template engine that uses Pug.
PugTemplateEngine(PugTemplateEngine) - Constructor for class io.vertx.reactivex.ext.web.templ.pug.PugTemplateEngine
 
PugTemplateEngine(Object) - Constructor for class io.vertx.reactivex.ext.web.templ.pug.PugTemplateEngine
 
punsubscribe(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Stop listening for messages posted to channels matching the given patterns.
push(HttpMethod, HostAndPort, String) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
push(HttpMethod, HostAndPort, String, MultiMap) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Push a response to the client.
push(HttpMethod, String) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
push(HttpMethod, String, MultiMap) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
pushHandler(Handler<HttpClientRequest>) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Set a push handler for this request.
put() - Method in class io.vertx.reactivex.ext.web.Router
Add a route that matches any HTTP PUT request
put(int, String, UriTemplate) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP PUT request to send to the server at the specified host and port.
put(int, String, String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP PUT request to send to the server at the specified host and port.
put(Session) - Method in class io.vertx.reactivex.ext.web.sstore.SessionStore
Add a session with the specified ID.
put(UriTemplate) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP PUT request to send to the server at the default host and port.
put(String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP PUT request to send to the server at the default host and port.
put(String) - Method in class io.vertx.reactivex.ext.web.Router
Add a route that matches a HTTP PUT request and the specified path
put(String, HashingAlgorithm) - Method in class io.vertx.reactivex.ext.auth.hashing.HashingStrategy
Put or replace an algorithm into the list of system loaded algorithms.
put(String, UriTemplate) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP PUT request to send to the server at the specified host and default port.
put(String, Object) - Method in class io.vertx.reactivex.ext.unit.TestContext
Put some data in the context.
put(String, Object) - Method in class io.vertx.reactivex.ext.web.RoutingContext
Put some arbitrary data in the context.
put(String, Object) - Method in class io.vertx.reactivex.ext.web.Session
Put some data in a session
put(String, String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP PUT request to send to the server at the specified host and default port.
put(String, Set<Authorization>) - Method in class io.vertx.reactivex.ext.auth.authorization.Authorizations
Replaces the current authorizations with the given authorizations for the given provider.
put(K, V) - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
Put a value in the map, asynchronously.
put(K, V) - Method in class io.vertx.reactivex.core.shareddata.LocalMap
Put an entry in the map
put(K, V, long) - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
Like AsyncMap.put(K, V) but specifying a time to live for the entry.
putAbs(UriTemplate) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP PUT request to send to the server using an absolute URI, specifying a response handler to receive the response
putAbs(String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP PUT request to send to the server using an absolute URI, specifying a response handler to receive the response
putHeader(CharSequence, CharSequence) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
putHeader(CharSequence, CharSequence) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
putHeader(CharSequence, Iterable<CharSequence>) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
putHeader(CharSequence, Iterable<CharSequence>) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
putHeader(String, Iterable<String>) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Put an HTTP header with multiple values
putHeader(String, Iterable<String>) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Like HttpServerResponse.putHeader(java.lang.String, java.lang.String) but providing multiple values via a String Iterable
putHeader(String, Iterable<String>) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Configure the request to set a new HTTP header with multiple values.
putHeader(String, String) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Put an HTTP header
putHeader(String, String) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Put an HTTP header
putHeader(String, String) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Configure the request to set a new HTTP header.
putHeaders(MultiMap) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Configure the request to add multiple HTTP headers .
putIfAbsent(String, Object) - Method in class io.vertx.reactivex.ext.web.Session
Put some data in a session if absent
putIfAbsent(K, V) - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
Put the entry only if there is no entry with the key already present.
putIfAbsent(K, V) - Method in class io.vertx.reactivex.core.shareddata.LocalMap
Put the entry only if there is no existing entry for that key
putIfAbsent(K, V, long) - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
Link AsyncMap.putIfAbsent(K, V) but specifying a time to live for the entry.
putMetadata(String, Object) - Method in class io.vertx.reactivex.ext.web.Route
Put metadata to this route.
putMetadata(String, Object) - Method in class io.vertx.reactivex.ext.web.Router
Put metadata to this router.
putTrailer(CharSequence, CharSequence) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
putTrailer(CharSequence, Iterable<CharSequence>) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
putTrailer(String, Iterable<String>) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Like HttpServerResponse.putTrailer(java.lang.String, java.lang.String) but providing multiple values via a String Iterable
putTrailer(String, String) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Put an HTTP trailer
putValue(String, String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Adds specified key/value pair
putValueWithOptions(String, String, KeyValueOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
 
putWithRegex(String) - Method in class io.vertx.reactivex.ext.web.Router
Add a route that matches a HTTP PUT request and the specified path regex

Q

qosLevel() - Method in class io.vertx.reactivex.mqtt.messages.MqttPublishMessage
 
qualityOfService() - Method in class io.vertx.reactivex.mqtt.MqttTopicSubscription
 
query() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
 
query() - Method in class io.vertx.reactivex.core.http.HttpRequestHead
 
query() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
 
query() - Method in class io.vertx.reactivex.core.http.ServerWebSocketHandshake
 
query() - Method in class io.vertx.reactivex.sqlclient.PreparedStatement
Create a prepared query for this statement.
query(Object, JsonPointerIterator) - Method in class io.vertx.reactivex.core.json.pointer.JsonPointer
Query objectToQuery using the provided JsonPointerIterator.
query(String) - Method in class io.vertx.reactivex.sqlclient.Pool
A connection is borrowed from the connection pool when the query is executed and then immediately returned to the pool after it completes.
query(String) - Method in class io.vertx.reactivex.sqlclient.SqlClient
Create a query, the Query.execute() method must be called to execute the query.
Query<T> - Class in io.vertx.reactivex.sqlclient
A query.
Query(Query) - Constructor for class io.vertx.reactivex.sqlclient.Query
 
Query(Object, TypeArg<T>) - Constructor for class io.vertx.reactivex.sqlclient.Query
 
queryJson(Object) - Method in class io.vertx.reactivex.core.json.pointer.JsonPointer
Query jsonElement.
queryJsonOrDefault(Object, Object) - Method in class io.vertx.reactivex.core.json.pointer.JsonPointer
Query jsonElement.
queryOrDefault(Object, JsonPointerIterator, Object) - Method in class io.vertx.reactivex.core.json.pointer.JsonPointer
Query objectToQuery using the provided JsonPointerIterator.
queryParam(String) - Method in class io.vertx.reactivex.ext.web.RoutingContext
Gets the value of a single query parameter.
queryParameter(ParameterProcessorFactory) - Method in class io.vertx.reactivex.ext.web.validation.builder.ValidationHandlerBuilder
 
queryParameter(StyledParameterProcessorFactory) - Method in class io.vertx.reactivex.ext.web.validation.builder.ValidationHandlerBuilder
 
queryParameter(String) - Method in class io.vertx.reactivex.ext.web.validation.RequestParameters
Get query parameter by name
queryParametersNames() - Method in class io.vertx.reactivex.ext.web.validation.RequestParameters
Get list of all parameter names inside query
queryParams() - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Return the current query parameters.
queryParams() - Method in class io.vertx.reactivex.ext.web.RoutingContext
Returns a map of all query parameters inside the query string
The query parameters are lazily decoded: the decoding happens on the first time this method is called.
queryParams(Charset) - Method in class io.vertx.reactivex.ext.web.RoutingContext
Always decode the current query string with the given encoding.
queryStream(Statement) - Method in class io.vertx.reactivex.cassandra.CassandraClient
Executes the given SQL statement which returns the results of the query as a read stream.
queryStream(String) - Method in class io.vertx.reactivex.cassandra.CassandraClient
Executes the given SQL SELECT statement which returns the results of the query as a read stream.
queue(Vertx, String) - Static method in class io.vertx.reactivex.ext.stomp.Destination
 
queueBind(String, String, String) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Bind a queue to an exchange
queueBind(String, String, String, Map<String, Object>) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Bind a queue to an exchange
queueDeclare(String, boolean, boolean, boolean) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Declare a queue
queueDeclare(String, boolean, boolean, boolean, JsonObject) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Declare a queue with config options
queueDeclareAuto() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Actively declare a server-named exclusive, autodelete, non-durable queue.
queueDelete(String) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Delete a queue, without regard for whether it is in use or has messages on it
queueDeleteIf(String, boolean, boolean) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Delete a queue
queueName() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQConsumer
 
queueSize() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQPublisher
Get the number of published, but not sent, messages.
queueUnbind(String, String, String) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Unbind a queue from an exchange
queueUnbind(String, String, String, Map<String, Object>) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Unbind a queue from an exchange
quit(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Close the connection.

R

RabbitMQClient - Class in io.vertx.reactivex.rabbitmq
NOTE: This class has been automatically generated from the original non RX-ified interface using Vert.x codegen.
RabbitMQClient(RabbitMQClient) - Constructor for class io.vertx.reactivex.rabbitmq.RabbitMQClient
 
RabbitMQClient(Object) - Constructor for class io.vertx.reactivex.rabbitmq.RabbitMQClient
 
RabbitMQConsumer - Class in io.vertx.reactivex.rabbitmq
A stream of messages from a rabbitmq queue.
RabbitMQConsumer(RabbitMQConsumer) - Constructor for class io.vertx.reactivex.rabbitmq.RabbitMQConsumer
 
RabbitMQConsumer(Object) - Constructor for class io.vertx.reactivex.rabbitmq.RabbitMQConsumer
 
RabbitMQMessage - Class in io.vertx.reactivex.rabbitmq
Represent a message received message received in a rabbitmq-queue.
RabbitMQMessage(RabbitMQMessage) - Constructor for class io.vertx.reactivex.rabbitmq.RabbitMQMessage
 
RabbitMQMessage(Object) - Constructor for class io.vertx.reactivex.rabbitmq.RabbitMQMessage
 
RabbitMQPublisher - Class in io.vertx.reactivex.rabbitmq
A reliable publisher that Queues up messages internally until it can successfully call basicPublish.
RabbitMQPublisher(RabbitMQPublisher) - Constructor for class io.vertx.reactivex.rabbitmq.RabbitMQPublisher
 
RabbitMQPublisher(Object) - Constructor for class io.vertx.reactivex.rabbitmq.RabbitMQPublisher
 
randomkey() - Method in class io.vertx.reactivex.redis.client.RedisAPI
Return a random key from the keyspace.
rawValue() - Method in class io.vertx.reactivex.ext.web.LanguageHeader
Contains the raw value that was received from the user agent
rawValue() - Method in class io.vertx.reactivex.ext.web.MIMEHeader
Contains the raw value that was received from the user agent
rawValue() - Method in interface io.vertx.reactivex.ext.web.ParsedHeaderValue
Contains the raw value that was received from the user agent
read(int) - Method in class io.vertx.reactivex.sqlclient.Cursor
Read rows from the cursor, the result is provided asynchronously to the handler.
read(Buffer, int, long, int) - Method in class io.vertx.reactivex.core.file.AsyncFile
Reads length bytes of data from the file at position position in the file, asynchronously.
readAclToken(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Reads an ACL token with the given Accessor ID
readByFileName(String) - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
Read file by name to ReadStream
readByFileNameWithOptions(String, GridFsDownloadOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
Read file by name to ReadStream with options
readById(String) - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
Read file by id to ReadStream
readDir(String) - Method in class io.vertx.reactivex.core.file.FileSystem
Read the contents of the directory specified by path, asynchronously.
readDir(String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
Read the contents of the directory specified by path, asynchronously.
readDirBlocking(String) - Method in class io.vertx.reactivex.core.file.FileSystem
readDirBlocking(String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
readFile(String) - Method in class io.vertx.reactivex.core.file.FileSystem
Reads the entire file as represented by the path path as a , asynchronously.
readFileBlocking(String) - Method in class io.vertx.reactivex.core.file.FileSystem
readonly() - Method in class io.vertx.reactivex.redis.client.RedisAPI
Enables read queries for a connection to a cluster replica node.
readPolicy(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
This endpoint reads an ACL policy with the given ID
readPolicyByName(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
This endpoint reads an ACL policy with the given name
ReadStream<T> - Interface in io.vertx.reactivex.core.streams
Represents a stream of items that can be read from.
readSymlink(String) - Method in class io.vertx.reactivex.core.file.FileSystem
Returns the path representing the file that the symbolic link specified by link points to, asynchronously.
readSymlinkBlocking(String) - Method in class io.vertx.reactivex.core.file.FileSystem
readwrite() - Method in class io.vertx.reactivex.redis.client.RedisAPI
Disables read queries for a connection to a cluster replica node.
realm() - Method in class io.vertx.reactivex.ext.auth.htdigest.HtdigestAuth
Return the currently used realm
reasonCode() - Method in class io.vertx.reactivex.mqtt.messages.MqttAuthenticationExchangeMessage
 
receivedFrameHandler(Handler<Frame>) - Method in class io.vertx.reactivex.ext.stomp.StompClient
Configures a received handler that gets notified when a STOMP frame is received by the client.
receivedFrameHandler(Handler<Frame>) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Configures a received handler that get notified when a STOMP frame is received by the client.
receivedFrameHandler(Handler<ServerFrame>) - Method in class io.vertx.reactivex.ext.stomp.StompServerHandler
Configures a handler that get notified when a STOMP frame is received by the server.
reconnectPolicy(Function<Integer, Long>) - Method in class io.vertx.reactivex.pgclient.pubsub.PgSubscriber
Set the reconnect policy that is executed when the subscriber is disconnected.
record() - Method in class io.vertx.reactivex.servicediscovery.ServiceReference
 
recordAt(int) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumerRecords
Get the record at the given index
RecordParser - Class in io.vertx.reactivex.core.parsetools
A helper class which allows you to easily parse protocols which are delimited by a sequence of bytes, or fixed size records.
RecordParser(RecordParser) - Constructor for class io.vertx.reactivex.core.parsetools.RecordParser
 
RecordParser(Object) - Constructor for class io.vertx.reactivex.core.parsetools.RecordParser
 
redirect(String) - Method in class io.vertx.reactivex.ext.web.RoutingContext
Perform a 302 redirect to url.
RedirectAuthHandler - Class in io.vertx.reactivex.ext.web.handler
An auth handler that's used to handle auth by redirecting user to a custom login page.
RedirectAuthHandler(RedirectAuthHandler) - Constructor for class io.vertx.reactivex.ext.web.handler.RedirectAuthHandler
 
RedirectAuthHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.RedirectAuthHandler
 
redirectHandler(Function<HttpClientResponse, Single<HttpClientRequest>>) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
 
redirectHandler(Function<HttpClientResponse, Future<HttpClientRequest>>) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
 
Redis - Class in io.vertx.reactivex.redis.client
A simple Redis client.
Redis(Redis) - Constructor for class io.vertx.reactivex.redis.client.Redis
 
Redis(Object) - Constructor for class io.vertx.reactivex.redis.client.Redis
 
RedisAPI - Class in io.vertx.reactivex.redis.client
Auto generated Redis API client wrapper.
RedisAPI(RedisAPI) - Constructor for class io.vertx.reactivex.redis.client.RedisAPI
 
RedisAPI(Object) - Constructor for class io.vertx.reactivex.redis.client.RedisAPI
 
RedisCluster - Class in io.vertx.reactivex.redis.client
Utilities for Redis cluster.
RedisCluster(RedisCluster) - Constructor for class io.vertx.reactivex.redis.client.RedisCluster
 
RedisCluster(Object) - Constructor for class io.vertx.reactivex.redis.client.RedisCluster
 
RedisConnection - Class in io.vertx.reactivex.redis.client
A simple Redis client.
RedisConnection(RedisConnection) - Constructor for class io.vertx.reactivex.redis.client.RedisConnection
 
RedisConnection(Object) - Constructor for class io.vertx.reactivex.redis.client.RedisConnection
 
RedisDataSource - Class in io.vertx.reactivex.servicediscovery.types
Service type for Redis data source.
RedisDataSource(RedisDataSource) - Constructor for class io.vertx.reactivex.servicediscovery.types.RedisDataSource
 
RedisDataSource(Object) - Constructor for class io.vertx.reactivex.servicediscovery.types.RedisDataSource
 
RedisSessionStore - Class in io.vertx.reactivex.ext.web.sstore.redis
A SessionStore that uses a Redis to store the sessions and associated data.
RedisSessionStore(RedisSessionStore) - Constructor for class io.vertx.reactivex.ext.web.sstore.redis.RedisSessionStore
 
RedisSessionStore(Object) - Constructor for class io.vertx.reactivex.ext.web.sstore.redis.RedisSessionStore
 
Ref - Class in io.vertx.reactivex.json.schema
JsonObject $ref resolver.
Ref(Ref) - Constructor for class io.vertx.reactivex.json.schema.Ref
 
Ref(Object) - Constructor for class io.vertx.reactivex.json.schema.Ref
 
REFERER - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Referer header name
refresh() - Method in class io.vertx.reactivex.ext.web.UserContext
Forces the current user to re-authenticate.
refresh(User) - Method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
Refresh the current User (access token).
refresh(String) - Method in class io.vertx.reactivex.ext.web.UserContext
Forces the current user to re-authenticate.
regenerateId() - Method in class io.vertx.reactivex.ext.web.Session
 
register(String) - Method in class io.vertx.reactivex.ext.unit.collect.EventBusCollector
Register the collector as a consumer of the event bus with the specified address.
register(String, long, Handler<Promise<Status>>) - Method in class io.vertx.reactivex.ext.healthchecks.HealthChecks
Registers a health check procedure.
register(String, long, Handler<Promise<Status>>) - Method in class io.vertx.reactivex.ext.web.healthchecks.HealthCheckHandler
Registers a health check procedure.
register(String, Handler<Promise<Status>>) - Method in class io.vertx.reactivex.ext.healthchecks.HealthChecks
Registers a health check procedure.
register(String, Handler<Promise<Status>>) - Method in class io.vertx.reactivex.ext.web.healthchecks.HealthCheckHandler
Registers a health check procedure.
registerCatalogService(Node, ServiceOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Register node with external service
registerCheck(CheckOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Add a new check to the local agent.
registerCodec(MessageCodec) - Method in class io.vertx.reactivex.core.eventbus.EventBus
Register a message codec.
registerService(ServiceOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Adds a new service, with an optional health check, to the local agent.
registerServiceExporter(ServiceExporter, JsonObject) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
Registers a discovery bridge.
registerServiceImporter(ServiceImporter, JsonObject) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
Registers a discovery service importer.
reject() - Method in class io.vertx.reactivex.core.http.ServerWebSocketHandshake
Reject the WebSocket.
reject(int) - Method in class io.vertx.reactivex.core.http.ServerWebSocketHandshake
Like ServerWebSocketHandshake.reject() but with a status.
reject(MqttConnectReturnCode) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Sends the CONNACK message to the remote MQTT client rejecting the connection request with specified return code.
reject(MqttConnectReturnCode, MqttProperties) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Sends the CONNACK message to the remote MQTT client rejecting the connection request with specified return code.
rejected() - Method in class io.vertx.reactivex.amqp.AmqpMessage
When receiving a message, and when auto-acknowledgement is disabled, this method is used to acknowledge the incoming message as rejected.
release() - Method in class io.vertx.reactivex.core.file.AsyncFileLock
Releases this lock;
release() - Method in class io.vertx.reactivex.core.shareddata.Lock
Release the lock.
release() - Method in class io.vertx.reactivex.servicediscovery.ServiceReference
Releases the reference.
release() - Method in class io.vertx.reactivex.sqlclient.Row
Signal the row can be recycled, this is only effective when dealing with a row in a collector query and the row has already been processed and transformed.
release(ServiceReference) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
Releases the service reference.
releaseBlocking() - Method in class io.vertx.reactivex.core.file.AsyncFileLock
Like AsyncFileLock.release() but blocking.
released() - Method in class io.vertx.reactivex.amqp.AmqpMessage
When receiving a message, and when auto-acknowledgement is disabled, this method is used to acknowledge the incoming message as released.
releaseServiceObject(ServiceDiscovery, Object) - Static method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
Release the service object retrieved using get methods from the service type interface.
remaining() - Method in class io.vertx.reactivex.cassandra.ResultSet
 
remainingCredits() - Method in class io.vertx.reactivex.amqp.AmqpSender
 
remoteAddress() - Method in class io.vertx.reactivex.core.http.ClientWebSocket
 
remoteAddress() - Method in class io.vertx.reactivex.core.http.HttpConnection
 
remoteAddress() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
 
remoteAddress() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
 
remoteAddress() - Method in class io.vertx.reactivex.core.http.ServerWebSocketHandshake
 
remoteAddress() - Method in class io.vertx.reactivex.core.http.WebSocket
 
remoteAddress() - Method in interface io.vertx.reactivex.core.http.WebSocketBase
 
remoteAddress() - Method in class io.vertx.reactivex.core.net.NetSocket
 
remoteAddress() - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
Return the remote address for this socket
remoteAddress() - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
 
remoteAddress(boolean) - Method in class io.vertx.reactivex.core.http.HttpConnection
Like HttpConnection.remoteAddress() but returns the proxy remote address when real is true
remoteAddress(boolean) - Method in class io.vertx.reactivex.core.net.NetSocket
Like NetSocket.remoteAddress() but returns the proxy remote address when real is true
remoteSettings() - Method in class io.vertx.reactivex.core.http.HttpConnection
 
remoteSettingsHandler(Handler<Http2Settings>) - Method in class io.vertx.reactivex.core.http.HttpConnection
Set an handler that is called when remote endpoint Http2Settings are updated.
remove() - Method in class io.vertx.reactivex.ext.web.Route
Remove this route from the router
remove(Object) - Method in class io.vertx.reactivex.core.shareddata.LocalMap
Remove an entry from the map
remove(String) - Method in class io.vertx.reactivex.ext.unit.TestContext
Remove some data from the context.
remove(String) - Method in class io.vertx.reactivex.ext.web.RoutingContext
Remove some data from the context.
remove(String) - Method in class io.vertx.reactivex.ext.web.Session
Remove some data from the session
remove(K) - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
Remove a value from the map, asynchronously.
removeBodyEndHandler(int) - Method in class io.vertx.reactivex.ext.web.RoutingContext
Remove a body end handler
removeCookie(String) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Expire a cookie, notifying a User Agent to remove it from its cookie jar.
removeCookie(String, boolean) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Remove a cookie from the cookie set.
removeCookie(String, String, String) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Expires a cookie from the cookie set.
removeCookie(String, String, String, boolean) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Remove a cookie from the cookie set.
removeCookies(String) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Expire all cookies, notifying a User Agent to remove it from its cookie jar.
removeCookies(String, boolean) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Remove all cookies from the cookie set.
removeDocument(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Remove a single matching document from a collection and return the handler with MongoClientDeleteResult result
removeDocuments(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Remove matching documents from a collection and return the handler with MongoClientDeleteResult result
removeDocumentsWithOptions(String, JsonObject, WriteOption) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Remove matching documents from a collection with the specified write option and return the handler with MongoClientDeleteResult result
removeDocumentWithOptions(String, JsonObject, WriteOption) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Remove a single matching document from a collection with the specified write option and return the handler with MongoClientDeleteResult result
removeEndHandler(int) - Method in class io.vertx.reactivex.ext.web.RoutingContext
Remove an end handler
removeHeader(CharSequence) - Method in class io.vertx.reactivex.ext.web.client.WebClientSession
Removes a previously added header.
removeHeader(String) - Method in class io.vertx.reactivex.ext.web.client.WebClientSession
Removes a previously added header.
removeHeadersEndHandler(int) - Method in class io.vertx.reactivex.ext.web.RoutingContext
Remove a headers end handler
removeIfPresent(K, V) - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
Remove a value from the map, only if entry already exists with same value.
removeIfPresent(K, V) - Method in class io.vertx.reactivex.core.shareddata.LocalMap
Remove the entry only if there is an entry with the specified key and value.
removeInboundInterceptor(Handler<DeliveryContext<T>>) - Method in class io.vertx.reactivex.core.eventbus.EventBus
removeOutboundInterceptor(Handler<DeliveryContext<T>>) - Method in class io.vertx.reactivex.core.eventbus.EventBus
removeTenant(String) - Method in class io.vertx.reactivex.ext.web.handler.MultiTenantHandler
Remove a handler for a given tenant from this handler.
rename(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Rename a key.
renameCollection(String, String) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Rename a collection
renameCollectionWithOptions(String, String, RenameCollectionOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Rename a collection
renamenx(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Rename a key, only if the new key does not exist.
render(JsonObject, String) - Method in class io.vertx.reactivex.ext.web.common.template.TemplateEngine
Render the template.
render(Map<String, Object>, String) - Method in class io.vertx.reactivex.ext.web.common.template.TemplateEngine
Render the template.
renewSession(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Renews the given session.
replace(K, V) - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
Replace the entry only if it is currently mapped to some value
replace(K, V) - Method in class io.vertx.reactivex.core.shareddata.LocalMap
Replace the entry only if there is an existing entry with the key
replace(K, V, long) - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
Replace the entry only if it is currently mapped to some value
replaceDocuments(String, JsonObject, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Replace matching documents in the specified collection and return the handler with MongoClientUpdateResult result
replaceDocumentsWithOptions(String, JsonObject, JsonObject, UpdateOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Replace matching documents in the specified collection, specifying options and return the handler with MongoClientUpdateResult result
replaceIfPresent(K, V, V) - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
Replace the entry only if it is currently mapped to a specific value
replaceIfPresent(K, V, V) - Method in class io.vertx.reactivex.core.shareddata.LocalMap
Replace the entry only if there is an existing entry with the specified key and value.
replaceIfPresent(K, V, V, long) - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
Replace the entry only if it is currently mapped to a specific value
replconf(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
An internal command for configuring the replication stream.
replicaof(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Make the server a replica of another instance, or promote it as master.
reply(Object) - Method in class io.vertx.reactivex.core.eventbus.Message
Reply to this message.
reply(Object, DeliveryOptions) - Method in class io.vertx.reactivex.core.eventbus.Message
Link Message.reply(java.lang.Object) but allows you to specify delivery options for the reply.
replyAddress() - Method in class io.vertx.reactivex.core.eventbus.Message
The reply address.
replyAndRequest(Object) - Method in class io.vertx.reactivex.core.eventbus.Message
Reply to this message, specifying a replyHandler for the reply - i.e.
replyAndRequest(Object, DeliveryOptions) - Method in class io.vertx.reactivex.core.eventbus.Message
Like Message.replyAndRequest(java.lang.Object) but specifying options that can be used to configure the delivery.
replyTo() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
replyTo(String) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
replyToGroupId() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
replyToGroupId(String) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
reportFailure(Throwable) - Method in class io.vertx.reactivex.core.net.endpoint.ServerInteraction
Report a failure.
reportRequestBegin() - Method in class io.vertx.reactivex.core.net.endpoint.ServerInteraction
The request has begun.
reportRequestEnd() - Method in class io.vertx.reactivex.core.net.endpoint.ServerInteraction
The request has ended.
reportResponseBegin() - Method in class io.vertx.reactivex.core.net.endpoint.ServerInteraction
The response has begun.
reportResponseEnd() - Method in class io.vertx.reactivex.core.net.endpoint.ServerInteraction
The request has ended.
request() - Method in interface io.vertx.reactivex.core.http.HttpClient
Create an HTTP request to send to the server with the default host and port of the client.
request() - Method in class io.vertx.reactivex.core.http.HttpClientAgent
Create an HTTP request to send to the server with the default host and port of the client.
request() - Method in class io.vertx.reactivex.core.http.HttpClientConnection
Create an HTTP request to send to the server with the default host and port of the client.
request() - Method in class io.vertx.reactivex.core.http.HttpClientResponse
 
request() - Method in class io.vertx.reactivex.ext.web.RoutingContext
 
request() - Method in class io.vertx.reactivex.grpc.client.GrpcClient
Like GrpcClient.request(io.vertx.core.net.Address) with the default remote server.
request(HttpMethod, int, String, UriTemplate) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP request to send to the server at the specified host and port.
request(HttpMethod, int, String, String) - Method in interface io.vertx.reactivex.core.http.HttpClient
Create an HTTP request to send to the server at the host and port.
request(HttpMethod, int, String, String) - Method in class io.vertx.reactivex.core.http.HttpClientAgent
Create an HTTP request to send to the server at the host and port.
request(HttpMethod, int, String, String) - Method in class io.vertx.reactivex.core.http.HttpClientConnection
Create an HTTP request to send to the server at the host and port.
request(HttpMethod, int, String, String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP request to send to the server at the specified host and port.
request(HttpMethod, RequestOptions) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP request to send to the server at the specified host and port.
request(HttpMethod, SocketAddress, int, String, UriTemplate) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Like WebClient.request(io.vertx.core.http.HttpMethod, int, java.lang.String, java.lang.String) using the serverAddress parameter to connect to the server instead of the port and host parameters.
request(HttpMethod, SocketAddress, int, String, String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Like WebClient.request(io.vertx.core.http.HttpMethod, int, java.lang.String, java.lang.String) using the serverAddress parameter to connect to the server instead of the port and host parameters.
request(HttpMethod, SocketAddress, RequestOptions) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Like WebClient.request(io.vertx.core.http.HttpMethod, int, java.lang.String, java.lang.String) using the serverAddress parameter to connect to the server instead of the options parameter.
request(HttpMethod, SocketAddress, UriTemplate) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Like WebClient.request(io.vertx.core.http.HttpMethod, int, java.lang.String, java.lang.String) using the serverAddress parameter to connect to the server instead of the default port and default host.
request(HttpMethod, SocketAddress, String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Like WebClient.request(io.vertx.core.http.HttpMethod, int, java.lang.String, java.lang.String) using the serverAddress parameter to connect to the server instead of the default port and default host.
request(HttpMethod, SocketAddress, String, UriTemplate) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Like WebClient.request(io.vertx.core.http.HttpMethod, int, java.lang.String, java.lang.String) using the serverAddress parameter to connect to the server instead of the default port and host parameter.
request(HttpMethod, SocketAddress, String, String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Like WebClient.request(io.vertx.core.http.HttpMethod, int, java.lang.String, java.lang.String) using the serverAddress parameter to connect to the server instead of the default port and host parameter.
request(HttpMethod, UriTemplate) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP request to send to the server at the default host and port.
request(HttpMethod, String) - Method in interface io.vertx.reactivex.core.http.HttpClient
Create an HTTP request to send to the server at the default host and port.
request(HttpMethod, String) - Method in class io.vertx.reactivex.core.http.HttpClientAgent
Create an HTTP request to send to the server at the default host and port.
request(HttpMethod, String) - Method in class io.vertx.reactivex.core.http.HttpClientConnection
Create an HTTP request to send to the server at the default host and port.
request(HttpMethod, String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP request to send to the server at the default host and port.
request(HttpMethod, String, UriTemplate) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP request to send to the server at the specified host and default port.
request(HttpMethod, String, String) - Method in interface io.vertx.reactivex.core.http.HttpClient
Create an HTTP request to send to the server at the host and default port.
request(HttpMethod, String, String) - Method in class io.vertx.reactivex.core.http.HttpClientAgent
Create an HTTP request to send to the server at the host and default port.
request(HttpMethod, String, String) - Method in class io.vertx.reactivex.core.http.HttpClientConnection
Create an HTTP request to send to the server at the host and default port.
request(HttpMethod, String, String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP request to send to the server at the specified host and default port.
request(RequestOptions) - Method in interface io.vertx.reactivex.core.http.HttpClient
Create an HTTP request to send to the server.
request(RequestOptions) - Method in class io.vertx.reactivex.core.http.HttpClientAgent
Create an HTTP request to send to the server.
request(RequestOptions) - Method in class io.vertx.reactivex.core.http.HttpClientConnection
Create an HTTP request to send to the server.
request(Address) - Method in class io.vertx.reactivex.grpc.client.GrpcClient
Connect to the remote server and create a request for any hosted gRPC service.
request(Address, ServiceMethod<Resp, Req>) - Method in class io.vertx.reactivex.grpc.client.GrpcClient
Connect to the remote server and create a request for any hosted gRPC service.
request(ServiceMethod<Resp, Req>) - Method in class io.vertx.reactivex.grpc.client.GrpcClient
Like GrpcClient.request(io.vertx.core.net.Address) with the default remote server.
request(String, Object) - Method in class io.vertx.reactivex.core.eventbus.EventBus
Sends a message and specify a replyHandler that will be called if the recipient subsequently replies to the message.
request(String, Object, DeliveryOptions) - Method in class io.vertx.reactivex.core.eventbus.EventBus
Like EventBus.request(java.lang.String, java.lang.Object) but specifying options that can be used to configure the delivery.
REQUEST_CONTEXT_KEY - Static variable in class io.vertx.reactivex.ext.web.validation.ValidationHandler
 
requestAbs(HttpMethod, SocketAddress, UriTemplate) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Like WebClient.requestAbs(io.vertx.core.http.HttpMethod, java.lang.String) using the serverAddress parameter to connect to the server instead of the absoluteURI parameter.
requestAbs(HttpMethod, SocketAddress, String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Like WebClient.requestAbs(io.vertx.core.http.HttpMethod, java.lang.String) using the serverAddress parameter to connect to the server instead of the absoluteURI parameter.
requestAbs(HttpMethod, UriTemplate) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP request to send to the server using an absolute URI
requestAbs(HttpMethod, String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Create an HTTP request to send to the server using an absolute URI
RequestBody - Class in io.vertx.reactivex.ext.web
 
RequestBody - Class in io.vertx.reactivex.openapi.contract
This interface represents the most important attributes of an OpenAPI Operation.
RequestBody(RequestBody) - Constructor for class io.vertx.reactivex.ext.web.RequestBody
 
RequestBody(RequestBody) - Constructor for class io.vertx.reactivex.openapi.contract.RequestBody
 
RequestBody(Object) - Constructor for class io.vertx.reactivex.ext.web.RequestBody
 
RequestBody(Object) - Constructor for class io.vertx.reactivex.openapi.contract.RequestBody
 
RequestExtractor - Class in io.vertx.reactivex.ext.web.openapi.router
 
RequestExtractor(RequestExtractor) - Constructor for class io.vertx.reactivex.ext.web.openapi.router.RequestExtractor
 
RequestExtractor(Object) - Constructor for class io.vertx.reactivex.ext.web.openapi.router.RequestExtractor
 
requestHandler(Handler<HttpServerRequest>) - Method in class io.vertx.reactivex.core.http.HttpServer
Set the request handler for the server to requestHandler.
RequestParameter - Class in io.vertx.reactivex.ext.web.validation
Request parameter holder
RequestParameter - Class in io.vertx.reactivex.openapi.validation
 
RequestParameter(RequestParameter) - Constructor for class io.vertx.reactivex.ext.web.validation.RequestParameter
 
RequestParameter(RequestParameter) - Constructor for class io.vertx.reactivex.openapi.validation.RequestParameter
 
RequestParameter(Object) - Constructor for class io.vertx.reactivex.ext.web.validation.RequestParameter
 
RequestParameter(Object) - Constructor for class io.vertx.reactivex.openapi.validation.RequestParameter
 
RequestParameters - Class in io.vertx.reactivex.ext.web.validation
Container for request parameters
RequestParameters(RequestParameters) - Constructor for class io.vertx.reactivex.ext.web.validation.RequestParameters
 
RequestParameters(Object) - Constructor for class io.vertx.reactivex.ext.web.validation.RequestParameters
 
RequestPredicate - Class in io.vertx.reactivex.ext.web.validation
Request predicate
RequestPredicate(RequestPredicate) - Constructor for class io.vertx.reactivex.ext.web.validation.RequestPredicate
 
RequestPredicate(Object) - Constructor for class io.vertx.reactivex.ext.web.validation.RequestPredicate
 
RequestPredicateResult - Class in io.vertx.reactivex.ext.web.validation
Result of a RequestPredicate
RequestPredicateResult(RequestPredicateResult) - Constructor for class io.vertx.reactivex.ext.web.validation.RequestPredicateResult
 
RequestPredicateResult(Object) - Constructor for class io.vertx.reactivex.ext.web.validation.RequestPredicateResult
 
RequestValidator - Class in io.vertx.reactivex.openapi.validation
The RequestValidator requires the parameters in a specific format to be able to parse and validate them.
RequestValidator(RequestValidator) - Constructor for class io.vertx.reactivex.openapi.validation.RequestValidator
 
RequestValidator(Object) - Constructor for class io.vertx.reactivex.openapi.validation.RequestValidator
 
reroute(HttpMethod, String) - Method in class io.vertx.reactivex.ext.web.RoutingContext
Restarts the current router with a new method and path.
reroute(String) - Method in class io.vertx.reactivex.ext.web.RoutingContext
Restarts the current router with a new path and reusing the original method.
reset() - Method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
Resets the circuit breaker state.
reset() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Reset this stream with the error code 0.
reset() - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Reset this HTTP/2 stream with the error code 0.
reset() - Method in class io.vertx.reactivex.redis.client.RedisAPI
Reset the connection.
reset(long) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Reset this request:
reset(long) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Reset this response:
reset(long, Throwable) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Reset this request:
resetConnection() - Method in class io.vertx.reactivex.mysqlclient.MySQLConnection
Send a RESET_CONNECTION command to reset the session state.
resolve(JsonObject) - Static method in class io.vertx.reactivex.json.schema.Ref
Resolve all $ref in the given .
resolve(JsonObject) - Method in class io.vertx.reactivex.json.schema.SchemaRepository
Resolve all $ref in the given .
resolve(Promise<Void>) - Method in class io.vertx.reactivex.ext.unit.Async
Completes the future upon completion, otherwise fails it.
resolve(Promise<Void>) - Method in class io.vertx.reactivex.ext.unit.TestCompletion
Completes the future upon completion, otherwise fails it.
resolve(Promise<T>) - Method in class io.vertx.reactivex.ext.unit.Completion
Completes the future upon completion, otherwise fails it.
resolveA(String) - Method in class io.vertx.reactivex.core.dns.DnsClient
Try to resolve all A (ipv4) records for the given name.
resolveAAAA(String) - Method in class io.vertx.reactivex.core.dns.DnsClient
Try to resolve all AAAA (ipv6) records for the given name.
resolveCNAME(String) - Method in class io.vertx.reactivex.core.dns.DnsClient
Try to resolve the CNAME record for the given name.
resolveEndpoint(Address) - Method in class io.vertx.reactivex.core.net.endpoint.EndpointResolver
Resolver an endpoint for the specified address
resolveMX(String) - Method in class io.vertx.reactivex.core.dns.DnsClient
Try to resolve the MX records for the given name.
resolveNS(String) - Method in class io.vertx.reactivex.core.dns.DnsClient
Try to resolve the NS records for the given name.
resolvePTR(String) - Method in class io.vertx.reactivex.core.dns.DnsClient
Try to resolve the PTR record for the given name.
resolveSRV(String) - Method in class io.vertx.reactivex.core.dns.DnsClient
Try to resolve the SRV records for the given name.
resolveTXT(String) - Method in class io.vertx.reactivex.core.dns.DnsClient
Try to resolve the TXT records for the given name.
resource(HttpVersion, HttpMethod, String) - Method in class io.vertx.reactivex.ext.auth.audit.SecurityAudit
 
resource(String) - Method in class io.vertx.reactivex.ext.auth.audit.SecurityAudit
 
respond(Function<RoutingContext, Maybe<T>>) - Method in class io.vertx.reactivex.ext.web.Route
Append a function request handler to the route handlers list.
respond(Function<RoutingContext, Future<T>>) - Method in class io.vertx.reactivex.ext.web.Route
Append a function request handler to the route handlers list.
response() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
 
response() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
 
response() - Method in class io.vertx.reactivex.ext.web.RoutingContext
 
response() - Method in class io.vertx.reactivex.grpc.client.GrpcClientRequest
 
response() - Method in class io.vertx.reactivex.grpc.server.GrpcServerRequest
 
Response - Class in io.vertx.reactivex.openapi.contract
 
Response(Response) - Constructor for class io.vertx.reactivex.openapi.contract.Response
 
Response(Object) - Constructor for class io.vertx.reactivex.openapi.contract.Response
 
ResponseContentTypeHandler - Class in io.vertx.reactivex.ext.web.handler
A handler which sets the response content type automatically according to the best Accept header match.
ResponseContentTypeHandler(ResponseContentTypeHandler) - Constructor for class io.vertx.reactivex.ext.web.handler.ResponseContentTypeHandler
 
ResponseContentTypeHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.ResponseContentTypeHandler
 
ResponseParameter - Class in io.vertx.reactivex.openapi.validation
 
ResponseParameter(ResponseParameter) - Constructor for class io.vertx.reactivex.openapi.validation.ResponseParameter
 
ResponseParameter(Object) - Constructor for class io.vertx.reactivex.openapi.validation.ResponseParameter
 
ResponseTimeHandler - Class in io.vertx.reactivex.ext.web.handler
Handler which adds a header `x-response-time` in the response of matching requests containing the time taken in ms to process the request.
ResponseTimeHandler(ResponseTimeHandler) - Constructor for class io.vertx.reactivex.ext.web.handler.ResponseTimeHandler
 
ResponseTimeHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.ResponseTimeHandler
 
restart() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQPublisher
Undo the effects of calling so that publish may be called again.
restartConnect(int) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
restart the rabbitMQ connect.
restore() - Method in class io.vertx.reactivex.ext.web.UserContext
Undo a previous call to a impersonation.
restore(String) - Method in class io.vertx.reactivex.ext.web.UserContext
Undo a previous call to an impersonation.
restore(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Create a key using the provided serialized value, previously obtained using DUMP.
restoreAsking(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
An internal command for migrating keys in a cluster.
resultMapper(Function<CheckResult, Single<CheckResult>>) - Method in class io.vertx.reactivex.ext.web.healthchecks.HealthCheckHandler
Sets a function which will be invoked before the gets written to clients.
resultMapper(Function<CheckResult, Future<CheckResult>>) - Method in class io.vertx.reactivex.ext.web.healthchecks.HealthCheckHandler
Sets a function which will be invoked before the gets written to clients.
ResultSet - Class in io.vertx.reactivex.cassandra
It is like AsyncResultSet, but adapted for Vert.x.
ResultSet(ResultSet) - Constructor for class io.vertx.reactivex.cassandra.ResultSet
 
ResultSet(Object) - Constructor for class io.vertx.reactivex.cassandra.ResultSet
 
resume() - Method in class io.vertx.reactivex.amqp.AmqpReceiver
 
resume() - Method in class io.vertx.reactivex.cassandra.CassandraRowStream
 
resume() - Method in class io.vertx.reactivex.core.eventbus.MessageConsumer
 
resume() - Method in class io.vertx.reactivex.core.file.AsyncFile
 
resume() - Method in class io.vertx.reactivex.core.http.ClientWebSocket
 
resume() - Method in class io.vertx.reactivex.core.http.HttpClientResponse
 
resume() - Method in class io.vertx.reactivex.core.http.HttpServerFileUpload
 
resume() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
 
resume() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
 
resume() - Method in class io.vertx.reactivex.core.http.WebSocket
 
resume() - Method in interface io.vertx.reactivex.core.http.WebSocketBase
 
resume() - Method in class io.vertx.reactivex.core.net.NetSocket
 
resume() - Method in class io.vertx.reactivex.core.parsetools.JsonParser
 
resume() - Method in class io.vertx.reactivex.core.parsetools.RecordParser
 
resume() - Method in interface io.vertx.reactivex.core.streams.ReadStream
Resume reading, and sets the buffer in flowing mode.
resume() - Method in class io.vertx.reactivex.ext.unit.report.TestSuiteReport
 
resume() - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
 
resume() - Method in class io.vertx.reactivex.grpc.client.GrpcClientResponse
 
resume() - Method in class io.vertx.reactivex.grpc.common.GrpcReadStream
 
resume() - Method in class io.vertx.reactivex.grpc.server.GrpcServerRequest
 
resume() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
 
resume() - Method in class io.vertx.reactivex.pgclient.pubsub.PgChannel
Resume the channel.
resume() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQConsumer
Resume reading from a queue.
resume() - Method in class io.vertx.reactivex.redis.client.RedisConnection
 
resume() - Method in class io.vertx.reactivex.sqlclient.RowStream
 
resume(TopicPartition) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Resume specified partition which have been paused with pause.
resume(Set<TopicPartition>) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Resume specified partitions which have been paused with pause.
RETRY_AFTER - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Retry-After header name
retryPolicy(RetryPolicy) - Method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
Set a RetryPolicy which computes a delay before a retry attempt.
RetryPolicy - Class in io.vertx.reactivex.circuitbreaker
A policy for retry execution.
RetryPolicy(RetryPolicy) - Constructor for class io.vertx.reactivex.circuitbreaker.RetryPolicy
 
RetryPolicy(Object) - Constructor for class io.vertx.reactivex.circuitbreaker.RetryPolicy
 
retryTimeout() - Method in class io.vertx.reactivex.ext.web.sstore.SessionStore
The retry timeout value in milli seconds used by the session handler when it retrieves a value from the store.
reverseLookup(String) - Method in class io.vertx.reactivex.core.dns.DnsClient
Try to do a reverse lookup of an IP address.
revoke(User) - Method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
Revoke an obtained access token.
revoke(User, String) - Method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
Revoke an obtained access or refresh token.
RockerTemplateEngine - Class in io.vertx.reactivex.ext.web.templ.rocker
A template engine that uses the Rocker library.
RockerTemplateEngine(RockerTemplateEngine) - Constructor for class io.vertx.reactivex.ext.web.templ.rocker.RockerTemplateEngine
 
RockerTemplateEngine(Object) - Constructor for class io.vertx.reactivex.ext.web.templ.rocker.RockerTemplateEngine
 
role() - Method in class io.vertx.reactivex.redis.client.RedisAPI
Return the role of the instance in the context of replication.
RoleBasedAuthorization - Class in io.vertx.reactivex.ext.auth.authorization
Represents a role.
RoleBasedAuthorization(RoleBasedAuthorization) - Constructor for class io.vertx.reactivex.ext.auth.authorization.RoleBasedAuthorization
 
RoleBasedAuthorization(Object) - Constructor for class io.vertx.reactivex.ext.auth.authorization.RoleBasedAuthorization
 
rollback() - Method in class io.vertx.reactivex.sqlclient.Transaction
Rollback the transaction and release the associated resources.
rootHandler(Handler<RoutingContext>) - Method in class io.vertx.reactivex.ext.web.openapi.router.RouterBuilder
Add global handler to be applied prior to being generated.
route() - Method in class io.vertx.reactivex.ext.web.Router
Add a route with no matching criteria, i.e. it matches all requests or failures.
route(HttpMethod, String) - Method in class io.vertx.reactivex.ext.web.Router
Add a route that matches the specified HTTP method and path
route(String) - Method in class io.vertx.reactivex.ext.web.Router
Add a route that matches the specified path
Route - Class in io.vertx.reactivex.ext.web
A route is a holder for a set of criteria which determine whether an HTTP request or failure should be routed to a handler.
Route(Route) - Constructor for class io.vertx.reactivex.ext.web.Route
 
Route(Object) - Constructor for class io.vertx.reactivex.ext.web.Route
 
routed(String) - Method in class io.vertx.reactivex.core.http.HttpServerRequest
Marks this request as being routed to the given route.
router() - Method in class io.vertx.reactivex.ext.web.handler.graphql.GraphiQLHandler
Creates a router configured to serve GraphiQL resources.
router(Vertx) - Static method in class io.vertx.reactivex.ext.web.Router
Create a router
Router - Class in io.vertx.reactivex.ext.web
A router receives request from an HttpServer and routes it to the first matching Route that it contains.
Router(Router) - Constructor for class io.vertx.reactivex.ext.web.Router
 
Router(Object) - Constructor for class io.vertx.reactivex.ext.web.Router
 
RouterBuilder - Class in io.vertx.reactivex.ext.web.openapi.router
Interface to build a Vert.x Web from an OpenAPI 3 contract.
RouterBuilder(RouterBuilder) - Constructor for class io.vertx.reactivex.ext.web.openapi.router.RouterBuilder
 
RouterBuilder(Object) - Constructor for class io.vertx.reactivex.ext.web.openapi.router.RouterBuilder
 
routeWithRegex(HttpMethod, String) - Method in class io.vertx.reactivex.ext.web.Router
Add a route that matches the specified HTTP method and path regex
routeWithRegex(String) - Method in class io.vertx.reactivex.ext.web.Router
Add a route that matches the specified path regex
routingContext() - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
 
RoutingContext - Class in io.vertx.reactivex.ext.web
Represents the context for the handling of a request in Vert.x-Web.
RoutingContext(RoutingContext) - Constructor for class io.vertx.reactivex.ext.web.RoutingContext
 
RoutingContext(Object) - Constructor for class io.vertx.reactivex.ext.web.RoutingContext
 
routingKey() - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Return the routing key, the routing key can be used by a Vert.x client side sticky load balancer to pin the request to a remote HTTP server.
routingKey(String) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Set the routing key, the routing key can be used by a Vert.x client side sticky load balancer to pin the request to a remote HTTP server.
Row - Class in io.vertx.reactivex.sqlclient
A single row of the execution result rowset.
Row(Row) - Constructor for class io.vertx.reactivex.sqlclient.Row
 
Row(Object) - Constructor for class io.vertx.reactivex.sqlclient.Row
 
rowCount() - Method in class io.vertx.reactivex.sqlclient.SqlResult
Get the number of the affected rows in the operation to this SqlResult.
RowIterator<R> - Class in io.vertx.reactivex.sqlclient
An iterator for processing rows.
RowIterator(RowIterator) - Constructor for class io.vertx.reactivex.sqlclient.RowIterator
 
RowIterator(Object, TypeArg<R>) - Constructor for class io.vertx.reactivex.sqlclient.RowIterator
 
RowMapper<T> - Class in io.vertx.reactivex.sqlclient.templates
Map a to an arbitrary T object.
RowMapper(RowMapper) - Constructor for class io.vertx.reactivex.sqlclient.templates.RowMapper
 
RowMapper(Object, TypeArg<T>) - Constructor for class io.vertx.reactivex.sqlclient.templates.RowMapper
 
RowSet<R> - Class in io.vertx.reactivex.sqlclient
The execution result of the row set of a query provided as , commonly used as a RowSet.
RowSet(RowSet) - Constructor for class io.vertx.reactivex.sqlclient.RowSet
 
RowSet(Object, TypeArg<R>) - Constructor for class io.vertx.reactivex.sqlclient.RowSet
 
RowStream<T> - Class in io.vertx.reactivex.sqlclient
A row oriented stream.
RowStream(RowStream) - Constructor for class io.vertx.reactivex.sqlclient.RowStream
 
RowStream(Object, TypeArg<T>) - Constructor for class io.vertx.reactivex.sqlclient.RowStream
 
rpop(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove and get the last elements in a list.
rpoplpush(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Deprecated.
rpush(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Append one or multiple elements to a list.
rpushx(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Append an element to a list, only if the list exists.
run() - Method in class io.vertx.reactivex.ext.unit.TestSuite
Run the testsuite with the default options.
run(TestOptions) - Method in class io.vertx.reactivex.ext.unit.TestSuite
Run the testsuite with the specified options.
run(Vertx) - Method in class io.vertx.reactivex.ext.unit.TestSuite
Run the testsuite with the default options and the specified vertx instance.
run(Vertx, TestOptions) - Method in class io.vertx.reactivex.ext.unit.TestSuite
Run the testsuite with the specified options and the specified vertx instance.
runCommand(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Run an arbitrary MongoDB command.
rxAbort(String) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Aborts a transaction.
rxAbort(String, Map<String, String>) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Aborts a transaction.
rxAbortTransaction() - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
Aborts the ongoing transaction.
rxAccept() - Method in class io.vertx.reactivex.core.http.ServerWebSocketHandshake
Accept the WebSocket and terminate the WebSocket handshake.
rxAck(String) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Sends an acknowledgement for a specific message.
rxAck(String, String) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Sends an acknowledgement for the given frame.
rxAcl(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
A container for Access List Control commands.
rxAddAndGet(long) - Method in class io.vertx.reactivex.core.shareddata.Counter
Add the value to the counter atomically and return the new count
rxAddConfirmListener(int) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Add a Confirm Listener to the channel.
rxAgentInfo() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the configuration and member information of the local agent
rxAll() - Method in class io.vertx.reactivex.cassandra.ResultSet
The method should not be used concurrently with others like ResultSet.fetchNextPage() or ResultSet.one().
rxAppend(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Append a value to a key.
rxAsking() - Method in class io.vertx.reactivex.redis.client.RedisAPI
Sent by cluster clients after an -ASK redirect.
rxAssign(TopicPartition) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Manually assign a partition to this consumer.
rxAssign(Set<TopicPartition>) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Manually assign a list of partition to this consumer.
rxAssignment() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Get the set of partitions currently assigned to this consumer.
rxAuth(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Authenticate to the server.
rxAuthenticate(Credentials) - Method in class io.vertx.reactivex.ext.auth.authentication.AuthenticationProvider
Authenticate a user.
rxAuthenticationExchange(MqttAuthenticationExchangeMessage) - Method in class io.vertx.reactivex.mqtt.MqttClient
It is used for Enhanced Authentication and is able to carry an authentication method and authentication data.
rxBasicAck(long, boolean) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Acknowledge one or several received messages.
rxBasicConsumer(String) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
 
rxBasicConsumer(String, QueueOptions) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Create a consumer with the given options.
rxBasicGet(String, boolean) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Retrieve a message from a queue using AMQP.Basic.Get
rxBasicNack(long, boolean, boolean) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Reject one or several received messages.
rxBasicPublish(String, String, BasicProperties, Buffer) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Publish a message.
rxBasicPublish(String, String, Buffer) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Publish a message.
rxBasicPublishWithDeliveryTag(String, String, BasicProperties, Buffer, Handler<Long>) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Publish a message.
rxBasicQos(int) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Request a specific prefetchCount "quality of service" settings for this channel.
rxBasicQos(int, boolean) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Request a specific prefetchCount "quality of service" settings for this channel.
rxBasicQos(int, int, boolean) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Request specific "quality of service" settings.
rxBatch(List<Request>) - Method in class io.vertx.reactivex.redis.client.Redis
Sends a list of commands in a single IO operation, this prevents any inter twinning to happen from other client users.
rxBatch(List<Request>) - Method in class io.vertx.reactivex.redis.client.RedisConnection
Sends a list of commands in a single IO operation, this prevents any inter twinning to happen from other client users.
rxBegin() - Method in class io.vertx.reactivex.sqlclient.SqlConnection
Begin a transaction and returns a Transaction for controlling and tracking this transaction.
rxBeginningOffsets(TopicPartition) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Get the first offset for the given partitions.
rxBeginTransaction() - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
Starts a new kafka transaction.
rxBeginTX(String) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Begins a transaction.
rxBeginTX(String, Map<String, String>) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Begins a transaction.
rxBfAdd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command BF.ADD.
rxBfCard(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command BF.CARD.
rxBfDebug(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command BF.DEBUG.
rxBfExists(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command BF.EXISTS.
rxBfInfo(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command BF.INFO.
rxBfInsert(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command BF.INSERT.
rxBfLoadchunk(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command BF.LOADCHUNK.
rxBfMadd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command BF.MADD.
rxBfMexists(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command BF.MEXISTS.
rxBfReserve(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command BF.RESERVE.
rxBfScandump(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command BF.SCANDUMP.
rxBgrewriteaof() - Method in class io.vertx.reactivex.redis.client.RedisAPI
Asynchronously rewrite the append-only file.
rxBgsave(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Asynchronously save the dataset to disk.
rxBitcount(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Count set bits in a string.
rxBitfield(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Perform arbitrary bitfield integer operations on strings.
rxBitfieldRo(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Perform arbitrary bitfield integer operations on strings.
rxBitop(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Perform bitwise operations between strings.
rxBitpos(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Find first bit set or clear in a string.
rxBlmove(String, String, String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Pop an element from a list, push it to another list and return it; or block until one is available.
rxBlmpop(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Pop elements from a list, or block until one is available.
rxBlockMulticastGroup(String, String) - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
Block the given address for the given multicast address and notifies the once the operation completes.
rxBlockMulticastGroup(String, String, String) - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
Block the given address for the given multicast address on the given network interface and notifies the once the operation completes.
rxBlpop(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove and get the first element in a list, or block until one is available.
rxBody() - Method in class io.vertx.reactivex.core.http.HttpClientResponse
Convenience method for receiving the entire request body in one piece.
rxBody() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
Convenience method for receiving the entire request body in one piece.
rxBrpop(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove and get the last element in a list, or block until one is available.
rxBrpoplpush(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Deprecated.
rxBulkWrite(String, List<BulkOperation>) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Execute a bulk operation.
rxBulkWriteWithOptions(String, List<BulkOperation>, BulkWriteOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Execute a bulk operation with the specified write options.
rxBzmpop(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove and return members with scores in a sorted set or block until one is available.
rxBzpopmax(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove and return the member with the highest score from one or more sorted sets, or block until one is available.
rxBzpopmin(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove and return the member with the lowest score from one or more sorted sets, or block until one is available.
rxCancel() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQConsumer
Stop message consumption from a queue.
rxCancelRequest() - Method in class io.vertx.reactivex.pgclient.PgConnection
Send a request cancellation message to tell the server to cancel processing request in this connection.
rxCatalogDatacenters() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Return all the datacenters that are known by the Consul server
rxCatalogNodes() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the nodes registered in a datacenter
rxCatalogNodeServices(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the node's registered services
rxCatalogNodeServicesWithOptions(String, BlockingQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the node's registered services This is blocking query unlike ConsulClient.catalogNodeServices(java.lang.String)
rxCatalogNodesWithOptions(NodeQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the nodes registered in a datacenter
rxCatalogServiceNodes(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the nodes providing a service
rxCatalogServiceNodesWithOptions(String, ServiceQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the nodes providing a service
rxCatalogServices() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the services registered in a datacenter
rxCatalogServicesWithOptions(BlockingQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the services registered in a datacenter This is blocking query unlike ConsulClient.catalogServices()
rxCfAdd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CF.ADD.
rxCfAddnx(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CF.ADDNX.
rxCfCompact(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CF.COMPACT.
rxCfCount(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CF.COUNT.
rxCfDebug(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CF.DEBUG.
rxCfDel(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CF.DEL.
rxCfExists(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CF.EXISTS.
rxCfInfo(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CF.INFO.
rxCfInsert(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CF.INSERT.
rxCfInsertnx(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CF.INSERTNX.
rxCfLoadchunk(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CF.LOADCHUNK.
rxCfMexists(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CF.MEXISTS.
rxCfReserve(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CF.RESERVE.
rxCfScandump(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CF.SCANDUMP.
rxChangeUser(MySQLAuthOptions) - Method in class io.vertx.reactivex.mysqlclient.MySQLConnection
Send a CHANGE_USER command to change the user of the current connection, this operation will also reset connection state.
rxCheckStatus() - Method in class io.vertx.reactivex.ext.healthchecks.HealthChecks
Invokes the registered procedures.
rxCheckStatus(String) - Method in class io.vertx.reactivex.ext.healthchecks.HealthChecks
Invokes the registered procedure with the given name and sub-procedures.
rxChmod(String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
Change the permissions on the file represented by path to perms, asynchronously.
rxChmodRecursive(String, String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
Change the permissions on the file represented by path to perms, asynchronously.
rxChown(String, String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
Change the ownership on the file represented by path to user and {code group}, asynchronously.
rxClear() - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
Clear all entries in the map
rxClear() - Method in class io.vertx.reactivex.ext.web.sstore.SessionStore
Remove all sessions from the store.
rxClient(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
A container for client connection commands.
rxCloneAclToken(String, CloneAclTokenOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Clones an existing ACL token
rxClose() - Method in class io.vertx.reactivex.amqp.AmqpClient
Closes the client.
rxClose() - Method in class io.vertx.reactivex.amqp.AmqpConnection
Closes the AMQP connection, i.e. allows the Close frame to be emitted.
rxClose() - Method in class io.vertx.reactivex.amqp.AmqpReceiver
Closes the receiver.
rxClose() - Method in class io.vertx.reactivex.amqp.AmqpSender
Closes the sender.
rxClose() - Method in class io.vertx.reactivex.cassandra.CassandraClient
Closes this client.
rxClose() - Method in class io.vertx.reactivex.config.ConfigRetriever
Closes the retriever.
rxClose() - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
Closes the DatagramSocket implementation asynchronous and notifies the handler once done.
rxClose() - Method in class io.vertx.reactivex.core.dns.DnsClient
Close the client.
rxClose() - Method in class io.vertx.reactivex.core.eventbus.MessageProducer
Closes the producer, this method should be called when the message producer is not used anymore.
rxClose() - Method in class io.vertx.reactivex.core.file.AsyncFile
Close the file.
rxClose() - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Close the WebSocket sending the default close frame.
rxClose() - Method in interface io.vertx.reactivex.core.http.HttpClient
Close immediately (shutdown(0, TimeUnit.SECONDS).
rxClose() - Method in class io.vertx.reactivex.core.http.HttpClientAgent
Close immediately (shutdown(0, TimeUnit.SECONDS).
rxClose() - Method in class io.vertx.reactivex.core.http.HttpClientConnection
 
rxClose() - Method in class io.vertx.reactivex.core.http.HttpConnection
Close immediately (shutdown(0, TimeUnit.SECONDS).
rxClose() - Method in class io.vertx.reactivex.core.http.HttpServer
Close the server.
rxClose() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
The WebSocket handshake will be accepted when it hasn't yet been settled or when an asynchronous handshake is in progress.
rxClose() - Method in class io.vertx.reactivex.core.http.WebSocket
Close the WebSocket sending the default close frame.
rxClose() - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Close the WebSocket sending the default close frame.
rxClose() - Method in class io.vertx.reactivex.core.http.WebSocketClient
Close immediately (shutdown(0, TimeUnit.SECONDS).
rxClose() - Method in class io.vertx.reactivex.core.net.NetClient
Close immediately (shutdown(0, TimeUnit.SECONDS).
rxClose() - Method in class io.vertx.reactivex.core.net.NetServer
Close the server.
rxClose() - Method in class io.vertx.reactivex.core.net.NetSocket
Close the socket
rxClose() - Method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.TcpEventBusBridge
Close the current socket.
rxClose() - Method in class io.vertx.reactivex.ext.mail.MailClient
Close the MailClient
rxClose() - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Close the client and release its resources
rxClose() - Method in class io.vertx.reactivex.ext.stomp.StompClient
Closes the client.
rxClose() - Method in class io.vertx.reactivex.ext.stomp.StompServer
Closes the server.
rxClose() - Method in class io.vertx.reactivex.grpc.client.GrpcClient
Close this client.
rxClose() - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
Close the admin client
rxClose() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Close the consumer
rxClose() - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
Close the producer
rxClose() - Method in class io.vertx.reactivex.mqtt.MqttServer
Close the server.
rxClose() - Method in class io.vertx.reactivex.pgclient.pubsub.PgSubscriber
Close the subscriber, the retry policy will not be invoked.
rxClose() - Method in class io.vertx.reactivex.redis.client.Redis
Closes the client and terminates any connection.
rxClose() - Method in class io.vertx.reactivex.redis.client.RedisConnection
Closes the connection or returns to the pool.
rxClose() - Method in class io.vertx.reactivex.sqlclient.Cursor
Release the cursor.
rxClose() - Method in class io.vertx.reactivex.sqlclient.PreparedStatement
Close the prepared query and release its resources.
rxClose() - Method in class io.vertx.reactivex.sqlclient.RowStream
Close the stream and release the resources.
rxClose() - Method in class io.vertx.reactivex.sqlclient.SqlClient
Close the client and release the associated resources.
rxClose(long) - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
Close the admin client
rxClose(long) - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
Close the producer
rxClose(short) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Close the WebSocket sending a close frame with specified status code.
rxClose(short) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Close the WebSocket sending a close frame with specified status code.
rxClose(short) - Method in class io.vertx.reactivex.core.http.WebSocket
Close the WebSocket sending a close frame with specified status code.
rxClose(short) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Close the WebSocket sending a close frame with specified status code.
rxClose(short, String) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Close sending a close frame with specified status code and reason.
rxClose(short, String) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Close sending a close frame with specified status code and reason.
rxClose(short, String) - Method in class io.vertx.reactivex.core.http.WebSocket
Close sending a close frame with specified status code and reason.
rxClose(short, String) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Close sending a close frame with specified status code and reason.
rxCloseFuture() - Method in class io.vertx.reactivex.amqp.AmqpConnection
 
rxCluster(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
A container for cluster commands.
rxCmsIncrby(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CMS.INCRBY.
rxCmsInfo(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CMS.INFO.
rxCmsInitbydim(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CMS.INITBYDIM.
rxCmsInitbyprob(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CMS.INITBYPROB.
rxCmsMerge(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CMS.MERGE.
rxCmsQuery(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command CMS.QUERY.
rxCommand(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get array of Redis command details.
rxCommit() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Commit current offsets for all the subscribed list of topics and partition.
rxCommit() - Method in class io.vertx.reactivex.sqlclient.Transaction
Commit the current transaction.
rxCommit(String) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Commits a transaction.
rxCommit(String, Map<String, String>) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Commits a transaction.
rxCommitted(TopicPartition) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Get the last committed offset for the given partition (whether the commit happened by this process or another).
rxCommitTransaction() - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
Commits the ongoing transaction.
rxCompareAndSet(long, long) - Method in class io.vertx.reactivex.core.shareddata.Counter
Set the counter to the specified value only if the current value is the expectec value.
rxCompletion() - Method in class io.vertx.reactivex.core.eventbus.MessageConsumer
 
rxCompletion() - Method in class io.vertx.reactivex.sqlclient.Transaction
Return the transaction completion Future that succeeds when the transaction commits and fails with TransactionRollbackException when the transaction rolls back.
rxConfig(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
A container for server configuration commands.
rxConfirmSelect() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Enables publisher acknowledgements on this channel.
rxConnect() - Method in class io.vertx.reactivex.amqp.AmqpClient
Connects to the AMQP broker or router.
rxConnect() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Create an HTTP tunnel to the server.
rxConnect() - Method in class io.vertx.reactivex.ext.stomp.StompClient
Connects to the server using the host and port configured in the client's options.
rxConnect() - Method in class io.vertx.reactivex.pgclient.pubsub.PgSubscriber
Connect the subscriber to Postgres.
rxConnect() - Method in class io.vertx.reactivex.redis.client.Redis
Connects to the Redis server.
rxConnect(int, String) - Method in class io.vertx.reactivex.core.net.NetClient
Open a connection to a server at the specific port and host.
rxConnect(int, String) - Method in class io.vertx.reactivex.ext.stomp.StompClient
Connects to the server.
rxConnect(int, String) - Method in class io.vertx.reactivex.mqtt.MqttClient
Connects to an MQTT server calling connectHandler after connection
rxConnect(int, String, String) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Connect this WebSocket to the specified port, host and relative request URI.
rxConnect(int, String, String) - Method in class io.vertx.reactivex.core.http.WebSocketClient
Connect a WebSocket to the specified port, host and relative request URI.
rxConnect(int, String, String) - Method in class io.vertx.reactivex.core.net.NetClient
Open a connection to a server at the specific port and host.
rxConnect(int, String, String) - Method in class io.vertx.reactivex.mqtt.MqttClient
Connects to an MQTT server calling connectHandler after connection
rxConnect(HttpConnectOptions) - Method in class io.vertx.reactivex.core.http.HttpClientAgent
Connect to a remote HTTP server with the specific options, the connection is un-pooled and the management of the connection is left to the user.
rxConnect(WebSocketConnectOptions) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Connect this WebSocket with the specified options.
rxConnect(WebSocketConnectOptions) - Method in class io.vertx.reactivex.core.http.WebSocketClient
Connect a WebSocket with the specified options.
rxConnect(ConnectOptions) - Method in class io.vertx.reactivex.core.net.NetClient
Open a connection to a server at the specific connectOptions.
rxConnect(SocketAddress) - Method in class io.vertx.reactivex.core.net.NetClient
Open a connection to a server at the specific remoteAddress.
rxConnect(SocketAddress, String) - Method in class io.vertx.reactivex.core.net.NetClient
Open a connection to a server at the specific remoteAddress.
rxConnect(Vertx) - Static method in class io.vertx.reactivex.pgclient.PgConnection
rxConnect(Vertx, DB2ConnectOptions) - Static method in class io.vertx.reactivex.db2client.DB2Connection
Create a connection to DB2 server with the given connectOptions.
rxConnect(Vertx, MSSQLConnectOptions) - Static method in class io.vertx.reactivex.mssqlclient.MSSQLConnection
Create a connection to SQL Server with the given connectOptions.
rxConnect(Vertx, MySQLConnectOptions) - Static method in class io.vertx.reactivex.mysqlclient.MySQLConnection
Create a connection to MySQL server with the given connectOptions.
rxConnect(Vertx, OracleConnectOptions) - Static method in class io.vertx.reactivex.oracleclient.OracleConnection
Create a connection to Oracle with the given connectOptions.
rxConnect(Vertx, PgConnectOptions) - Static method in class io.vertx.reactivex.pgclient.PgConnection
Connects to the database and returns the connection if that succeeds.
rxConnect(Vertx, String) - Static method in class io.vertx.reactivex.db2client.DB2Connection
rxConnect(Vertx, String) - Static method in class io.vertx.reactivex.mssqlclient.MSSQLConnection
rxConnect(Vertx, String) - Static method in class io.vertx.reactivex.mysqlclient.MySQLConnection
rxConnect(Vertx, String) - Static method in class io.vertx.reactivex.oracleclient.OracleConnection
rxConnect(Vertx, String) - Static method in class io.vertx.reactivex.pgclient.PgConnection
rxConnect(String) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Connect this WebSocket at the relative request URI using the default host and port.
rxConnect(String) - Method in class io.vertx.reactivex.core.http.WebSocketClient
Connect a WebSocket to the default client port, default client host and specified, relative request URI.
rxConnect(String, String) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Connect this WebSocket to the host and relative request URI and default port.
rxConnect(String, String) - Method in class io.vertx.reactivex.core.http.WebSocketClient
Connect a WebSocket to the default client port and specified host and relative request URI.
rxCoordinateDatacenters() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the WAN network coordinates for all Consul servers, organized by DCs
rxCoordinateNodes() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the LAN network coordinates for all nodes in a given DC
rxCoordinateNodesWithOptions(BlockingQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the LAN network coordinates for all nodes in a given DC This is blocking query unlike ConsulClient.coordinateNodes()
rxCopy(String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
Copy a file from the path from to path to, asynchronously.
rxCopy(String, String, CopyOptions) - Method in class io.vertx.reactivex.core.file.FileSystem
Copy a file from the path from to path to, asynchronously.
rxCopy(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Copy a key.
rxCopyRecursive(String, String, boolean) - Method in class io.vertx.reactivex.core.file.FileSystem
Copy a file from the path from to path to, asynchronously.
rxCount(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Count matching documents in a collection.
rxCountWithOptions(String, JsonObject, CountOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Count matching documents in a collection.
rxCreateAclPolicy(AclPolicy) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Creates a new ACL policy
rxCreateAcls(List<AclBinding>) - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
Create the ACL rules.
rxCreateAclToken(AclToken) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Create an Acl token
rxCreateAnonymousSender() - Method in class io.vertx.reactivex.amqp.AmqpConnection
Creates an anonymous sender.
rxCreateAuthenticator(String, OtpKey) - Method in class io.vertx.reactivex.ext.auth.otp.hotp.HotpAuth
Creating authenticator from user id and key.
rxCreateAuthenticator(String, OtpKey) - Method in class io.vertx.reactivex.ext.auth.otp.totp.TotpAuth
Creating authenticator from user id and key.
rxCreateCollection(String) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Create a new collection
rxCreateCollectionWithOptions(String, CreateCollectionOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Create a new collection with options
rxCreateCredentialsOptions(JsonObject) - Method in class io.vertx.reactivex.ext.auth.webauthn4j.WebAuthn4J
Gets a challenge and any other parameters for the navigator.credentials.create() call.
rxCreateDefaultGridFsBucketService() - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Creates a MongoGridFsClient used to interact with Mongo GridFS.
rxCreateDynamicReceiver() - Method in class io.vertx.reactivex.amqp.AmqpConnection
Creates a dynamic receiver.
rxCreateFile(String) - Method in class io.vertx.reactivex.core.file.FileSystem
Creates an empty file with the specified path, asynchronously.
rxCreateFile(String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
Creates an empty file with the specified path and permissions perms, asynchronously.
rxCreateGridFsBucketService(String) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Creates a MongoGridFsClient used to interact with Mongo GridFS.
rxCreateHashedUser(String, String) - Method in class io.vertx.reactivex.ext.auth.sqlclient.SqlUserUtil
Insert a user into a database.
rxCreateIndex(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Creates an index.
rxCreateIndexes(String, List<IndexModel>) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
creates an indexes
rxCreateIndexWithOptions(String, JsonObject, IndexOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Creates an index.
rxCreatePartitions(Map<String, NewPartitions>) - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
Creates a batch of new partitions in the Kafka topic
rxCreatePreparedQuery(PreparedQueryDefinition) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
 
rxCreateReceiver(String) - Method in class io.vertx.reactivex.amqp.AmqpClient
Creates a receiver used to consume messages from the given address.
rxCreateReceiver(String) - Method in class io.vertx.reactivex.amqp.AmqpConnection
Creates a receiver used to consume messages from the given address.
rxCreateReceiver(String, AmqpReceiverOptions) - Method in class io.vertx.reactivex.amqp.AmqpClient
Creates a receiver used to consumer messages from the given address.
rxCreateReceiver(String, AmqpReceiverOptions) - Method in class io.vertx.reactivex.amqp.AmqpConnection
Creates a receiver used to consumer messages from the given address.
rxCreateRolePermission(String, String) - Method in class io.vertx.reactivex.ext.auth.sqlclient.SqlUserUtil
Insert a role permission into a database.
rxCreateSender(String) - Method in class io.vertx.reactivex.amqp.AmqpClient
Creates a sender used to send messages to the given address.
rxCreateSender(String) - Method in class io.vertx.reactivex.amqp.AmqpConnection
Creates a sender used to send messages to the given address.
rxCreateSender(String, AmqpSenderOptions) - Method in class io.vertx.reactivex.amqp.AmqpClient
Creates a sender used to send messages to the given address.
rxCreateSender(String, AmqpSenderOptions) - Method in class io.vertx.reactivex.amqp.AmqpConnection
Creates a sender used to send messages to the given address.
rxCreateSession() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Initialize a new session
rxCreateSessionWithOptions(SessionOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Initialize a new session
rxCreateTempDirectory(String) - Method in class io.vertx.reactivex.core.file.FileSystem
Creates a new directory in the default temporary-file directory, using the given prefix to generate its name, asynchronously.
rxCreateTempDirectory(String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
Creates a new directory in the default temporary-file directory, using the given prefix to generate its name, asynchronously.
rxCreateTempDirectory(String, String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
Creates a new directory in the directory provided by the path path, using the given prefix to generate its name, asynchronously.
rxCreateTempFile(String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
Creates a new file in the default temporary-file directory, using the given prefix and suffix to generate its name, asynchronously.
rxCreateTempFile(String, String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
Creates a new file in the directory provided by the path dir, using the given prefix and suffix to generate its name, asynchronously.
rxCreateTempFile(String, String, String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
Creates a new file in the directory provided by the path dir, using the given prefix and suffix to generate its name, asynchronously.
rxCreateTopics(List<NewTopic>) - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
Creates a batch of new Kafka topics
rxCreateUser(String, String) - Method in class io.vertx.reactivex.ext.auth.sqlclient.SqlUserUtil
Insert a user into a database.
rxCreateUserRole(String, String) - Method in class io.vertx.reactivex.ext.auth.sqlclient.SqlUserUtil
Insert a user role into a database.
rxDbsize() - Method in class io.vertx.reactivex.redis.client.RedisAPI
Return the number of keys in the selected database.
rxDebug() - Method in class io.vertx.reactivex.db2client.DB2Connection
Send a DEBUG command to dump debug information to the server's stdout.
rxDebug() - Method in class io.vertx.reactivex.mysqlclient.MySQLConnection
Send a DEBUG command to dump debug information to the server's stdout.
rxDebug(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
A container for debugging commands.
rxDecr(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Decrement the integer value of a key by one.
rxDecrby(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Decrement the integer value of a key by the given number.
rxDecrementAndGet() - Method in class io.vertx.reactivex.core.shareddata.Counter
Decrement the counter atomically and return the new count
rxDel(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Delete a key.
rxDelete() - Method in class io.vertx.reactivex.ext.web.FileUpload
Delete the uploaded file on the disk.
rxDelete(String) - Method in class io.vertx.reactivex.core.file.FileSystem
Deletes the file represented by the specified path, asynchronously.
rxDelete(String) - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
Deletes a file by it's ID
rxDelete(String) - Method in class io.vertx.reactivex.ext.web.sstore.SessionStore
Delete the session with the specified ID.
rxDeleteAcls(List<AclBindingFilter>) - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
Delete the ACL rules.
rxDeleteAclToken(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Deletes an ACL token
rxDeleteConsumerGroupOffsets(String, Set<TopicPartition>) - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
Delete committed offsets for a set of partitions in a consumer group.
rxDeleteConsumerGroups(List<String>) - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
Delete consumer groups from the cluster.
rxDeletePolicy(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
This endpoint deletes an ACL policy
rxDeletePreparedQuery(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Deletes an existing prepared query
rxDeleteRecursive(String) - Method in class io.vertx.reactivex.core.file.FileSystem
Deletes the file represented by the specified path, asynchronously.
rxDeleteTopics(List<String>) - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
Deletes a batch of Kafka topics
rxDeleteValue(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Remove the key/value pair that corresponding to the specified key
rxDeleteValues(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Removes all the key/value pair that corresponding to the specified key prefix
rxDeregisterCatalogService(String, String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Deregister entities from the node or deregister the node itself.
rxDeregisterCheck(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Remove a check from the local agent.
rxDeregisterService(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Remove a service from the local agent.
rxDescribeAcls(AclBindingFilter) - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
Describe the ACL rules.
rxDescribeCluster() - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
Describe the nodes in the cluster with the default options
rxDescribeCluster(DescribeClusterOptions) - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
Like KafkaAdminClient.describeCluster() but allows customized options.
rxDescribeConsumerGroups(List<String>) - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
Describe some group ids in the cluster, with the default options
rxDescribeConsumerGroups(List<String>, DescribeConsumerGroupsOptions) - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
rxDescribeTopics(List<String>) - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
Describe some topics in the cluster, with the default options.
rxDescribeTopics(List<String>, DescribeTopicsOptions) - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
rxDestroySession(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Destroys the given session
rxDiscard() - Method in class io.vertx.reactivex.redis.client.RedisAPI
Discard all commands issued after MULTI.
rxDisconnect() - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Disconnects the client.
rxDisconnect() - Method in class io.vertx.reactivex.mqtt.MqttClient
Disconnects from the MQTT server
rxDisconnect(Frame) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Disconnects the client.
rxDiscover(Vertx, OAuth2Options) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.AmazonCognitoAuth
Create a OAuth2Auth provider for OpenID Connect Discovery.
rxDiscover(Vertx, OAuth2Options) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.AzureADAuth
Create a OAuth2Auth provider for OpenID Connect Discovery.
rxDiscover(Vertx, OAuth2Options) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.GoogleAuth
Create a OAuth2Auth provider for OpenID Connect Discovery.
rxDiscover(Vertx, OAuth2Options) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.IBMCloudAuth
Create a OAuth2Auth provider for OpenID Connect Discovery.
rxDiscover(Vertx, OAuth2Options) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.KeycloakAuth
Create a OAuth2Auth provider for OpenID Connect Discovery.
rxDiscover(Vertx, OAuth2Options) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.OpenIDConnectAuth
Create a OAuth2Auth provider for OpenID Connect Discovery.
rxDiscover(Vertx, OAuth2Options) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.SalesforceAuth
Create a OAuth2Auth provider for OpenID Connect Discovery.
rxDiscover(Vertx, PubSecKeyOptions, OAuth2Options) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.AppleIdAuth
Create a OAuth2Auth provider for OpenID Connect Discovery.
rxDistinct(String, String, String) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Gets the distinct values of the specified field name.
rxDistinct(String, String, String, DistinctOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Gets the distinct values of the specified field name.
rxDistinctWithQuery(String, String, String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Gets the distinct values of the specified field name filtered by specified query.
rxDistinctWithQuery(String, String, String, JsonObject, DistinctOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Gets the distinct values of the specified field name filtered by specified query.
rxDownloadByFileName(WriteStream<Buffer>, String) - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
 
rxDownloadByFileNameWithOptions(WriteStream<Buffer>, String, GridFsDownloadOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
 
rxDownloadById(WriteStream<Buffer>, String) - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
 
rxDownloadFile(String) - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
Downloads a file.
rxDownloadFileAs(String, String) - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
Downloads a file and gives it a new name.
rxDownloadFileByID(String, String) - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
Downloads a file using the ID generated by GridFs.
rxDrop() - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
Drops the entire file bucket with all of its contents
rxDropCollection(String) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Drop a collection
rxDropIndex(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Drops the index given the keys used to create it.
rxDropIndex(String, String) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Drops the index given its name.
rxDump(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Return a serialized version of the value stored at the specified key.
rxEcho(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Echo the given string.
rxEnd() - Method in class io.vertx.reactivex.amqp.AmqpSender
Ends the stream.
rxEnd() - Method in class io.vertx.reactivex.core.file.AsyncFile
Ends the stream.
rxEnd() - Method in class io.vertx.reactivex.core.http.ClientWebSocket
rxEnd() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Ends the request.
rxEnd() - Method in class io.vertx.reactivex.core.http.HttpClientResponse
Returns a future signaling when the response has been fully received successfully or failed.
rxEnd() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
Returns a future signaling when the request has been fully received successfully or failed.
rxEnd() - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Ends the response.
rxEnd() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
rxEnd() - Method in class io.vertx.reactivex.core.http.WebSocket
rxEnd() - Method in interface io.vertx.reactivex.core.http.WebSocketBase
rxEnd() - Method in class io.vertx.reactivex.core.net.NetSocket
rxEnd() - Method in interface io.vertx.reactivex.core.streams.WriteStream
Ends the stream.
rxEnd() - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
rxEnd() - Method in class io.vertx.reactivex.ext.web.RoutingContext
Shortcut to the response end.
rxEnd() - Method in class io.vertx.reactivex.grpc.client.GrpcClientRequest
Ends the stream.
rxEnd() - Method in class io.vertx.reactivex.grpc.common.GrpcReadStream
 
rxEnd() - Method in class io.vertx.reactivex.grpc.common.GrpcWriteStream
Ends the stream.
rxEnd() - Method in class io.vertx.reactivex.grpc.server.GrpcServerResponse
Ends the stream.
rxEnd() - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
Ends the stream.
rxEnd(Buffer) - Method in class io.vertx.reactivex.core.file.AsyncFile
Same as WriteStream.end() but writes some data to the stream before ending.
rxEnd(Buffer) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Same as WebSocketBase.end(io.vertx.core.buffer.Buffer) but writes some data to the stream before ending.
rxEnd(Buffer) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Same as HttpClientRequest.end(java.lang.String) but writes some data to the request body before ending.
rxEnd(Buffer) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Same as HttpServerResponse.end(java.lang.String) but writes some data to the response body before ending.
rxEnd(Buffer) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Same as WebSocketBase.end(io.vertx.core.buffer.Buffer) but writes some data to the stream before ending.
rxEnd(Buffer) - Method in class io.vertx.reactivex.core.http.WebSocket
Same as WebSocketBase.end(io.vertx.core.buffer.Buffer) but writes some data to the stream before ending.
rxEnd(Buffer) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Same as WebSocketBase.end(io.vertx.core.buffer.Buffer) but writes some data to the stream before ending.
rxEnd(Buffer) - Method in class io.vertx.reactivex.core.net.NetSocket
Same as NetSocket.end(io.vertx.core.buffer.Buffer) but writes some data to the stream before ending.
rxEnd(Buffer) - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
Same as SockJSSocket.end(io.vertx.core.buffer.Buffer) but writes some data to the stream before ending.
rxEnd(Buffer) - Method in class io.vertx.reactivex.ext.web.RoutingContext
Shortcut to the response end.
rxEnd(AmqpMessage) - Method in class io.vertx.reactivex.amqp.AmqpSender
Same as WriteStream.end() but writes some data to the stream before ending.
rxEnd(KafkaProducerRecord<K, V>) - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
Same as WriteStream.end() but writes some data to the stream before ending.
rxEnd(String) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Same as HttpClientRequest.end(java.lang.String) but writes a String in UTF-8 encoding
rxEnd(String) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Same as HttpServerResponse.end(java.lang.String) but writes a String in UTF-8 encoding before ending the response.
rxEnd(String) - Method in class io.vertx.reactivex.ext.web.RoutingContext
Shortcut to the response end.
rxEnd(String, String) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Same as HttpClientRequest.end(java.lang.String) but writes a String with the specified encoding
rxEnd(String, String) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Same as HttpServerResponse.end(java.lang.String) but writes a String with the specified encoding before ending the response.
rxEnd(Req) - Method in class io.vertx.reactivex.grpc.client.GrpcClientRequest
Same as WriteStream.end() but writes some data to the stream before ending.
rxEnd(Resp) - Method in class io.vertx.reactivex.grpc.server.GrpcServerResponse
Same as WriteStream.end() but writes some data to the stream before ending.
rxEnd(T) - Method in interface io.vertx.reactivex.core.streams.WriteStream
Same as WriteStream.end() but writes some data to the stream before ending.
rxEnd(T) - Method in class io.vertx.reactivex.grpc.common.GrpcWriteStream
Same as WriteStream.end() but writes some data to the stream before ending.
rxEndMessage(GrpcMessage) - Method in class io.vertx.reactivex.grpc.common.GrpcWriteStream
End the stream with an encoded gRPC message.
rxEndOffsets(TopicPartition) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Get the last offset for the given partition.
rxEval(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Execute a Lua script server side.
rxEvalRo(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Execute a read-only Lua script server side.
rxEvalsha(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Execute a Lua script server side.
rxEvalshaRo(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Execute a read-only Lua script server side.
rxExchangeBind(String, String, String) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Bind an exchange to an exchange.
rxExchangeBind(String, String, String, Map<String, Object>) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Bind an exchange to an exchange.
rxExchangeDeclare(String, String, boolean, boolean) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Declare an exchange.
rxExchangeDeclare(String, String, boolean, boolean, JsonObject) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Declare an exchange with additional parameters such as dead lettering, an alternate exchange or TTL.
rxExchangeDelete(String) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Delete an exchange, without regard for whether it is in use or not.
rxExchangeUnbind(String, String, String) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Unbind an exchange from an exchange.
rxExchangeUnbind(String, String, String, Map<String, Object>) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Unbind an exchange from an exchange.
rxExec() - Method in class io.vertx.reactivex.redis.client.RedisAPI
Execute all commands issued after MULTI.
rxExecute() - Method in class io.vertx.reactivex.sqlclient.PreparedQuery
Execute the query.
rxExecute() - Method in class io.vertx.reactivex.sqlclient.Query
Execute the query.
rxExecute(Statement) - Method in class io.vertx.reactivex.cassandra.CassandraClient
Execute the statement and provide a handler for consuming results.
rxExecute(I) - Method in class io.vertx.reactivex.sqlclient.templates.SqlTemplate
Execute the query with the parameters
rxExecute(Handler<Promise<T>>) - Method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
rxExecute(Tuple) - Method in class io.vertx.reactivex.sqlclient.PreparedQuery
Execute the query.
rxExecute(String) - Method in class io.vertx.reactivex.cassandra.CassandraClient
Execute the query and provide a handler for consuming results.
rxExecute(Supplier<Future<T>>) - Method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
rxExecuteBatch(List<I>) - Method in class io.vertx.reactivex.sqlclient.templates.SqlTemplate
Execute a batch query with the batch.
rxExecuteBatch(List<Tuple>) - Method in class io.vertx.reactivex.sqlclient.PreparedQuery
Execute the query with a batch of tuples.
rxExecutePreparedQuery(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Executes an existing prepared query.
rxExecutePreparedQueryWithOptions(String, PreparedQueryExecuteOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Executes an existing prepared query.
rxExecuteWithFallback(Handler<Promise<T>>, Function<Throwable, T>) - Method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
Executes the given operation with the circuit breaker control.
rxExecuteWithFallback(Supplier<Future<T>>, Function<Throwable, T>) - Method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
Executes the given operation with the circuit breaker control.
rxExecuteWithFullFetch(Statement) - Method in class io.vertx.reactivex.cassandra.CassandraClient
Execute the query and provide a handler for consuming results.
rxExecuteWithFullFetch(String) - Method in class io.vertx.reactivex.cassandra.CassandraClient
Execute the query and provide a handler for consuming results.
rxExists(String) - Method in class io.vertx.reactivex.core.file.FileSystem
Determines whether the file as specified by the path path exists, asynchronously.
rxExists(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Determine if a key exists.
rxExpire(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Set a key's time to live in seconds.
rxExpireat(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Set the expiration for a key as a UNIX timestamp.
rxExpiretime(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the expiration Unix timestamp for a key.
rxExtractValidatableRequest(RoutingContext, Operation) - Method in class io.vertx.reactivex.ext.web.openapi.router.RequestExtractor
Extracts and transforms the parameters and the body of an incoming request into a that can be validated by the RequestValidator.
rxFailCheck(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Set status of the check to "critical".
rxFailCheckWithNote(String, String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Set status of the check to "critical".
rxFailover(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Start a coordinated failover between this server and one of its replicas.
rxFcall(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Invoke a function.
rxFcallRo(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Invoke a read-only function.
rxFetchNextPage() - Method in class io.vertx.reactivex.cassandra.ResultSet
 
rxFind(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Find matching documents in the specified collection
rxFind(String, String) - Method in class io.vertx.reactivex.ext.auth.webauthn4j.CredentialStorage
Finds an existing list of credentials for a given user name and credential ID.
rxFindAllIds() - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
Finds all file ids in the bucket
rxFindIds(JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
Finds all file ids that match a query.
rxFindOne(String, JsonObject, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Find a single matching document in the specified collection
rxFindOneAndDelete(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Find a single matching document in the specified collection and delete it.
rxFindOneAndDeleteWithOptions(String, JsonObject, FindOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Find a single matching document in the specified collection and delete it.
rxFindOneAndReplace(String, JsonObject, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Find a single matching document in the specified collection and replace it.
rxFindOneAndReplaceWithOptions(String, JsonObject, JsonObject, FindOptions, UpdateOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Find a single matching document in the specified collection and replace it.
rxFindOneAndUpdate(String, JsonObject, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Find a single matching document in the specified collection and update it.
rxFindOneAndUpdateWithOptions(String, JsonObject, JsonObject, FindOptions, UpdateOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Find a single matching document in the specified collection and update it.
rxFindWithOptions(String, JsonObject, FindOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Find matching documents in the specified collection, specifying options
rxFireEvent(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Fires a new user event
rxFireEventWithOptions(String, EventOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Fires a new user event
rxFlush() - Method in class io.vertx.reactivex.core.file.AsyncFile
Flush any writes made to this file to underlying persistent storage.
rxFlush() - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
Invoking this method makes all buffered records immediately available to write
rxFlush(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.SessionHandler
Flush a context session earlier to the store, this will allow the end user to have full control on the event of a failure at the store level.
rxFlush(RoutingContext, boolean) - Method in class io.vertx.reactivex.ext.web.handler.SessionHandler
Flush a context session earlier to the store, this will allow the end user to have full control on the event of a failure at the store level.
rxFlushall(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove all keys from all databases.
rxFlushdb(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove all keys from the current database.
rxFrom(Vertx, JsonObject) - Static method in class io.vertx.reactivex.openapi.contract.OpenAPIContract
Resolves / dereferences the passed contract and creates an OpenAPIContract instance.
rxFrom(Vertx, JsonObject, Map<String, JsonObject>) - Static method in class io.vertx.reactivex.openapi.contract.OpenAPIContract
Resolves / dereferences the passed contract and creates an OpenAPIContract instance.
rxFrom(Vertx, String) - Static method in class io.vertx.reactivex.openapi.contract.OpenAPIContract
Resolves / dereferences the passed contract and creates an OpenAPIContract instance.
rxFrom(Vertx, String, Map<String, String>) - Static method in class io.vertx.reactivex.openapi.contract.OpenAPIContract
Resolves / dereferences the passed contract and creates an OpenAPIContract instance.
rxFsProps(String) - Method in class io.vertx.reactivex.core.file.FileSystem
Returns properties of the file-system being used by the specified path, asynchronously.
rxFtAdd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.ADD.
rxFtAggregate(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.AGGREGATE.
rxFtAliasadd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.ALIASADD.
rxFtAliasaddifnx(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.
rxFtAliasdel(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.ALIASDEL.
rxFtAliasdelifx(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.
rxFtAliasupdate(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.ALIASUPDATE.
rxFtAlter(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.ALTER.
rxFtAlterifnx(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.
rxFtConfig(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.CONFIG.
rxFtCreate(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.CREATE.
rxFtCreateifnx(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.
rxFtCursor(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.CURSOR.
rxFtDebug(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.DEBUG.
rxFtDel(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.DEL.
rxFtDictadd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.DICTADD.
rxFtDictdel(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.DICTDEL.
rxFtDictdump(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.DICTDUMP.
rxFtDrop(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.DROP.
rxFtDropifx(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.
rxFtDropindex(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.DROPINDEX.
rxFtDropindexifx(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.
rxFtExplain(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.EXPLAIN.
rxFtExplaincli(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.EXPLAINCLI.
rxFtGet(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.GET.
rxFtInfo(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.INFO.
rxFtList(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.
rxFtMget(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.MGET.
rxFtProfile(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.PROFILE.
rxFtSafeadd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.SAFEADD.
rxFtSearch(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.SEARCH.
rxFtSpellcheck(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.SPELLCHECK.
rxFtSugadd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.SUGADD.
rxFtSugdel(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.SUGDEL.
rxFtSugget(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.SUGGET.
rxFtSuglen(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.SUGLEN.
rxFtSynadd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.SYNADD.
rxFtSyndump(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.SYNDUMP.
rxFtSynupdate(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.SYNUPDATE.
rxFtTagvals(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command FT.TAGVALS.
rxFunction(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
A container for function commands.
rxFuture() - Method in class io.vertx.reactivex.ext.bridge.BaseBridgeEvent
 
rxFuture() - Method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.BridgeEvent
 
rxFuture() - Method in class io.vertx.reactivex.ext.web.handler.graphql.ws.ConnectionInitEvent
 
rxFuture() - Method in class io.vertx.reactivex.ext.web.handler.sockjs.BridgeEvent
 
rxGeoadd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Add one or more geospatial items in the geospatial index represented using a sorted set.
rxGeodist(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Returns the distance between two members of a geospatial index.
rxGeohash(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Returns members of a geospatial index as standard geohash strings.
rxGeopos(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Returns longitude and latitude of members of a geospatial index.
rxGeoradius(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Deprecated.
rxGeoradiusbymember(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Deprecated.
rxGeoradiusbymemberRo(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Deprecated.
rxGeoradiusRo(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Deprecated.
rxGeosearch(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Query a sorted set representing a geospatial index to fetch members inside an area of a box or a circle.
rxGeosearchstore(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Query a sorted set representing a geospatial index to fetch members inside an area of a box or a circle, and store the result in another key.
rxGet() - Method in class io.vertx.reactivex.core.shareddata.Counter
Get the current value of the counter
rxGet(String) - Method in class io.vertx.reactivex.ext.web.sstore.SessionStore
Get the session with the specified ID.
rxGet(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the value of a key.
rxGet(K) - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
Get a value from the map, asynchronously.
rxGetAclPolicies() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
This endpoint lists all the ACL policies.
rxGetAclTokens() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Get list of Acl token
rxGetAllPreparedQueries() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns a list of all prepared queries.
rxGetAndAdd(long) - Method in class io.vertx.reactivex.core.shareddata.Counter
Add the value to the counter atomically and return the value before the add
rxGetAndIncrement() - Method in class io.vertx.reactivex.core.shareddata.Counter
Increment the counter atomically and return the value before the increment.
rxGetAsyncMap(String) - Method in class io.vertx.reactivex.core.shareddata.SharedData
Get the AsyncMap with the specified name.
rxGetAuthorizations(User) - Method in class io.vertx.reactivex.ext.auth.abac.PolicyBasedAuthorizationProvider
Updates the user with the set of authorizations.
rxGetAuthorizations(User) - Method in interface io.vertx.reactivex.ext.auth.authorization.AuthorizationProvider
Updates the user with the set of authorizations.
rxGetAuthorizations(User) - Method in class io.vertx.reactivex.ext.auth.jwt.authorization.JWTAuthorization
Updates the user with the set of authorizations.
rxGetAuthorizations(User) - Method in class io.vertx.reactivex.ext.auth.jwt.authorization.MicroProfileAuthorization
Updates the user with the set of authorizations.
rxGetAuthorizations(User) - Method in class io.vertx.reactivex.ext.auth.oauth2.authorization.KeycloakAuthorization
Updates the user with the set of authorizations.
rxGetAuthorizations(User) - Method in class io.vertx.reactivex.ext.auth.oauth2.authorization.ScopeAuthorization
Updates the user with the set of authorizations.
rxGetAuthorizations(User) - Method in class io.vertx.reactivex.ext.auth.properties.PropertyFileAuthorization
Updates the user with the set of authorizations.
rxGetAuthorizations(User) - Method in class io.vertx.reactivex.ext.auth.sqlclient.SqlAuthorization
Updates the user with the set of authorizations.
rxGetbit(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Returns the bit value at offset in the string value stored at key.
rxGetClient(ServiceDiscovery, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.HttpEndpoint
Convenient method that looks for a HTTP endpoint and provides the configured .
rxGetClient(ServiceDiscovery, JsonObject, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.HttpEndpoint
Convenient method that looks for a HTTP endpoint and provides the configured .
rxGetClient(ServiceDiscovery, Function<Record, Boolean>) - Static method in class io.vertx.reactivex.servicediscovery.types.HttpEndpoint
Convenient method that looks for a HTTP endpoint and provides the configured .
rxGetClient(ServiceDiscovery, Function<Record, Boolean>, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.HttpEndpoint
Convenient method that looks for a HTTP endpoint and provides the configured .
rxGetClusterWideMap(String) - Method in class io.vertx.reactivex.core.shareddata.SharedData
Get the cluster wide map with the specified name.
rxGetCollections() - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Get a list of all collections in the database.
rxGetConfig() - Method in class io.vertx.reactivex.config.ConfigRetriever
Reads the configuration from the different and computes the final configuration.
rxGetConnection() - Method in class io.vertx.reactivex.sqlclient.Pool
Get a connection from the pool.
rxGetConsumer(ServiceDiscovery, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.MessageSource
Convenient method that looks for a message source and provides the configured .
rxGetConsumer(ServiceDiscovery, Function<Record, Boolean>) - Static method in class io.vertx.reactivex.servicediscovery.types.MessageSource
Convenient method that looks for a message source and provides the configured .
rxGetCounter(String) - Method in class io.vertx.reactivex.core.shareddata.SharedData
Get an asynchronous counter.
rxGetCredentialsOptions(String) - Method in class io.vertx.reactivex.ext.auth.webauthn4j.WebAuthn4J
Creates an assertion challenge and any other parameters for the navigator.credentials.get() call.
rxGetdel(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the value of a key and delete the key.
rxGetex(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the value of a key and optionally set its expiration.
rxGetInternalStatistics() - Method in class io.vertx.reactivex.mysqlclient.MySQLConnection
Send a STATISTICS command to get a human readable string of the server internal status.
rxGetKeys(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the list of keys that corresponding to the specified key prefix.
rxGetKeysWithOptions(String, BlockingQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the list of keys that corresponding to the specified key prefix.
rxGetLocalAsyncMap(String) - Method in class io.vertx.reactivex.core.shareddata.SharedData
Get the AsyncMap with the specified name.
rxGetLocalCounter(String) - Method in class io.vertx.reactivex.core.shareddata.SharedData
Get an asynchronous local counter.
rxGetLocalLock(String) - Method in class io.vertx.reactivex.core.shareddata.SharedData
Get an asynchronous local lock with the specified name.
rxGetLocalLockWithTimeout(String, long) - Method in class io.vertx.reactivex.core.shareddata.SharedData
Like SharedData.getLocalLock(java.lang.String) but specifying a timeout.
rxGetLock(String) - Method in class io.vertx.reactivex.core.shareddata.SharedData
Get an asynchronous lock with the specified name.
rxGetLockWithTimeout(String, long) - Method in class io.vertx.reactivex.core.shareddata.SharedData
Like SharedData.getLock(java.lang.String) but specifying a timeout.
rxGetMongoClient(ServiceDiscovery, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.MongoDataSource
Convenient method that looks for a Mongo datasource source and provides the configured MongoClient.
rxGetMongoClient(ServiceDiscovery, JsonObject, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.MongoDataSource
Convenient method that looks for a Mongo datasource source and provides the configured MongoClient.
rxGetMongoClient(ServiceDiscovery, Function<Record, Boolean>) - Static method in class io.vertx.reactivex.servicediscovery.types.MongoDataSource
Convenient method that looks for a Mongo datasource source and provides the configured MongoClient.
rxGetPreparedQuery(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns an existing prepared query
rxGetrange(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get a substring of the string stored at a key.
rxGetRecord(JsonObject) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
Lookups for a single record.
rxGetRecord(String) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
Looks up for a single record by its registration id.
rxGetRecord(Function<Record, Boolean>) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
Lookups for a single record.
rxGetRecord(Function<Record, Boolean>, boolean) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
Lookups for a single record.
rxGetRecords(JsonObject) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
Lookups for a set of records.
rxGetRecords(Function<Record, Boolean>) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
Lookups for a set of records.
rxGetRecords(Function<Record, Boolean>, boolean) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
Lookups for a set of records.
rxGetRedisClient(ServiceDiscovery, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.RedisDataSource
Convenient method that looks for a Redis data source and provides the configured Redis.
rxGetRedisClient(ServiceDiscovery, JsonObject, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.RedisDataSource
Convenient method that looks for a Redis data source and provides the configured Redis.
rxGetRedisClient(ServiceDiscovery, Function<Record, Boolean>) - Static method in class io.vertx.reactivex.servicediscovery.types.RedisDataSource
Convenient method that looks for a Redis data source and provides the configured Redis.
rxGetRedisClient(ServiceDiscovery, Function<Record, Boolean>, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.RedisDataSource
Convenient method that looks for a Redis data source and provides the configured Redis.
rxGetServiceProxy(ServiceDiscovery, Function<Record, Boolean>, Class<T>) - Static method in class io.vertx.reactivex.servicediscovery.types.EventBusService
Lookup for a service record and if found, retrieve it and return the service object (used to consume the service).
rxGetServiceProxy(ServiceDiscovery, Function<Record, Boolean>, Class<T>, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.EventBusService
Lookup for a service record and if found, retrieve it and return the service object (used to consume the service).
rxGetServiceProxyWithJsonFilter(ServiceDiscovery, JsonObject, Class<T>) - Static method in class io.vertx.reactivex.servicediscovery.types.EventBusService
Lookup for a service record and if found, retrieve it and return the service object (used to consume the service).
rxGetServiceProxyWithJsonFilter(ServiceDiscovery, JsonObject, Class<T>, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.EventBusService
Lookup for a service record and if found, retrieve it and return the service object (used to consume the service).
rxGetset(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Deprecated.
rxGetTransactionIsolation() - Method in class io.vertx.reactivex.jdbcclient.JDBCConnection
 
rxGetValue(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns key/value pair that corresponding to the specified key.
rxGetValues(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the list of key/value pairs that corresponding to the specified key prefix.
rxGetValuesWithOptions(String, BlockingQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the list of key/value pairs that corresponding to the specified key prefix.
rxGetValueWithOptions(String, BlockingQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns key/value pair that corresponding to the specified key.
rxGetWebClient(ServiceDiscovery, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.HttpEndpoint
Convenient method that looks for a HTTP endpoint and provides the configured .
rxGetWebClient(ServiceDiscovery, JsonObject, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.HttpEndpoint
Convenient method that looks for a HTTP endpoint and provides the configured .
rxGetWebClient(ServiceDiscovery, Function<Record, Boolean>) - Static method in class io.vertx.reactivex.servicediscovery.types.HttpEndpoint
Convenient method that looks for a HTTP endpoint and provides the configured .
rxGetWebClient(ServiceDiscovery, Function<Record, Boolean>, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.HttpEndpoint
Convenient method that looks for a HTTP endpoint and provides the configured .
rxGraphBulk(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command GRAPH.BULK.
rxGraphConfig(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command GRAPH.CONFIG.
rxGraphDebug(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command GRAPH.DEBUG.
rxGraphDelete(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command GRAPH.DELETE.
rxGraphExplain(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command GRAPH.EXPLAIN.
rxGraphList(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command GRAPH.LIST.
rxGraphProfile(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command GRAPH.PROFILE.
rxGraphQuery(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command GRAPH.QUERY.
rxGraphRoQuery(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command GRAPH.RO_QUERY.
rxGraphSlowlog(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command GRAPH.SLOWLOG.
rxGroupByNodes(List<Request>) - Method in class io.vertx.reactivex.redis.client.RedisCluster
Groups the requests into a RequestGrouping, which contains: keyed requests: requests that include a key and it is therefore possible to determine to which master node they should be sent; all requests in each inner list in the keyed collection are guaranteed to be sent to the same master node; unkeyed requests: requests that do not include a key and it is therefore not possible to determine to which master node they should be sent. If any of the requests includes multiple keys that belong to different master nodes, the resulting future will fail.
rxHdel(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Delete one or more hash fields.
rxHealthChecks(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the checks associated with the service
rxHealthChecksWithOptions(String, CheckQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the checks associated with the service
rxHealthNodesWithOptions(String, CheckQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the checks specific to the node provided on the path.
rxHealthServiceNodes(String, boolean) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the nodes providing the service.
rxHealthServiceNodesWithOptions(String, boolean, ServiceQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the nodes providing the service.
rxHealthState(HealthState) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the checks in the specified status
rxHealthStateWithOptions(HealthState, CheckQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the checks in the specified status
rxHello(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Handshake with Redis.
rxHexists(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Determine if a hash field exists.
rxHget(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the value of a hash field.
rxHgetall(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get all the fields and values in a hash.
rxHincrby(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Increment the integer value of a hash field by the given number.
rxHincrbyfloat(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Increment the float value of a hash field by the given amount.
rxHkeys(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get all the fields in a hash.
rxHlen(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the number of fields in a hash.
rxHmget(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the values of all the given hash fields.
rxHmset(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Deprecated.
rxHrandfield(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get one or multiple random fields from a hash.
rxHscan(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Incrementally iterate hash fields and associated values.
rxHset(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Set the string value of a hash field.
rxHsetnx(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Set the value of a hash field, only if the field does not exist.
rxHstrlen(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the length of the value of a hash field.
rxHvals(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get all the values in a hash.
rxImpersonate() - Method in class io.vertx.reactivex.ext.web.UserContext
Impersonates a second identity.
rxImpersonate(String) - Method in class io.vertx.reactivex.ext.web.UserContext
Impersonates a second identity.
rxIncr(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Increment the integer value of a key by one.
rxIncrby(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Increment the integer value of a key by the given amount.
rxIncrbyfloat(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Increment the float value of a key by the given amount.
rxIncrementAndGet() - Method in class io.vertx.reactivex.core.shareddata.Counter
Increment the counter atomically and return the new count
rxInfo(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get information and statistics about the server.
rxInfoSession(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the requested session information
rxInfoSessionWithOptions(String, BlockingQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the requested session information This is blocking query unlike ConsulClient.infoSession(java.lang.String)
rxInitTransactions() - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
Initializes the underlying kafka transactional producer.
rxInsert(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Insert a document in the specified collection
rxInsertWithOptions(String, JsonObject, WriteOption) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Insert a document in the specified collection with the specified write option
rxInvoke(String) - Method in class io.vertx.reactivex.ext.healthchecks.HealthChecks
Invokes the registered procedure with the given name and sub-procedures.
rxIsValid() - Method in class io.vertx.reactivex.core.file.AsyncFileLock
A lock remains valid until it is released or the file corresponding AsyncFile is closed.
rxJson(Object) - Method in class io.vertx.reactivex.ext.web.RoutingContext
Encode an Object to JSON and end the request.
rxJsonArrappend(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.ARRAPPEND.
rxJsonArrindex(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.ARRINDEX.
rxJsonArrinsert(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.ARRINSERT.
rxJsonArrlen(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.ARRLEN.
rxJsonArrpop(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.ARRPOP.
rxJsonArrtrim(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.ARRTRIM.
rxJsonClear(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.CLEAR.
rxJsonDebug(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.DEBUG.
rxJsonDel(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.DEL.
rxJsonForget(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.FORGET.
rxJsonGet(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.GET.
rxJsonMget(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.MGET.
rxJsonNumincrby(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.NUMINCRBY.
rxJsonNummultby(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.NUMMULTBY.
rxJsonNumpowby(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.NUMPOWBY.
rxJsonObjkeys(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.OBJKEYS.
rxJsonObjlen(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.OBJLEN.
rxJsonResp(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.RESP.
rxJsonSet(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.SET.
rxJsonStrappend(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.STRAPPEND.
rxJsonStrlen(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.STRLEN.
rxJsonToggle(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.TOGGLE.
rxJsonType(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command JSON.TYPE.
rxJWKSet() - Method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
Retrieve the public server JSON Web Key (JWK) required to verify the authenticity of issued ID and access tokens.
rxKeys() - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
Get the keys of the map, asynchronously.
rxKeys(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Find all keys matching the given pattern.
rxLast() - Method in class io.vertx.reactivex.grpc.client.GrpcClientResponse
 
rxLast() - Method in class io.vertx.reactivex.grpc.common.GrpcReadStream
 
rxLast() - Method in class io.vertx.reactivex.grpc.server.GrpcServerRequest
 
rxLastsave() - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the UNIX time stamp of the last successful save to disk.
rxLatency(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
A container for latency diagnostics commands.
rxLcs(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Find longest common substring.
rxLeaderStatus() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Get the Raft leader for the datacenter in which the agent is running.
rxLindex(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get an element from a list by its index.
rxLink(String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
Create a hard link on the file system from link to existing, asynchronously.
rxLinsert(String, String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Insert an element before or after another element in a list.
rxListConsumerGroups() - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
Get the the consumer groups available in the cluster with the default options
rxListen() - Method in class io.vertx.reactivex.core.http.HttpServer
Tell the server to start listening.
rxListen() - Method in class io.vertx.reactivex.core.net.NetServer
Start listening on the port and host as configured in the NetServerOptions used when creating the server.
rxListen() - Method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.TcpEventBusBridge
Start listening on the port and host as configured in the NetServerOptions used when creating the server.
rxListen() - Method in class io.vertx.reactivex.ext.stomp.StompServer
Connects the STOMP server default port (61613) and network interface (0.0.0.0).
rxListen() - Method in class io.vertx.reactivex.mqtt.MqttServer
Start the server listening for incoming connections using the specified options through the constructor
rxListen(int) - Method in class io.vertx.reactivex.core.http.HttpServer
Like HttpServer.listen() but the server will listen on host "0.0.0.0" and port specified here ignoring any value in the HttpServerOptions that was used when creating the server.
rxListen(int) - Method in class io.vertx.reactivex.core.net.NetServer
Start listening on the specified port and host "0.0.0.0", ignoring port and host configured in the NetServerOptions used when creating the server.
rxListen(int) - Method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.TcpEventBusBridge
Start listening on the specified port and host "0.0.0.0", ignoring port and host configured in the NetServerOptions used when creating the server.
rxListen(int) - Method in class io.vertx.reactivex.ext.stomp.StompServer
Connects the STOMP server to the given port.
rxListen(int) - Method in class io.vertx.reactivex.mqtt.MqttServer
Start the server listening for incoming connections on the port specified but on "0.0.0.0" as host.
rxListen(int, String) - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
Start listening on the given port and host.
rxListen(int, String) - Method in class io.vertx.reactivex.core.http.HttpServer
Tell the server to start listening.
rxListen(int, String) - Method in class io.vertx.reactivex.core.net.NetServer
Start listening on the specified port and host, ignoring port and host configured in the NetServerOptions used when creating the server.
rxListen(int, String) - Method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.TcpEventBusBridge
Start listening on the specified port and host, ignoring port and host configured in the NetServerOptions used when creating the server.
rxListen(int, String) - Method in class io.vertx.reactivex.ext.stomp.StompServer
Connects the STOMP server to the given port / interface.
rxListen(int, String) - Method in class io.vertx.reactivex.mqtt.MqttServer
Start the server listening for incoming connections on the port and host specified
rxListen(SocketAddress) - Method in class io.vertx.reactivex.core.http.HttpServer
Tell the server to start listening on the given address supplying a handler that will be called when the server is actually listening (or has failed).
rxListen(SocketAddress) - Method in class io.vertx.reactivex.core.net.NetServer
Start listening on the specified local address, ignoring port and host configured in the NetServerOptions used when creating the server.
rxListen(SocketAddress) - Method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.TcpEventBusBridge
Start listening on the specified local address, ignoring port and host configured in the used when creating the server.
rxListenMulticastGroup(String) - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
Joins a multicast group and listens for packets send to it.
rxListenMulticastGroup(String, String, String) - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
Joins a multicast group and listens for packets send to it on the given network interface.
rxListEvents() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the most recent events known by the agent
rxListEventsWithOptions(EventListOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the most recent events known by the agent.
rxListIndexes(String) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Get all the indexes in this collection.
rxListNodeSessions(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the active sessions for a given node
rxListNodeSessionsWithOptions(String, BlockingQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the active sessions for a given node This is blocking query unlike ConsulClient.listNodeSessions(java.lang.String)
rxListSessions() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the active sessions
rxListSessionsWithOptions(BlockingQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns the active sessions This is blocking query unlike ConsulClient.listSessions()
rxListTopics() - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
List the topics available in the cluster with the default options.
rxLlen(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the length of a list.
rxLmove(String, String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Pop an element from a list, push it to another list and return it.
rxLmpop(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Pop elements from a list.
rxLocalChecks() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Return all the checks that are registered with the local agent.
rxLocalServices() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Returns list of services registered with the local agent.
rxLock() - Method in class io.vertx.reactivex.core.file.AsyncFile
Acquire a non-shared lock on the entire file.
rxLock(long, long, boolean) - Method in class io.vertx.reactivex.core.file.AsyncFile
Acquire a lock on a portion of this file.
rxLogout() - Method in class io.vertx.reactivex.ext.web.UserContext
Logout can be called from any route handler which needs to terminate a login session.
rxLogout(String) - Method in class io.vertx.reactivex.ext.web.UserContext
Logout can be called from any route handler which needs to terminate a login session.
rxLolwut(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Display some computer art and the Redis version.
rxLookup(String) - Method in class io.vertx.reactivex.core.dns.DnsClient
Try to lookup the A (ipv4) or AAAA (ipv6) record for the given name.
rxLookup4(String) - Method in class io.vertx.reactivex.core.dns.DnsClient
Try to lookup the A (ipv4) record for the given name.
rxLookup6(String) - Method in class io.vertx.reactivex.core.dns.DnsClient
Try to lookup the AAAA (ipv6) record for the given name.
rxLpop(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove and get the first elements in a list.
rxLpos(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Return the index of matching elements on a list.
rxLprops(String) - Method in class io.vertx.reactivex.core.file.FileSystem
Obtain properties for the link represented by path, asynchronously.
rxLpush(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Prepend one or multiple elements to a list.
rxLpushx(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Prepend an element to a list, only if the list exists.
rxLrange(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get a range of elements from a list.
rxLrem(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove elements from a list.
rxLset(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Set the value of an element in a list by its index.
rxLtrim(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Trim a list to the specified range.
rxMaintenanceService(MaintenanceOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Places a given service into "maintenance mode"
rxMemory(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
A container for memory diagnostics commands.
rxMessageCount(String) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Returns the number of messages in a queue ready to be delivered.
rxMetadata() - Method in class io.vertx.reactivex.cassandra.CassandraClient
Get for the session.
rxMget(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the values of all the given keys.
rxMigrate(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Atomically transfer a key from a Redis instance to another one.
rxMkdir(String) - Method in class io.vertx.reactivex.core.file.FileSystem
Create the directory represented by path, asynchronously.
rxMkdir(String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
Create the directory represented by path, asynchronously.
rxMkdirs(String) - Method in class io.vertx.reactivex.core.file.FileSystem
Create the directory represented by path and any non existent parents, asynchronously.
rxMkdirs(String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
Create the directory represented by path and any non existent parents, asynchronously.
rxModule(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
A container for module commands.
rxMonitor() - Method in class io.vertx.reactivex.redis.client.RedisAPI
Listen for all requests received by the server in real time.
rxMove(String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
Move a file from the path from to path to, asynchronously.
rxMove(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Move a key to another database.
rxMove(String, String, CopyOptions) - Method in class io.vertx.reactivex.core.file.FileSystem
Move a file from the path from to path to, asynchronously.
rxMset(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Set multiple keys to multiple values.
rxMsetnx(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Set multiple keys to multiple values, only if none of the keys exist.
rxMulti() - Method in class io.vertx.reactivex.redis.client.RedisAPI
Mark the start of a transaction block.
rxNack(String) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Sends a non-acknowledgement for the given message.
rxNack(String, String) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Sends a non-acknowledgement for the given frame.
rxObject(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
A container for object introspection commands.
rxOf(HttpServerRequest, Operation) - Static method in class io.vertx.reactivex.openapi.validation.ValidatableRequest
Creates a new ValidatableRequest object based on the passed and .
rxOffsetsForTimes(TopicPartition, Long) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Look up the offset for the given partition by timestamp.
rxOnAllMasterNodes(Request) - Method in class io.vertx.reactivex.redis.client.RedisCluster
Runs the request against all master nodes in the cluster.
rxOnAllNodes(Request) - Method in class io.vertx.reactivex.redis.client.RedisCluster
Runs the request against all nodes in the cluster.
rxOnAuthenticationRequest(StompServerConnection, String, String) - Method in class io.vertx.reactivex.ext.stomp.StompServerHandler
Called when the client connects to a server requiring authentication.
rxOpen(String, OpenOptions) - Method in class io.vertx.reactivex.core.file.FileSystem
Open the file represented by path, asynchronously.
rxOpenIdConnectHandler(Function<String, Single<OAuth2AuthHandler>>) - Method in class io.vertx.reactivex.ext.web.openapi.router.Security
Configure the to be used when creating the router.
rxOpenIdConnectHandler(String, Function<String, Single<OAuth2AuthHandler>>) - Method in class io.vertx.reactivex.ext.web.openapi.router.Security
Configure the to be used when creating the router.
rxOpenIdConnectHandler(String, Function<String, Future<OAuth2AuthHandler>>) - Method in class io.vertx.reactivex.ext.web.openapi.router.Security
Configure the to be used when creating the router.
rxOpenIdConnectHandler(Function<String, Future<OAuth2AuthHandler>>) - Method in class io.vertx.reactivex.ext.web.openapi.router.Security
Configure the to be used when creating the router.
rxPartitionsFor(String) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Get metadata about the partitions for a given topic.
rxPartitionsFor(String) - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
Get the partition metadata for the give topic.
rxPassCheck(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Set status of the check to "passing".
rxPassCheckWithNote(String, String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Set status of the check to "passing".
rxPause(TopicPartition) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Suspend fetching from the requested partition.
rxPause(Set<TopicPartition>) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Suspend fetching from the requested partitions.
rxPaused() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Get the set of partitions that were previously paused by a call to pause(Set).
rxPeersStatus() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Retrieves the Raft peers for the datacenter in which the the agent is running.
rxPersist(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove the expiration from a key.
rxPexpire(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Set a key's time to live in milliseconds.
rxPexpireat(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Set the expiration for a key as a UNIX timestamp specified in milliseconds.
rxPexpiretime(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the expiration Unix timestamp for a key in milliseconds.
rxPfadd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Adds the specified elements to the specified HyperLogLog.
rxPfcount(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Return the approximated cardinality of the set(s) observed by the HyperLogLog at key(s).
rxPfdebug(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Internal commands for debugging HyperLogLog values.
rxPfmerge(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Merge N different HyperLogLogs into a single one.
rxPfselftest() - Method in class io.vertx.reactivex.redis.client.RedisAPI
An internal command for testing HyperLogLog values.
rxPing() - Method in class io.vertx.reactivex.db2client.DB2Connection
Send a PING command to check if the server is alive.
rxPing() - Method in class io.vertx.reactivex.mysqlclient.MySQLConnection
Send a PING command to check if the server is alive.
rxPing(Buffer) - Method in class io.vertx.reactivex.core.http.HttpConnection
Send a frame to the remote endpoint.
rxPing(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Ping the server.
rxPipeTo(WriteStream<Row>) - Method in class io.vertx.reactivex.cassandra.CassandraRowStream
 
rxPipeTo(WriteStream<Buffer>) - Method in class io.vertx.reactivex.core.file.AsyncFile
Pipe this ReadStream to the WriteStream.
rxPipeTo(WriteStream<Buffer>) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Pipe this ReadStream to the WriteStream.
rxPipeTo(WriteStream<Buffer>) - Method in class io.vertx.reactivex.core.http.HttpClientResponse
Pipe this ReadStream to the WriteStream.
rxPipeTo(WriteStream<Buffer>) - Method in class io.vertx.reactivex.core.http.HttpServerFileUpload
Pipe this ReadStream to the WriteStream.
rxPipeTo(WriteStream<Buffer>) - Method in class io.vertx.reactivex.core.http.HttpServerRequest
Pipe this ReadStream to the WriteStream.
rxPipeTo(WriteStream<Buffer>) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Pipe this ReadStream to the WriteStream.
rxPipeTo(WriteStream<Buffer>) - Method in class io.vertx.reactivex.core.http.WebSocket
Pipe this ReadStream to the WriteStream.
rxPipeTo(WriteStream<Buffer>) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Pipe this ReadStream to the WriteStream.
rxPipeTo(WriteStream<Buffer>) - Method in class io.vertx.reactivex.core.net.NetSocket
Pipe this ReadStream to the WriteStream.
rxPipeTo(WriteStream<Buffer>) - Method in class io.vertx.reactivex.core.parsetools.RecordParser
Pipe this ReadStream to the WriteStream.
rxPipeTo(WriteStream<Buffer>) - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
Pipe this ReadStream to the WriteStream.
rxPipeTo(WriteStream<JsonEvent>) - Method in class io.vertx.reactivex.core.parsetools.JsonParser
Pipe this ReadStream to the WriteStream.
rxPipeTo(WriteStream<AmqpMessage>) - Method in class io.vertx.reactivex.amqp.AmqpReceiver
Pipe this ReadStream to the WriteStream.
rxPipeTo(WriteStream<Message<T>>) - Method in class io.vertx.reactivex.core.eventbus.MessageConsumer
Pipe this ReadStream to the WriteStream.
rxPipeTo(WriteStream<TestCaseReport>) - Method in class io.vertx.reactivex.ext.unit.report.TestSuiteReport
Pipe this ReadStream to the WriteStream.
rxPipeTo(WriteStream<KafkaConsumerRecord<K, V>>) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Pipe this ReadStream to the WriteStream.
rxPipeTo(WriteStream<RabbitMQMessage>) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQConsumer
Pipe this ReadStream to the WriteStream.
rxPipeTo(WriteStream<Response>) - Method in class io.vertx.reactivex.redis.client.RedisConnection
Pipe this ReadStream to the WriteStream.
rxPipeTo(WriteStream<String>) - Method in class io.vertx.reactivex.pgclient.pubsub.PgChannel
Pipe this ReadStream to the WriteStream.
rxPipeTo(WriteStream<Req>) - Method in class io.vertx.reactivex.grpc.server.GrpcServerRequest
Pipe this ReadStream to the WriteStream.
rxPipeTo(WriteStream<Resp>) - Method in class io.vertx.reactivex.grpc.client.GrpcClientResponse
Pipe this ReadStream to the WriteStream.
rxPipeTo(WriteStream<T>) - Method in interface io.vertx.reactivex.core.streams.ReadStream
Pipe this ReadStream to the WriteStream.
rxPipeTo(WriteStream<T>) - Method in class io.vertx.reactivex.grpc.common.GrpcReadStream
Pipe this ReadStream to the WriteStream.
rxPipeTo(WriteStream<T>) - Method in class io.vertx.reactivex.sqlclient.RowStream
Pipe this ReadStream to the WriteStream.
rxPoll(Duration) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Executes a poll for getting messages from Kafka.
rxPosition(TopicPartition) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Get the offset of the next record that will be fetched (if a record with that offset exists).
rxPrepare(SimpleStatement) - Method in class io.vertx.reactivex.cassandra.CassandraClient
Prepares the provided a .
rxPrepare(String) - Method in class io.vertx.reactivex.cassandra.CassandraClient
Prepares the provided query string.
rxPrepare(String) - Method in class io.vertx.reactivex.sqlclient.SqlConnection
Create a prepared statement using the given sql string.
rxPrepare(String, PrepareOptions) - Method in class io.vertx.reactivex.sqlclient.SqlConnection
Create a prepared statement using the given sql string.
rxProps(String) - Method in class io.vertx.reactivex.core.file.FileSystem
Obtain properties for the file represented by path, asynchronously.
rxPsetex(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Set the value and expiration in milliseconds of a key.
rxPsubscribe(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Listen for messages published to channels matching the given patterns.
rxPsync(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Internal command used for replication.
rxPttl(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the time to live for a key in milliseconds.
rxPublish(Record) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
Publishes a record.
rxPublish(Record) - Method in class io.vertx.reactivex.servicediscovery.spi.ServicePublisher
Publishes a record.
rxPublish(String, Buffer, MqttQoS, boolean, boolean) - Method in class io.vertx.reactivex.mqtt.MqttClient
Sends the PUBLISH message to the remote MQTT server
rxPublish(String, Buffer, MqttQoS, boolean, boolean) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Sends the PUBLISH message to the remote MQTT client
rxPublish(String, Buffer, MqttQoS, boolean, boolean, int) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Sends the PUBLISH message to the remote MQTT server explicitly specifying the messageId
rxPublish(String, Buffer, MqttQoS, boolean, boolean, int, MqttProperties) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Sends the PUBLISH message to the remote MQTT server explicitly specifying the messageId
rxPublish(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Post a message to a channel.
rxPublish(String, String, BasicProperties, Buffer) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQPublisher
Publish a message.
rxPublishConfirm(String, String, BasicProperties, Buffer) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQPublisher
Publish a message and complete when publish confirm has returned.
rxPubsub(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
A container for Pub/Sub commands.
rxPunsubscribe(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Stop listening for messages posted to channels matching the given patterns.
rxPush(HttpMethod, HostAndPort, String) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
rxPush(HttpMethod, HostAndPort, String, MultiMap) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Push a response to the client.
rxPush(HttpMethod, String) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
rxPush(HttpMethod, String, MultiMap) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
rxPut(Session) - Method in class io.vertx.reactivex.ext.web.sstore.SessionStore
Add a session with the specified ID.
rxPut(K, V) - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
Put a value in the map, asynchronously.
rxPut(K, V, long) - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
Like AsyncMap.put(K, V) but specifying a time to live for the entry.
rxPutIfAbsent(K, V) - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
Put the entry only if there is no entry with the key already present.
rxPutIfAbsent(K, V, long) - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
Link AsyncMap.putIfAbsent(K, V) but specifying a time to live for the entry.
rxPutValue(String, String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Adds specified key/value pair
rxPutValueWithOptions(String, String, KeyValueOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
 
rxQueryStream(Statement) - Method in class io.vertx.reactivex.cassandra.CassandraClient
Executes the given SQL statement which returns the results of the query as a read stream.
rxQueryStream(String) - Method in class io.vertx.reactivex.cassandra.CassandraClient
Executes the given SQL SELECT statement which returns the results of the query as a read stream.
rxQueueBind(String, String, String) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Bind a queue to an exchange
rxQueueBind(String, String, String, Map<String, Object>) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Bind a queue to an exchange
rxQueueDeclare(String, boolean, boolean, boolean) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Declare a queue
rxQueueDeclare(String, boolean, boolean, boolean, JsonObject) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Declare a queue with config options
rxQueueDeclareAuto() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Actively declare a server-named exclusive, autodelete, non-durable queue.
rxQueueDelete(String) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Delete a queue, without regard for whether it is in use or has messages on it
rxQueueDeleteIf(String, boolean, boolean) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Delete a queue
rxQueueUnbind(String, String, String) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Unbind a queue from an exchange
rxQueueUnbind(String, String, String, Map<String, Object>) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Unbind a queue from an exchange
rxQuit(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Close the connection.
rxRandomkey() - Method in class io.vertx.reactivex.redis.client.RedisAPI
Return a random key from the keyspace.
rxRead(int) - Method in class io.vertx.reactivex.sqlclient.Cursor
Read rows from the cursor, the result is provided asynchronously to the handler.
rxRead(Buffer, int, long, int) - Method in class io.vertx.reactivex.core.file.AsyncFile
Reads length bytes of data from the file at position position in the file, asynchronously.
rxReadAclToken(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Reads an ACL token with the given Accessor ID
rxReadDir(String) - Method in class io.vertx.reactivex.core.file.FileSystem
Read the contents of the directory specified by path, asynchronously.
rxReadDir(String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
Read the contents of the directory specified by path, asynchronously.
rxReadFile(String) - Method in class io.vertx.reactivex.core.file.FileSystem
Reads the entire file as represented by the path path as a , asynchronously.
rxReadonly() - Method in class io.vertx.reactivex.redis.client.RedisAPI
Enables read queries for a connection to a cluster replica node.
rxReadPolicy(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
This endpoint reads an ACL policy with the given ID
rxReadPolicyByName(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
This endpoint reads an ACL policy with the given name
rxReadSymlink(String) - Method in class io.vertx.reactivex.core.file.FileSystem
Returns the path representing the file that the symbolic link specified by link points to, asynchronously.
rxReadwrite() - Method in class io.vertx.reactivex.redis.client.RedisAPI
Disables read queries for a connection to a cluster replica node.
rxRedirect(String) - Method in class io.vertx.reactivex.ext.web.RoutingContext
Perform a 302 redirect to url.
rxRefresh() - Method in class io.vertx.reactivex.ext.web.UserContext
Forces the current user to re-authenticate.
rxRefresh(User) - Method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
Refresh the current User (access token).
rxRefresh(String) - Method in class io.vertx.reactivex.ext.web.UserContext
Forces the current user to re-authenticate.
rxRegisterCatalogService(Node, ServiceOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Register node with external service
rxRegisterCheck(CheckOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Add a new check to the local agent.
rxRegisterService(ServiceOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Adds a new service, with an optional health check, to the local agent.
rxRegisterServiceExporter(ServiceExporter, JsonObject) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
Registers a discovery bridge.
rxRegisterServiceImporter(ServiceImporter, JsonObject) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
Registers a discovery service importer.
rxReject() - Method in class io.vertx.reactivex.core.http.ServerWebSocketHandshake
Reject the WebSocket.
rxReject(int) - Method in class io.vertx.reactivex.core.http.ServerWebSocketHandshake
Like ServerWebSocketHandshake.reject() but with a status.
rxRelease() - Method in class io.vertx.reactivex.core.file.AsyncFileLock
Releases this lock;
rxRemove(K) - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
Remove a value from the map, asynchronously.
rxRemoveDocument(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Remove a single matching document from a collection and return the handler with MongoClientDeleteResult result
rxRemoveDocuments(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Remove matching documents from a collection and return the handler with MongoClientDeleteResult result
rxRemoveDocumentsWithOptions(String, JsonObject, WriteOption) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Remove matching documents from a collection with the specified write option and return the handler with MongoClientDeleteResult result
rxRemoveDocumentWithOptions(String, JsonObject, WriteOption) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Remove a single matching document from a collection with the specified write option and return the handler with MongoClientDeleteResult result
rxRemoveIfPresent(K, V) - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
Remove a value from the map, only if entry already exists with same value.
rxRename(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Rename a key.
rxRenameCollection(String, String) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Rename a collection
rxRenameCollectionWithOptions(String, String, RenameCollectionOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Rename a collection
rxRenamenx(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Rename a key, only if the new key does not exist.
rxRender(JsonObject, String) - Method in class io.vertx.reactivex.ext.web.common.template.TemplateEngine
Render the template.
rxRender(Map<String, Object>, String) - Method in class io.vertx.reactivex.ext.web.common.template.TemplateEngine
Render the template.
rxRenewSession(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Renews the given session.
rxReplace(K, V) - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
Replace the entry only if it is currently mapped to some value
rxReplace(K, V, long) - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
Replace the entry only if it is currently mapped to some value
rxReplaceDocuments(String, JsonObject, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Replace matching documents in the specified collection and return the handler with MongoClientUpdateResult result
rxReplaceDocumentsWithOptions(String, JsonObject, JsonObject, UpdateOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Replace matching documents in the specified collection, specifying options and return the handler with MongoClientUpdateResult result
rxReplaceIfPresent(K, V, V) - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
Replace the entry only if it is currently mapped to a specific value
rxReplaceIfPresent(K, V, V, long) - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
Replace the entry only if it is currently mapped to a specific value
rxReplconf(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
An internal command for configuring the replication stream.
rxReplicaof(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Make the server a replica of another instance, or promote it as master.
rxReplyAndRequest(Object) - Method in class io.vertx.reactivex.core.eventbus.Message
Reply to this message, specifying a replyHandler for the reply - i.e.
rxReplyAndRequest(Object, DeliveryOptions) - Method in class io.vertx.reactivex.core.eventbus.Message
Like Message.replyAndRequest(java.lang.Object) but specifying options that can be used to configure the delivery.
rxRequest() - Method in interface io.vertx.reactivex.core.http.HttpClient
Create an HTTP request to send to the server with the default host and port of the client.
rxRequest() - Method in class io.vertx.reactivex.core.http.HttpClientAgent
Create an HTTP request to send to the server with the default host and port of the client.
rxRequest() - Method in class io.vertx.reactivex.core.http.HttpClientConnection
Create an HTTP request to send to the server with the default host and port of the client.
rxRequest() - Method in class io.vertx.reactivex.grpc.client.GrpcClient
Like GrpcClient.request(io.vertx.core.net.Address) with the default remote server.
rxRequest(HttpMethod, int, String, String) - Method in interface io.vertx.reactivex.core.http.HttpClient
Create an HTTP request to send to the server at the host and port.
rxRequest(HttpMethod, int, String, String) - Method in class io.vertx.reactivex.core.http.HttpClientAgent
Create an HTTP request to send to the server at the host and port.
rxRequest(HttpMethod, int, String, String) - Method in class io.vertx.reactivex.core.http.HttpClientConnection
Create an HTTP request to send to the server at the host and port.
rxRequest(HttpMethod, String) - Method in interface io.vertx.reactivex.core.http.HttpClient
Create an HTTP request to send to the server at the default host and port.
rxRequest(HttpMethod, String) - Method in class io.vertx.reactivex.core.http.HttpClientAgent
Create an HTTP request to send to the server at the default host and port.
rxRequest(HttpMethod, String) - Method in class io.vertx.reactivex.core.http.HttpClientConnection
Create an HTTP request to send to the server at the default host and port.
rxRequest(HttpMethod, String, String) - Method in interface io.vertx.reactivex.core.http.HttpClient
Create an HTTP request to send to the server at the host and default port.
rxRequest(HttpMethod, String, String) - Method in class io.vertx.reactivex.core.http.HttpClientAgent
Create an HTTP request to send to the server at the host and default port.
rxRequest(HttpMethod, String, String) - Method in class io.vertx.reactivex.core.http.HttpClientConnection
Create an HTTP request to send to the server at the host and default port.
rxRequest(RequestOptions) - Method in interface io.vertx.reactivex.core.http.HttpClient
Create an HTTP request to send to the server.
rxRequest(RequestOptions) - Method in class io.vertx.reactivex.core.http.HttpClientAgent
Create an HTTP request to send to the server.
rxRequest(RequestOptions) - Method in class io.vertx.reactivex.core.http.HttpClientConnection
Create an HTTP request to send to the server.
rxRequest(Address) - Method in class io.vertx.reactivex.grpc.client.GrpcClient
Connect to the remote server and create a request for any hosted gRPC service.
rxRequest(Address, ServiceMethod<Resp, Req>) - Method in class io.vertx.reactivex.grpc.client.GrpcClient
Connect to the remote server and create a request for any hosted gRPC service.
rxRequest(ServiceMethod<Resp, Req>) - Method in class io.vertx.reactivex.grpc.client.GrpcClient
Like GrpcClient.request(io.vertx.core.net.Address) with the default remote server.
rxRequest(String, Object) - Method in class io.vertx.reactivex.core.eventbus.EventBus
Sends a message and specify a replyHandler that will be called if the recipient subsequently replies to the message.
rxRequest(String, Object, DeliveryOptions) - Method in class io.vertx.reactivex.core.eventbus.EventBus
Like EventBus.request(java.lang.String, java.lang.Object) but specifying options that can be used to configure the delivery.
rxReset() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Reset this stream with the error code 0.
rxReset() - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Reset this HTTP/2 stream with the error code 0.
rxReset() - Method in class io.vertx.reactivex.redis.client.RedisAPI
Reset the connection.
rxReset(long) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Reset this request:
rxReset(long) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Reset this response:
rxReset(long, Throwable) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Reset this request:
rxResetConnection() - Method in class io.vertx.reactivex.mysqlclient.MySQLConnection
Send a RESET_CONNECTION command to reset the session state.
rxResolveA(String) - Method in class io.vertx.reactivex.core.dns.DnsClient
Try to resolve all A (ipv4) records for the given name.
rxResolveAAAA(String) - Method in class io.vertx.reactivex.core.dns.DnsClient
Try to resolve all AAAA (ipv6) records for the given name.
rxResolveCNAME(String) - Method in class io.vertx.reactivex.core.dns.DnsClient
Try to resolve the CNAME record for the given name.
rxResolveEndpoint(Address) - Method in class io.vertx.reactivex.core.net.endpoint.EndpointResolver
Resolver an endpoint for the specified address
rxResolveMX(String) - Method in class io.vertx.reactivex.core.dns.DnsClient
Try to resolve the MX records for the given name.
rxResolveNS(String) - Method in class io.vertx.reactivex.core.dns.DnsClient
Try to resolve the NS records for the given name.
rxResolvePTR(String) - Method in class io.vertx.reactivex.core.dns.DnsClient
Try to resolve the PTR record for the given name.
rxResolveSRV(String) - Method in class io.vertx.reactivex.core.dns.DnsClient
Try to resolve the SRV records for the given name.
rxResolveTXT(String) - Method in class io.vertx.reactivex.core.dns.DnsClient
Try to resolve the TXT records for the given name.
rxResponse() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
 
rxResponse() - Method in class io.vertx.reactivex.grpc.client.GrpcClientRequest
 
rxRestartConnect(int) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
restart the rabbitMQ connect.
rxRestore() - Method in class io.vertx.reactivex.ext.web.UserContext
Undo a previous call to a impersonation.
rxRestore(String) - Method in class io.vertx.reactivex.ext.web.UserContext
Undo a previous call to an impersonation.
rxRestore(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Create a key using the provided serialized value, previously obtained using DUMP.
rxRestoreAsking(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
An internal command for migrating keys in a cluster.
rxResume(TopicPartition) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Resume specified partition which have been paused with pause.
rxResume(Set<TopicPartition>) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Resume specified partitions which have been paused with pause.
rxReverseLookup(String) - Method in class io.vertx.reactivex.core.dns.DnsClient
Try to do a reverse lookup of an IP address.
rxRevoke(User) - Method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
Revoke an obtained access token.
rxRevoke(User, String) - Method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
Revoke an obtained access or refresh token.
rxRole() - Method in class io.vertx.reactivex.redis.client.RedisAPI
Return the role of the instance in the context of replication.
rxRollback() - Method in class io.vertx.reactivex.sqlclient.Transaction
Rollback the transaction and release the associated resources.
rxRpop(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove and get the last elements in a list.
rxRpoplpush(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Deprecated.
rxRpush(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Append one or multiple elements to a list.
rxRpushx(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Append an element to a list, only if the list exists.
rxRunCommand(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Run an arbitrary MongoDB command.
rxSadd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Add one or more members to a set.
rxSave() - Method in class io.vertx.reactivex.redis.client.RedisAPI
Synchronously save the dataset to disk.
rxSave(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Save a document in the specified collection
rxSaveWithOptions(String, JsonObject, WriteOption) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Save a document in the specified collection with the specified write option
rxScan(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Incrementally iterate the keys space.
rxScard(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the number of members in a set.
rxScript(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
A container for Lua scripts management commands.
rxSdiff(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Subtract multiple sets.
rxSdiffstore(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Subtract multiple sets and store the resulting set in a key.
rxSeek(TopicPartition, long) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Overrides the fetch offsets that the consumer will use on the next poll.
rxSeek(TopicPartition, OffsetAndMetadata) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Overrides the fetch offsets that the consumer will use on the next poll.
rxSeekToBeginning(TopicPartition) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Seek to the first offset for each of the given partition.
rxSeekToBeginning(Set<TopicPartition>) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Seek to the first offset for each of the given partitions.
rxSeekToEnd(TopicPartition) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Seek to the last offset for each of the given partition.
rxSeekToEnd(Set<TopicPartition>) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Seek to the last offset for each of the given partitions.
rxSelect(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Change the selected database for the current connection.
rxSend() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Send the request with an empty body.
rxSend() - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Send the request with an empty body.
rxSend() - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Send a request, the handler will receive the response as an HttpResponse.
rxSend(Flowable<Buffer>) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Send the request with a stream body.
rxSend(Flowable<Buffer>) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Send the request with a stream body.
rxSend(Flowable<Req>) - Method in class io.vertx.reactivex.grpc.client.GrpcClientRequest
 
rxSend(Flowable<Resp>) - Method in class io.vertx.reactivex.grpc.server.GrpcServerResponse
 
rxSend(Buffer) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Send the request with a buffer body.
rxSend(Buffer) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Send the request with a buffer body.
rxSend(Buffer, int, String) - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
Write the given Buffer to the SocketAddress.
rxSend(ClientForm) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Like HttpClientRequest.send() but with a form.
rxSend(Frame) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Sends the given frame to the server.
rxSend(HttpServerResponse) - Method in class io.vertx.reactivex.openapi.validation.ValidatedResponse
Add all parameters from the validated response to the passed and send it.
rxSend(ReadStream<Buffer>) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Send the request with a stream body.
rxSend(ReadStream<Buffer>) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Send the request with a stream body.
rxSend(ReadStream<Req>) - Method in class io.vertx.reactivex.grpc.client.GrpcClientRequest
 
rxSend(ReadStream<Resp>) - Method in class io.vertx.reactivex.grpc.server.GrpcServerResponse
 
rxSend(KafkaProducerRecord<K, V>) - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
Asynchronously write a record to a topic
rxSend(Request) - Method in class io.vertx.reactivex.redis.client.Redis
Send the given command to the Redis server or cluster.
rxSend(Request) - Method in class io.vertx.reactivex.redis.client.RedisConnection
Send the given command to the redis server or cluster.
rxSend(String) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Send the request with a string body.
rxSend(String) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Send the request with a string body.
rxSend(String, int, String) - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
Write the given String to the SocketAddress using UTF8 encoding.
rxSend(String, Buffer) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Sends a SEND frame to the server to the given destination.
rxSend(String, String, int, String) - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
Write the given String to the SocketAddress using the given encoding.
rxSend(String, Map<String, String>, Buffer) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Sends a SEND frame to the server to the given destination.
rxSend(Map<String, String>, Buffer) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Sends a SEND frame to the server.
rxSend(Req) - Method in class io.vertx.reactivex.grpc.client.GrpcClientRequest
 
rxSend(Resp) - Method in class io.vertx.reactivex.grpc.server.GrpcServerResponse
 
rxSendBuffer(Buffer) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Like HttpRequest.send() but with an HTTP request body buffer.
rxSendFile(String) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Send the request with a stream body.
rxSendFile(String) - Method in class io.vertx.reactivex.core.net.NetSocket
Tell the operating system to stream a file as specified by filename directly from disk to the outgoing connection, bypassing userspace altogether (where supported by the underlying operating system.
rxSendFile(String, long) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Same as HttpServerResponse.sendFile(java.lang.String) using length @code{Long.MAX_VALUE} which means until the end of the file.
rxSendFile(String, long) - Method in class io.vertx.reactivex.core.net.NetSocket
Tell the operating system to stream a file as specified by filename directly from disk to the outgoing connection, bypassing userspace altogether (where supported by the underlying operating system.
rxSendFile(String, long, long) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Ask the OS to stream a file as specified by filename directly from disk to the outgoing connection, bypassing userspace altogether (where supported by the underlying operating system.
rxSendFile(String, long, long) - Method in class io.vertx.reactivex.core.net.NetSocket
Tell the operating system to stream a file as specified by filename directly from disk to the outgoing connection, bypassing userspace altogether (where supported by the underlying operating system.
rxSendForm(MultiMap) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Like HttpRequest.send() but with an HTTP request body multimap encoded as form and the content type set to application/x-www-form-urlencoded.
rxSendForm(MultiMap, String) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Like HttpRequest.send() but with an HTTP request body multimap encoded as form and the content type set to application/x-www-form-urlencoded.
rxSendHead() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Forces the head of the request to be written before HttpClientRequest.end(java.lang.String) is called on the request or any data is written to it.
rxSendJson(Object) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Like HttpRequest.send() but with an HTTP request body object encoded as json and the content type set to application/json.
rxSendJsonObject(JsonObject) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Like HttpRequest.send() but with an HTTP request body object encoded as json and the content type set to application/json.
rxSendMail(MailMessage) - Method in class io.vertx.reactivex.ext.mail.MailClient
send a single mail via MailClient
rxSendMultipartForm(MultipartForm) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Like HttpRequest.send() but with an HTTP request body multimap encoded as form and the content type set to multipart/form-data.
rxSendStream(Flowable<Buffer>) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Like HttpRequest.send() but with an HTTP request body stream.
rxSendStream(ReadStream<Buffer>) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Like HttpRequest.send() but with an HTTP request body stream.
rxSendWithAck(AmqpMessage) - Method in class io.vertx.reactivex.amqp.AmqpSender
Sends an AMQP message and waits for an acknowledgement.
rxSet(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Set the string value of a key.
rxSetbit(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Sets or clears the bit at offset in the string value stored at key.
rxSetex(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Set the value and expiration of a key.
rxSetnx(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Set the value of a key, only if the key does not exist.
rxSetOption(MySQLSetOption) - Method in class io.vertx.reactivex.mysqlclient.MySQLConnection
Send a SET_OPTION command to set options for the current connection.
rxSetrange(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Overwrite part of a string at key starting at the specified offset.
rxSetTransactionIsolation(int) - Method in class io.vertx.reactivex.jdbcclient.JDBCConnection
 
rxSetUser(RoutingContext, User) - Method in class io.vertx.reactivex.ext.web.handler.SessionHandler
Set the user for the session
rxShutdown() - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Like WebSocketBase.shutdown() with a 30 seconds timeout, the status code 1000 a null reason.
rxShutdown() - Method in interface io.vertx.reactivex.core.http.HttpClient
Shutdown with a 30 seconds timeout (shutdown(30, TimeUnit.SECONDS)).
rxShutdown() - Method in class io.vertx.reactivex.core.http.HttpClientAgent
Shutdown with a 30 seconds timeout (shutdown(30, TimeUnit.SECONDS)).
rxShutdown() - Method in class io.vertx.reactivex.core.http.HttpClientConnection
 
rxShutdown() - Method in class io.vertx.reactivex.core.http.HttpConnection
Shutdown with a 30 seconds timeout (shutdown(30, TimeUnit.SECONDS)).
rxShutdown() - Method in class io.vertx.reactivex.core.http.HttpServer
Shutdown with a 30 seconds timeout (shutdown(30, TimeUnit.SECONDS)).
rxShutdown() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Like WebSocketBase.shutdown() with a 30 seconds timeout, the status code 1000 a null reason.
rxShutdown() - Method in class io.vertx.reactivex.core.http.WebSocket
Like WebSocketBase.shutdown() with a 30 seconds timeout, the status code 1000 a null reason.
rxShutdown() - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Like WebSocketBase.shutdown() with a 30 seconds timeout, the status code 1000 a null reason.
rxShutdown() - Method in class io.vertx.reactivex.core.http.WebSocketClient
Shutdown with a 30 seconds timeout (shutdown(30, TimeUnit.SECONDS)).
rxShutdown() - Method in class io.vertx.reactivex.core.net.NetClient
Shutdown with a 30 seconds timeout (shutdown(30, TimeUnit.SECONDS)).
rxShutdown() - Method in class io.vertx.reactivex.core.net.NetServer
Shutdown with a 30 seconds timeout (shutdown(30, TimeUnit.SECONDS)).
rxShutdown(long, TimeUnit) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Calls WebSocketBase.shutdown() with the status code 1000 and a null reason.
rxShutdown(long, TimeUnit) - Method in interface io.vertx.reactivex.core.http.HttpClient
Initiate the client shutdown sequence.
rxShutdown(long, TimeUnit) - Method in class io.vertx.reactivex.core.http.HttpClientAgent
Initiate the client shutdown sequence.
rxShutdown(long, TimeUnit) - Method in class io.vertx.reactivex.core.http.HttpClientConnection
 
rxShutdown(long, TimeUnit) - Method in class io.vertx.reactivex.core.http.HttpConnection
Initiate a graceful connection shutdown, the connection is taken out of service and closed when all the inflight requests are processed, otherwise after a timeout the connection will be closed.
rxShutdown(long, TimeUnit) - Method in class io.vertx.reactivex.core.http.HttpServer
Initiate the server shutdown sequence.
rxShutdown(long, TimeUnit) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Calls WebSocketBase.shutdown() with the status code 1000 and a null reason.
rxShutdown(long, TimeUnit) - Method in class io.vertx.reactivex.core.http.WebSocket
Calls WebSocketBase.shutdown() with the status code 1000 and a null reason.
rxShutdown(long, TimeUnit) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Calls WebSocketBase.shutdown() with the status code 1000 and a null reason.
rxShutdown(long, TimeUnit) - Method in class io.vertx.reactivex.core.http.WebSocketClient
Initiate the client shutdown sequence.
rxShutdown(long, TimeUnit) - Method in class io.vertx.reactivex.core.net.NetClient
Initiate the client shutdown sequence.
rxShutdown(long, TimeUnit) - Method in class io.vertx.reactivex.core.net.NetServer
Initiate the server shutdown sequence.
rxShutdown(long, TimeUnit, short) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Calls WebSocketBase.shutdown() with a null reason.
rxShutdown(long, TimeUnit, short) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Calls WebSocketBase.shutdown() with a null reason.
rxShutdown(long, TimeUnit, short) - Method in class io.vertx.reactivex.core.http.WebSocket
Calls WebSocketBase.shutdown() with a null reason.
rxShutdown(long, TimeUnit, short) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Calls WebSocketBase.shutdown() with a null reason.
rxShutdown(long, TimeUnit, short, String) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Initiate a graceful WebSocket shutdown, the shutdown handler is notified and shall close the WebSocket, otherwise after a timeout the WebSocket will be closed.
rxShutdown(long, TimeUnit, short, String) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Initiate a graceful WebSocket shutdown, the shutdown handler is notified and shall close the WebSocket, otherwise after a timeout the WebSocket will be closed.
rxShutdown(long, TimeUnit, short, String) - Method in class io.vertx.reactivex.core.http.WebSocket
Initiate a graceful WebSocket shutdown, the shutdown handler is notified and shall close the WebSocket, otherwise after a timeout the WebSocket will be closed.
rxShutdown(long, TimeUnit, short, String) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Initiate a graceful WebSocket shutdown, the shutdown handler is notified and shall close the WebSocket, otherwise after a timeout the WebSocket will be closed.
rxShutdown(short) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Like WebSocketBase.shutdown() with a 30 seconds timeout and a null reason.
rxShutdown(short) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Like WebSocketBase.shutdown() with a 30 seconds timeout and a null reason.
rxShutdown(short) - Method in class io.vertx.reactivex.core.http.WebSocket
Like WebSocketBase.shutdown() with a 30 seconds timeout and a null reason.
rxShutdown(short) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Like WebSocketBase.shutdown() with a 30 seconds timeout and a null reason.
rxShutdown(short, String) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Like WebSocketBase.shutdown() with a 30 seconds timeout.
rxShutdown(short, String) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Like WebSocketBase.shutdown() with a 30 seconds timeout.
rxShutdown(short, String) - Method in class io.vertx.reactivex.core.http.WebSocket
Like WebSocketBase.shutdown() with a 30 seconds timeout.
rxShutdown(short, String) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Like WebSocketBase.shutdown() with a 30 seconds timeout.
rxShutdown(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Synchronously save the dataset to disk and then shut down the server.
rxSinter(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Intersect multiple sets.
rxSintercard(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Intersect multiple sets and return the cardinality of the result.
rxSinterstore(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Intersect multiple sets and store the resulting set in a key.
rxSismember(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Determine if a given value is a member of a set.
rxSize() - Method in class io.vertx.reactivex.core.file.AsyncFile
 
rxSize() - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
Provide the number of entries in the map
rxSize() - Method in class io.vertx.reactivex.ext.web.sstore.SessionStore
Get the number of sessions in the store.
rxSlaveof(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Deprecated.
rxSlowlog(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
A container for slow log commands.
rxSmembers(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get all the members in a set.
rxSmismember(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Returns the membership associated with the given elements for a set.
rxSmove(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Move a member from one set to another.
rxSort(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Sort the elements in a list, set or sorted set.
rxSortRo(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Sort the elements in a list, set or sorted set.
rxSpecifySchema(String) - Method in class io.vertx.reactivex.mysqlclient.MySQLConnection
Send a INIT_DB command to change the default schema of the connection.
rxSpop(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove and return one or multiple random members from a set.
rxSpublish(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Post a message to a shard channel.
rxSrandmember(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get one or multiple random members from a set.
rxSrem(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove one or more members from a set.
rxSscan(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Incrementally iterate Set elements.
rxSsubscribe(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Listen for messages published to the given shard channels.
rxStart() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Start the rabbitMQ client.
rxStart() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQPublisher
Start the rabbitMQ publisher.
rxStop() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Stop the rabbitMQ client.
rxStop() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQPublisher
Stop the rabbitMQ publisher.
rxStoreCredential(Authenticator) - Method in class io.vertx.reactivex.ext.auth.webauthn4j.CredentialStorage
Persists a new credential, bound by its user name (may be null) and credential ID (cannot be null, must be unique).
rxStreamToFileSystem(String) - Method in class io.vertx.reactivex.core.http.HttpServerFileUpload
Stream the content of this upload to the given file on storage.
rxStrlen(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the length of the value stored in a key.
rxSubscribe(String) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Subscribe to the given topic to get dynamically assigned partitions.
rxSubscribe(String, int) - Method in class io.vertx.reactivex.mqtt.MqttClient
Subscribes to the topic with a specified QoS level
rxSubscribe(String, Handler<Frame>) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Subscribes to the given destination.
rxSubscribe(String, Map<String, String>, Handler<Frame>) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Subscribes to the given destination.
rxSubscribe(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Listen for messages published to the given channels.
rxSubscribe(Map<String, Integer>) - Method in class io.vertx.reactivex.mqtt.MqttClient
Subscribes to the topics with related QoS levels
rxSubscribe(Pattern) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Subscribe to all topics matching specified pattern to get dynamically assigned partitions.
rxSubscribe(Set<String>) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Subscribe to the given list of topics to get dynamically assigned partitions.
rxSubscription() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Get the current subscription.
rxSubstr(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Deprecated.
rxSunion(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Add multiple sets.
rxSunionstore(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Add multiple sets and store the resulting set in a key.
rxSunsubscribe(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Stop listening for messages posted to the given shard channels.
rxSwapdb(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Swaps two Redis databases.
rxSymlink(String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
Create a symbolic link on the file system from link to existing, asynchronously.
rxSync() - Method in class io.vertx.reactivex.redis.client.RedisAPI
Internal command used for replication.
rxTdigestAdd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TDIGEST.ADD.
rxTdigestByrank(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TDIGEST.BYRANK.
rxTdigestByrevrank(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TDIGEST.BYREVRANK.
rxTdigestCdf(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TDIGEST.CDF.
rxTdigestCreate(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TDIGEST.CREATE.
rxTdigestInfo(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TDIGEST.INFO.
rxTdigestMax(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TDIGEST.MAX.
rxTdigestMerge(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TDIGEST.MERGE.
rxTdigestMin(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TDIGEST.MIN.
rxTdigestQuantile(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TDIGEST.QUANTILE.
rxTdigestRank(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TDIGEST.RANK.
rxTdigestReset(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TDIGEST.RESET.
rxTdigestRevrank(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TDIGEST.REVRANK.
rxTdigestTrimmedMean(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TDIGEST.TRIMMED_MEAN.
rxTime() - Method in class io.vertx.reactivex.redis.client.RedisAPI
Return the current server time.
rxTimeseriesClusterset(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TIMESERIES.CLUSTERSET.
rxTimeseriesClustersetfromshard(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
rxTimeseriesHello(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TIMESERIES.HELLO.
rxTimeseriesInfocluster(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TIMESERIES.INFOCLUSTER.
rxTimeseriesInnercommunication(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
rxTimeseriesNetworktest(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TIMESERIES.NETWORKTEST.
rxTimeseriesRefreshcluster(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
rxTo(WriteStream<T>) - Method in class io.vertx.reactivex.core.streams.Pipe
Start to pipe the elements to the destination WriteStream.
rxToNetSocket() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
Establish a TCP tunnel with the client.
rxTopkAdd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TOPK.ADD.
rxTopkCount(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TOPK.COUNT.
rxTopkIncrby(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TOPK.INCRBY.
rxTopkInfo(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TOPK.INFO.
rxTopkList(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TOPK.LIST.
rxTopkQuery(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TOPK.QUERY.
rxTopkReserve(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TOPK.RESERVE.
rxTouch(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Alters the last access time of a key(s).
rxToWebSocket() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
Upgrade the connection of the current request to a WebSocket.
rxTransaction(TxnRequest) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Manages multiple operations inside a single, atomic transaction.
rxTruncate(String, long) - Method in class io.vertx.reactivex.core.file.FileSystem
Truncate the file represented by path to length len in bytes, asynchronously.
rxTsAdd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TS.ADD.
rxTsAlter(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TS.ALTER.
rxTsCreate(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TS.CREATE.
rxTsCreaterule(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TS.CREATERULE.
rxTsDecrby(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TS.DECRBY.
rxTsDel(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TS.DEL.
rxTsDeleterule(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TS.DELETERULE.
rxTsGet(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TS.GET.
rxTsIncrby(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TS.INCRBY.
rxTsInfo(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TS.INFO.
rxTsMadd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TS.MADD.
rxTsMget(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TS.MGET.
rxTsMrange(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TS.MRANGE.
rxTsMrevrange(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TS.MREVRANGE.
rxTsQueryindex(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TS.QUERYINDEX.
rxTsRange(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TS.RANGE.
rxTsRevrange(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TS.REVRANGE.
rxTtl(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the time to live for a key in seconds.
rxType(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Determine the type stored at key.
rxUnlink(String) - Method in class io.vertx.reactivex.core.file.FileSystem
Unlinks the link on the file system represented by the path link, asynchronously.
rxUnlink(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Delete a key asynchronously in another thread.
rxUnlistenMulticastGroup(String) - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
Leaves a multicast group and stops listening for packets send to it.
rxUnlistenMulticastGroup(String, String, String) - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
Leaves a multicast group and stops listening for packets send to it on the given network interface.
rxUnpublish(String) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
Un-publishes a record.
rxUnpublish(String) - Method in class io.vertx.reactivex.servicediscovery.spi.ServicePublisher
Un-publishes a record.
rxUnregister() - Method in class io.vertx.reactivex.core.eventbus.MessageConsumer
Unregisters the handler which created this registration
rxUnsubscribe() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Unsubscribe from topics currently subscribed with subscribe.
rxUnsubscribe(String) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Un-subscribes from the given destination.
rxUnsubscribe(String) - Method in class io.vertx.reactivex.mqtt.MqttClient
Unsubscribe from receiving messages on given topic
rxUnsubscribe(String, Map<String, String>) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Un-subscribes from the given destination.
rxUnsubscribe(List<String>) - Method in class io.vertx.reactivex.mqtt.MqttClient
Unsubscribe from receiving messages on given list of topic
rxUnsubscribe(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Stop listening for messages posted to the given channels.
rxUnwatch() - Method in class io.vertx.reactivex.redis.client.RedisAPI
Forget about all watched keys.
rxUpdate(Record) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
Updates the given record.
rxUpdate(Record) - Method in class io.vertx.reactivex.servicediscovery.spi.ServicePublisher
Updates an existing record.
rxUpdateAclToken(String, AclToken) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Update an existing Acl token
rxUpdateCheck(String, CheckStatus) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Set status of the check to given status.
rxUpdateCheckWithNote(String, CheckStatus, String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Set status of the check to given status.
rxUpdateCollection(String, JsonObject, JsonArray) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Use an aggregation pipeline to update documents in the specified collection and return the handler with MongoClientUpdateResult result
rxUpdateCollection(String, JsonObject, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Update matching documents in the specified collection and return the handler with MongoClientUpdateResult result
rxUpdateCollectionWithOptions(String, JsonObject, JsonArray, UpdateOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Use an aggregation pipeline to update documents in the specified collection, specifying options and return the handler with MongoClientUpdateResult result
rxUpdateCollectionWithOptions(String, JsonObject, JsonObject, UpdateOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Update matching documents in the specified collection, specifying options and return the handler with MongoClientUpdateResult result
rxUpdateCounter(Authenticator) - Method in class io.vertx.reactivex.ext.auth.webauthn4j.CredentialStorage
Updates a previously stored credential counter, as identified by its user name (may be null) and credential ID (cannot be null, must be unique).
rxUpdatePolicy(String, AclPolicy) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
This endpoint updates an existing ACL policy
rxUpdatePreparedQuery(PreparedQueryDefinition) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
 
rxUpdateSettings(Http2Settings) - Method in class io.vertx.reactivex.core.http.HttpConnection
Send to the remote endpoint an update of this endpoint settings
rxUpdateSSLOptions(ClientSSLOptions) - Method in class io.vertx.reactivex.core.http.HttpClientAgent
Update the client with new SSL options, the update happens if the options object is valid and different from the existing options object.
rxUpdateSSLOptions(ClientSSLOptions) - Method in class io.vertx.reactivex.core.http.WebSocketClient
Update the client with new SSL options, the update happens if the options object is valid and different from the existing options object.
rxUpdateSSLOptions(ClientSSLOptions) - Method in class io.vertx.reactivex.core.net.NetClient
Update the client with new SSL options, the update happens if the options object is valid and different from the existing options object.
rxUpdateSSLOptions(ClientSSLOptions) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Update the client with new SSL options, the update happens if the options object is valid and different from the existing options object.
rxUpdateSSLOptions(ClientSSLOptions, boolean) - Method in class io.vertx.reactivex.core.http.HttpClientAgent
Update the client with new SSL options, the update happens if the options object is valid and different from the existing options object.
rxUpdateSSLOptions(ClientSSLOptions, boolean) - Method in class io.vertx.reactivex.core.http.WebSocketClient
Update the client with new SSL options, the update happens if the options object is valid and different from the existing options object.
rxUpdateSSLOptions(ClientSSLOptions, boolean) - Method in class io.vertx.reactivex.core.net.NetClient
Update the client with new SSL options, the update happens if the options object is valid and different from the existing options object.
rxUpdateSSLOptions(ClientSSLOptions, boolean) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Update the client with new SSL options, the update happens if the options object is valid and different from the existing options object.
rxUpdateSSLOptions(ServerSSLOptions) - Method in class io.vertx.reactivex.core.http.HttpServer
Update the server with new SSL options, the update happens if the options object is valid and different from the existing options object.
rxUpdateSSLOptions(ServerSSLOptions) - Method in class io.vertx.reactivex.core.net.NetServer
Update the server with new SSL options, the update happens if the options object is valid and different from the existing options object.
rxUpdateSSLOptions(ServerSSLOptions, boolean) - Method in class io.vertx.reactivex.core.http.HttpServer
Update the server with new SSL options, the update happens if the options object is valid and different from the existing options object.
rxUpdateSSLOptions(ServerSSLOptions, boolean) - Method in class io.vertx.reactivex.core.net.NetServer
Update the server with new SSL options, the update happens if the options object is valid and different from the existing options object.
rxUpdateTrafficShapingOptions(TrafficShapingOptions) - Method in class io.vertx.reactivex.core.http.HttpServer
Update the server with new traffic options, the update happens if the options object is valid and different from the existing options object.
rxUpdateTrafficShapingOptions(TrafficShapingOptions) - Method in class io.vertx.reactivex.core.net.NetServer
Update the server with new traffic options, the update happens if the options object is valid and different from the existing options object.
rxUpgradeToSsl() - Method in class io.vertx.reactivex.core.net.NetSocket
Like NetSocket.upgradeToSsl() with the default SSL options, without indicating a server name, without an upgrade message.
rxUpgradeToSsl(Buffer) - Method in class io.vertx.reactivex.core.net.NetSocket
Like NetSocket.upgradeToSsl() with the default SSL options and without indicating a server name.
rxUpgradeToSsl(SSLOptions) - Method in class io.vertx.reactivex.core.net.NetSocket
Upgrade channel to use SSL/TLS.
rxUpgradeToSsl(SSLOptions, Buffer) - Method in class io.vertx.reactivex.core.net.NetSocket
Like NetSocket.upgradeToSsl() without indicating a server name
rxUpgradeToSsl(SSLOptions, String) - Method in class io.vertx.reactivex.core.net.NetSocket
Like NetSocket.upgradeToSsl() without an upgrade message.
rxUpgradeToSsl(SSLOptions, String, Buffer) - Method in class io.vertx.reactivex.core.net.NetSocket
Upgrade the channel to use SSL/TLS, in other words proceeds to the TLS handshake.
rxUpgradeToSsl(String) - Method in class io.vertx.reactivex.core.net.NetSocket
Like NetSocket.upgradeToSsl() with the default SSL options and without an update message.
rxUpgradeToSsl(String, Buffer) - Method in class io.vertx.reactivex.core.net.NetSocket
Like NetSocket.upgradeToSsl() with the default SSL options.
rxUploadByFileName(Flowable<Buffer>, String) - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
 
rxUploadByFileName(ReadStream<Buffer>, String) - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
 
rxUploadByFileNameWithOptions(Flowable<Buffer>, String, GridFsUploadOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
 
rxUploadByFileNameWithOptions(ReadStream<Buffer>, String, GridFsUploadOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
 
rxUploadFile(String) - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
Upload a file to gridfs
rxUploadFileWithOptions(String, GridFsUploadOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
Upload a file to gridfs with options
rxUserInfo(User) - Method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
Retrieve profile information and other attributes for a logged-in end-user.
rxValidate(HttpServerRequest) - Method in class io.vertx.reactivex.openapi.validation.RequestValidator
Like RequestValidator.validate(io.vertx.reactivex.core.http.HttpServerRequest), but the operationId and ValidatableRequest are determined from the passed request.
rxValidate(HttpServerRequest, String) - Method in class io.vertx.reactivex.openapi.validation.RequestValidator
rxValidate(ValidatableRequest, String) - Method in class io.vertx.reactivex.openapi.validation.RequestValidator
Validates the passed request parameters against the operation defined in the related OpenAPI contract.
rxValues() - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
Get the values of the map, asynchronously.
rxWait(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Wait for the synchronous replication of all the write commands sent in the context of the current connection.
rxWaitForConfirms() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Wait until all messages published since the last call have been either ack'd or nack'd by the broker.
rxWaitForConfirms(long) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Wait until all messages published since the last call have been either ack'd or nack'd by the broker; or until timeout elapses.
rxWarnCheck(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Set status of the check to "warning".
rxWarnCheckWithNote(String, String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Set status of the check to "warning".
rxWatch(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Watch the given keys to determine execution of the MULTI/EXEC block.
rxWithConnection(Function<SqlConnection, Maybe<T>>) - Method in class io.vertx.reactivex.sqlclient.Pool
Get a connection from the pool and execute the given function.
rxWithConnection(Function<SqlConnection, Future<T>>) - Method in class io.vertx.reactivex.sqlclient.Pool
Get a connection from the pool and execute the given function.
rxWithLocalLock(String, long, Supplier<Future<T>>) - Method in class io.vertx.reactivex.core.shareddata.SharedData
rxWithLocalLock(String, Supplier<Future<T>>) - Method in class io.vertx.reactivex.core.shareddata.SharedData
Get an asynchronous local lock with the specified name.
rxWithLock(long, long, boolean, Supplier<Future<T>>) - Method in class io.vertx.reactivex.core.file.AsyncFile
Acquire a lock on a portion of this file.
rxWithLock(String, long, Supplier<Future<T>>) - Method in class io.vertx.reactivex.core.shareddata.SharedData
rxWithLock(String, Supplier<Future<T>>) - Method in class io.vertx.reactivex.core.shareddata.SharedData
Get an asynchronous lock with the specified name.
rxWithLock(Supplier<Future<T>>) - Method in class io.vertx.reactivex.core.file.AsyncFile
Acquire a non-shared lock on the entire file.
rxWithTransaction(Function<SqlConnection, Maybe<T>>) - Method in class io.vertx.reactivex.sqlclient.Pool
Execute the given function within a transaction.
rxWithTransaction(TransactionPropagation, Function<SqlConnection, Maybe<T>>) - Method in class io.vertx.reactivex.sqlclient.Pool
Like Pool.withTransaction(java.util.function.Function<io.vertx.reactivex.sqlclient.SqlConnection, io.vertx.core.Future<T>>) but allows for setting the mode, defining how the acquired connection is managed during the execution of the function.
rxWithTransaction(TransactionPropagation, Function<SqlConnection, Future<T>>) - Method in class io.vertx.reactivex.sqlclient.Pool
Like Pool.withTransaction(java.util.function.Function<io.vertx.reactivex.sqlclient.SqlConnection, io.vertx.core.Future<T>>) but allows for setting the mode, defining how the acquired connection is managed during the execution of the function.
rxWithTransaction(Function<SqlConnection, Future<T>>) - Method in class io.vertx.reactivex.sqlclient.Pool
Execute the given function within a transaction.
rxWrite(Buffer) - Method in class io.vertx.reactivex.core.file.AsyncFile
Write some data to the stream.
rxWrite(Buffer) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Write some data to the stream.
rxWrite(Buffer) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Write some data to the stream.
rxWrite(Buffer) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Write some data to the stream.
rxWrite(Buffer) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Write some data to the stream.
rxWrite(Buffer) - Method in class io.vertx.reactivex.core.http.WebSocket
Write some data to the stream.
rxWrite(Buffer) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Write some data to the stream.
rxWrite(Buffer) - Method in class io.vertx.reactivex.core.net.NetSocket
Write some data to the stream.
rxWrite(Buffer) - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
 
rxWrite(Buffer, long) - Method in class io.vertx.reactivex.core.file.AsyncFile
Write a Buffer to the file at position position in the file, asynchronously.
rxWrite(AmqpMessage) - Method in class io.vertx.reactivex.amqp.AmqpSender
Write some data to the stream.
rxWrite(KafkaProducerRecord<K, V>) - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
Write some data to the stream.
rxWrite(String) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Write a String to the request body, encoded as UTF-8.
rxWrite(String) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Write a String to the response body, encoded in UTF-8.
rxWrite(String) - Method in class io.vertx.reactivex.core.net.NetSocket
Write a String to the connection, encoded in UTF-8.
rxWrite(String) - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
Write a String to the socket, encoded in UTF-8.
rxWrite(String, String) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Write a String to the request body, encoded using the encoding enc.
rxWrite(String, String) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Write a String to the response body, encoded using the encoding enc.
rxWrite(String, String) - Method in class io.vertx.reactivex.core.net.NetSocket
Write a String to the connection, encoded using the encoding enc.
rxWrite(Req) - Method in class io.vertx.reactivex.grpc.client.GrpcClientRequest
Write some data to the stream.
rxWrite(Resp) - Method in class io.vertx.reactivex.grpc.server.GrpcServerResponse
Write some data to the stream.
rxWrite(T) - Method in class io.vertx.reactivex.core.eventbus.MessageProducer
Write a message to the event-bus, either sending or publishing.
rxWrite(T) - Method in interface io.vertx.reactivex.core.streams.WriteStream
Write some data to the stream.
rxWrite(T) - Method in class io.vertx.reactivex.grpc.common.GrpcWriteStream
Write some data to the stream.
rxWriteBinaryMessage(Buffer) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Writes a (potentially large) piece of binary data to the connection.
rxWriteBinaryMessage(Buffer) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Writes a (potentially large) piece of binary data to the connection.
rxWriteBinaryMessage(Buffer) - Method in class io.vertx.reactivex.core.http.WebSocket
Writes a (potentially large) piece of binary data to the connection.
rxWriteBinaryMessage(Buffer) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Writes a (potentially large) piece of binary data to the connection.
rxWriteContinue() - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Used to write an interim 100 Continue response to signify that the client should send the rest of the request.
rxWriteCustomFrame(int, int, Buffer) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Write an HTTP/2 frame to the request, allowing to extend the HTTP/2 protocol.
rxWriteCustomFrame(int, int, Buffer) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Write an HTTP/2 frame to the response, allowing to extend the HTTP/2 protocol.
rxWriteCustomFrame(HttpFrame) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
rxWriteCustomFrame(HttpFrame) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
rxWriteEarlyHints(MultiMap) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Used to write an interim 103 Early Hints response to return some HTTP headers before the final HTTP message.
rxWriteFile(String, Buffer) - Method in class io.vertx.reactivex.core.file.FileSystem
Creates the file, and writes the specified Buffer data to the file represented by the path path, asynchronously.
rxWriteFinalBinaryFrame(Buffer) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Write a final WebSocket binary frame to the connection
rxWriteFinalBinaryFrame(Buffer) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Write a final WebSocket binary frame to the connection
rxWriteFinalBinaryFrame(Buffer) - Method in class io.vertx.reactivex.core.http.WebSocket
Write a final WebSocket binary frame to the connection
rxWriteFinalBinaryFrame(Buffer) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Write a final WebSocket binary frame to the connection
rxWriteFinalTextFrame(String) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Write a final WebSocket text frame to the connection
rxWriteFinalTextFrame(String) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Write a final WebSocket text frame to the connection
rxWriteFinalTextFrame(String) - Method in class io.vertx.reactivex.core.http.WebSocket
Write a final WebSocket text frame to the connection
rxWriteFinalTextFrame(String) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Write a final WebSocket text frame to the connection
rxWriteFrame(WebSocketFrame) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Write a WebSocket frame to the connection
rxWriteFrame(WebSocketFrame) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Write a WebSocket frame to the connection
rxWriteFrame(WebSocketFrame) - Method in class io.vertx.reactivex.core.http.WebSocket
Write a WebSocket frame to the connection
rxWriteFrame(WebSocketFrame) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Write a WebSocket frame to the connection
rxWriteMessage(GrpcMessage) - Method in class io.vertx.reactivex.grpc.common.GrpcWriteStream
Write an encoded gRPC message.
rxWritePing(Buffer) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Writes a ping frame to the connection.
rxWritePing(Buffer) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Writes a ping frame to the connection.
rxWritePing(Buffer) - Method in class io.vertx.reactivex.core.http.WebSocket
Writes a ping frame to the connection.
rxWritePing(Buffer) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Writes a ping frame to the connection.
rxWritePong(Buffer) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Writes a pong frame to the connection.
rxWritePong(Buffer) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Writes a pong frame to the connection.
rxWritePong(Buffer) - Method in class io.vertx.reactivex.core.http.WebSocket
Writes a pong frame to the connection.
rxWritePong(Buffer) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Writes a pong frame to the connection.
rxWriteTextMessage(String) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Writes a (potentially large) piece of text data to the connection.
rxWriteTextMessage(String) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Writes a (potentially large) piece of text data to the connection.
rxWriteTextMessage(String) - Method in class io.vertx.reactivex.core.http.WebSocket
Writes a (potentially large) piece of text data to the connection.
rxWriteTextMessage(String) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Writes a (potentially large) piece of text data to the connection.
rxXack(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Marks a pending message as correctly processed, effectively removing it from the pending entries list of the consumer group.
rxXadd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Appends a new entry to a stream.
rxXautoclaim(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Changes (or acquires) ownership of messages in a consumer group, as if the messages were delivered to the specified consumer.
rxXclaim(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Changes (or acquires) ownership of a message in a consumer group, as if the message was delivered to the specified consumer.
rxXdel(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Removes the specified entries from the stream.
rxXgroup(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
A container for consumer groups commands.
rxXinfo(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
A container for stream introspection commands.
rxXlen(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Return the number of entries in a stream.
rxXpending(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Return information and entries from a stream consumer group pending entries list, that are messages fetched but never acknowledged.
rxXrange(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Return a range of elements in a stream, with IDs matching the specified IDs interval.
rxXread(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Return never seen elements in multiple streams, with IDs greater than the ones reported by the caller for each stream.
rxXreadgroup(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Return new entries from a stream using a consumer group, or access the history of the pending entries for a given consumer.
rxXrevrange(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Return a range of elements in a stream, with IDs matching the specified IDs interval, in reverse order (from greater to smaller IDs) compared to XRANGE.
rxXsetid(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
An internal command for replicating stream values.
rxXtrim(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Trims the stream to (approximately if '~' is passed) a certain size.
rxZadd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Add one or more members to a sorted set, or update its score if it already exists.
rxZcard(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the number of members in a sorted set.
rxZcount(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Count the members in a sorted set with scores within the given values.
rxZdiff(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Subtract multiple sorted sets.
rxZdiffstore(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Subtract multiple sorted sets and store the resulting sorted set in a new key.
rxZincrby(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Increment the score of a member in a sorted set.
rxZinter(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Intersect multiple sorted sets.
rxZintercard(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Intersect multiple sorted sets and return the cardinality of the result.
rxZinterstore(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Intersect multiple sorted sets and store the resulting sorted set in a new key.
rxZlexcount(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Count the number of members in a sorted set between a given lexicographical range.
rxZmpop(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove and return members with scores in a sorted set.
rxZmscore(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the score associated with the given members in a sorted set.
rxZpopmax(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove and return members with the highest scores in a sorted set.
rxZpopmin(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove and return members with the lowest scores in a sorted set.
rxZrandmember(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get one or multiple random elements from a sorted set.
rxZrange(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Return a range of members in a sorted set.
rxZrangebylex(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Deprecated.
rxZrangebyscore(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Deprecated.
rxZrangestore(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Store a range of members from sorted set into another key.
rxZrank(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Determine the index of a member in a sorted set.
rxZrem(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove one or more members from a sorted set.
rxZremrangebylex(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove all members in a sorted set between the given lexicographical range.
rxZremrangebyrank(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove all members in a sorted set within the given indexes.
rxZremrangebyscore(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove all members in a sorted set within the given scores.
rxZrevrange(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Deprecated.
rxZrevrangebylex(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Deprecated.
rxZrevrangebyscore(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Deprecated.
rxZrevrank(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Determine the index of a member in a sorted set, with scores ordered from high to low.
rxZscan(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Incrementally iterate sorted sets elements and associated scores.
rxZscore(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the score associated with the given member in a sorted set.
rxZunion(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Add multiple sorted sets.
rxZunionstore(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Add multiple sorted sets and store the resulting sorted set in a new key.

S

sadd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Add one or more members to a set.
SalesforceAuth - Class in io.vertx.reactivex.ext.auth.oauth2.providers
Simplified factory to create an for Salesforce.
SalesforceAuth(SalesforceAuth) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.SalesforceAuth
 
SalesforceAuth(Object) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.SalesforceAuth
 
SAMEORIGIN - Static variable in class io.vertx.reactivex.ext.web.handler.XFrameHandler
The page can only be displayed in a frame on the same origin as the page itself.
save() - Method in class io.vertx.reactivex.redis.client.RedisAPI
Synchronously save the dataset to disk.
save(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Save a document in the specified collection
saveWithOptions(String, JsonObject, WriteOption) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Save a document in the specified collection with the specified write option
scan(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Incrementally iterate the keys space.
scard(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the number of members in a set.
SchemaRepository - Class in io.vertx.reactivex.json.schema
A repository is a holder of dereferenced schemas, it can be used to create validator instances for a specific schema.
SchemaRepository(SchemaRepository) - Constructor for class io.vertx.reactivex.json.schema.SchemaRepository
 
SchemaRepository(Object) - Constructor for class io.vertx.reactivex.json.schema.SchemaRepository
 
scheme() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
 
scheme() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
 
scheme() - Method in class io.vertx.reactivex.core.http.ServerWebSocketHandshake
 
ScopeAuthorization - Class in io.vertx.reactivex.ext.auth.oauth2.authorization
Scope is a mechanism in OAuth 2.0 to limit an application's access to a user's account.
ScopeAuthorization(ScopeAuthorization) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.authorization.ScopeAuthorization
 
ScopeAuthorization(Object) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.authorization.ScopeAuthorization
 
scopeDelimiter(String) - Method in class io.vertx.reactivex.ext.web.handler.JWTAuthHandler
Set the scope delimiter.
script(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
A container for Lua scripts management commands.
sdiff(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Subtract multiple sets.
sdiffstore(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Subtract multiple sets and store the resulting set in a key.
secretKey() - Method in class io.vertx.reactivex.pgclient.PgConnection
 
security(String) - Method in class io.vertx.reactivex.ext.web.openapi.router.RouterBuilder
Creates a new security scheme for the required .
Security - Class in io.vertx.reactivex.ext.web.openapi.router
An authentication handler factory.
Security(Security) - Constructor for class io.vertx.reactivex.ext.web.openapi.router.Security
 
Security(Object) - Constructor for class io.vertx.reactivex.ext.web.openapi.router.Security
 
SecurityAudit - Class in io.vertx.reactivex.ext.auth.audit
 
SecurityAudit(SecurityAudit) - Constructor for class io.vertx.reactivex.ext.auth.audit.SecurityAudit
 
SecurityAudit(Object) - Constructor for class io.vertx.reactivex.ext.auth.audit.SecurityAudit
 
SecurityAuditLoggerHandler - Class in io.vertx.reactivex.ext.web.handler
A handler that logs security audit events.
SecurityAuditLoggerHandler(SecurityAuditLoggerHandler) - Constructor for class io.vertx.reactivex.ext.web.handler.SecurityAuditLoggerHandler
 
SecurityAuditLoggerHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.SecurityAuditLoggerHandler
 
SecurityPolicyHandler - Interface in io.vertx.reactivex.ext.web.handler
Base security policy interface for handlers that provide HTTP security related headers.
SecurityRequirement - Class in io.vertx.reactivex.openapi.contract
A Security requirement is an object that contains the names of the security schemes that apply to the operation.
SecurityRequirement(SecurityRequirement) - Constructor for class io.vertx.reactivex.openapi.contract.SecurityRequirement
 
SecurityRequirement(Object) - Constructor for class io.vertx.reactivex.openapi.contract.SecurityRequirement
 
securityScheme(String) - Method in class io.vertx.reactivex.openapi.contract.OpenAPIContract
Gets the related SecurityScheme object based on the passed name.
SecurityScheme - Class in io.vertx.reactivex.openapi.contract
Represents a Security Scheme Object.
SecurityScheme(SecurityScheme) - Constructor for class io.vertx.reactivex.openapi.contract.SecurityScheme
 
SecurityScheme(Object) - Constructor for class io.vertx.reactivex.openapi.contract.SecurityScheme
 
seek(TopicPartition, long) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Overrides the fetch offsets that the consumer will use on the next poll.
seek(TopicPartition, OffsetAndMetadata) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Overrides the fetch offsets that the consumer will use on the next poll.
seekToBeginning(TopicPartition) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Seek to the first offset for each of the given partition.
seekToBeginning(Set<TopicPartition>) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Seek to the first offset for each of the given partitions.
seekToEnd(TopicPartition) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Seek to the last offset for each of the given partition.
seekToEnd(Set<TopicPartition>) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Seek to the last offset for each of the given partitions.
select(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Change the selected database for the current connection.
selectServer() - Method in class io.vertx.reactivex.core.net.endpoint.Endpoint
Select a server.
selectServer(String) - Method in class io.vertx.reactivex.core.net.endpoint.Endpoint
Select a node, using a routing key
send() - Method in class io.vertx.reactivex.core.eventbus.DeliveryContext
 
send() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Send the request with an empty body.
send() - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Send the request with an empty body.
send() - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Send a request, the handler will receive the response as an HttpResponse.
send(Flowable<Buffer>) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Send the request with a stream body.
send(Flowable<Buffer>) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Send the request with a stream body.
send(Flowable<Req>) - Method in class io.vertx.reactivex.grpc.client.GrpcClientRequest
 
send(Flowable<Resp>) - Method in class io.vertx.reactivex.grpc.server.GrpcServerResponse
 
send(Buffer) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Send the request with a buffer body.
send(Buffer) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Send the request with a buffer body.
send(Buffer, int, String) - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
Write the given Buffer to the SocketAddress.
send(ClientForm) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Like HttpClientRequest.send() but with a form.
send(Frame) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Sends the given frame to the server.
send(AmqpMessage) - Method in class io.vertx.reactivex.amqp.AmqpSender
Sends an AMQP message.
send(HttpServerResponse) - Method in class io.vertx.reactivex.openapi.validation.ValidatedResponse
Add all parameters from the validated response to the passed and send it.
send(ReadStream<Buffer>) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Send the request with a stream body.
send(ReadStream<Buffer>) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Send the request with a stream body.
send(ReadStream<Req>) - Method in class io.vertx.reactivex.grpc.client.GrpcClientRequest
 
send(ReadStream<Resp>) - Method in class io.vertx.reactivex.grpc.server.GrpcServerResponse
 
send(KafkaProducerRecord<K, V>) - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
Asynchronously write a record to a topic
send(Request) - Method in class io.vertx.reactivex.redis.client.Redis
Send the given command to the Redis server or cluster.
send(Request) - Method in class io.vertx.reactivex.redis.client.RedisConnection
Send the given command to the redis server or cluster.
send(String) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Send the request with a string body.
send(String) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Send the request with a string body.
send(String, int, String) - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
Write the given String to the SocketAddress using UTF8 encoding.
send(String, Buffer) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Sends a SEND frame to the server to the given destination.
send(String, Object) - Method in class io.vertx.reactivex.core.eventbus.EventBus
Sends a message.
send(String, Object, DeliveryOptions) - Method in class io.vertx.reactivex.core.eventbus.EventBus
Like EventBus.send(java.lang.String, java.lang.Object) but specifying options that can be used to configure the delivery.
send(String, String, int, String) - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
Write the given String to the SocketAddress using the given encoding.
send(String, Map<String, String>, Buffer) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Sends a SEND frame to the server to the given destination.
send(Map<String, String>, Buffer) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Sends a SEND frame to the server.
send(Req) - Method in class io.vertx.reactivex.grpc.client.GrpcClientRequest
 
send(Resp) - Method in class io.vertx.reactivex.grpc.server.GrpcServerResponse
 
sendBuffer(Buffer) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Like HttpRequest.send() but with an HTTP request body buffer.
sender(int, String) - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
Returns a WriteStream able to send to the SocketAddress.
sender(String) - Method in class io.vertx.reactivex.core.eventbus.EventBus
Create a message sender against the specified address.
sender(String, DeliveryOptions) - Method in class io.vertx.reactivex.core.eventbus.EventBus
Like EventBus.sender(java.lang.String) but specifying delivery options that will be used for configuring the delivery of the message.
sendFile(String) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Send the request with a stream body.
sendFile(String) - Method in class io.vertx.reactivex.core.net.NetSocket
Tell the operating system to stream a file as specified by filename directly from disk to the outgoing connection, bypassing userspace altogether (where supported by the underlying operating system.
sendFile(String, long) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Same as HttpServerResponse.sendFile(java.lang.String) using length @code{Long.MAX_VALUE} which means until the end of the file.
sendFile(String, long) - Method in class io.vertx.reactivex.core.net.NetSocket
Tell the operating system to stream a file as specified by filename directly from disk to the outgoing connection, bypassing userspace altogether (where supported by the underlying operating system.
sendFile(String, long, long) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Ask the OS to stream a file as specified by filename directly from disk to the outgoing connection, bypassing userspace altogether (where supported by the underlying operating system.
sendFile(String, long, long) - Method in class io.vertx.reactivex.core.net.NetSocket
Tell the operating system to stream a file as specified by filename directly from disk to the outgoing connection, bypassing userspace altogether (where supported by the underlying operating system.
sendForm(MultiMap) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Like HttpRequest.send() but with an HTTP request body multimap encoded as form and the content type set to application/x-www-form-urlencoded.
sendForm(MultiMap, String) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Like HttpRequest.send() but with an HTTP request body multimap encoded as form and the content type set to application/x-www-form-urlencoded.
sendHandler(Handler<ServerFrame>) - Method in class io.vertx.reactivex.ext.stomp.StompServerHandler
Configures the action to execute when a SEND frame is received.
sendHead() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Forces the head of the request to be written before HttpClientRequest.end(java.lang.String) is called on the request or any data is written to it.
sendJson(Object) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Like HttpRequest.send() but with an HTTP request body object encoded as json and the content type set to application/json.
sendJsonObject(JsonObject) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Like HttpRequest.send() but with an HTTP request body object encoded as json and the content type set to application/json.
sendMail(MailMessage) - Method in class io.vertx.reactivex.ext.mail.MailClient
send a single mail via MailClient
sendMultipartForm(MultipartForm) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Like HttpRequest.send() but with an HTTP request body multimap encoded as form and the content type set to multipart/form-data.
sendStream(Flowable<Buffer>) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Like HttpRequest.send() but with an HTTP request body stream.
sendStream(ReadStream<Buffer>) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Like HttpRequest.send() but with an HTTP request body stream.
sendWithAck(AmqpMessage) - Method in class io.vertx.reactivex.amqp.AmqpSender
Sends an AMQP message and waits for an acknowledgement.
separator() - Method in class io.vertx.reactivex.ext.auth.oauth2.authorization.ScopeAuthorization
Returns the configured separator.
serializableChecker(Function<String, Boolean>) - Method in class io.vertx.reactivex.core.eventbus.EventBus
Register a predicate to invoke when verifying if an object is allowed to be encoded/decoded as Serializable.
serializedParam(String, ArrayParserFactory, ArraySchemaBuilder) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Parameters
Creates a required array parameter deserializable using the provided parser factory.
serializedParam(String, ObjectParserFactory, ObjectSchemaBuilder) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Parameters
Creates a required object parameter deserializable using the provided parser factory.
serializedParam(String, TupleParserFactory, TupleSchemaBuilder) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Parameters
Creates a required tuple parameter deserializable using the provided parser factory.
server() - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
 
server() - Method in class io.vertx.reactivex.ext.stomp.StompServerConnection
 
server(Vertx) - Static method in class io.vertx.reactivex.grpc.server.GrpcServer
Create a blank gRPC server with default options.
server(Vertx, GrpcServerOptions) - Static method in class io.vertx.reactivex.grpc.server.GrpcServer
Create a blank gRPC server with specified options.
Server - Class in io.vertx.reactivex.openapi.contract
This interface represents the most important attributes of an OpenAPI Server.
Server(Server) - Constructor for class io.vertx.reactivex.openapi.contract.Server
 
Server(Object) - Constructor for class io.vertx.reactivex.openapi.contract.Server
 
SERVER - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Server header name
ServerEndpoint - Class in io.vertx.reactivex.core.net.endpoint
A physical server of an endpoint.
ServerEndpoint(ServerEndpoint) - Constructor for class io.vertx.reactivex.core.net.endpoint.ServerEndpoint
 
ServerEndpoint(Object) - Constructor for class io.vertx.reactivex.core.net.endpoint.ServerEndpoint
 
ServerFrame - Class in io.vertx.reactivex.ext.stomp
Structure passed to server handler when receiving a frame.
ServerFrame(ServerFrame) - Constructor for class io.vertx.reactivex.ext.stomp.ServerFrame
 
ServerFrame(Object) - Constructor for class io.vertx.reactivex.ext.stomp.ServerFrame
 
ServerInteraction - Class in io.vertx.reactivex.core.net.endpoint
Request interaction with an endpoint, mostly callbacks to gather statistics.
ServerInteraction(ServerInteraction) - Constructor for class io.vertx.reactivex.core.net.endpoint.ServerInteraction
 
ServerInteraction(Object) - Constructor for class io.vertx.reactivex.core.net.endpoint.ServerInteraction
 
servers() - Method in class io.vertx.reactivex.core.net.endpoint.Endpoint
The servers capable of serving requests for this endpoint.
ServerWebSocket - Class in io.vertx.reactivex.core.http
Represents a server side WebSocket.
ServerWebSocket(ServerWebSocket) - Constructor for class io.vertx.reactivex.core.http.ServerWebSocket
 
ServerWebSocket(Object) - Constructor for class io.vertx.reactivex.core.http.ServerWebSocket
 
ServerWebSocketHandshake - Class in io.vertx.reactivex.core.http
A server WebSocket handshake, allows to control acceptance or rejection of a WebSocket.
ServerWebSocketHandshake(ServerWebSocketHandshake) - Constructor for class io.vertx.reactivex.core.http.ServerWebSocketHandshake
 
ServerWebSocketHandshake(Object) - Constructor for class io.vertx.reactivex.core.http.ServerWebSocketHandshake
 
service(String, Vertx) - Static method in class io.vertx.reactivex.ext.consul.Watch
Creates Watch to monitoring the nodes providing the service.
service(String, Vertx, ConsulClientOptions) - Static method in class io.vertx.reactivex.ext.consul.Watch
Creates Watch to monitoring the nodes providing the service.
ServiceDiscovery - Class in io.vertx.reactivex.servicediscovery
Service Discovery main entry point.
ServiceDiscovery(ServiceDiscovery) - Constructor for class io.vertx.reactivex.servicediscovery.ServiceDiscovery
 
ServiceDiscovery(Object) - Constructor for class io.vertx.reactivex.servicediscovery.ServiceDiscovery
 
ServiceExporter - Class in io.vertx.reactivex.servicediscovery.spi
The service exporter allows integrate other discovery technologies with the Vert.x service discovery.
ServiceExporter(ServiceExporter) - Constructor for class io.vertx.reactivex.servicediscovery.spi.ServiceExporter
 
ServiceExporter(Object) - Constructor for class io.vertx.reactivex.servicediscovery.spi.ServiceExporter
 
serviceHealthChecks(String, CheckQueryOptions, Vertx, ConsulClientOptions) - Static method in class io.vertx.reactivex.ext.consul.Watch
Creates Watch to monitoring the health checks of the nodes.
ServiceImporter - Class in io.vertx.reactivex.servicediscovery.spi
The service importer allows integrate other discovery technologies with the Vert.x service discovery.
ServiceImporter(ServiceImporter) - Constructor for class io.vertx.reactivex.servicediscovery.spi.ServiceImporter
 
ServiceImporter(Object) - Constructor for class io.vertx.reactivex.servicediscovery.spi.ServiceImporter
 
serviceName() - Method in class io.vertx.reactivex.grpc.server.GrpcServerRequest
 
serviceName(ServiceName) - Method in class io.vertx.reactivex.grpc.client.GrpcClientRequest
Set the service name to call.
ServicePublisher - Class in io.vertx.reactivex.servicediscovery.spi
The publisher is used by the importer to publish or unpublish records.
ServicePublisher(ServicePublisher) - Constructor for class io.vertx.reactivex.servicediscovery.spi.ServicePublisher
 
ServicePublisher(Object) - Constructor for class io.vertx.reactivex.servicediscovery.spi.ServicePublisher
 
ServiceReference - Class in io.vertx.reactivex.servicediscovery
Once a consumer has chosen a service, it builds a ServiceReference managing the binding with the chosen service provider.
ServiceReference(ServiceReference) - Constructor for class io.vertx.reactivex.servicediscovery.ServiceReference
 
ServiceReference(Object) - Constructor for class io.vertx.reactivex.servicediscovery.ServiceReference
 
services() - Method in class io.vertx.reactivex.grpc.server.GrpcServer
Get a list of all services registered with this gRPC server.
services(Vertx) - Static method in class io.vertx.reactivex.ext.consul.Watch
Creates Watch to monitoring the list of available services.
services(Vertx, ConsulClientOptions) - Static method in class io.vertx.reactivex.ext.consul.Watch
Creates Watch to monitoring the list of available services.
session() - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
 
session() - Method in class io.vertx.reactivex.ext.stomp.StompServerConnection
 
session() - Method in class io.vertx.reactivex.ext.web.RoutingContext
Get the session.
Session - Class in io.vertx.reactivex.ext.web
Represents a browser session.
Session(Session) - Constructor for class io.vertx.reactivex.ext.web.Session
 
Session(Object) - Constructor for class io.vertx.reactivex.ext.web.Session
 
SessionHandler - Class in io.vertx.reactivex.ext.web.handler
A handler that maintains a Session for each browser session.
SessionHandler(SessionHandler) - Constructor for class io.vertx.reactivex.ext.web.handler.SessionHandler
 
SessionHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.SessionHandler
 
SessionStore - Class in io.vertx.reactivex.ext.web.sstore
A session store is used to store sessions for an Vert.x-Web web app
SessionStore(SessionStore) - Constructor for class io.vertx.reactivex.ext.web.sstore.SessionStore
 
SessionStore(Object) - Constructor for class io.vertx.reactivex.ext.web.sstore.SessionStore
 
set(CharSequence, CharSequence) - Static method in class io.vertx.reactivex.core.http.HttpHeaders
 
set(String, String) - Static method in class io.vertx.reactivex.core.http.HttpHeaders
 
set(String, String) - Method in class io.vertx.reactivex.uritemplate.Variables
Set a single variable.
set(String, List<String>) - Method in class io.vertx.reactivex.uritemplate.Variables
Set a list variable.
set(String, Map<String, String>) - Method in class io.vertx.reactivex.uritemplate.Variables
Set a map variable.
set(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Set the string value of a key.
SET_COOKIE - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Set-Cookie header name
setAcceptableContentType(String) - Method in class io.vertx.reactivex.ext.web.RoutingContext
Set the acceptable content type.
setAccessed() - Method in class io.vertx.reactivex.ext.web.Session
Mark the session as being accessed.
setAll(JsonObject) - Method in class io.vertx.reactivex.uritemplate.Variables
Like Variables.addAll(io.vertx.core.json.JsonObject) but overwrites previous variables.
setAlwaysAsyncFS(boolean) - Method in class io.vertx.reactivex.ext.web.handler.StaticHandler
Set whether async filesystem access should always be used
setBeforeScanHandler(Handler<Void>) - Method in class io.vertx.reactivex.config.ConfigRetriever
Registers a handler called before every scan.
setbit(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Sets or clears the bit at offset in the string value stored at key.
setBodyLimit(long) - Method in class io.vertx.reactivex.ext.web.handler.BodyHandler
Set the maximum body size in bytes, -1 means no limit.
setCacheEntryTimeout(long) - Method in class io.vertx.reactivex.ext.web.handler.StaticHandler
Set the server cache entry timeout when caching is enabled
setCachingEnabled(boolean) - Method in class io.vertx.reactivex.ext.web.handler.StaticHandler
Set whether cache header handling is enabled
setCharset(String) - Method in class io.vertx.reactivex.ext.web.multipart.MultipartForm
Set the charset to use when encoding the form.
setCharset(Charset) - Method in class io.vertx.reactivex.ext.web.multipart.MultipartForm
Set the charset to use when encoding the form.
setChunked(boolean) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
If chunked is true then the request will be set into HTTP chunked mode
setChunked(boolean) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
If chunked is true, this response will use HTTP chunked encoding, and each call to write to the body will correspond to a new HTTP chunk sent on the wire.
setClientIdentifier(String) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Set client identifier if not provided by the remote MQTT client (zero-bytes)
setConfigurationProcessor(Function<JsonObject, JsonObject>) - Method in class io.vertx.reactivex.config.ConfigRetriever
Registers a handler that process the configuration before being injected into or ConfigRetriever.listen(io.vertx.core.Handler<io.vertx.config.ConfigChange>).
setContentId(String) - Method in class io.vertx.reactivex.ext.mail.MailAttachment
set the Content-ID field to be used in the attachment
setContentType(String) - Method in class io.vertx.reactivex.ext.mail.MailAttachment
set the Content-Type
setCookieHttpOnly(boolean) - Method in class io.vertx.reactivex.ext.web.handler.CSRFHandler
Set the cookie httpOnly attribute.
setCookieHttpOnlyFlag(boolean) - Method in class io.vertx.reactivex.ext.web.handler.SessionHandler
Sets whether the 'HttpOnly' flag should be set for the session cookie.
setCookieless(boolean) - Method in class io.vertx.reactivex.ext.web.handler.SessionHandler
Use sessions based on url paths instead of cookies.
setCookieMaxAge(long) - Method in class io.vertx.reactivex.ext.web.handler.SessionHandler
Set a Cookie max-age to the session cookie.
setCookieName(String) - Method in class io.vertx.reactivex.ext.web.handler.CSRFHandler
Set the cookie name.
setCookiePath(String) - Method in class io.vertx.reactivex.ext.web.handler.CSRFHandler
Set the cookie path.
setCookieSameSite(CookieSameSite) - Method in class io.vertx.reactivex.ext.web.handler.SessionHandler
Set the session cookie SameSite policy to use.
setCookieSecure(boolean) - Method in class io.vertx.reactivex.ext.web.handler.CSRFHandler
Sets the cookie secure flag.
setCookieSecureFlag(boolean) - Method in class io.vertx.reactivex.ext.web.handler.SessionHandler
Sets whether the 'secure' flag should be set for the session cookie.
setData(Buffer) - Method in class io.vertx.reactivex.ext.mail.MailAttachment
set the data
setDefaultContentEncoding(String) - Method in class io.vertx.reactivex.ext.web.handler.StaticHandler
Set the default content encoding for text related files.
setDeleteUploadedFilesOnEnd(boolean) - Method in class io.vertx.reactivex.ext.web.handler.BodyHandler
Set whether uploaded files should be removed after handling the request.
setDescription(String) - Method in class io.vertx.reactivex.ext.mail.MailAttachment
set the description field to be used in the attachment
setDirective(String, String) - Method in class io.vertx.reactivex.ext.web.handler.CSPHandler
Sets a single directive entry to the handler.
setDirectLoggedInOKURL(String) - Method in class io.vertx.reactivex.ext.web.handler.FormLoginHandler
Set the url to redirect to if the user logs in directly at the url of the form login handler without being redirected here first
setDirectoryListing(boolean) - Method in class io.vertx.reactivex.ext.web.handler.StaticHandler
Set whether directory listing is enabled
setDirectoryTemplate(String) - Method in class io.vertx.reactivex.ext.web.handler.StaticHandler
Set the directory template to be used when directory listing
setDisposition(String) - Method in class io.vertx.reactivex.ext.mail.MailAttachment
set the disposition field to be used in the attachment
setDoSecurity(boolean) - Method in class io.vertx.reactivex.ext.web.openapi.router.OpenAPIRoute
Sets the security flag for incoming requests.
setDoValidation(boolean) - Method in class io.vertx.reactivex.ext.web.openapi.router.OpenAPIRoute
Sets the validation flag for incoming requests.
setEnableFSTuning(boolean) - Method in class io.vertx.reactivex.ext.web.handler.StaticHandler
Set whether async/sync filesystem tuning should enabled
setEnableRangeSupport(boolean) - Method in class io.vertx.reactivex.ext.web.handler.StaticHandler
Set whether range requests (resumable downloads; media streaming) should be enabled.
setex(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Set the value and expiration of a key.
setExpectMultipart(boolean) - Method in class io.vertx.reactivex.core.http.HttpServerRequest
Call this with true if you are expecting a multi-part body to be submitted in the request.
setFilesReadOnly(boolean) - Method in class io.vertx.reactivex.ext.web.handler.StaticHandler
Set whether files are read-only and will never change
setFollowRedirects(boolean) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Set the request to follow HTTP redirects up to HttpClientOptions.
setHandleFileUploads(boolean) - Method in class io.vertx.reactivex.ext.web.handler.BodyHandler
Set whether file uploads will be handled.
setHandler(Handler<WatchResult<T>>) - Method in class io.vertx.reactivex.ext.consul.Watch
Set the result handler.
setHeaderName(String) - Method in class io.vertx.reactivex.ext.web.handler.CSRFHandler
Set the header name.
setHeaders(MultiMap) - Method in class io.vertx.reactivex.ext.mail.MailAttachment
Set the headers to be added for this attachment.
setHttp2PushMapping(List<Http2PushMapping>) - Method in class io.vertx.reactivex.ext.web.handler.StaticHandler
Set the file mapping for http2push and link preload
setIncludeHidden(boolean) - Method in class io.vertx.reactivex.ext.web.handler.StaticHandler
Set whether hidden files should be served
setIndexPage(String) - Method in class io.vertx.reactivex.ext.web.handler.StaticHandler
Set the index page
setIndexTemplate(String) - Method in class io.vertx.reactivex.ext.web.handler.TemplateHandler
Set the index template
setLazySession(boolean) - Method in class io.vertx.reactivex.ext.web.handler.SessionHandler
Use a lazy session creation mechanism.
setMaxAgeSeconds(long) - Method in class io.vertx.reactivex.ext.web.handler.StaticHandler
Set value for max age in caching headers
setMaxAvgServeTimeNs(long) - Method in class io.vertx.reactivex.ext.web.handler.StaticHandler
Set the max serve time in ns, above which serves are considered slow
setMaxCacheSize(int) - Method in class io.vertx.reactivex.ext.web.handler.StaticHandler
Set the max cache size, when caching is enabled
setMaxRedirects(int) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Set the max number of HTTP redirects this request will follow.
setMergeFormAttributes(boolean) - Method in class io.vertx.reactivex.ext.web.handler.BodyHandler
Set whether form attributes will be added to the request parameters.
setMethod(HttpMethod) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Set the HTTP method for this request.
setMinLength(int) - Method in class io.vertx.reactivex.ext.web.handler.SessionHandler
Set expected session id minimum length.
setNagHttps(boolean) - Method in class io.vertx.reactivex.ext.web.handler.CSRFHandler
Should the handler give warning messages if this handler is used in other than https protocols?
setNagHttps(boolean) - Method in class io.vertx.reactivex.ext.web.handler.SessionHandler
Set whether a nagging log warning should be written if the session handler is accessed over HTTP, not HTTPS
setName(String) - Method in class io.vertx.reactivex.ext.mail.MailAttachment
set the name
setName(String) - Method in class io.vertx.reactivex.ext.web.Route
Giving a name to a route will provide this name as metadata to requests matching this route.
setnx(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Set the value of a key, only if the key does not exist.
setOption(MySQLSetOption) - Method in class io.vertx.reactivex.mysqlclient.MySQLConnection
Send a SET_OPTION command to set options for the current connection.
setOrigin(String) - Method in class io.vertx.reactivex.ext.web.handler.CSRFHandler
Set the origin for this server.
setOrigin(String) - Method in class io.vertx.reactivex.ext.web.handler.WebAuthn4JHandler
Set the Origin to be validated by the webauthn object.
setOutput(Handler<Buffer>) - Method in class io.vertx.reactivex.core.parsetools.RecordParser
 
setParamsCharset(String) - Method in class io.vertx.reactivex.core.http.HttpServerRequest
Override the charset to use for decoding the query parameter map, when none is set, UTF8 is used.
setPasswordParam(String) - Method in class io.vertx.reactivex.ext.web.handler.FormLoginHandler
Set the name of the form param used to submit the password
setPolicies(List<Policy>) - Method in class io.vertx.reactivex.ext.auth.abac.PolicyBasedAuthorizationProvider
 
setPreallocateBodyBuffer(boolean) - Method in class io.vertx.reactivex.ext.web.handler.BodyHandler
Pre-allocate the body buffer according to the value parsed from content-length header.
setQueryParam(String, String) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Set a query parameter to the request.
setQueryTimeout(int) - Method in class io.vertx.reactivex.jdbcclient.JDBCConnection
Sets a connection wide query timeout.
setQueueName(String) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQConsumer
Set the name of the queue.
setrange(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Overwrite part of a string at key starting at the specified offset.
setRawMessage(JsonObject) - Method in class io.vertx.reactivex.ext.bridge.BaseBridgeEvent
Override the raw JSON message for the event.
setRawMessage(JsonObject) - Method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.BridgeEvent
Get the raw JSON message for the event.
setRawMessage(JsonObject) - Method in class io.vertx.reactivex.ext.web.handler.sockjs.BridgeEvent
Set the raw JSON message for the event.
setReadBufferSize(int) - Method in class io.vertx.reactivex.core.file.AsyncFile
Sets the buffer size that will be used to read the data from the file.
setReadLength(long) - Method in class io.vertx.reactivex.core.file.AsyncFile
Sets the number of bytes that will be read when using the file as a ReadStream.
setReadPos(long) - Method in class io.vertx.reactivex.core.file.AsyncFile
Sets the position from which data will be read from when using the file as a ReadStream.
setRegexGroupsNames(List<String>) - Method in class io.vertx.reactivex.ext.web.Route
When you add a new route with a regular expression, you can add named capture groups for parameters.
setReportOnly(boolean) - Method in class io.vertx.reactivex.ext.web.handler.CSPHandler
To ease deployment, CSP can be deployed in report-only mode.
setResource(String) - Method in class io.vertx.reactivex.ext.auth.authorization.PermissionBasedAuthorization
sets an optional resource that the permission is assigned-on
setResource(String) - Method in class io.vertx.reactivex.ext.auth.authorization.RoleBasedAuthorization
sets an optional resource that the role is assigned-on
setResource(String) - Method in class io.vertx.reactivex.ext.auth.authorization.WildcardPermissionBasedAuthorization
sets an optional resource that the permission is assigned-on
setReturnURLParam(String) - Method in class io.vertx.reactivex.ext.web.handler.FormLoginHandler
Set the name of the session attrioute used to specify the return url
setSendVaryHeader(boolean) - Method in class io.vertx.reactivex.ext.web.handler.StaticHandler
Set whether vary header should be sent with response.
setSessionCookieName(String) - Method in class io.vertx.reactivex.ext.web.handler.SessionHandler
Set the session cookie name
setSessionCookiePath(String) - Method in class io.vertx.reactivex.ext.web.handler.SessionHandler
Set the session cookie path
setSessionTimeout(long) - Method in class io.vertx.reactivex.ext.web.handler.SessionHandler
Set the session timeout
setSigningSecret(String) - Method in class io.vertx.reactivex.ext.web.handler.SessionHandler
Set signing secret for the session cookie.
setSize(int) - Method in class io.vertx.reactivex.ext.mail.MailAttachment
Sets the size of the attachment.
setStatusCode(int) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Set the status code.
setStatusMessage(String) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Set the status message
setStream(Flowable<Buffer>) - Method in class io.vertx.reactivex.ext.mail.MailAttachment
Sets the data stream.
setStream(ReadStream<Buffer>) - Method in class io.vertx.reactivex.ext.mail.MailAttachment
Sets the data stream.
setStreamPriority(StreamPriority) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Sets the priority of the associated stream.
setStreamPriority(StreamPriority) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Sets the priority of the associated stream
setTemplateParam(String, String) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Set a request URI template string parameter to the request, expanded when the request URI is a .
setTemplateParam(String, List<String>) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Set a request URI template list parameter to the request, expanded when the request URI is a .
setTemplateParam(String, Map<String, String>) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Set a request URI template map parameter to the request, expanded when the request URI is a .
setTimeout(long) - Method in class io.vertx.reactivex.ext.web.handler.CSRFHandler
Set the timeout for tokens generated by the handler, by default it uses the default from the session handler.
settings() - Method in class io.vertx.reactivex.core.http.HttpConnection
 
setTransactionIsolation(int) - Method in class io.vertx.reactivex.jdbcclient.JDBCConnection
 
setupCallback(Route) - Method in class io.vertx.reactivex.ext.web.handler.OAuth2AuthHandler
add the callback handler to a given route.
setupCallback(Route) - Method in class io.vertx.reactivex.ext.web.handler.OtpAuthHandler
Setup the required route where authenticators to submit the challenge response.
setupCallback(Route) - Method in class io.vertx.reactivex.ext.web.handler.WebAuthn4JHandler
The callback route to verify attestations and assertions.
setupCredentialsCreateCallback(Route) - Method in class io.vertx.reactivex.ext.web.handler.WebAuthn4JHandler
The callback route to create registration attestations.
setupCredentialsGetCallback(Route) - Method in class io.vertx.reactivex.ext.web.handler.WebAuthn4JHandler
The callback route to create login attestations.
setUploadsDirectory(String) - Method in class io.vertx.reactivex.ext.web.handler.BodyHandler
Set the uploads directory to use.
setupRegisterCallback(Route) - Method in class io.vertx.reactivex.ext.web.handler.OtpAuthHandler
Setup the optional route where authenticators are allowed to register.
setURI(String) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Set the request uri.
setUser(RoutingContext, User) - Method in class io.vertx.reactivex.ext.web.handler.SessionHandler
Set the user for the session
setUsernameParam(String) - Method in class io.vertx.reactivex.ext.web.handler.FormLoginHandler
Set the name of the form param used to submit the username
setWindowSize(int) - Method in class io.vertx.reactivex.core.http.HttpConnection
Update the current connection wide window size to a new size.
setWritePos(long) - Method in class io.vertx.reactivex.core.file.AsyncFile
Sets the position from which data will be written when using the file as a WriteStream.
setWriteQueueMaxSize(int) - Method in class io.vertx.reactivex.amqp.AmqpSender
 
setWriteQueueMaxSize(int) - Method in class io.vertx.reactivex.core.file.AsyncFile
 
setWriteQueueMaxSize(int) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
 
setWriteQueueMaxSize(int) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
 
setWriteQueueMaxSize(int) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
 
setWriteQueueMaxSize(int) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
 
setWriteQueueMaxSize(int) - Method in class io.vertx.reactivex.core.http.WebSocket
 
setWriteQueueMaxSize(int) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
 
setWriteQueueMaxSize(int) - Method in class io.vertx.reactivex.core.net.NetSocket
 
setWriteQueueMaxSize(int) - Method in interface io.vertx.reactivex.core.streams.WriteStream
Set the maximum size of the write queue to maxSize.
setWriteQueueMaxSize(int) - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
 
setWriteQueueMaxSize(int) - Method in class io.vertx.reactivex.grpc.client.GrpcClientRequest
 
setWriteQueueMaxSize(int) - Method in class io.vertx.reactivex.grpc.common.GrpcWriteStream
 
setWriteQueueMaxSize(int) - Method in class io.vertx.reactivex.grpc.server.GrpcServerResponse
 
setWriteQueueMaxSize(int) - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
 
SharedData - Class in io.vertx.reactivex.core.shareddata
Shared data allows you to share data safely between different parts of your application in a safe way.
SharedData(SharedData) - Constructor for class io.vertx.reactivex.core.shareddata.SharedData
 
SharedData(Object) - Constructor for class io.vertx.reactivex.core.shareddata.SharedData
 
ShopifyAuth - Class in io.vertx.reactivex.ext.auth.oauth2.providers
Simplified factory to create an for Shopify.
ShopifyAuth(ShopifyAuth) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.ShopifyAuth
 
ShopifyAuth(Object) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.ShopifyAuth
 
shutdown() - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Like WebSocketBase.shutdown() with a 30 seconds timeout, the status code 1000 a null reason.
shutdown() - Method in interface io.vertx.reactivex.core.http.HttpClient
Shutdown with a 30 seconds timeout (shutdown(30, TimeUnit.SECONDS)).
shutdown() - Method in class io.vertx.reactivex.core.http.HttpClientAgent
Shutdown with a 30 seconds timeout (shutdown(30, TimeUnit.SECONDS)).
shutdown() - Method in class io.vertx.reactivex.core.http.HttpClientConnection
 
shutdown() - Method in class io.vertx.reactivex.core.http.HttpConnection
Shutdown with a 30 seconds timeout (shutdown(30, TimeUnit.SECONDS)).
shutdown() - Method in class io.vertx.reactivex.core.http.HttpServer
Shutdown with a 30 seconds timeout (shutdown(30, TimeUnit.SECONDS)).
shutdown() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Like WebSocketBase.shutdown() with a 30 seconds timeout, the status code 1000 a null reason.
shutdown() - Method in class io.vertx.reactivex.core.http.WebSocket
Like WebSocketBase.shutdown() with a 30 seconds timeout, the status code 1000 a null reason.
shutdown() - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Like WebSocketBase.shutdown() with a 30 seconds timeout, the status code 1000 a null reason.
shutdown() - Method in class io.vertx.reactivex.core.http.WebSocketClient
Shutdown with a 30 seconds timeout (shutdown(30, TimeUnit.SECONDS)).
shutdown() - Method in class io.vertx.reactivex.core.net.NetClient
Shutdown with a 30 seconds timeout (shutdown(30, TimeUnit.SECONDS)).
shutdown() - Method in class io.vertx.reactivex.core.net.NetServer
Shutdown with a 30 seconds timeout (shutdown(30, TimeUnit.SECONDS)).
shutdown(long, TimeUnit) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Calls WebSocketBase.shutdown() with the status code 1000 and a null reason.
shutdown(long, TimeUnit) - Method in interface io.vertx.reactivex.core.http.HttpClient
Initiate the client shutdown sequence.
shutdown(long, TimeUnit) - Method in class io.vertx.reactivex.core.http.HttpClientAgent
Initiate the client shutdown sequence.
shutdown(long, TimeUnit) - Method in class io.vertx.reactivex.core.http.HttpClientConnection
 
shutdown(long, TimeUnit) - Method in class io.vertx.reactivex.core.http.HttpConnection
Initiate a graceful connection shutdown, the connection is taken out of service and closed when all the inflight requests are processed, otherwise after a timeout the connection will be closed.
shutdown(long, TimeUnit) - Method in class io.vertx.reactivex.core.http.HttpServer
Initiate the server shutdown sequence.
shutdown(long, TimeUnit) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Calls WebSocketBase.shutdown() with the status code 1000 and a null reason.
shutdown(long, TimeUnit) - Method in class io.vertx.reactivex.core.http.WebSocket
Calls WebSocketBase.shutdown() with the status code 1000 and a null reason.
shutdown(long, TimeUnit) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Calls WebSocketBase.shutdown() with the status code 1000 and a null reason.
shutdown(long, TimeUnit) - Method in class io.vertx.reactivex.core.http.WebSocketClient
Initiate the client shutdown sequence.
shutdown(long, TimeUnit) - Method in class io.vertx.reactivex.core.net.NetClient
Initiate the client shutdown sequence.
shutdown(long, TimeUnit) - Method in class io.vertx.reactivex.core.net.NetServer
Initiate the server shutdown sequence.
shutdown(long, TimeUnit, short) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Calls WebSocketBase.shutdown() with a null reason.
shutdown(long, TimeUnit, short) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Calls WebSocketBase.shutdown() with a null reason.
shutdown(long, TimeUnit, short) - Method in class io.vertx.reactivex.core.http.WebSocket
Calls WebSocketBase.shutdown() with a null reason.
shutdown(long, TimeUnit, short) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Calls WebSocketBase.shutdown() with a null reason.
shutdown(long, TimeUnit, short, String) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Initiate a graceful WebSocket shutdown, the shutdown handler is notified and shall close the WebSocket, otherwise after a timeout the WebSocket will be closed.
shutdown(long, TimeUnit, short, String) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Initiate a graceful WebSocket shutdown, the shutdown handler is notified and shall close the WebSocket, otherwise after a timeout the WebSocket will be closed.
shutdown(long, TimeUnit, short, String) - Method in class io.vertx.reactivex.core.http.WebSocket
Initiate a graceful WebSocket shutdown, the shutdown handler is notified and shall close the WebSocket, otherwise after a timeout the WebSocket will be closed.
shutdown(long, TimeUnit, short, String) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Initiate a graceful WebSocket shutdown, the shutdown handler is notified and shall close the WebSocket, otherwise after a timeout the WebSocket will be closed.
shutdown(short) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Like WebSocketBase.shutdown() with a 30 seconds timeout and a null reason.
shutdown(short) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Like WebSocketBase.shutdown() with a 30 seconds timeout and a null reason.
shutdown(short) - Method in class io.vertx.reactivex.core.http.WebSocket
Like WebSocketBase.shutdown() with a 30 seconds timeout and a null reason.
shutdown(short) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Like WebSocketBase.shutdown() with a 30 seconds timeout and a null reason.
shutdown(short, String) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Like WebSocketBase.shutdown() with a 30 seconds timeout.
shutdown(short, String) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Like WebSocketBase.shutdown() with a 30 seconds timeout.
shutdown(short, String) - Method in class io.vertx.reactivex.core.http.WebSocket
Like WebSocketBase.shutdown() with a 30 seconds timeout.
shutdown(short, String) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Like WebSocketBase.shutdown() with a 30 seconds timeout.
shutdown(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Synchronously save the dataset to disk and then shut down the server.
shutdownHandler(Handler<Void>) - Method in class io.vertx.reactivex.core.http.HttpConnection
Set a handler notified when the HTTP connection is shutdown: the client or server will close the connection within a certain amount of time.
shutdownHandler(Handler<Void>) - Method in class io.vertx.reactivex.core.http.WebSocket
 
shutdownHandler(Handler<Void>) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Set a handler notified when the WebSocket is shutdown: the client or server will close the connection within a certain amount of time.
shutdownHandler(Handler<Void>) - Method in class io.vertx.reactivex.core.net.NetSocket
Set a handler notified when the socket is shutdown: the client or server will close the connection within a certain amount of time.
SimpleAuthenticationHandler - Class in io.vertx.reactivex.ext.web.handler
A user customizable authentication handler.
SimpleAuthenticationHandler(SimpleAuthenticationHandler) - Constructor for class io.vertx.reactivex.ext.web.handler.SimpleAuthenticationHandler
 
SimpleAuthenticationHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.SimpleAuthenticationHandler
 
sinter(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Intersect multiple sets.
sintercard(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Intersect multiple sets and return the cardinality of the result.
sinterstore(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Intersect multiple sets and store the resulting set in a key.
sismember(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Determine if a given value is a member of a set.
size() - Method in class io.vertx.reactivex.core.file.AsyncFile
 
size() - Method in class io.vertx.reactivex.core.file.AsyncFileLock
 
size() - Method in class io.vertx.reactivex.core.http.HttpServerFileUpload
The size of the upload may not be available until it is all read.
size() - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
Provide the number of entries in the map
size() - Method in class io.vertx.reactivex.core.shareddata.LocalMap
Get the size of the map
size() - Method in class io.vertx.reactivex.ext.web.FileUpload
 
size() - Method in class io.vertx.reactivex.ext.web.sstore.SessionStore
Get the number of sessions in the store.
size() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumerRecords
 
size() - Method in class io.vertx.reactivex.openapi.contract.SecurityRequirement
How many requirements are present
size() - Method in class io.vertx.reactivex.sqlclient.Pool
 
size() - Method in class io.vertx.reactivex.sqlclient.SqlResult
Get the number of rows retrieved in the SqlResult.
size() - Method in class io.vertx.reactivex.sqlclient.Tuple
 
sizeBlocking() - Method in class io.vertx.reactivex.core.file.AsyncFile
Like AsyncFile.size() but blocking.
skipCompressionForMediaTypes(Set<String>) - Method in class io.vertx.reactivex.ext.web.handler.StaticHandler
Skip compression if the media type of the file to send is in the provided mediaTypes set.
skipCompressionForSuffixes(Set<String>) - Method in class io.vertx.reactivex.ext.web.handler.StaticHandler
Skip compression if the suffix of the file to send is in the provided fileSuffixes set.
slaveof(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Deprecated.
slowlog(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
A container for slow log commands.
smembers(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get all the members in a set.
smismember(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Returns the membership associated with the given elements for a set.
smove(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Move a member from one set to another.
socket() - Method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.BridgeEvent
Get the SockJSSocket instance corresponding to the event
socket() - Method in class io.vertx.reactivex.ext.web.handler.graphql.ws.Message
 
socket() - Method in class io.vertx.reactivex.ext.web.handler.sockjs.BridgeEvent
Get the SockJSSocket instance corresponding to the event
socketHandler(Handler<SockJSSocket>) - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSHandler
Set a SockJS socket handler.
SockJSHandler - Class in io.vertx.reactivex.ext.web.handler.sockjs
A handler that allows you to handle SockJS connections from clients.
SockJSHandler(SockJSHandler) - Constructor for class io.vertx.reactivex.ext.web.handler.sockjs.SockJSHandler
 
SockJSHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.sockjs.SockJSHandler
 
SockJSSocket - Class in io.vertx.reactivex.ext.web.handler.sockjs
You interact with SockJS clients through instances of SockJS socket.
SockJSSocket(SockJSSocket) - Constructor for class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
 
SockJSSocket(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
 
sort(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Sort the elements in a list, set or sorted set.
sortRo(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Sort the elements in a list, set or sorted set.
SoundcloudAuth - Class in io.vertx.reactivex.ext.auth.oauth2.providers
Simplified factory to create an for SoundCloud.
SoundcloudAuth(SoundcloudAuth) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.SoundcloudAuth
 
SoundcloudAuth(Object) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.SoundcloudAuth
 
source(SocketAddress) - Method in class io.vertx.reactivex.ext.auth.audit.SecurityAudit
 
specifySchema(String) - Method in class io.vertx.reactivex.mysqlclient.MySQLConnection
Send a INIT_DB command to change the default schema of the connection.
spop(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove and return one or multiple random members from a set.
spublish(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Post a message to a shard channel.
SqlAuthentication - Class in io.vertx.reactivex.ext.auth.sqlclient
Factory interface for creating AuthenticationProvider instances that use the Vert.x SQL client.
SqlAuthentication(SqlAuthentication) - Constructor for class io.vertx.reactivex.ext.auth.sqlclient.SqlAuthentication
 
SqlAuthentication(Object) - Constructor for class io.vertx.reactivex.ext.auth.sqlclient.SqlAuthentication
 
SqlAuthorization - Class in io.vertx.reactivex.ext.auth.sqlclient
Factory interface for creating instances that use the Vert.x SQL client.
SqlAuthorization(SqlAuthorization) - Constructor for class io.vertx.reactivex.ext.auth.sqlclient.SqlAuthorization
 
SqlAuthorization(Object) - Constructor for class io.vertx.reactivex.ext.auth.sqlclient.SqlAuthorization
 
SqlClient - Class in io.vertx.reactivex.sqlclient
Defines common SQL client operations with a database server.
SqlClient(SqlClient) - Constructor for class io.vertx.reactivex.sqlclient.SqlClient
 
SqlClient(Object) - Constructor for class io.vertx.reactivex.sqlclient.SqlClient
 
SqlConnection - Class in io.vertx.reactivex.sqlclient
A connection to the database server.
SqlConnection(SqlConnection) - Constructor for class io.vertx.reactivex.sqlclient.SqlConnection
 
SqlConnection(Object) - Constructor for class io.vertx.reactivex.sqlclient.SqlConnection
 
SqlOutParam - Class in io.vertx.reactivex.jdbcclient
Tag if a parameter is of type OUT or INOUT.
SqlOutParam(SqlOutParam) - Constructor for class io.vertx.reactivex.jdbcclient.SqlOutParam
 
SqlOutParam(Object) - Constructor for class io.vertx.reactivex.jdbcclient.SqlOutParam
 
SqlResult<T> - Class in io.vertx.reactivex.sqlclient
An interface that represents the execution result of an operation on the database server.
SqlResult(SqlResult) - Constructor for class io.vertx.reactivex.sqlclient.SqlResult
 
SqlResult(Object, TypeArg<T>) - Constructor for class io.vertx.reactivex.sqlclient.SqlResult
 
SqlTemplate<I,​R> - Class in io.vertx.reactivex.sqlclient.templates
An SQL template.
SqlTemplate(SqlTemplate) - Constructor for class io.vertx.reactivex.sqlclient.templates.SqlTemplate
 
SqlTemplate(Object, TypeArg<I>, TypeArg<R>) - Constructor for class io.vertx.reactivex.sqlclient.templates.SqlTemplate
 
SqlUserUtil - Class in io.vertx.reactivex.ext.auth.sqlclient
Utility to create users/roles/permissions.
SqlUserUtil(SqlUserUtil) - Constructor for class io.vertx.reactivex.ext.auth.sqlclient.SqlUserUtil
 
SqlUserUtil(Object) - Constructor for class io.vertx.reactivex.ext.auth.sqlclient.SqlUserUtil
 
srandmember(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get one or multiple random members from a set.
srem(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove one or more members from a set.
sscan(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Incrementally iterate Set elements.
ssl() - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
 
ssl(Boolean) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Configure the request whether to use SSL.
sslSession() - Method in class io.vertx.reactivex.core.http.ClientWebSocket
 
sslSession() - Method in class io.vertx.reactivex.core.http.HttpConnection
 
sslSession() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
 
sslSession() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
 
sslSession() - Method in class io.vertx.reactivex.core.http.ServerWebSocketHandshake
 
sslSession() - Method in class io.vertx.reactivex.core.http.WebSocket
 
sslSession() - Method in class io.vertx.reactivex.core.net.NetSocket
 
sslSession() - Method in class io.vertx.reactivex.ext.stomp.StompServerConnection
 
ssubscribe(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Listen for messages published to the given shard channels.
stackTrace() - Method in class io.vertx.reactivex.ext.unit.report.Failure
 
start() - Method in class io.vertx.reactivex.ext.consul.Watch
Start this Watch
start() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Start the rabbitMQ client.
start() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQPublisher
Start the rabbitMQ publisher.
start(Vertx, ServicePublisher, JsonObject, Promise<Void>) - Method in class io.vertx.reactivex.servicediscovery.spi.ServiceImporter
Starts the importer.
state() - Method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
 
StaticHandler - Class in io.vertx.reactivex.ext.web.handler
A handler for serving static resources from the file system or classpath.
StaticHandler(StaticHandler) - Constructor for class io.vertx.reactivex.ext.web.handler.StaticHandler
 
StaticHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.StaticHandler
 
status() - Method in class io.vertx.reactivex.grpc.client.GrpcClientResponse
 
status(int) - Static method in class io.vertx.reactivex.core.http.HttpResponseExpectation
Creates an expectation asserting that the status response code is equal to statusCode.
status(int) - Method in class io.vertx.reactivex.ext.auth.audit.SecurityAudit
 
status(int, int) - Static method in class io.vertx.reactivex.core.http.HttpResponseExpectation
Creates an expectation asserting that the status response code is between to min (inclusive) and max (exclusive).
status(GrpcStatus) - Method in class io.vertx.reactivex.grpc.server.GrpcServerResponse
Set the grpc status response
statusCode() - Method in class io.vertx.reactivex.core.http.HttpClientResponse
 
statusCode() - Method in interface io.vertx.reactivex.core.http.HttpResponseHead
 
statusCode() - Method in class io.vertx.reactivex.ext.web.client.HttpResponse
 
statusCode() - Method in class io.vertx.reactivex.ext.web.RoutingContext
If the context is being routed to failure handlers after a failure has been triggered by calling RoutingContext.fail(int) then this will return that status code.
statusMessage() - Method in class io.vertx.reactivex.core.http.HttpClientResponse
 
statusMessage() - Method in interface io.vertx.reactivex.core.http.HttpResponseHead
 
statusMessage() - Method in class io.vertx.reactivex.ext.web.client.HttpResponse
 
statusMessage() - Method in class io.vertx.reactivex.grpc.client.GrpcClientResponse
 
statusMessage(String) - Method in class io.vertx.reactivex.grpc.server.GrpcServerResponse
Set the grpc status response message
StompClient - Class in io.vertx.reactivex.ext.stomp
Defines a STOMP client.
StompClient(StompClient) - Constructor for class io.vertx.reactivex.ext.stomp.StompClient
 
StompClient(Object) - Constructor for class io.vertx.reactivex.ext.stomp.StompClient
 
StompClientConnection - Class in io.vertx.reactivex.ext.stomp
Once a connection to the STOMP server has been made, client receives a StompClientConnection, that let send and receive STOMP frames.
StompClientConnection(StompClientConnection) - Constructor for class io.vertx.reactivex.ext.stomp.StompClientConnection
 
StompClientConnection(Object) - Constructor for class io.vertx.reactivex.ext.stomp.StompClientConnection
 
stompHandler() - Method in class io.vertx.reactivex.ext.stomp.StompServer
 
stompHandler(Handler<ServerFrame>) - Method in class io.vertx.reactivex.ext.stomp.StompServerHandler
Configures the action to execute when a STOMP frame is received.
StompServer - Class in io.vertx.reactivex.ext.stomp
Defines a STOMP server.
StompServer(StompServer) - Constructor for class io.vertx.reactivex.ext.stomp.StompServer
 
StompServer(Object) - Constructor for class io.vertx.reactivex.ext.stomp.StompServer
 
StompServerConnection - Class in io.vertx.reactivex.ext.stomp
Class representing a connection between a STOMP client a the server.
StompServerConnection(StompServerConnection) - Constructor for class io.vertx.reactivex.ext.stomp.StompServerConnection
 
StompServerConnection(Object) - Constructor for class io.vertx.reactivex.ext.stomp.StompServerConnection
 
StompServerHandler - Class in io.vertx.reactivex.ext.stomp
STOMP server handler implements the behavior of the STOMP server when a specific event occurs.
StompServerHandler(StompServerHandler) - Constructor for class io.vertx.reactivex.ext.stomp.StompServerHandler
 
StompServerHandler(Object) - Constructor for class io.vertx.reactivex.ext.stomp.StompServerHandler
 
stop() - Method in class io.vertx.reactivex.ext.consul.Watch
Stop the watch and release its resources
stop() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Stop the rabbitMQ client.
stop() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQPublisher
Stop the rabbitMQ publisher.
storeCredential(Authenticator) - Method in class io.vertx.reactivex.ext.auth.webauthn4j.CredentialStorage
Persists a new credential, bound by its user name (may be null) and credential ID (cannot be null, must be unique).
stream() - Method in class io.vertx.reactivex.sqlclient.RowSet
 
stream(Function<Buffer, T>) - Static method in class io.vertx.reactivex.ext.web.codec.BodyCodec
Create a codec that buffers the entire body and then apply the decode function and returns the result.
StreamBase - Interface in io.vertx.reactivex.core.streams
Base interface for a stream.
streamId() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
 
streamId() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
 
streamId() - Method in class io.vertx.reactivex.core.http.HttpServerResponse
 
streamPriority() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
 
streamPriorityHandler(Handler<StreamPriority>) - Method in class io.vertx.reactivex.core.http.HttpClientResponse
Set an handler for stream priority changes.
streamPriorityHandler(Handler<StreamPriority>) - Method in class io.vertx.reactivex.core.http.HttpServerRequest
Set an handler for stream priority changes
streamToFileSystem(String) - Method in class io.vertx.reactivex.core.http.HttpServerFileUpload
Stream the content of this upload to the given file on storage.
strictAsync(int) - Method in class io.vertx.reactivex.ext.unit.TestContext
Create and returns a new async object, the returned async controls the completion of the test.
string() - Static method in class io.vertx.reactivex.ext.web.codec.BodyCodec
 
string(String) - Static method in class io.vertx.reactivex.ext.web.codec.BodyCodec
A codec for strings using a specific encoding.
StripeAuth - Class in io.vertx.reactivex.ext.auth.oauth2.providers
Simplified factory to create an for Stripe.
StripeAuth(StripeAuth) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.StripeAuth
 
StripeAuth(Object) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.StripeAuth
 
strlen(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the length of the value stored in a key.
StyledParameterProcessorFactory - Class in io.vertx.reactivex.ext.web.validation.builder
This interface is used to build complex parameter processors supported only in cookie & query.
StyledParameterProcessorFactory(StyledParameterProcessorFactory) - Constructor for class io.vertx.reactivex.ext.web.validation.builder.StyledParameterProcessorFactory
 
StyledParameterProcessorFactory(Object) - Constructor for class io.vertx.reactivex.ext.web.validation.builder.StyledParameterProcessorFactory
 
subComponent() - Method in class io.vertx.reactivex.ext.web.MIMEHeader
Gets the parsed subcomponent part of the MIME.
subject() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
subject() - Method in class io.vertx.reactivex.ext.auth.User
The user subject.
subject(String) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
subProtocol() - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Returns the WebSocket sub protocol selected by the WebSocket handshake.
subProtocol() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Returns the WebSocket sub protocol selected by the WebSocket handshake.
subProtocol() - Method in class io.vertx.reactivex.core.http.WebSocket
Returns the WebSocket sub protocol selected by the WebSocket handshake.
subProtocol() - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Returns the WebSocket sub protocol selected by the WebSocket handshake.
subRouter(Router) - Method in class io.vertx.reactivex.ext.web.Route
Use a (sub) Router as a handler.
subscribe(StompServerConnection, Frame) - Method in class io.vertx.reactivex.ext.stomp.Destination
Handles a subscription request to the current Destination.
subscribe(String) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Subscribe to the given topic to get dynamically assigned partitions.
subscribe(String, int) - Method in class io.vertx.reactivex.mqtt.MqttClient
Subscribes to the topic with a specified QoS level
subscribe(String, Handler<Frame>) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Subscribes to the given destination.
subscribe(String, Map<String, String>, Handler<Frame>) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Subscribes to the given destination.
subscribe(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Listen for messages published to the given channels.
subscribe(Map<String, Integer>) - Method in class io.vertx.reactivex.mqtt.MqttClient
Subscribes to the topics with related QoS levels
subscribe(Pattern) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Subscribe to all topics matching specified pattern to get dynamically assigned partitions.
subscribe(Set<String>) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Subscribe to the given list of topics to get dynamically assigned partitions.
subscribeAcknowledge(int, List<MqttQoS>) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Sends the SUBACK message to the remote MQTT client
subscribeAcknowledge(int, List<MqttSubAckReasonCode>, MqttProperties) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Sends the SUBACK message to the remote MQTT client
subscribeCompletionHandler(Handler<MqttSubAckMessage>) - Method in class io.vertx.reactivex.mqtt.MqttClient
Sets handler which will be called after SUBACK packet receiving
subscribeHandler(Handler<ServerFrame>) - Method in class io.vertx.reactivex.ext.stomp.StompServerHandler
Configures the action to execute when a SUBSCRIBE frame is received.
subscribeHandler(Handler<MqttSubscribeMessage>) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Set a subscribe handler on the MQTT endpoint.
subscribeHandler(Handler<Void>) - Method in class io.vertx.reactivex.pgclient.pubsub.PgChannel
Set an handler called when the the channel get subscribed.
subscriber(Vertx, PgConnectOptions) - Static method in class io.vertx.reactivex.pgclient.pubsub.PgSubscriber
Create a subscriber.
subscription() - Method in class io.vertx.reactivex.ext.stomp.Acknowledgement
 
subscription() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Get the current subscription.
subscriptionAutoAck(boolean) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Enable/disable subscription/unsubscription requests auto acknowledge
subscriptionOption() - Method in class io.vertx.reactivex.mqtt.MqttTopicSubscription
Subscription option
substr(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Deprecated.
subtag() - Method in class io.vertx.reactivex.ext.web.LanguageHeader
The subtag of the language as specified by rfc7231#section-3.1.3.1.
Equivalent to
subtag(int) - Method in class io.vertx.reactivex.ext.web.LanguageHeader
A subtag of this language header.
+ info: rfc7231#section-3.1.3.1
subtagCount() - Method in class io.vertx.reactivex.ext.web.LanguageHeader
 
succeed(Boolean) - Method in class io.vertx.reactivex.ext.bridge.BaseBridgeEvent
 
succeed(Boolean) - Method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.BridgeEvent
 
succeed(Boolean) - Method in class io.vertx.reactivex.ext.web.handler.sockjs.BridgeEvent
 
succeed(Object) - Method in class io.vertx.reactivex.ext.web.handler.graphql.ws.ConnectionInitEvent
 
succeeded() - Method in class io.vertx.reactivex.ext.consul.WatchResult
Did it succeed?
succeeded() - Method in class io.vertx.reactivex.ext.unit.report.TestResult
Did it succeed?
succeeded() - Method in class io.vertx.reactivex.ext.web.validation.RequestPredicateResult
Predicate succeeded
success() - Static method in class io.vertx.reactivex.ext.web.validation.RequestPredicateResult
 
sunion(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Add multiple sets.
sunionstore(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Add multiple sets and store the resulting set in a key.
sunsubscribe(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Stop listening for messages posted to the given shard channels.
SUPPORTED_MEDIA_TYPES - Static variable in class io.vertx.reactivex.openapi.contract.MediaType
 
swapdb(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Swaps two Redis databases.
symlink(String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
Create a symbolic link on the file system from link to existing, asynchronously.
symlinkBlocking(String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
sync() - Method in class io.vertx.reactivex.redis.client.RedisAPI
Internal command used for replication.
SYSTEM_PROPERTY_NAME - Static variable in class io.vertx.reactivex.ext.web.common.WebEnvironment
 

T

tag() - Method in class io.vertx.reactivex.ext.web.LanguageHeader
The tag of the language as specified by rfc7231#section-3.1.3.1.
Equivalent to
TcpEventBusBridge - Class in io.vertx.reactivex.ext.eventbus.bridge.tcp
TCP EventBus bridge for Vert.x
TcpEventBusBridge(TcpEventBusBridge) - Constructor for class io.vertx.reactivex.ext.eventbus.bridge.tcp.TcpEventBusBridge
 
TcpEventBusBridge(Object) - Constructor for class io.vertx.reactivex.ext.eventbus.bridge.tcp.TcpEventBusBridge
 
tdigestAdd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TDIGEST.ADD.
tdigestByrank(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TDIGEST.BYRANK.
tdigestByrevrank(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TDIGEST.BYREVRANK.
tdigestCdf(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TDIGEST.CDF.
tdigestCreate(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TDIGEST.CREATE.
tdigestInfo(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TDIGEST.INFO.
tdigestMax(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TDIGEST.MAX.
tdigestMerge(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TDIGEST.MERGE.
tdigestMin(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TDIGEST.MIN.
tdigestQuantile(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TDIGEST.QUANTILE.
tdigestRank(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TDIGEST.RANK.
tdigestReset(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TDIGEST.RESET.
tdigestRevrank(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TDIGEST.REVRANK.
tdigestTrimmedMean(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TDIGEST.TRIMMED_MEAN.
TemplateEngine - Class in io.vertx.reactivex.ext.web.common.template
A template template uses a specific template and the data in a routing context to render a resource into a buffer.
TemplateEngine(TemplateEngine) - Constructor for class io.vertx.reactivex.ext.web.common.template.TemplateEngine
 
TemplateEngine(Object) - Constructor for class io.vertx.reactivex.ext.web.common.template.TemplateEngine
 
TemplateHandler - Class in io.vertx.reactivex.ext.web.handler
A handler which renders responses using a template engine and where the template name is selected from the URI path.
TemplateHandler(TemplateHandler) - Constructor for class io.vertx.reactivex.ext.web.handler.TemplateHandler
 
TemplateHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.TemplateHandler
 
templateParams() - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Return the current request URI template parameters.
TENANT - Static variable in class io.vertx.reactivex.ext.web.handler.MultiTenantHandler
The default key used to identify a tenant in the context data.
test(Single<T>) - Method in class io.vertx.reactivex.circuitbreaker.FailurePolicy
Invoked by the CircuitBreaker when an operation completes.
test(Future<T>) - Method in class io.vertx.reactivex.circuitbreaker.FailurePolicy
Invoked by the CircuitBreaker when an operation completes.
test(String, int, Handler<TestContext>) - Method in class io.vertx.reactivex.ext.unit.TestSuite
Add a new test case to the suite.
test(String, Handler<TestContext>) - Method in class io.vertx.reactivex.ext.unit.TestSuite
Add a new test case to the suite.
TestCase - Class in io.vertx.reactivex.ext.unit
A test case object can be used to create a single test.
TestCase(TestCase) - Constructor for class io.vertx.reactivex.ext.unit.TestCase
 
TestCase(Object) - Constructor for class io.vertx.reactivex.ext.unit.TestCase
 
TestCaseReport - Class in io.vertx.reactivex.ext.unit.report
Report the execution of a test case.
TestCaseReport(TestCaseReport) - Constructor for class io.vertx.reactivex.ext.unit.report.TestCaseReport
 
TestCaseReport(Object) - Constructor for class io.vertx.reactivex.ext.unit.report.TestCaseReport
 
TestCompletion - Class in io.vertx.reactivex.ext.unit
This object provides callback-ability for the end of a test suite, the completion succeeds when all tests pass otherwise it fails.
TestCompletion(TestCompletion) - Constructor for class io.vertx.reactivex.ext.unit.TestCompletion
 
TestCompletion(Object) - Constructor for class io.vertx.reactivex.ext.unit.TestCompletion
 
TestContext - Class in io.vertx.reactivex.ext.unit
The test context is used for performing test assertions and manage the completion of the test.
TestContext(TestContext) - Constructor for class io.vertx.reactivex.ext.unit.TestContext
 
TestContext(Object) - Constructor for class io.vertx.reactivex.ext.unit.TestContext
 
TestResult - Class in io.vertx.reactivex.ext.unit.report
The result of a test.
TestResult(TestResult) - Constructor for class io.vertx.reactivex.ext.unit.report.TestResult
 
TestResult(Object) - Constructor for class io.vertx.reactivex.ext.unit.report.TestResult
 
TestSuite - Class in io.vertx.reactivex.ext.unit
A named suite of test cases that are executed altogether.
TestSuite(TestSuite) - Constructor for class io.vertx.reactivex.ext.unit.TestSuite
 
TestSuite(Object) - Constructor for class io.vertx.reactivex.ext.unit.TestSuite
 
TestSuiteReport - Class in io.vertx.reactivex.ext.unit.report
The test suite reports is basically a stream of events reporting the test suite execution.
TestSuiteReport(TestSuiteReport) - Constructor for class io.vertx.reactivex.ext.unit.report.TestSuiteReport
 
TestSuiteReport(Object) - Constructor for class io.vertx.reactivex.ext.unit.report.TestSuiteReport
 
TEXT_HTML - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
text/html header value
TEXT_PLAIN - Static variable in class io.vertx.reactivex.openapi.contract.MediaType
 
TEXT_PLAIN_UTF8 - Static variable in class io.vertx.reactivex.openapi.contract.MediaType
 
textFileUpload(String, String, Buffer, String) - Method in class io.vertx.reactivex.ext.web.multipart.MultipartForm
Add a text file upload form data part.
textFileUpload(String, String, String, String) - Method in class io.vertx.reactivex.ext.web.multipart.MultipartForm
Add a text file upload form data part.
textHandlerID() - Method in class io.vertx.reactivex.core.http.ClientWebSocket
When a WebSocket is created, it may register an event handler with the eventbus, the ID of that handler is given by textHandlerID.
textHandlerID() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
When a WebSocket is created, it may register an event handler with the eventbus, the ID of that handler is given by textHandlerID.
textHandlerID() - Method in class io.vertx.reactivex.core.http.WebSocket
When a WebSocket is created, it may register an event handler with the eventbus, the ID of that handler is given by textHandlerID.
textHandlerID() - Method in interface io.vertx.reactivex.core.http.WebSocketBase
When a WebSocket is created, it may register an event handler with the eventbus, the ID of that handler is given by textHandlerID.
textMessageHandler(Handler<String>) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
 
textMessageHandler(Handler<String>) - Method in class io.vertx.reactivex.core.http.WebSocket
 
textMessageHandler(Handler<String>) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Set a text message handler on the connection.
textPlain(StringSchemaBuilder) - Static method in class io.vertx.reactivex.ext.web.validation.builder.Bodies
Create a text/plain body processor
ThymeleafTemplateEngine - Class in io.vertx.reactivex.ext.web.templ.thymeleaf
A template engine that uses the Thymeleaf library.
ThymeleafTemplateEngine(ThymeleafTemplateEngine) - Constructor for class io.vertx.reactivex.ext.web.templ.thymeleaf.ThymeleafTemplateEngine
 
ThymeleafTemplateEngine(Object) - Constructor for class io.vertx.reactivex.ext.web.templ.thymeleaf.ThymeleafTemplateEngine
 
time() - Method in class io.vertx.reactivex.redis.client.RedisAPI
Return the current server time.
timeout() - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
 
timeout() - Method in class io.vertx.reactivex.ext.web.Session
 
timeout() - Method in class io.vertx.reactivex.grpc.server.GrpcServerRequest
 
timeout(long) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Configures the amount of time in milliseconds after which if the request does not return any data within the timeout period an TimeoutException fails the request.
timeout(long, TimeUnit) - Method in class io.vertx.reactivex.grpc.client.GrpcClientRequest
Set a grpc-timeout header to be sent to the server to indicate the client expects a response with a timeout.
TimeoutHandler - Class in io.vertx.reactivex.ext.web.handler
Handler that will timeout requests if the response has not been written after a certain time.
TimeoutHandler(TimeoutHandler) - Constructor for class io.vertx.reactivex.ext.web.handler.TimeoutHandler
 
TimeoutHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.TimeoutHandler
 
timeseriesClusterset(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TIMESERIES.CLUSTERSET.
timeseriesClustersetfromshard(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
timeseriesHello(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TIMESERIES.HELLO.
timeseriesInfocluster(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TIMESERIES.INFOCLUSTER.
timeseriesInnercommunication(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
timeseriesNetworktest(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TIMESERIES.NETWORKTEST.
timeseriesRefreshcluster(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
timestamp() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumerRecord
 
timestamp() - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducerRecord
 
timestampType() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumerRecord
 
to(WriteStream<T>) - Method in class io.vertx.reactivex.core.streams.Pipe
Start to pipe the elements to the destination WriteStream.
toFlowable() - Method in class io.vertx.reactivex.amqp.AmqpReceiver
 
toFlowable() - Method in class io.vertx.reactivex.cassandra.CassandraRowStream
 
toFlowable() - Method in class io.vertx.reactivex.core.eventbus.MessageConsumer
 
toFlowable() - Method in class io.vertx.reactivex.core.file.AsyncFile
 
toFlowable() - Method in class io.vertx.reactivex.core.http.ClientWebSocket
 
toFlowable() - Method in class io.vertx.reactivex.core.http.HttpClientResponse
 
toFlowable() - Method in class io.vertx.reactivex.core.http.HttpServerFileUpload
 
toFlowable() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
 
toFlowable() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
 
toFlowable() - Method in class io.vertx.reactivex.core.http.WebSocket
 
toFlowable() - Method in class io.vertx.reactivex.core.net.NetSocket
 
toFlowable() - Method in class io.vertx.reactivex.core.parsetools.JsonParser
 
toFlowable() - Method in class io.vertx.reactivex.core.parsetools.RecordParser
 
toFlowable() - Method in interface io.vertx.reactivex.core.streams.ReadStream
 
toFlowable() - Method in class io.vertx.reactivex.ext.unit.report.TestSuiteReport
 
toFlowable() - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
 
toFlowable() - Method in class io.vertx.reactivex.grpc.client.GrpcClientResponse
 
toFlowable() - Method in class io.vertx.reactivex.grpc.common.GrpcReadStream
 
toFlowable() - Method in class io.vertx.reactivex.grpc.server.GrpcServerRequest
 
toFlowable() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
 
toFlowable() - Method in class io.vertx.reactivex.pgclient.pubsub.PgChannel
 
toFlowable() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQConsumer
 
toFlowable() - Method in class io.vertx.reactivex.redis.client.RedisConnection
 
toFlowable() - Method in class io.vertx.reactivex.sqlclient.RowStream
 
toJson() - Method in class io.vertx.reactivex.ext.auth.abac.Attribute
 
toJson() - Method in class io.vertx.reactivex.ext.auth.authorization.AndAuthorization
 
toJson() - Method in interface io.vertx.reactivex.ext.auth.authorization.Authorization
 
toJson() - Method in class io.vertx.reactivex.ext.auth.authorization.NotAuthorization
 
toJson() - Method in class io.vertx.reactivex.ext.auth.authorization.OrAuthorization
 
toJson() - Method in class io.vertx.reactivex.ext.auth.authorization.PermissionBasedAuthorization
 
toJson() - Method in class io.vertx.reactivex.ext.auth.authorization.RoleBasedAuthorization
 
toJson() - Method in class io.vertx.reactivex.ext.auth.authorization.WildcardPermissionBasedAuthorization
 
toJson() - Method in class io.vertx.reactivex.ext.mail.MailAttachment
convert this object to JSON representation
toJson() - Method in class io.vertx.reactivex.ext.web.validation.RequestParameters
This method converts RequestParameters in an unique JsonObject with 6 fields: cookie, path, query, header, form, body
cookie, path, query, header, form are JsonObject where keys are param names and values are param values, while body depends on body's shape and may not exist
toJson() - Method in class io.vertx.reactivex.sqlclient.Row
Return a JSON object representation of the row.
tokenExtractor(Function<String, Single<String>>) - Method in class io.vertx.reactivex.ext.web.handler.APIKeyHandler
Transform from user's token format to the AuthenticationHandler's format.
tokenExtractor(Function<String, Future<String>>) - Method in class io.vertx.reactivex.ext.web.handler.APIKeyHandler
Transform from user's token format to the AuthenticationHandler's format.
toNetSocket() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
Establish a TCP tunnel with the client.
toObservable() - Method in class io.vertx.reactivex.amqp.AmqpReceiver
 
toObservable() - Method in class io.vertx.reactivex.cassandra.CassandraRowStream
 
toObservable() - Method in class io.vertx.reactivex.core.eventbus.MessageConsumer
 
toObservable() - Method in class io.vertx.reactivex.core.file.AsyncFile
 
toObservable() - Method in class io.vertx.reactivex.core.http.ClientWebSocket
 
toObservable() - Method in class io.vertx.reactivex.core.http.HttpClientResponse
 
toObservable() - Method in class io.vertx.reactivex.core.http.HttpServerFileUpload
 
toObservable() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
 
toObservable() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
 
toObservable() - Method in class io.vertx.reactivex.core.http.WebSocket
 
toObservable() - Method in class io.vertx.reactivex.core.net.NetSocket
 
toObservable() - Method in class io.vertx.reactivex.core.parsetools.JsonParser
 
toObservable() - Method in class io.vertx.reactivex.core.parsetools.RecordParser
 
toObservable() - Method in interface io.vertx.reactivex.core.streams.ReadStream
 
toObservable() - Method in class io.vertx.reactivex.ext.unit.report.TestSuiteReport
 
toObservable() - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
 
toObservable() - Method in class io.vertx.reactivex.grpc.client.GrpcClientResponse
 
toObservable() - Method in class io.vertx.reactivex.grpc.common.GrpcReadStream
 
toObservable() - Method in class io.vertx.reactivex.grpc.server.GrpcServerRequest
 
toObservable() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
 
toObservable() - Method in class io.vertx.reactivex.pgclient.pubsub.PgChannel
 
toObservable() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQConsumer
 
toObservable() - Method in class io.vertx.reactivex.redis.client.RedisConnection
 
toObservable() - Method in class io.vertx.reactivex.sqlclient.RowStream
 
toObserver() - Method in class io.vertx.reactivex.amqp.AmqpSender
 
toObserver() - Method in class io.vertx.reactivex.core.file.AsyncFile
 
toObserver() - Method in class io.vertx.reactivex.core.http.ClientWebSocket
 
toObserver() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
 
toObserver() - Method in class io.vertx.reactivex.core.http.HttpServerResponse
 
toObserver() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
 
toObserver() - Method in class io.vertx.reactivex.core.http.WebSocket
 
toObserver() - Method in class io.vertx.reactivex.core.net.NetSocket
 
toObserver() - Method in interface io.vertx.reactivex.core.streams.WriteStream
 
toObserver() - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
 
toObserver() - Method in class io.vertx.reactivex.grpc.client.GrpcClientRequest
 
toObserver() - Method in class io.vertx.reactivex.grpc.common.GrpcWriteStream
 
toObserver() - Method in class io.vertx.reactivex.grpc.server.GrpcServerResponse
 
toObserver() - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
 
topic() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumerRecord
 
topic() - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducerRecord
 
topic(Vertx, String) - Static method in class io.vertx.reactivex.ext.stomp.Destination
 
topicName() - Method in class io.vertx.reactivex.mqtt.messages.MqttPublishMessage
 
topicName() - Method in class io.vertx.reactivex.mqtt.MqttTopicSubscription
 
topics() - Method in class io.vertx.reactivex.mqtt.messages.MqttUnsubscribeMessage
 
topicSubscriptions() - Method in class io.vertx.reactivex.mqtt.messages.MqttSubscribeMessage
 
topkAdd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TOPK.ADD.
topkCount(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TOPK.COUNT.
topkIncrby(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TOPK.INCRBY.
topkInfo(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TOPK.INFO.
topkList(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TOPK.LIST.
topkQuery(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TOPK.QUERY.
topkReserve(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TOPK.RESERVE.
toString() - Method in class io.vertx.reactivex.amqp.AmqpClient
 
toString() - Method in class io.vertx.reactivex.amqp.AmqpConnection
 
toString() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
toString() - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
toString() - Method in class io.vertx.reactivex.amqp.AmqpReceiver
 
toString() - Method in class io.vertx.reactivex.amqp.AmqpSender
 
toString() - Method in class io.vertx.reactivex.cassandra.CassandraClient
 
toString() - Method in class io.vertx.reactivex.cassandra.CassandraRowStream
 
toString() - Method in class io.vertx.reactivex.cassandra.ResultSet
 
toString() - Method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
 
toString() - Method in class io.vertx.reactivex.circuitbreaker.FailurePolicy
 
toString() - Method in class io.vertx.reactivex.circuitbreaker.RetryPolicy
 
toString() - Method in class io.vertx.reactivex.config.ConfigRetriever
 
toString() - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
 
toString() - Method in class io.vertx.reactivex.core.dns.DnsClient
 
toString() - Method in class io.vertx.reactivex.core.eventbus.DeliveryContext
 
toString() - Method in class io.vertx.reactivex.core.eventbus.EventBus
 
toString() - Method in class io.vertx.reactivex.core.eventbus.Message
 
toString() - Method in class io.vertx.reactivex.core.eventbus.MessageConsumer
 
toString() - Method in class io.vertx.reactivex.core.eventbus.MessageProducer
 
toString() - Method in class io.vertx.reactivex.core.file.AsyncFile
 
toString() - Method in class io.vertx.reactivex.core.file.AsyncFileLock
 
toString() - Method in class io.vertx.reactivex.core.file.FileSystem
 
toString() - Method in class io.vertx.reactivex.core.http.ClientWebSocket
 
toString() - Method in class io.vertx.reactivex.core.http.HttpClientAgent
 
toString() - Method in class io.vertx.reactivex.core.http.HttpClientBuilder
 
toString() - Method in class io.vertx.reactivex.core.http.HttpClientConnection
 
toString() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
 
toString() - Method in class io.vertx.reactivex.core.http.HttpClientResponse
 
toString() - Method in class io.vertx.reactivex.core.http.HttpConnection
 
toString() - Method in class io.vertx.reactivex.core.http.HttpHeaders
 
toString() - Method in class io.vertx.reactivex.core.http.HttpRequestHead
 
toString() - Method in class io.vertx.reactivex.core.http.HttpServer
 
toString() - Method in class io.vertx.reactivex.core.http.HttpServerFileUpload
 
toString() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
 
toString() - Method in class io.vertx.reactivex.core.http.HttpServerResponse
 
toString() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
 
toString() - Method in class io.vertx.reactivex.core.http.ServerWebSocketHandshake
 
toString() - Method in class io.vertx.reactivex.core.http.WebSocket
 
toString() - Method in class io.vertx.reactivex.core.http.WebSocketClient
 
toString() - Method in class io.vertx.reactivex.core.json.pointer.JsonPointer
Build a string representation of the JSON Pointer
toString() - Method in class io.vertx.reactivex.core.json.pointer.JsonPointerIterator
 
toString() - Method in class io.vertx.reactivex.core.net.endpoint.Endpoint
 
toString() - Method in class io.vertx.reactivex.core.net.endpoint.EndpointResolver
 
toString() - Method in class io.vertx.reactivex.core.net.endpoint.ServerEndpoint
 
toString() - Method in class io.vertx.reactivex.core.net.endpoint.ServerInteraction
 
toString() - Method in class io.vertx.reactivex.core.net.NetClient
 
toString() - Method in class io.vertx.reactivex.core.net.NetServer
 
toString() - Method in class io.vertx.reactivex.core.net.NetSocket
 
toString() - Method in class io.vertx.reactivex.core.parsetools.JsonParser
 
toString() - Method in class io.vertx.reactivex.core.parsetools.RecordParser
 
toString() - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
 
toString() - Method in class io.vertx.reactivex.core.shareddata.Counter
 
toString() - Method in class io.vertx.reactivex.core.shareddata.LocalMap
 
toString() - Method in class io.vertx.reactivex.core.shareddata.Lock
 
toString() - Method in class io.vertx.reactivex.core.shareddata.SharedData
 
toString() - Method in class io.vertx.reactivex.core.streams.Pipe
 
toString() - Method in class io.vertx.reactivex.db2client.DB2Builder
 
toString() - Method in class io.vertx.reactivex.db2client.DB2Connection
 
toString() - Method in class io.vertx.reactivex.ext.auth.abac.Attribute
 
toString() - Method in class io.vertx.reactivex.ext.auth.abac.PolicyBasedAuthorizationProvider
 
toString() - Method in class io.vertx.reactivex.ext.auth.audit.SecurityAudit
 
toString() - Method in class io.vertx.reactivex.ext.auth.authentication.AuthenticationProvider
 
toString() - Method in class io.vertx.reactivex.ext.auth.authorization.AndAuthorization
 
toString() - Method in class io.vertx.reactivex.ext.auth.authorization.AuthorizationContext
 
toString() - Method in class io.vertx.reactivex.ext.auth.authorization.Authorizations
 
toString() - Method in class io.vertx.reactivex.ext.auth.authorization.NotAuthorization
 
toString() - Method in class io.vertx.reactivex.ext.auth.authorization.OrAuthorization
 
toString() - Method in class io.vertx.reactivex.ext.auth.authorization.PermissionBasedAuthorization
 
toString() - Method in class io.vertx.reactivex.ext.auth.authorization.RoleBasedAuthorization
 
toString() - Method in class io.vertx.reactivex.ext.auth.authorization.WildcardPermissionBasedAuthorization
 
toString() - Method in class io.vertx.reactivex.ext.auth.ChainAuth
 
toString() - Method in class io.vertx.reactivex.ext.auth.hashing.HashingAlgorithm
 
toString() - Method in class io.vertx.reactivex.ext.auth.hashing.HashingStrategy
 
toString() - Method in class io.vertx.reactivex.ext.auth.htdigest.HtdigestAuth
 
toString() - Method in class io.vertx.reactivex.ext.auth.htpasswd.HtpasswdAuth
 
toString() - Method in class io.vertx.reactivex.ext.auth.jwt.authorization.JWTAuthorization
 
toString() - Method in class io.vertx.reactivex.ext.auth.jwt.authorization.MicroProfileAuthorization
 
toString() - Method in class io.vertx.reactivex.ext.auth.jwt.JWTAuth
 
toString() - Method in class io.vertx.reactivex.ext.auth.ldap.LdapAuthentication
 
toString() - Method in class io.vertx.reactivex.ext.auth.oauth2.authorization.KeycloakAuthorization
 
toString() - Method in class io.vertx.reactivex.ext.auth.oauth2.authorization.ScopeAuthorization
 
toString() - Method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
 
toString() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.AmazonCognitoAuth
 
toString() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.AppleIdAuth
 
toString() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.AzureADAuth
 
toString() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.BoxAuth
 
toString() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.CloudFoundryAuth
 
toString() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.DropboxAuth
 
toString() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.FacebookAuth
 
toString() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.FoursquareAuth
 
toString() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.GiteeAuth
 
toString() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.GithubAuth
 
toString() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.GitLabAuth
 
toString() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.GoogleAuth
 
toString() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.HerokuAuth
 
toString() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.IBMCloudAuth
 
toString() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.InstagramAuth
 
toString() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.KeycloakAuth
 
toString() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.LinkedInAuth
 
toString() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.LiveAuth
 
toString() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.MailchimpAuth
 
toString() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.OpenIDConnectAuth
 
toString() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.SalesforceAuth
 
toString() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.ShopifyAuth
 
toString() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.SoundcloudAuth
 
toString() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.StripeAuth
 
toString() - Method in class io.vertx.reactivex.ext.auth.oauth2.providers.TwitterAuth
 
toString() - Method in class io.vertx.reactivex.ext.auth.otp.hotp.HotpAuth
 
toString() - Method in class io.vertx.reactivex.ext.auth.otp.OtpKeyGenerator
 
toString() - Method in class io.vertx.reactivex.ext.auth.otp.totp.TotpAuth
 
toString() - Method in class io.vertx.reactivex.ext.auth.prng.VertxContextPRNG
 
toString() - Method in class io.vertx.reactivex.ext.auth.properties.PropertyFileAuthentication
 
toString() - Method in class io.vertx.reactivex.ext.auth.properties.PropertyFileAuthorization
 
toString() - Method in class io.vertx.reactivex.ext.auth.sqlclient.SqlAuthentication
 
toString() - Method in class io.vertx.reactivex.ext.auth.sqlclient.SqlAuthorization
 
toString() - Method in class io.vertx.reactivex.ext.auth.sqlclient.SqlUserUtil
 
toString() - Method in class io.vertx.reactivex.ext.auth.User
 
toString() - Method in class io.vertx.reactivex.ext.auth.webauthn4j.CredentialStorage
 
toString() - Method in class io.vertx.reactivex.ext.auth.webauthn4j.WebAuthn4J
 
toString() - Method in class io.vertx.reactivex.ext.bridge.BaseBridgeEvent
 
toString() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
 
toString() - Method in class io.vertx.reactivex.ext.consul.Watch
 
toString() - Method in class io.vertx.reactivex.ext.consul.WatchResult
 
toString() - Method in class io.vertx.reactivex.ext.dropwizard.MetricsService
 
toString() - Method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.BridgeEvent
 
toString() - Method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.TcpEventBusBridge
 
toString() - Method in class io.vertx.reactivex.ext.healthchecks.HealthChecks
 
toString() - Method in class io.vertx.reactivex.ext.mail.MailAttachment
 
toString() - Method in class io.vertx.reactivex.ext.mail.MailClient
 
toString() - Method in class io.vertx.reactivex.ext.mongo.MongoClient
 
toString() - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
 
toString() - Method in class io.vertx.reactivex.ext.stomp.Acknowledgement
 
toString() - Method in class io.vertx.reactivex.ext.stomp.Destination
 
toString() - Method in class io.vertx.reactivex.ext.stomp.DestinationFactory
 
toString() - Method in class io.vertx.reactivex.ext.stomp.Frames
 
toString() - Method in class io.vertx.reactivex.ext.stomp.ServerFrame
 
toString() - Method in class io.vertx.reactivex.ext.stomp.StompClient
 
toString() - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
 
toString() - Method in class io.vertx.reactivex.ext.stomp.StompServer
 
toString() - Method in class io.vertx.reactivex.ext.stomp.StompServerConnection
 
toString() - Method in class io.vertx.reactivex.ext.stomp.StompServerHandler
 
toString() - Method in class io.vertx.reactivex.ext.unit.Async
 
toString() - Method in class io.vertx.reactivex.ext.unit.collect.EventBusCollector
 
toString() - Method in class io.vertx.reactivex.ext.unit.Completion
 
toString() - Method in class io.vertx.reactivex.ext.unit.report.Failure
 
toString() - Method in class io.vertx.reactivex.ext.unit.report.TestCaseReport
 
toString() - Method in class io.vertx.reactivex.ext.unit.report.TestResult
 
toString() - Method in class io.vertx.reactivex.ext.unit.report.TestSuiteReport
 
toString() - Method in class io.vertx.reactivex.ext.unit.TestCase
 
toString() - Method in class io.vertx.reactivex.ext.unit.TestCompletion
 
toString() - Method in class io.vertx.reactivex.ext.unit.TestContext
 
toString() - Method in class io.vertx.reactivex.ext.unit.TestSuite
 
toString() - Method in class io.vertx.reactivex.ext.web.client.CachingWebClient
 
toString() - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
 
toString() - Method in class io.vertx.reactivex.ext.web.client.HttpResponse
 
toString() - Method in class io.vertx.reactivex.ext.web.client.OAuth2WebClient
 
toString() - Method in class io.vertx.reactivex.ext.web.client.WebClient
 
toString() - Method in class io.vertx.reactivex.ext.web.client.WebClientSession
 
toString() - Method in class io.vertx.reactivex.ext.web.codec.BodyCodec
 
toString() - Method in class io.vertx.reactivex.ext.web.common.template.TemplateEngine
 
toString() - Method in class io.vertx.reactivex.ext.web.common.WebEnvironment
 
toString() - Method in class io.vertx.reactivex.ext.web.FileUpload
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.APIKeyHandler
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.AuthorizationHandler
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.BasicAuthHandler
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.BodyHandler
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.ChainAuthHandler
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.CorsHandler
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.CSPHandler
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.CSRFHandler
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.DigestAuthHandler
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.ErrorHandler
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.FaviconHandler
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.FormLoginHandler
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.graphql.ExecutionInputBuilderWithContext
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.graphql.GraphiQLHandler
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.graphql.GraphiQLHandlerBuilder
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.graphql.GraphQLHandler
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.graphql.GraphQLHandlerBuilder
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.graphql.UploadScalar
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.graphql.ws.ConnectionInitEvent
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.graphql.ws.GraphQLWSHandler
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.graphql.ws.GraphQLWSHandlerBuilder
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.graphql.ws.Message
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.HSTSHandler
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.JWTAuthHandler
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.LoggerFormatter
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.LoggerHandler
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.MethodOverrideHandler
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.MultiTenantHandler
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.OAuth2AuthHandler
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.OtpAuthHandler
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.RedirectAuthHandler
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.ResponseContentTypeHandler
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.ResponseTimeHandler
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.SecurityAuditLoggerHandler
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.SessionHandler
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.SimpleAuthenticationHandler
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.sockjs.BridgeEvent
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSHandler
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.StaticHandler
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.TemplateHandler
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.TimeoutHandler
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.WebAuthn4JHandler
 
toString() - Method in class io.vertx.reactivex.ext.web.handler.XFrameHandler
 
toString() - Method in class io.vertx.reactivex.ext.web.healthchecks.HealthCheckHandler
 
toString() - Method in class io.vertx.reactivex.ext.web.LanguageHeader
 
toString() - Method in class io.vertx.reactivex.ext.web.MIMEHeader
 
toString() - Method in class io.vertx.reactivex.ext.web.multipart.FormDataPart
 
toString() - Method in class io.vertx.reactivex.ext.web.multipart.MultipartForm
 
toString() - Method in class io.vertx.reactivex.ext.web.openapi.router.OpenAPIRoute
 
toString() - Method in class io.vertx.reactivex.ext.web.openapi.router.RequestExtractor
 
toString() - Method in class io.vertx.reactivex.ext.web.openapi.router.RouterBuilder
 
toString() - Method in class io.vertx.reactivex.ext.web.openapi.router.Security
 
toString() - Method in class io.vertx.reactivex.ext.web.ParsedHeaderValues
 
toString() - Method in class io.vertx.reactivex.ext.web.RequestBody
 
toString() - Method in class io.vertx.reactivex.ext.web.Route
 
toString() - Method in class io.vertx.reactivex.ext.web.Router
 
toString() - Method in class io.vertx.reactivex.ext.web.RoutingContext
 
toString() - Method in class io.vertx.reactivex.ext.web.Session
 
toString() - Method in class io.vertx.reactivex.ext.web.sstore.ClusteredSessionStore
 
toString() - Method in class io.vertx.reactivex.ext.web.sstore.cookie.CookieSessionStore
 
toString() - Method in class io.vertx.reactivex.ext.web.sstore.infinispan.InfinispanSessionStore
 
toString() - Method in class io.vertx.reactivex.ext.web.sstore.LocalSessionStore
 
toString() - Method in class io.vertx.reactivex.ext.web.sstore.redis.RedisSessionStore
 
toString() - Method in class io.vertx.reactivex.ext.web.sstore.SessionStore
 
toString() - Method in class io.vertx.reactivex.ext.web.templ.freemarker.FreeMarkerTemplateEngine
 
toString() - Method in class io.vertx.reactivex.ext.web.templ.handlebars.HandlebarsTemplateEngine
 
toString() - Method in class io.vertx.reactivex.ext.web.templ.mvel.MVELTemplateEngine
 
toString() - Method in class io.vertx.reactivex.ext.web.templ.pebble.PebbleTemplateEngine
 
toString() - Method in class io.vertx.reactivex.ext.web.templ.pug.PugTemplateEngine
 
toString() - Method in class io.vertx.reactivex.ext.web.templ.rocker.RockerTemplateEngine
 
toString() - Method in class io.vertx.reactivex.ext.web.templ.thymeleaf.ThymeleafTemplateEngine
 
toString() - Method in class io.vertx.reactivex.ext.web.UserContext
 
toString() - Method in class io.vertx.reactivex.ext.web.validation.builder.ArrayParserFactory
 
toString() - Method in class io.vertx.reactivex.ext.web.validation.builder.Bodies
 
toString() - Method in class io.vertx.reactivex.ext.web.validation.builder.BodyProcessorFactory
 
toString() - Method in class io.vertx.reactivex.ext.web.validation.builder.ObjectParserFactory
 
toString() - Method in class io.vertx.reactivex.ext.web.validation.builder.ParameterProcessorFactory
 
toString() - Method in class io.vertx.reactivex.ext.web.validation.builder.Parameters
 
toString() - Method in class io.vertx.reactivex.ext.web.validation.builder.Parsers
 
toString() - Method in class io.vertx.reactivex.ext.web.validation.builder.StyledParameterProcessorFactory
 
toString() - Method in class io.vertx.reactivex.ext.web.validation.builder.TupleParserFactory
 
toString() - Method in class io.vertx.reactivex.ext.web.validation.builder.ValidationHandlerBuilder
 
toString() - Method in class io.vertx.reactivex.ext.web.validation.RequestParameter
 
toString() - Method in class io.vertx.reactivex.ext.web.validation.RequestParameters
 
toString() - Method in class io.vertx.reactivex.ext.web.validation.RequestPredicate
 
toString() - Method in class io.vertx.reactivex.ext.web.validation.RequestPredicateResult
 
toString() - Method in class io.vertx.reactivex.ext.web.validation.ValidationHandler
 
toString() - Method in class io.vertx.reactivex.grpc.client.GrpcClient
 
toString() - Method in class io.vertx.reactivex.grpc.client.GrpcClientBuilder
 
toString() - Method in class io.vertx.reactivex.grpc.client.GrpcClientRequest
 
toString() - Method in class io.vertx.reactivex.grpc.client.GrpcClientResponse
 
toString() - Method in class io.vertx.reactivex.grpc.common.GrpcReadStream
 
toString() - Method in class io.vertx.reactivex.grpc.common.GrpcWriteStream
 
toString() - Method in class io.vertx.reactivex.grpc.server.GrpcServer
 
toString() - Method in class io.vertx.reactivex.grpc.server.GrpcServerRequest
 
toString() - Method in class io.vertx.reactivex.grpc.server.GrpcServerResponse
 
toString() - Method in class io.vertx.reactivex.jdbcclient.JDBCConnection
 
toString() - Method in class io.vertx.reactivex.jdbcclient.JDBCPool
 
toString() - Method in class io.vertx.reactivex.jdbcclient.SqlOutParam
 
toString() - Method in class io.vertx.reactivex.json.schema.JsonFormatValidator
 
toString() - Method in class io.vertx.reactivex.json.schema.JsonSchema
 
toString() - Method in class io.vertx.reactivex.json.schema.Ref
 
toString() - Method in class io.vertx.reactivex.json.schema.SchemaRepository
 
toString() - Method in class io.vertx.reactivex.json.schema.Validator
 
toString() - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
 
toString() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
 
toString() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumerRecord
 
toString() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumerRecords
 
toString() - Method in class io.vertx.reactivex.kafka.client.producer.KafkaHeader
 
toString() - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
 
toString() - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducerRecord
 
toString() - Method in class io.vertx.reactivex.micrometer.MetricsService
 
toString() - Method in class io.vertx.reactivex.micrometer.PrometheusRequestHandler
 
toString() - Method in class io.vertx.reactivex.micrometer.PrometheusScrapingHandler
 
toString() - Method in class io.vertx.reactivex.mqtt.messages.MqttAuthenticationExchangeMessage
 
toString() - Method in class io.vertx.reactivex.mqtt.messages.MqttConnAckMessage
 
toString() - Method in class io.vertx.reactivex.mqtt.messages.MqttDisconnectMessage
 
toString() - Method in class io.vertx.reactivex.mqtt.messages.MqttPubAckMessage
 
toString() - Method in class io.vertx.reactivex.mqtt.messages.MqttPubCompMessage
 
toString() - Method in class io.vertx.reactivex.mqtt.messages.MqttPublishMessage
 
toString() - Method in class io.vertx.reactivex.mqtt.messages.MqttPubRecMessage
 
toString() - Method in class io.vertx.reactivex.mqtt.messages.MqttPubRelMessage
 
toString() - Method in class io.vertx.reactivex.mqtt.messages.MqttSubAckMessage
 
toString() - Method in class io.vertx.reactivex.mqtt.messages.MqttSubscribeMessage
 
toString() - Method in class io.vertx.reactivex.mqtt.messages.MqttUnsubscribeMessage
 
toString() - Method in class io.vertx.reactivex.mqtt.MqttClient
 
toString() - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
 
toString() - Method in class io.vertx.reactivex.mqtt.MqttServer
 
toString() - Method in class io.vertx.reactivex.mqtt.MqttTopicSubscription
 
toString() - Method in class io.vertx.reactivex.mssqlclient.MSSQLBuilder
 
toString() - Method in class io.vertx.reactivex.mssqlclient.MSSQLConnection
 
toString() - Method in class io.vertx.reactivex.mysqlclient.MySQLBuilder
 
toString() - Method in class io.vertx.reactivex.mysqlclient.MySQLClient
 
toString() - Method in class io.vertx.reactivex.mysqlclient.MySQLConnection
 
toString() - Method in class io.vertx.reactivex.openapi.contract.MediaType
 
toString() - Method in class io.vertx.reactivex.openapi.contract.OAuthFlow
 
toString() - Method in class io.vertx.reactivex.openapi.contract.OAuthFlows
 
toString() - Method in class io.vertx.reactivex.openapi.contract.OpenAPIContract
 
toString() - Method in class io.vertx.reactivex.openapi.contract.Operation
 
toString() - Method in class io.vertx.reactivex.openapi.contract.Parameter
 
toString() - Method in class io.vertx.reactivex.openapi.contract.Path
 
toString() - Method in class io.vertx.reactivex.openapi.contract.RequestBody
 
toString() - Method in class io.vertx.reactivex.openapi.contract.Response
 
toString() - Method in class io.vertx.reactivex.openapi.contract.SecurityRequirement
 
toString() - Method in class io.vertx.reactivex.openapi.contract.SecurityScheme
 
toString() - Method in class io.vertx.reactivex.openapi.contract.Server
 
toString() - Method in class io.vertx.reactivex.openapi.validation.RequestParameter
 
toString() - Method in class io.vertx.reactivex.openapi.validation.RequestValidator
 
toString() - Method in class io.vertx.reactivex.openapi.validation.ResponseParameter
 
toString() - Method in class io.vertx.reactivex.openapi.validation.ValidatableRequest
 
toString() - Method in class io.vertx.reactivex.openapi.validation.ValidatableResponse
 
toString() - Method in class io.vertx.reactivex.openapi.validation.ValidatedRequest
 
toString() - Method in class io.vertx.reactivex.openapi.validation.ValidatedResponse
 
toString() - Method in class io.vertx.reactivex.oracleclient.OracleBuilder
 
toString() - Method in class io.vertx.reactivex.oracleclient.OracleClient
 
toString() - Method in class io.vertx.reactivex.oracleclient.OracleConnection
 
toString() - Method in class io.vertx.reactivex.pgclient.PgBuilder
 
toString() - Method in class io.vertx.reactivex.pgclient.PgConnection
 
toString() - Method in class io.vertx.reactivex.pgclient.pubsub.PgChannel
 
toString() - Method in class io.vertx.reactivex.pgclient.pubsub.PgSubscriber
 
toString() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
 
toString() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQConsumer
 
toString() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQMessage
 
toString() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQPublisher
 
toString() - Method in class io.vertx.reactivex.redis.client.Redis
 
toString() - Method in class io.vertx.reactivex.redis.client.RedisAPI
 
toString() - Method in class io.vertx.reactivex.redis.client.RedisCluster
 
toString() - Method in class io.vertx.reactivex.redis.client.RedisConnection
 
toString() - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
 
toString() - Method in class io.vertx.reactivex.servicediscovery.ServiceReference
 
toString() - Method in class io.vertx.reactivex.servicediscovery.spi.ServiceExporter
 
toString() - Method in class io.vertx.reactivex.servicediscovery.spi.ServiceImporter
 
toString() - Method in class io.vertx.reactivex.servicediscovery.spi.ServicePublisher
 
toString() - Method in class io.vertx.reactivex.servicediscovery.types.EventBusService
 
toString() - Method in class io.vertx.reactivex.servicediscovery.types.HttpEndpoint
 
toString() - Method in class io.vertx.reactivex.servicediscovery.types.MessageSource
 
toString() - Method in class io.vertx.reactivex.servicediscovery.types.MongoDataSource
 
toString() - Method in class io.vertx.reactivex.servicediscovery.types.RedisDataSource
 
toString() - Method in class io.vertx.reactivex.sqlclient.ClientBuilder
 
toString() - Method in class io.vertx.reactivex.sqlclient.Cursor
 
toString() - Method in class io.vertx.reactivex.sqlclient.desc.ColumnDescriptor
 
toString() - Method in class io.vertx.reactivex.sqlclient.Pool
 
toString() - Method in class io.vertx.reactivex.sqlclient.PreparedQuery
 
toString() - Method in class io.vertx.reactivex.sqlclient.PreparedStatement
 
toString() - Method in class io.vertx.reactivex.sqlclient.PropertyKind
 
toString() - Method in class io.vertx.reactivex.sqlclient.Query
 
toString() - Method in class io.vertx.reactivex.sqlclient.Row
 
toString() - Method in class io.vertx.reactivex.sqlclient.RowIterator
 
toString() - Method in class io.vertx.reactivex.sqlclient.RowSet
 
toString() - Method in class io.vertx.reactivex.sqlclient.RowStream
 
toString() - Method in class io.vertx.reactivex.sqlclient.spi.DatabaseMetadata
 
toString() - Method in class io.vertx.reactivex.sqlclient.SqlClient
 
toString() - Method in class io.vertx.reactivex.sqlclient.SqlConnection
 
toString() - Method in class io.vertx.reactivex.sqlclient.SqlResult
 
toString() - Method in class io.vertx.reactivex.sqlclient.templates.RowMapper
 
toString() - Method in class io.vertx.reactivex.sqlclient.templates.SqlTemplate
 
toString() - Method in class io.vertx.reactivex.sqlclient.templates.TupleMapper
 
toString() - Method in class io.vertx.reactivex.sqlclient.Transaction
 
toString() - Method in class io.vertx.reactivex.sqlclient.Tuple
 
toString() - Method in class io.vertx.reactivex.uritemplate.UriTemplate
 
toString() - Method in class io.vertx.reactivex.uritemplate.Variables
 
toSubscriber() - Method in class io.vertx.reactivex.amqp.AmqpSender
 
toSubscriber() - Method in class io.vertx.reactivex.core.file.AsyncFile
 
toSubscriber() - Method in class io.vertx.reactivex.core.http.ClientWebSocket
 
toSubscriber() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
 
toSubscriber() - Method in class io.vertx.reactivex.core.http.HttpServerResponse
 
toSubscriber() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
 
toSubscriber() - Method in class io.vertx.reactivex.core.http.WebSocket
 
toSubscriber() - Method in class io.vertx.reactivex.core.net.NetSocket
 
toSubscriber() - Method in interface io.vertx.reactivex.core.streams.WriteStream
 
toSubscriber() - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
 
toSubscriber() - Method in class io.vertx.reactivex.grpc.client.GrpcClientRequest
 
toSubscriber() - Method in class io.vertx.reactivex.grpc.common.GrpcWriteStream
 
toSubscriber() - Method in class io.vertx.reactivex.grpc.server.GrpcServerResponse
 
toSubscriber() - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
 
TotpAuth - Class in io.vertx.reactivex.ext.auth.otp.totp
An extension of AuthProvider which uses the one time passwords based on time to perform authentication.
TotpAuth(TotpAuth) - Constructor for class io.vertx.reactivex.ext.auth.otp.totp.TotpAuth
 
TotpAuth(Object) - Constructor for class io.vertx.reactivex.ext.auth.otp.totp.TotpAuth
 
touch(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Alters the last access time of a key(s).
toURI() - Method in class io.vertx.reactivex.core.json.pointer.JsonPointer
Build a URI representation of the JSON Pointer
toWebSocket() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
Upgrade the connection of the current request to a WebSocket.
trace() - Method in class io.vertx.reactivex.ext.web.Router
Add a route that matches any HTTP TRACE request
trace(String) - Method in class io.vertx.reactivex.ext.web.Router
Add a route that matches a HTTP TRACE request and the specified path
tracedQuery(Object, JsonPointerIterator) - Method in class io.vertx.reactivex.core.json.pointer.JsonPointer
Query objectToQuery tracing each element walked during the query, including the first and the result (if any).
The first element of the list is objectToQuery and the last is the result, or the element before the first null was encountered
traceOperation() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
 
traceOperation() - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
 
traceOperation(String) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Set the trace operation of this request.
traceOperation(String) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Trace operation name override.
traceWithRegex(String) - Method in class io.vertx.reactivex.ext.web.Router
Add a route that matches a HTTP TRACE request and the specified path regex
trailers() - Method in class io.vertx.reactivex.core.http.HttpClientResponse
 
trailers() - Method in class io.vertx.reactivex.core.http.HttpServerResponse
 
trailers() - Method in class io.vertx.reactivex.ext.web.client.HttpResponse
 
trailers() - Method in class io.vertx.reactivex.grpc.client.GrpcClientResponse
 
trailers() - Method in class io.vertx.reactivex.grpc.server.GrpcServerResponse
 
transaction() - Method in class io.vertx.reactivex.sqlclient.SqlConnection
 
transaction(TxnRequest) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Manages multiple operations inside a single, atomic transaction.
Transaction - Class in io.vertx.reactivex.sqlclient
A transaction.
Transaction(Transaction) - Constructor for class io.vertx.reactivex.sqlclient.Transaction
 
Transaction(Object) - Constructor for class io.vertx.reactivex.sqlclient.Transaction
 
TRANSFER_ENCODING - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Transfer-Encoding header name
truncate(String, long) - Method in class io.vertx.reactivex.core.file.FileSystem
Truncate the file represented by path to length len in bytes, asynchronously.
truncateBlocking(String, long) - Method in class io.vertx.reactivex.core.file.FileSystem
tryComplete(Boolean) - Method in class io.vertx.reactivex.ext.bridge.BaseBridgeEvent
Like Promise.complete(T, java.lang.Throwable) but returns false when the promise is already completed instead of throwing an IllegalStateException, it returns true otherwise.
tryComplete(Boolean) - Method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.BridgeEvent
Like Promise.complete(T, java.lang.Throwable) but returns false when the promise is already completed instead of throwing an IllegalStateException, it returns true otherwise.
tryComplete(Boolean) - Method in class io.vertx.reactivex.ext.web.handler.sockjs.BridgeEvent
Like Promise.complete(T, java.lang.Throwable) but returns false when the promise is already completed instead of throwing an IllegalStateException, it returns true otherwise.
tryComplete(Object) - Method in class io.vertx.reactivex.ext.web.handler.graphql.ws.ConnectionInitEvent
Like Promise.complete(T, java.lang.Throwable) but returns false when the promise is already completed instead of throwing an IllegalStateException, it returns true otherwise.
tryLock() - Method in class io.vertx.reactivex.core.file.AsyncFile
Try to acquire a non-shared lock on the entire file.
tryLock(long, long, boolean) - Method in class io.vertx.reactivex.core.file.AsyncFile
Try to acquire a lock on a portion of this file.
tsAdd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TS.ADD.
tsAlter(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TS.ALTER.
tsCreate(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TS.CREATE.
tsCreaterule(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TS.CREATERULE.
tsDecrby(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TS.DECRBY.
tsDel(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TS.DEL.
tsDeleterule(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TS.DELETERULE.
tsGet(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TS.GET.
tsIncrby(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TS.INCRBY.
tsInfo(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TS.INFO.
tsMadd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TS.MADD.
tsMget(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TS.MGET.
tsMrange(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TS.MRANGE.
tsMrevrange(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TS.MREVRANGE.
tsQueryindex(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TS.QUERYINDEX.
tsRange(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TS.RANGE.
tsRevrange(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Redis command TS.REVRANGE.
ttl() - Method in class io.vertx.reactivex.amqp.AmqpMessage
 
ttl(long) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
ttl(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the time to live for a key in seconds.
tuple() - Static method in class io.vertx.reactivex.sqlclient.Tuple
 
tuple(List<Object>) - Static method in class io.vertx.reactivex.sqlclient.Tuple
Create a tuple with the provided elements list.
Tuple - Class in io.vertx.reactivex.sqlclient
A general purpose tuple.
Tuple(Tuple) - Constructor for class io.vertx.reactivex.sqlclient.Tuple
 
Tuple(Object) - Constructor for class io.vertx.reactivex.sqlclient.Tuple
 
TupleMapper<T> - Class in io.vertx.reactivex.sqlclient.templates
Map an arbitrary T object to a .
TupleMapper(TupleMapper) - Constructor for class io.vertx.reactivex.sqlclient.templates.TupleMapper
 
TupleMapper(Object, TypeArg<T>) - Constructor for class io.vertx.reactivex.sqlclient.templates.TupleMapper
 
TupleParserFactory - Class in io.vertx.reactivex.ext.web.validation.builder
This interface is used to create able to parse serialized object structures.
TupleParserFactory(TupleParserFactory) - Constructor for class io.vertx.reactivex.ext.web.validation.builder.TupleParserFactory
 
TupleParserFactory(Object) - Constructor for class io.vertx.reactivex.ext.web.validation.builder.TupleParserFactory
 
TwitterAuth - Class in io.vertx.reactivex.ext.auth.oauth2.providers
Simplified factory to create an for Twitter.
TwitterAuth(TwitterAuth) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.TwitterAuth
 
TwitterAuth(Object) - Constructor for class io.vertx.reactivex.ext.auth.oauth2.providers.TwitterAuth
 
type() - Method in class io.vertx.reactivex.ext.bridge.BaseBridgeEvent
 
type() - Method in class io.vertx.reactivex.ext.web.handler.graphql.ws.Message
 
type() - Method in class io.vertx.reactivex.jdbcclient.SqlOutParam
Get the output type
type(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Determine the type stored at key.
TYPE - Static variable in class io.vertx.reactivex.servicediscovery.types.EventBusService
Name of the type.
TYPE - Static variable in class io.vertx.reactivex.servicediscovery.types.HttpEndpoint
 
TYPE - Static variable in class io.vertx.reactivex.servicediscovery.types.MessageSource
 
TYPE - Static variable in class io.vertx.reactivex.servicediscovery.types.MongoDataSource
 
TYPE - Static variable in class io.vertx.reactivex.servicediscovery.types.RedisDataSource
 
typeName() - Method in class io.vertx.reactivex.sqlclient.desc.ColumnDescriptor
 

U

UNKNOWN - Static variable in class io.vertx.reactivex.servicediscovery.types.EventBusService
Unknown type.
UNKNOWN - Static variable in class io.vertx.reactivex.servicediscovery.types.HttpEndpoint
Unknown type.
UNKNOWN - Static variable in class io.vertx.reactivex.servicediscovery.types.MessageSource
Unknown type.
UNKNOWN - Static variable in class io.vertx.reactivex.servicediscovery.types.MongoDataSource
Unknown type.
UNKNOWN - Static variable in class io.vertx.reactivex.servicediscovery.types.RedisDataSource
Unknown type.
unlink(String) - Method in class io.vertx.reactivex.core.file.FileSystem
Unlinks the link on the file system represented by the path link, asynchronously.
unlink(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Delete a key asynchronously in another thread.
unlinkBlocking(String) - Method in class io.vertx.reactivex.core.file.FileSystem
unlistenMulticastGroup(String) - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
Leaves a multicast group and stops listening for packets send to it.
unlistenMulticastGroup(String, String, String) - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
Leaves a multicast group and stops listening for packets send to it on the given network interface.
unpublish(String) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
Un-publishes a record.
unpublish(String) - Method in class io.vertx.reactivex.servicediscovery.spi.ServicePublisher
Un-publishes a record.
unregister() - Method in class io.vertx.reactivex.core.eventbus.MessageConsumer
Unregisters the handler which created this registration
unregister(String) - Method in class io.vertx.reactivex.ext.healthchecks.HealthChecks
Unregisters a procedure.
unregister(String) - Method in class io.vertx.reactivex.ext.web.healthchecks.HealthCheckHandler
Unregisters a procedure.
unregisterCodec(String) - Method in class io.vertx.reactivex.core.eventbus.EventBus
Unregister a message codec.
unsubscribe() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
Unsubscribe from topics currently subscribed with subscribe.
unsubscribe(StompServerConnection, Frame) - Method in class io.vertx.reactivex.ext.stomp.Destination
Handles a un-subscription request to the current Destination.
unsubscribe(String) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Un-subscribes from the given destination.
unsubscribe(String) - Method in class io.vertx.reactivex.mqtt.MqttClient
Unsubscribe from receiving messages on given topic
unsubscribe(String, Map<String, String>) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Un-subscribes from the given destination.
unsubscribe(List<String>) - Method in class io.vertx.reactivex.mqtt.MqttClient
Unsubscribe from receiving messages on given list of topic
unsubscribe(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Stop listening for messages posted to the given channels.
unsubscribeAcknowledge(int) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Sends the UNSUBACK message to the remote MQTT client
unsubscribeAcknowledge(int, List<MqttUnsubAckReasonCode>, MqttProperties) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Sends the UNSUBACK message to the remote MQTT client
unsubscribeCompletionHandler(Handler<Integer>) - Method in class io.vertx.reactivex.mqtt.MqttClient
Sets handler which will be called after UNSUBACK packet receiving
unsubscribeConnection(StompServerConnection) - Method in class io.vertx.reactivex.ext.stomp.Destination
Removes all subscriptions of the given connection
unsubscribeHandler(Handler<ServerFrame>) - Method in class io.vertx.reactivex.ext.stomp.StompServerHandler
Configures the action to execute when a UNSUBSCRIBE frame is received.
unsubscribeHandler(Handler<MqttUnsubscribeMessage>) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
Set a unsubscribe handler on the MQTT endpoint.
unwatch() - Method in class io.vertx.reactivex.redis.client.RedisAPI
Forget about all watched keys.
unwrap() - Method in class io.vertx.reactivex.amqp.AmqpConnection
 
unwrap() - Method in class io.vertx.reactivex.amqp.AmqpReceiver
 
unwrap() - Method in class io.vertx.reactivex.amqp.AmqpSender
 
unwrap() - Method in class io.vertx.reactivex.ext.web.common.template.TemplateEngine
Returns the underlying engine, so further configurations or customizations may be applied or null when the engine cannot unwrap it.
unwrap() - Method in class io.vertx.reactivex.ext.web.templ.freemarker.FreeMarkerTemplateEngine
 
unwrap() - Method in class io.vertx.reactivex.ext.web.templ.handlebars.HandlebarsTemplateEngine
 
unwrap() - Method in class io.vertx.reactivex.ext.web.templ.pebble.PebbleTemplateEngine
 
unwrap() - Method in class io.vertx.reactivex.ext.web.templ.pug.PugTemplateEngine
 
unwrap() - Method in class io.vertx.reactivex.ext.web.templ.thymeleaf.ThymeleafTemplateEngine
 
update(Record) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
Updates the given record.
update(Record) - Method in class io.vertx.reactivex.servicediscovery.spi.ServicePublisher
Updates an existing record.
updateAclToken(String, AclToken) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Update an existing Acl token
updateCheck(String, CheckStatus) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Set status of the check to given status.
updateCheckWithNote(String, CheckStatus, String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Set status of the check to given status.
updateCollection(String, JsonObject, JsonArray) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Use an aggregation pipeline to update documents in the specified collection and return the handler with MongoClientUpdateResult result
updateCollection(String, JsonObject, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Update matching documents in the specified collection and return the handler with MongoClientUpdateResult result
updateCollectionWithOptions(String, JsonObject, JsonArray, UpdateOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Use an aggregation pipeline to update documents in the specified collection, specifying options and return the handler with MongoClientUpdateResult result
updateCollectionWithOptions(String, JsonObject, JsonObject, UpdateOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Update matching documents in the specified collection, specifying options and return the handler with MongoClientUpdateResult result
updateCounter(Authenticator) - Method in class io.vertx.reactivex.ext.auth.webauthn4j.CredentialStorage
Updates a previously stored credential counter, as identified by its user name (may be null) and credential ID (cannot be null, must be unique).
updatePolicy(String, AclPolicy) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
This endpoint updates an existing ACL policy
updatePreparedQuery(PreparedQueryDefinition) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
 
updateSettings(Http2Settings) - Method in class io.vertx.reactivex.core.http.HttpConnection
Send to the remote endpoint an update of this endpoint settings
updateSSLOptions(ClientSSLOptions) - Method in class io.vertx.reactivex.core.http.HttpClientAgent
Update the client with new SSL options, the update happens if the options object is valid and different from the existing options object.
updateSSLOptions(ClientSSLOptions) - Method in class io.vertx.reactivex.core.http.WebSocketClient
Update the client with new SSL options, the update happens if the options object is valid and different from the existing options object.
updateSSLOptions(ClientSSLOptions) - Method in class io.vertx.reactivex.core.net.NetClient
Update the client with new SSL options, the update happens if the options object is valid and different from the existing options object.
updateSSLOptions(ClientSSLOptions) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Update the client with new SSL options, the update happens if the options object is valid and different from the existing options object.
updateSSLOptions(ClientSSLOptions, boolean) - Method in class io.vertx.reactivex.core.http.HttpClientAgent
Update the client with new SSL options, the update happens if the options object is valid and different from the existing options object.
updateSSLOptions(ClientSSLOptions, boolean) - Method in class io.vertx.reactivex.core.http.WebSocketClient
Update the client with new SSL options, the update happens if the options object is valid and different from the existing options object.
updateSSLOptions(ClientSSLOptions, boolean) - Method in class io.vertx.reactivex.core.net.NetClient
Update the client with new SSL options, the update happens if the options object is valid and different from the existing options object.
updateSSLOptions(ClientSSLOptions, boolean) - Method in class io.vertx.reactivex.ext.web.client.WebClient
Update the client with new SSL options, the update happens if the options object is valid and different from the existing options object.
updateSSLOptions(ServerSSLOptions) - Method in class io.vertx.reactivex.core.http.HttpServer
Update the server with new SSL options, the update happens if the options object is valid and different from the existing options object.
updateSSLOptions(ServerSSLOptions) - Method in class io.vertx.reactivex.core.net.NetServer
Update the server with new SSL options, the update happens if the options object is valid and different from the existing options object.
updateSSLOptions(ServerSSLOptions, boolean) - Method in class io.vertx.reactivex.core.http.HttpServer
Update the server with new SSL options, the update happens if the options object is valid and different from the existing options object.
updateSSLOptions(ServerSSLOptions, boolean) - Method in class io.vertx.reactivex.core.net.NetServer
Update the server with new SSL options, the update happens if the options object is valid and different from the existing options object.
updateTrafficShapingOptions(TrafficShapingOptions) - Method in class io.vertx.reactivex.core.http.HttpServer
Update the server with new traffic options, the update happens if the options object is valid and different from the existing options object.
updateTrafficShapingOptions(TrafficShapingOptions) - Method in class io.vertx.reactivex.core.net.NetServer
Update the server with new traffic options, the update happens if the options object is valid and different from the existing options object.
UPGRADE - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Upgrade header value
upgradeToSsl() - Method in class io.vertx.reactivex.core.net.NetSocket
Like NetSocket.upgradeToSsl() with the default SSL options, without indicating a server name, without an upgrade message.
upgradeToSsl(Buffer) - Method in class io.vertx.reactivex.core.net.NetSocket
Like NetSocket.upgradeToSsl() with the default SSL options and without indicating a server name.
upgradeToSsl(SSLOptions) - Method in class io.vertx.reactivex.core.net.NetSocket
Upgrade channel to use SSL/TLS.
upgradeToSsl(SSLOptions, Buffer) - Method in class io.vertx.reactivex.core.net.NetSocket
Like NetSocket.upgradeToSsl() without indicating a server name
upgradeToSsl(SSLOptions, String) - Method in class io.vertx.reactivex.core.net.NetSocket
Like NetSocket.upgradeToSsl() without an upgrade message.
upgradeToSsl(SSLOptions, String, Buffer) - Method in class io.vertx.reactivex.core.net.NetSocket
Upgrade the channel to use SSL/TLS, in other words proceeds to the TLS handshake.
upgradeToSsl(String) - Method in class io.vertx.reactivex.core.net.NetSocket
Like NetSocket.upgradeToSsl() with the default SSL options and without an update message.
upgradeToSsl(String, Buffer) - Method in class io.vertx.reactivex.core.net.NetSocket
Like NetSocket.upgradeToSsl() with the default SSL options.
uploadByFileName(Flowable<Buffer>, String) - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
 
uploadByFileName(ReadStream<Buffer>, String) - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
 
uploadByFileNameWithOptions(Flowable<Buffer>, String, GridFsUploadOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
 
uploadByFileNameWithOptions(ReadStream<Buffer>, String, GridFsUploadOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
 
uploadedFileName() - Method in class io.vertx.reactivex.ext.web.FileUpload
 
uploadFile(String) - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
Upload a file to gridfs
uploadFileWithOptions(String, GridFsUploadOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
Upload a file to gridfs with options
uploadHandler(Handler<HttpServerFileUpload>) - Method in class io.vertx.reactivex.core.http.HttpServerRequest
Set an upload handler.
UploadScalar - Class in io.vertx.reactivex.ext.web.handler.graphql
 
UploadScalar(UploadScalar) - Constructor for class io.vertx.reactivex.ext.web.handler.graphql.UploadScalar
 
UploadScalar(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.graphql.UploadScalar
 
uri() - Method in class io.vertx.reactivex.core.http.HttpRequestHead
 
uri() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
 
uri() - Method in class io.vertx.reactivex.core.http.ServerWebSocketHandshake
 
uri() - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
 
uri() - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
Return the URI corresponding to the last request for this socket or the websocket handshake
uri(String) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Configure the request to use a new request URI value.
UriTemplate - Class in io.vertx.reactivex.uritemplate
A URI template that follows the rfc6570 level 4.
UriTemplate(UriTemplate) - Constructor for class io.vertx.reactivex.uritemplate.UriTemplate
 
UriTemplate(Object) - Constructor for class io.vertx.reactivex.uritemplate.UriTemplate
 
useNormalizedPath(boolean) - Method in class io.vertx.reactivex.ext.web.Route
If true then the normalized request path will be used when routing (e.g. removing duplicate /) Default is true
user() - Method in class io.vertx.reactivex.ext.auth.authorization.AuthorizationContext
Get the authenticated user
user() - Method in class io.vertx.reactivex.ext.web.RoutingContext
Get the authenticated user (if any).
user(User) - Method in class io.vertx.reactivex.ext.auth.audit.SecurityAudit
 
User - Class in io.vertx.reactivex.ext.auth
Represents an authenticates User and contains operations to authorise the user.
User(User) - Constructor for class io.vertx.reactivex.ext.auth.User
 
User(Object) - Constructor for class io.vertx.reactivex.ext.auth.User
 
USER_AGENT - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
User-Agent header name
userContext() - Method in class io.vertx.reactivex.ext.web.RoutingContext
Control the user associated with this request.
UserContext - Class in io.vertx.reactivex.ext.web
A web user is extended user coupled to the context and is used to perform verifications and actions on behalf of the user.
UserContext(UserContext) - Constructor for class io.vertx.reactivex.ext.web.UserContext
 
UserContext(Object) - Constructor for class io.vertx.reactivex.ext.web.UserContext
 
userInfo(User) - Method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
Retrieve profile information and other attributes for a logged-in end-user.
using(Vertx) - Method in class io.vertx.reactivex.sqlclient.ClientBuilder
Sets the vertx instance to use.

V

ValidatableRequest - Class in io.vertx.reactivex.openapi.validation
 
ValidatableRequest(ValidatableRequest) - Constructor for class io.vertx.reactivex.openapi.validation.ValidatableRequest
 
ValidatableRequest(Object) - Constructor for class io.vertx.reactivex.openapi.validation.ValidatableRequest
 
ValidatableResponse - Class in io.vertx.reactivex.openapi.validation
 
ValidatableResponse(ValidatableResponse) - Constructor for class io.vertx.reactivex.openapi.validation.ValidatableResponse
 
ValidatableResponse(Object) - Constructor for class io.vertx.reactivex.openapi.validation.ValidatableResponse
 
validate(HttpServerRequest) - Method in class io.vertx.reactivex.openapi.validation.RequestValidator
Like RequestValidator.validate(io.vertx.reactivex.core.http.HttpServerRequest), but the operationId and ValidatableRequest are determined from the passed request.
validate(HttpServerRequest, String) - Method in class io.vertx.reactivex.openapi.validation.RequestValidator
validate(ValidatableRequest, String) - Method in class io.vertx.reactivex.openapi.validation.RequestValidator
Validates the passed request parameters against the operation defined in the related OpenAPI contract.
validate(Object) - Method in class io.vertx.reactivex.json.schema.Validator
Validate a given input against the initial schema.
ValidatedRequest - Class in io.vertx.reactivex.openapi.validation
 
ValidatedRequest(ValidatedRequest) - Constructor for class io.vertx.reactivex.openapi.validation.ValidatedRequest
 
ValidatedRequest(Object) - Constructor for class io.vertx.reactivex.openapi.validation.ValidatedRequest
 
ValidatedResponse - Class in io.vertx.reactivex.openapi.validation
 
ValidatedResponse(ValidatedResponse) - Constructor for class io.vertx.reactivex.openapi.validation.ValidatedResponse
 
ValidatedResponse(Object) - Constructor for class io.vertx.reactivex.openapi.validation.ValidatedResponse
 
validateFormat(String, String, Object) - Method in class io.vertx.reactivex.json.schema.JsonFormatValidator
 
ValidationHandler - Class in io.vertx.reactivex.ext.web.validation
 
ValidationHandler(ValidationHandler) - Constructor for class io.vertx.reactivex.ext.web.validation.ValidationHandler
 
ValidationHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.validation.ValidationHandler
 
ValidationHandlerBuilder - Class in io.vertx.reactivex.ext.web.validation.builder
Builder for a .
ValidationHandlerBuilder(ValidationHandlerBuilder) - Constructor for class io.vertx.reactivex.ext.web.validation.builder.ValidationHandlerBuilder
 
ValidationHandlerBuilder(Object) - Constructor for class io.vertx.reactivex.ext.web.validation.builder.ValidationHandlerBuilder
 
validator(JsonSchema) - Method in class io.vertx.reactivex.json.schema.SchemaRepository
A new validator instance using this repository options.
validator(JsonSchema, JsonSchemaOptions) - Method in class io.vertx.reactivex.json.schema.SchemaRepository
A new validator instance overriding this repository options.
validator(JsonSchema, JsonSchemaOptions, boolean) - Method in class io.vertx.reactivex.json.schema.SchemaRepository
A new validator instance overriding this repository options.
validator(String) - Method in class io.vertx.reactivex.json.schema.SchemaRepository
A new validator instance using this repository options.
validator(String, JsonSchemaOptions) - Method in class io.vertx.reactivex.json.schema.SchemaRepository
A new validator instance overriding this repository options.
Validator - Class in io.vertx.reactivex.json.schema
A validator, validates some input object using a well known schema.
Validator(Validator) - Constructor for class io.vertx.reactivex.json.schema.Validator
 
Validator(Object) - Constructor for class io.vertx.reactivex.json.schema.Validator
 
value() - Method in class io.vertx.reactivex.ext.web.LanguageHeader
Holds the unparsed value of the header.
For the most part, this is the content before the semi-colon (";")
value() - Method in class io.vertx.reactivex.ext.web.MIMEHeader
Holds the unparsed value of the header.
For the most part, this is the content before the semi-colon (";")
value() - Method in class io.vertx.reactivex.ext.web.multipart.FormDataPart
 
value() - Method in interface io.vertx.reactivex.ext.web.ParsedHeaderValue
Holds the unparsed value of the header.
For the most part, this is the content before the semi-colon (";")
value() - Method in class io.vertx.reactivex.ext.web.Session
The short representation of the session to be added to the session cookie.
value() - Method in class io.vertx.reactivex.jdbcclient.SqlOutParam
Get the input value
value() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumerRecord
 
value() - Method in class io.vertx.reactivex.kafka.client.producer.KafkaHeader
 
value() - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducerRecord
 
value() - Method in class io.vertx.reactivex.sqlclient.RowSet
Get the execution result value, the execution result type may vary such as a rowSet or even a String.
value() - Method in class io.vertx.reactivex.sqlclient.SqlResult
Get the execution result value, the execution result type may vary such as a rowSet or even a String.
values() - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
Get the values of the map, asynchronously.
variables() - Method in class io.vertx.reactivex.ext.auth.authorization.AuthorizationContext
 
variables() - Static method in class io.vertx.reactivex.uritemplate.Variables
 
variables(JsonObject) - Static method in class io.vertx.reactivex.uritemplate.Variables
Create an instance populated from a JSON object: null are conserved JsonArray is converted to List JsonObject is converted to Map any other value is converted to a string Note that nested JSON elements are converted to a string, so { "user": { "first_name": "John", "last_name": "Doe", "address" : { "city": "Paris", etc... } } } flattens the JSON "address" to the string "{\"city\":\"Paris\",etc...}".
Variables - Class in io.vertx.reactivex.uritemplate
Holds a set of name/value pairs where each value can be a String or a List or a Map.
Variables(Variables) - Constructor for class io.vertx.reactivex.uritemplate.Variables
 
Variables(Object) - Constructor for class io.vertx.reactivex.uritemplate.Variables
 
VARY - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
Vary header name
verify(Handler<Void>) - Method in class io.vertx.reactivex.ext.unit.TestContext
Execute the provided handler, which may contain assertions, possibly from any third-party assertion framework.
verify(Authorization) - Method in class io.vertx.reactivex.ext.auth.authorization.AndAuthorization
this method verifies whether or not the authorization implies the specified authorization.
verify(Authorization) - Method in interface io.vertx.reactivex.ext.auth.authorization.Authorization
this method verifies whether or not the authorization implies the specified authorization.
verify(Authorization) - Method in class io.vertx.reactivex.ext.auth.authorization.Authorizations
Verifies that the given authorization is present in the authorizations.
verify(Authorization) - Method in class io.vertx.reactivex.ext.auth.authorization.NotAuthorization
this method verifies whether or not the authorization implies the specified authorization.
verify(Authorization) - Method in class io.vertx.reactivex.ext.auth.authorization.OrAuthorization
this method verifies whether or not the authorization implies the specified authorization.
verify(Authorization) - Method in class io.vertx.reactivex.ext.auth.authorization.PermissionBasedAuthorization
this method verifies whether or not the authorization implies the specified authorization.
verify(Authorization) - Method in class io.vertx.reactivex.ext.auth.authorization.RoleBasedAuthorization
this method verifies whether or not the authorization implies the specified authorization.
verify(Authorization) - Method in class io.vertx.reactivex.ext.auth.authorization.WildcardPermissionBasedAuthorization
this method verifies whether or not the authorization implies the specified authorization.
verify(String, String) - Method in class io.vertx.reactivex.ext.auth.hashing.HashingStrategy
Time constant password check.
verifyUrl(String) - Method in class io.vertx.reactivex.ext.web.handler.OtpAuthHandler
Specify the URL where requests are to be redirected when a user is already known in the request.
version() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
 
version() - Method in class io.vertx.reactivex.core.http.HttpClientResponse
 
version() - Method in interface io.vertx.reactivex.core.http.HttpResponseHead
 
version() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
 
version() - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
 
version() - Method in class io.vertx.reactivex.ext.web.client.HttpResponse
 
vertx() - Method in class io.vertx.reactivex.ext.stomp.StompClient
 
vertx() - Method in class io.vertx.reactivex.ext.stomp.StompServer
 
vertx() - Method in class io.vertx.reactivex.ext.web.RoutingContext
 
VertxContextPRNG - Class in io.vertx.reactivex.ext.auth.prng
A secure non blocking random number generator isolated to the current context.
VertxContextPRNG(VertxContextPRNG) - Constructor for class io.vertx.reactivex.ext.auth.prng.VertxContextPRNG
 
VertxContextPRNG(Object) - Constructor for class io.vertx.reactivex.ext.auth.prng.VertxContextPRNG
 
virtualHost() - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
 
virtualHost(String) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
Configure the request to use a virtual host value.
virtualHost(String) - Method in class io.vertx.reactivex.ext.web.Route
Add a virtual host filter for this route.

W

wait(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Wait for the synchronous replication of all the write commands sent in the context of the current connection.
waitForConfirms() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Wait until all messages published since the last call have been either ack'd or nack'd by the broker.
waitForConfirms(long) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
Wait until all messages published since the last call have been either ack'd or nack'd by the broker; or until timeout elapses.
warnCheck(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Set status of the check to "warning".
warnCheckWithNote(String, String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
Set status of the check to "warning".
wasApplied() - Method in class io.vertx.reactivex.cassandra.ResultSet
 
watch(String, JsonArray, boolean, int) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
Watch the collection change.
watch(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Watch the given keys to determine execution of the MULTI/EXEC block.
Watch<T> - Class in io.vertx.reactivex.ext.consul
Watches are a way of specifying a view of data (e.g. list of nodes, KV pairs, health checks) which is monitored for updates.
Watch(Watch) - Constructor for class io.vertx.reactivex.ext.consul.Watch
 
Watch(Object, TypeArg<T>) - Constructor for class io.vertx.reactivex.ext.consul.Watch
 
WatchResult<T> - Class in io.vertx.reactivex.ext.consul
 
WatchResult(WatchResult) - Constructor for class io.vertx.reactivex.ext.consul.WatchResult
 
WatchResult(Object, TypeArg<T>) - Constructor for class io.vertx.reactivex.ext.consul.WatchResult
 
WebAuthn4J - Class in io.vertx.reactivex.ext.auth.webauthn4j
Factory interface for creating WebAuthN based AuthenticationProvider instances.
WebAuthn4J(WebAuthn4J) - Constructor for class io.vertx.reactivex.ext.auth.webauthn4j.WebAuthn4J
 
WebAuthn4J(Object) - Constructor for class io.vertx.reactivex.ext.auth.webauthn4j.WebAuthn4J
 
WebAuthn4JHandler - Class in io.vertx.reactivex.ext.web.handler
An auth handler that provides FIDO2 WebAuthN Relay Party support.
WebAuthn4JHandler(WebAuthn4JHandler) - Constructor for class io.vertx.reactivex.ext.web.handler.WebAuthn4JHandler
 
WebAuthn4JHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.WebAuthn4JHandler
 
WebClient - Class in io.vertx.reactivex.ext.web.client
An asynchronous HTTP / HTTP/2 client called WebClient.
WebClient(WebClient) - Constructor for class io.vertx.reactivex.ext.web.client.WebClient
 
WebClient(Object) - Constructor for class io.vertx.reactivex.ext.web.client.WebClient
 
WebClientSession - Class in io.vertx.reactivex.ext.web.client
An asynchronous sessions aware HTTP / HTTP/2 client called WebClientSession.
WebClientSession(WebClientSession) - Constructor for class io.vertx.reactivex.ext.web.client.WebClientSession
 
WebClientSession(Object) - Constructor for class io.vertx.reactivex.ext.web.client.WebClientSession
 
WebEnvironment - Class in io.vertx.reactivex.ext.web.common
Utility API to verify which environment is the web application running.
WebEnvironment(WebEnvironment) - Constructor for class io.vertx.reactivex.ext.web.common.WebEnvironment
 
WebEnvironment(Object) - Constructor for class io.vertx.reactivex.ext.web.common.WebEnvironment
 
webSession() - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
 
webSocket() - Method in class io.vertx.reactivex.core.http.WebSocketClient
Create a WebSocket that is not yet connected to the server.
WebSocket - Class in io.vertx.reactivex.core.http
Common WebSocket implementation.
WebSocket(WebSocket) - Constructor for class io.vertx.reactivex.core.http.WebSocket
 
WebSocket(Object) - Constructor for class io.vertx.reactivex.core.http.WebSocket
 
WEBSOCKET - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
WebSocket header value
WebSocketBase - Interface in io.vertx.reactivex.core.http
Base WebSocket implementation.
WebSocketClient - Class in io.vertx.reactivex.core.http
An asynchronous WebSocket client.
WebSocketClient(WebSocketClient) - Constructor for class io.vertx.reactivex.core.http.WebSocketClient
 
WebSocketClient(Object) - Constructor for class io.vertx.reactivex.core.http.WebSocketClient
 
webSocketHandler() - Method in class io.vertx.reactivex.ext.stomp.StompServer
Gets the able to manage web socket connections.
webSocketHandler(Handler<ServerWebSocket>) - Method in class io.vertx.reactivex.core.http.HttpServer
Set the WebSocket handler for the server to wsHandler.
webSocketHandshakeHandler() - Method in class io.vertx.reactivex.ext.stomp.StompServer
Gets the able to manage web socket connection handshakes.
webSocketHandshakeHandler(Handler<ServerWebSocketHandshake>) - Method in class io.vertx.reactivex.core.http.HttpServer
Set a handler for WebSocket handshake.
webUser() - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
 
weight() - Method in class io.vertx.reactivex.ext.web.LanguageHeader
Holds the weight specified in the "q" parameter of the header.
If the parameter is not specified, 1.0 is assumed according to rfc7231
weight() - Method in class io.vertx.reactivex.ext.web.MIMEHeader
Holds the weight specified in the "q" parameter of the header.
If the parameter is not specified, 1.0 is assumed according to rfc7231
weight() - Method in interface io.vertx.reactivex.ext.web.ParsedHeaderValue
Holds the weight specified in the "q" parameter of the header.
If the parameter is not specified, 1.0 is assumed according to rfc7231
weightedOrder() - Method in class io.vertx.reactivex.ext.web.LanguageHeader
An integer that represents the absolute order position of this header
weightedOrder() - Method in class io.vertx.reactivex.ext.web.MIMEHeader
An integer that represents the absolute order position of this header
weightedOrder() - Method in interface io.vertx.reactivex.ext.web.ParsedHeaderValue
An integer that represents the absolute order position of this header
WildcardPermissionBasedAuthorization - Class in io.vertx.reactivex.ext.auth.authorization
Represents a wildcard permission (ie: 'manage:order:*' '*:orders', '*', etc.)
WildcardPermissionBasedAuthorization(WildcardPermissionBasedAuthorization) - Constructor for class io.vertx.reactivex.ext.auth.authorization.WildcardPermissionBasedAuthorization
 
WildcardPermissionBasedAuthorization(Object) - Constructor for class io.vertx.reactivex.ext.auth.authorization.WildcardPermissionBasedAuthorization
 
will() - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
 
with(HttpClientOptions) - Method in class io.vertx.reactivex.core.http.HttpClientBuilder
Configure the client options.
with(HttpClientOptions) - Method in class io.vertx.reactivex.grpc.client.GrpcClientBuilder
Configure the client HTTP transport options.
with(PoolOptions) - Method in class io.vertx.reactivex.core.http.HttpClientBuilder
Configure the client with the given pool options.
with(NetClientOptions) - Method in class io.vertx.reactivex.sqlclient.ClientBuilder
Configure the client pool with the given transport options.
with(GraphiQLHandlerOptions) - Method in class io.vertx.reactivex.ext.web.handler.graphql.GraphiQLHandlerBuilder
Change the GraphiQLHandlerOptions to use.
with(GraphQLHandlerOptions) - Method in class io.vertx.reactivex.ext.web.handler.graphql.GraphQLHandlerBuilder
Change the GraphQLHandlerOptions to use.
with(GraphQLWSOptions) - Method in class io.vertx.reactivex.ext.web.handler.graphql.ws.GraphQLWSHandlerBuilder
Change the GraphQLWSOptions to use.
with(GrpcClientOptions) - Method in class io.vertx.reactivex.grpc.client.GrpcClientBuilder
Configure the client options.
with(PoolOptions) - Method in class io.vertx.reactivex.sqlclient.ClientBuilder
Configure the client with the given pool options
withAddressResolver(AddressResolver) - Method in class io.vertx.reactivex.grpc.client.GrpcClientBuilder
Configure the client to use a specific address resolver.
withBody(String) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
withBodyHandler() - Static method in class io.vertx.reactivex.ext.web.openapi.router.RequestExtractor
 
withBooleanAsBody(boolean) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
withBufferAsBody(Buffer) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
withByteAsBody(byte) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
withCharAsBody(char) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
withConnectHandler(Handler<HttpConnection>) - Method in class io.vertx.reactivex.core.http.HttpClientBuilder
Set a connection handler for the client.
withConnectHandler(Handler<SqlConnection>) - Method in class io.vertx.reactivex.sqlclient.ClientBuilder
Set a handler called when the pool has established a connection to the database.
withConnection(Function<SqlConnection, Maybe<T>>) - Method in class io.vertx.reactivex.sqlclient.Pool
Get a connection from the pool and execute the given function.
withConnection(Function<SqlConnection, Future<T>>) - Method in class io.vertx.reactivex.sqlclient.Pool
Get a connection from the pool and execute the given function.
withCredentials(Credentials) - Method in class io.vertx.reactivex.ext.web.client.OAuth2WebClient
Mark that request should be dispatched with authentication obtained from passed OAuth2Auth provider
withDoubleAsBody(double) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
withFloatAsBody(float) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
withInstantAsBody(Instant) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
withIntegerAsBody(int) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
withJsonArrayAsBody(JsonArray) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
withJsonObjectAsBody(JsonObject) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
withLoadBalancer(LoadBalancer) - Method in class io.vertx.reactivex.core.http.HttpClientBuilder
Configure the client to use a load balancer.
withLoadBalancer(LoadBalancer) - Method in class io.vertx.reactivex.grpc.client.GrpcClientBuilder
Configure the client to use a load balancer.
withLocalLock(String, long, Supplier<Future<T>>) - Method in class io.vertx.reactivex.core.shareddata.SharedData
withLocalLock(String, Supplier<Future<T>>) - Method in class io.vertx.reactivex.core.shareddata.SharedData
Get an asynchronous local lock with the specified name.
withLock(long, long, boolean, Supplier<Future<T>>) - Method in class io.vertx.reactivex.core.file.AsyncFile
Acquire a lock on a portion of this file.
withLock(String, long, Supplier<Future<T>>) - Method in class io.vertx.reactivex.core.shareddata.SharedData
withLock(String, Supplier<Future<T>>) - Method in class io.vertx.reactivex.core.shareddata.SharedData
Get an asynchronous lock with the specified name.
withLock(Supplier<Future<T>>) - Method in class io.vertx.reactivex.core.file.AsyncFile
Acquire a non-shared lock on the entire file.
withLongAsBody(long) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
withRedirectHandler(Function<HttpClientResponse, Single<RequestOptions>>) - Method in class io.vertx.reactivex.core.http.HttpClientBuilder
Set a redirect handler for the http client.
withRedirectHandler(Function<HttpClientResponse, Future<RequestOptions>>) - Method in class io.vertx.reactivex.core.http.HttpClientBuilder
Set a redirect handler for the http client.
withScope(String) - Method in class io.vertx.reactivex.ext.web.handler.JWTAuthHandler
Return a new instance with the internal state copied from the caller but the scopes to be requested during a token request are unique to the instance.
withScope(String) - Method in class io.vertx.reactivex.ext.web.handler.OAuth2AuthHandler
Return a new instance with the internal state copied from the caller but the scopes to be requested during a token request are unique to the instance.
withScopes(List<String>) - Method in class io.vertx.reactivex.ext.web.handler.JWTAuthHandler
Return a new instance with the internal state copied from the caller but the scopes to be requested during a token request are unique to the instance.
withScopes(List<String>) - Method in class io.vertx.reactivex.ext.web.handler.OAuth2AuthHandler
Return a new instance with the internal state copied from the caller but the scopes to be requested during a token request are unique to the instance.
withShortAsBody(short) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
withSymbolAsBody(String) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
withTransaction(Function<SqlConnection, Maybe<T>>) - Method in class io.vertx.reactivex.sqlclient.Pool
Execute the given function within a transaction.
withTransaction(TransactionPropagation, Function<SqlConnection, Maybe<T>>) - Method in class io.vertx.reactivex.sqlclient.Pool
Like Pool.withTransaction(java.util.function.Function<io.vertx.reactivex.sqlclient.SqlConnection, io.vertx.core.Future<T>>) but allows for setting the mode, defining how the acquired connection is managed during the execution of the function.
withTransaction(TransactionPropagation, Function<SqlConnection, Future<T>>) - Method in class io.vertx.reactivex.sqlclient.Pool
Like Pool.withTransaction(java.util.function.Function<io.vertx.reactivex.sqlclient.SqlConnection, io.vertx.core.Future<T>>) but allows for setting the mode, defining how the acquired connection is managed during the execution of the function.
withTransaction(Function<SqlConnection, Future<T>>) - Method in class io.vertx.reactivex.sqlclient.Pool
Execute the given function within a transaction.
withUuidAsBody(UUID) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
wrap(HttpClient) - Static method in class io.vertx.reactivex.ext.web.client.WebClient
Wrap an httpClient with a web client and default options.
wrap(HttpClient, WebClientOptions) - Static method in class io.vertx.reactivex.ext.web.client.WebClient
Wrap an httpClient with a web client and default options.
wrap(Object[]) - Static method in class io.vertx.reactivex.sqlclient.Tuple
Wrap the provided array with a tuple.
wrap(List<T>) - Static method in class io.vertx.reactivex.sqlclient.Tuple
Wrap the provided list with a tuple.
write(Buffer) - Method in class io.vertx.reactivex.core.file.AsyncFile
Write some data to the stream.
write(Buffer) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Write some data to the stream.
write(Buffer) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Write some data to the stream.
write(Buffer) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Write some data to the stream.
write(Buffer) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Write some data to the stream.
write(Buffer) - Method in class io.vertx.reactivex.core.http.WebSocket
Write some data to the stream.
write(Buffer) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Write some data to the stream.
write(Buffer) - Method in class io.vertx.reactivex.core.net.NetSocket
Write some data to the stream.
write(Buffer) - Method in class io.vertx.reactivex.core.parsetools.JsonParser
Handle a Buffer, pretty much like calling Handler.
write(Buffer) - Method in class io.vertx.reactivex.ext.stomp.StompServerConnection
Writes the given buffer to the socket.
write(Buffer) - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
 
write(Buffer, long) - Method in class io.vertx.reactivex.core.file.AsyncFile
Write a Buffer to the file at position position in the file, asynchronously.
write(Frame) - Method in class io.vertx.reactivex.ext.stomp.StompServerConnection
Writes the given frame to the socket.
write(AmqpMessage) - Method in class io.vertx.reactivex.amqp.AmqpSender
Write some data to the stream.
write(KafkaProducerRecord<K, V>) - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
Write some data to the stream.
write(Object, JsonPointerIterator, Object, boolean) - Method in class io.vertx.reactivex.core.json.pointer.JsonPointer
Write newElement in objectToWrite using this pointer.
write(String) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Write a String to the request body, encoded as UTF-8.
write(String) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Write a String to the response body, encoded in UTF-8.
write(String) - Method in class io.vertx.reactivex.core.net.NetSocket
Write a String to the connection, encoded in UTF-8.
write(String) - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
Write a String to the socket, encoded in UTF-8.
write(String, String) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Write a String to the request body, encoded using the encoding enc.
write(String, String) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Write a String to the response body, encoded using the encoding enc.
write(String, String) - Method in class io.vertx.reactivex.core.net.NetSocket
Write a String to the connection, encoded using the encoding enc.
write(Req) - Method in class io.vertx.reactivex.grpc.client.GrpcClientRequest
Write some data to the stream.
write(Resp) - Method in class io.vertx.reactivex.grpc.server.GrpcServerResponse
Write some data to the stream.
write(T) - Method in class io.vertx.reactivex.core.eventbus.MessageProducer
Write a message to the event-bus, either sending or publishing.
write(T) - Method in interface io.vertx.reactivex.core.streams.WriteStream
Write some data to the stream.
write(T) - Method in class io.vertx.reactivex.grpc.common.GrpcWriteStream
Write some data to the stream.
writeArrayElement(Object, int, Object) - Method in class io.vertx.reactivex.core.json.pointer.JsonPointerIterator
Write array element at specified index
writeBinaryMessage(Buffer) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Writes a (potentially large) piece of binary data to the connection.
writeBinaryMessage(Buffer) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Writes a (potentially large) piece of binary data to the connection.
writeBinaryMessage(Buffer) - Method in class io.vertx.reactivex.core.http.WebSocket
Writes a (potentially large) piece of binary data to the connection.
writeBinaryMessage(Buffer) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Writes a (potentially large) piece of binary data to the connection.
writeContinue() - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Used to write an interim 100 Continue response to signify that the client should send the rest of the request.
writeCustomFrame(int, int, Buffer) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
Write an HTTP/2 frame to the request, allowing to extend the HTTP/2 protocol.
writeCustomFrame(int, int, Buffer) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Write an HTTP/2 frame to the response, allowing to extend the HTTP/2 protocol.
writeCustomFrame(HttpFrame) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
writeCustomFrame(HttpFrame) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
writeEarlyHints(MultiMap) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
Used to write an interim 103 Early Hints response to return some HTTP headers before the final HTTP message.
writeFile(String, Buffer) - Method in class io.vertx.reactivex.core.file.FileSystem
Creates the file, and writes the specified Buffer data to the file represented by the path path, asynchronously.
writeFileBlocking(String, Buffer) - Method in class io.vertx.reactivex.core.file.FileSystem
writeFinalBinaryFrame(Buffer) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Write a final WebSocket binary frame to the connection
writeFinalBinaryFrame(Buffer) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Write a final WebSocket binary frame to the connection
writeFinalBinaryFrame(Buffer) - Method in class io.vertx.reactivex.core.http.WebSocket
Write a final WebSocket binary frame to the connection
writeFinalBinaryFrame(Buffer) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Write a final WebSocket binary frame to the connection
writeFinalTextFrame(String) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Write a final WebSocket text frame to the connection
writeFinalTextFrame(String) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Write a final WebSocket text frame to the connection
writeFinalTextFrame(String) - Method in class io.vertx.reactivex.core.http.WebSocket
Write a final WebSocket text frame to the connection
writeFinalTextFrame(String) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Write a final WebSocket text frame to the connection
writeFrame(WebSocketFrame) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Write a WebSocket frame to the connection
writeFrame(WebSocketFrame) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Write a WebSocket frame to the connection
writeFrame(WebSocketFrame) - Method in class io.vertx.reactivex.core.http.WebSocket
Write a WebSocket frame to the connection
writeFrame(WebSocketFrame) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Write a WebSocket frame to the connection
writeHandlerID() - Method in class io.vertx.reactivex.core.net.NetSocket
When a NetSocket is created, it may register an event handler with the event bus, the ID of that handler is given by writeHandlerID.
writeHandlerID() - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
When a SockJSSocket is created it can register an event handler with the event bus, the ID of that handler is given by writeHandlerID.
writeJson(Object, Object) - Method in class io.vertx.reactivex.core.json.pointer.JsonPointer
Write newElement in jsonElement using this pointer.
writeJson(Object, Object, boolean) - Method in class io.vertx.reactivex.core.json.pointer.JsonPointer
Write newElement in jsonElement using this pointer.
writeMessage(GrpcMessage) - Method in class io.vertx.reactivex.grpc.common.GrpcWriteStream
Write an encoded gRPC message.
writeObjectParameter(Object, String, Object) - Method in class io.vertx.reactivex.core.json.pointer.JsonPointerIterator
Write object parameter at specified key
writePing(Buffer) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Writes a ping frame to the connection.
writePing(Buffer) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Writes a ping frame to the connection.
writePing(Buffer) - Method in class io.vertx.reactivex.core.http.WebSocket
Writes a ping frame to the connection.
writePing(Buffer) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Writes a ping frame to the connection.
writePong(Buffer) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Writes a pong frame to the connection.
writePong(Buffer) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Writes a pong frame to the connection.
writePong(Buffer) - Method in class io.vertx.reactivex.core.http.WebSocket
Writes a pong frame to the connection.
writePong(Buffer) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Writes a pong frame to the connection.
writeQueueFull() - Method in class io.vertx.reactivex.amqp.AmqpSender
This will return true if there are more bytes in the write queue than the value set using AmqpSender.setWriteQueueMaxSize(int)
writeQueueFull() - Method in class io.vertx.reactivex.core.file.AsyncFile
This will return true if there are more bytes in the write queue than the value set using AsyncFile.setWriteQueueMaxSize(int)
writeQueueFull() - Method in class io.vertx.reactivex.core.http.ClientWebSocket
This will return true if there are more bytes in the write queue than the value set using ClientWebSocket.setWriteQueueMaxSize(int)
writeQueueFull() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
This will return true if there are more bytes in the write queue than the value set using HttpClientRequest.setWriteQueueMaxSize(int)
writeQueueFull() - Method in class io.vertx.reactivex.core.http.HttpServerResponse
This will return true if there are more bytes in the write queue than the value set using HttpServerResponse.setWriteQueueMaxSize(int)
writeQueueFull() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
This will return true if there are more bytes in the write queue than the value set using ServerWebSocket.setWriteQueueMaxSize(int)
writeQueueFull() - Method in class io.vertx.reactivex.core.http.WebSocket
This will return true if there are more bytes in the write queue than the value set using WebSocket.setWriteQueueMaxSize(int)
writeQueueFull() - Method in interface io.vertx.reactivex.core.http.WebSocketBase
This will return true if there are more bytes in the write queue than the value set using WebSocketBase.setWriteQueueMaxSize(int)
writeQueueFull() - Method in class io.vertx.reactivex.core.net.NetSocket
This will return true if there are more bytes in the write queue than the value set using NetSocket.setWriteQueueMaxSize(int)
writeQueueFull() - Method in interface io.vertx.reactivex.core.streams.WriteStream
This will return true if there are more bytes in the write queue than the value set using WriteStream.setWriteQueueMaxSize(int)
writeQueueFull() - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
This will return true if there are more bytes in the write queue than the value set using SockJSSocket.setWriteQueueMaxSize(int)
writeQueueFull() - Method in class io.vertx.reactivex.grpc.client.GrpcClientRequest
This will return true if there are more bytes in the write queue than the value set using GrpcClientRequest.setWriteQueueMaxSize(int)
writeQueueFull() - Method in class io.vertx.reactivex.grpc.common.GrpcWriteStream
This will return true if there are more bytes in the write queue than the value set using GrpcWriteStream.setWriteQueueMaxSize(int)
writeQueueFull() - Method in class io.vertx.reactivex.grpc.server.GrpcServerResponse
This will return true if there are more bytes in the write queue than the value set using GrpcServerResponse.setWriteQueueMaxSize(int)
writeQueueFull() - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
This will return true if there are more bytes in the write queue than the value set using KafkaProducer.setWriteQueueMaxSize(int)
WriteStream<T> - Interface in io.vertx.reactivex.core.streams
Represents a stream of data that can be written to.
writeTextMessage(String) - Method in class io.vertx.reactivex.core.http.ClientWebSocket
Writes a (potentially large) piece of text data to the connection.
writeTextMessage(String) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
Writes a (potentially large) piece of text data to the connection.
writeTextMessage(String) - Method in class io.vertx.reactivex.core.http.WebSocket
Writes a (potentially large) piece of text data to the connection.
writeTextMessage(String) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
Writes a (potentially large) piece of text data to the connection.
writingFrameHandler(Handler<Frame>) - Method in class io.vertx.reactivex.ext.stomp.StompClient
Configures a writing handler that gets notified when a STOMP frame is written on the wire.
writingFrameHandler(Handler<Frame>) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
Configures a handler notified when a frame is going to be written on the wire.
writingFrameHandler(Handler<ServerFrame>) - Method in class io.vertx.reactivex.ext.stomp.StompServer
Configures the handler that is invoked every time a frame is going to be written to the "wire".

X

xack(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Marks a pending message as correctly processed, effectively removing it from the pending entries list of the consumer group.
xadd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Appends a new entry to a stream.
xautoclaim(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Changes (or acquires) ownership of messages in a consumer group, as if the messages were delivered to the specified consumer.
xclaim(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Changes (or acquires) ownership of a message in a consumer group, as if the message was delivered to the specified consumer.
xdel(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Removes the specified entries from the stream.
XFrameHandler - Class in io.vertx.reactivex.ext.web.handler
The X-Frame-Options HTTP response header can be used to indicate whether or not a browser should be allowed to render a page in a , , or .
XFrameHandler(XFrameHandler) - Constructor for class io.vertx.reactivex.ext.web.handler.XFrameHandler
 
XFrameHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.XFrameHandler
 
xgroup(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
A container for consumer groups commands.
xinfo(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
A container for stream introspection commands.
xlen(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Return the number of entries in a stream.
xpending(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Return information and entries from a stream consumer group pending entries list, that are messages fetched but never acknowledged.
xrange(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Return a range of elements in a stream, with IDs matching the specified IDs interval.
xread(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Return never seen elements in multiple streams, with IDs greater than the ones reported by the caller for each stream.
xreadgroup(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Return new entries from a stream using a consumer group, or access the history of the pending entries for a given consumer.
xrevrange(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Return a range of elements in a stream, with IDs matching the specified IDs interval, in reverse order (from greater to smaller IDs) compared to XRANGE.
xsetid(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
An internal command for replicating stream values.
xtrim(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Trims the stream to (approximately if '~' is passed) a certain size.

Z

zadd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Add one or more members to a sorted set, or update its score if it already exists.
zcard(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the number of members in a sorted set.
zcount(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Count the members in a sorted set with scores within the given values.
zdiff(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Subtract multiple sorted sets.
zdiffstore(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Subtract multiple sorted sets and store the resulting sorted set in a new key.
zincrby(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Increment the score of a member in a sorted set.
zinter(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Intersect multiple sorted sets.
zintercard(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Intersect multiple sorted sets and return the cardinality of the result.
zinterstore(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Intersect multiple sorted sets and store the resulting sorted set in a new key.
zlexcount(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Count the number of members in a sorted set between a given lexicographical range.
zmpop(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove and return members with scores in a sorted set.
zmscore(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the score associated with the given members in a sorted set.
zpopmax(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove and return members with the highest scores in a sorted set.
zpopmin(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove and return members with the lowest scores in a sorted set.
zrandmember(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get one or multiple random elements from a sorted set.
zrange(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Return a range of members in a sorted set.
zrangebylex(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Deprecated.
zrangebyscore(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Deprecated.
zrangestore(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Store a range of members from sorted set into another key.
zrank(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Determine the index of a member in a sorted set.
zrem(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove one or more members from a sorted set.
zremrangebylex(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove all members in a sorted set between the given lexicographical range.
zremrangebyrank(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove all members in a sorted set within the given indexes.
zremrangebyscore(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Remove all members in a sorted set within the given scores.
zrevrange(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Deprecated.
zrevrangebylex(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Deprecated.
zrevrangebyscore(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Deprecated.
zrevrank(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Determine the index of a member in a sorted set, with scores ordered from high to low.
zscan(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Incrementally iterate sorted sets elements and associated scores.
zscore(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Get the score associated with the given member in a sorted set.
zunion(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Add multiple sorted sets.
zunionstore(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
Add multiple sorted sets and store the resulting sorted set in a new key.

_

__TYPE_ARG - Static variable in class io.vertx.reactivex.amqp.AmqpClient
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.amqp.AmqpConnection
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.amqp.AmqpMessage
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.amqp.AmqpMessageBuilder
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.amqp.AmqpReceiver
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.amqp.AmqpSender
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.cassandra.CassandraClient
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.cassandra.CassandraRowStream
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.cassandra.ResultSet
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.circuitbreaker.FailurePolicy
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.circuitbreaker.RetryPolicy
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.config.ConfigRetriever
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.datagram.DatagramSocket
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.dns.DnsClient
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.eventbus.DeliveryContext
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.eventbus.EventBus
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.eventbus.Message
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.eventbus.MessageConsumer
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.eventbus.MessageProducer
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.file.AsyncFile
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.file.AsyncFileLock
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.file.FileSystem
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.http.ClientWebSocket
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.http.HttpClientAgent
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.http.HttpClientBuilder
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.http.HttpClientConnection
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.http.HttpClientRequest
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.http.HttpClientResponse
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.http.HttpConnection
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.http.HttpHeaders
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.http.HttpRequestHead
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.http.HttpServer
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.http.HttpServerFileUpload
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.http.HttpServerRequest
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.http.HttpServerResponse
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.http.ServerWebSocket
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.http.ServerWebSocketHandshake
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.http.WebSocket
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.http.WebSocketClient
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.json.pointer.JsonPointer
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.json.pointer.JsonPointerIterator
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.net.endpoint.Endpoint
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.net.endpoint.EndpointResolver
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.net.endpoint.ServerEndpoint
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.net.endpoint.ServerInteraction
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.net.NetClient
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.net.NetServer
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.net.NetSocket
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.parsetools.JsonParser
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.parsetools.RecordParser
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.shareddata.AsyncMap
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.shareddata.Counter
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.shareddata.LocalMap
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.shareddata.Lock
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.shareddata.SharedData
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.core.streams.Pipe
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.db2client.DB2Builder
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.db2client.DB2Connection
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.abac.Attribute
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.abac.PolicyBasedAuthorizationProvider
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.audit.SecurityAudit
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.authentication.AuthenticationProvider
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.authorization.AndAuthorization
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.authorization.AuthorizationContext
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.authorization.Authorizations
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.authorization.NotAuthorization
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.authorization.OrAuthorization
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.authorization.PermissionBasedAuthorization
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.authorization.RoleBasedAuthorization
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.authorization.WildcardPermissionBasedAuthorization
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.ChainAuth
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.hashing.HashingAlgorithm
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.hashing.HashingStrategy
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.htdigest.HtdigestAuth
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.htpasswd.HtpasswdAuth
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.jwt.authorization.JWTAuthorization
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.jwt.authorization.MicroProfileAuthorization
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.jwt.JWTAuth
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.ldap.LdapAuthentication
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.oauth2.authorization.KeycloakAuthorization
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.oauth2.authorization.ScopeAuthorization
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.oauth2.providers.AmazonCognitoAuth
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.oauth2.providers.AppleIdAuth
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.oauth2.providers.AzureADAuth
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.oauth2.providers.BoxAuth
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.oauth2.providers.CloudFoundryAuth
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.oauth2.providers.DropboxAuth
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.oauth2.providers.FacebookAuth
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.oauth2.providers.FoursquareAuth
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.oauth2.providers.GiteeAuth
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.oauth2.providers.GithubAuth
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.oauth2.providers.GitLabAuth
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.oauth2.providers.GoogleAuth
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.oauth2.providers.HerokuAuth
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.oauth2.providers.IBMCloudAuth
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.oauth2.providers.InstagramAuth
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.oauth2.providers.KeycloakAuth
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.oauth2.providers.LinkedInAuth
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.oauth2.providers.LiveAuth
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.oauth2.providers.MailchimpAuth
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.oauth2.providers.OpenIDConnectAuth
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.oauth2.providers.SalesforceAuth
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.oauth2.providers.ShopifyAuth
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.oauth2.providers.SoundcloudAuth
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.oauth2.providers.StripeAuth
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.oauth2.providers.TwitterAuth
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.otp.hotp.HotpAuth
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.otp.OtpKeyGenerator
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.otp.totp.TotpAuth
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.prng.VertxContextPRNG
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.properties.PropertyFileAuthentication
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.properties.PropertyFileAuthorization
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.sqlclient.SqlAuthentication
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.sqlclient.SqlAuthorization
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.sqlclient.SqlUserUtil
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.User
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.webauthn4j.CredentialStorage
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.auth.webauthn4j.WebAuthn4J
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.bridge.BaseBridgeEvent
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.consul.ConsulClient
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.consul.Watch
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.consul.WatchResult
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.dropwizard.MetricsService
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.eventbus.bridge.tcp.BridgeEvent
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.eventbus.bridge.tcp.TcpEventBusBridge
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.healthchecks.HealthChecks
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.mail.MailAttachment
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.mail.MailClient
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.mongo.MongoClient
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.mongo.MongoGridFsClient
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.stomp.Acknowledgement
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.stomp.Destination
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.stomp.DestinationFactory
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.stomp.Frames
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.stomp.ServerFrame
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.stomp.StompClient
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.stomp.StompClientConnection
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.stomp.StompServer
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.stomp.StompServerConnection
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.stomp.StompServerHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.unit.Async
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.unit.collect.EventBusCollector
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.unit.Completion
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.unit.report.Failure
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.unit.report.TestCaseReport
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.unit.report.TestResult
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.unit.report.TestSuiteReport
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.unit.TestCase
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.unit.TestCompletion
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.unit.TestContext
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.unit.TestSuite
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.client.CachingWebClient
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.client.HttpRequest
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.client.HttpResponse
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.client.OAuth2WebClient
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.client.WebClient
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.client.WebClientSession
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.codec.BodyCodec
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.common.template.TemplateEngine
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.common.WebEnvironment
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.FileUpload
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.APIKeyHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.AuthorizationHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.BasicAuthHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.BodyHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.ChainAuthHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.CorsHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.CSPHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.CSRFHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.DigestAuthHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.ErrorHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.FaviconHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.FormLoginHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.graphql.ExecutionInputBuilderWithContext
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.graphql.GraphiQLHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.graphql.GraphiQLHandlerBuilder
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.graphql.GraphQLHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.graphql.GraphQLHandlerBuilder
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.graphql.UploadScalar
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.graphql.ws.ConnectionInitEvent
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.graphql.ws.GraphQLWSHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.graphql.ws.GraphQLWSHandlerBuilder
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.graphql.ws.Message
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.HSTSHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.JWTAuthHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.LoggerFormatter
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.LoggerHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.MethodOverrideHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.MultiTenantHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.OAuth2AuthHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.OtpAuthHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.RedirectAuthHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.ResponseContentTypeHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.ResponseTimeHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.SecurityAuditLoggerHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.SessionHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.SimpleAuthenticationHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.sockjs.BridgeEvent
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.StaticHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.TemplateHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.TimeoutHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.WebAuthn4JHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.handler.XFrameHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.healthchecks.HealthCheckHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.LanguageHeader
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.MIMEHeader
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.multipart.FormDataPart
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.multipart.MultipartForm
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.openapi.router.OpenAPIRoute
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.openapi.router.RequestExtractor
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.openapi.router.RouterBuilder
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.openapi.router.Security
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.ParsedHeaderValues
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.RequestBody
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.Route
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.Router
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.RoutingContext
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.Session
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.sstore.ClusteredSessionStore
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.sstore.cookie.CookieSessionStore
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.sstore.infinispan.InfinispanSessionStore
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.sstore.LocalSessionStore
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.sstore.redis.RedisSessionStore
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.sstore.SessionStore
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.templ.freemarker.FreeMarkerTemplateEngine
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.templ.handlebars.HandlebarsTemplateEngine
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.templ.mvel.MVELTemplateEngine
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.templ.pebble.PebbleTemplateEngine
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.templ.pug.PugTemplateEngine
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.templ.rocker.RockerTemplateEngine
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.templ.thymeleaf.ThymeleafTemplateEngine
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.UserContext
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.validation.builder.ArrayParserFactory
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.validation.builder.Bodies
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.validation.builder.BodyProcessorFactory
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.validation.builder.ObjectParserFactory
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.validation.builder.ParameterProcessorFactory
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.validation.builder.Parameters
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.validation.builder.Parsers
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.validation.builder.StyledParameterProcessorFactory
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.validation.builder.TupleParserFactory
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.validation.builder.ValidationHandlerBuilder
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.validation.RequestParameter
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.validation.RequestParameters
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.validation.RequestPredicate
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.validation.RequestPredicateResult
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.ext.web.validation.ValidationHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.grpc.client.GrpcClient
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.grpc.client.GrpcClientBuilder
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.grpc.client.GrpcClientRequest
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.grpc.client.GrpcClientResponse
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.grpc.common.GrpcReadStream
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.grpc.common.GrpcWriteStream
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.grpc.server.GrpcServer
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.grpc.server.GrpcServerRequest
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.grpc.server.GrpcServerResponse
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.jdbcclient.JDBCConnection
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.jdbcclient.JDBCPool
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.jdbcclient.SqlOutParam
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.json.schema.JsonFormatValidator
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.json.schema.JsonSchema
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.json.schema.Ref
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.json.schema.SchemaRepository
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.json.schema.Validator
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumerRecord
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumerRecords
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.kafka.client.producer.KafkaHeader
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.kafka.client.producer.KafkaProducerRecord
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.micrometer.MetricsService
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.micrometer.PrometheusRequestHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.micrometer.PrometheusScrapingHandler
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.mqtt.messages.MqttAuthenticationExchangeMessage
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.mqtt.messages.MqttConnAckMessage
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.mqtt.messages.MqttDisconnectMessage
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.mqtt.messages.MqttPubAckMessage
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.mqtt.messages.MqttPubCompMessage
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.mqtt.messages.MqttPublishMessage
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.mqtt.messages.MqttPubRecMessage
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.mqtt.messages.MqttPubRelMessage
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.mqtt.messages.MqttSubAckMessage
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.mqtt.messages.MqttSubscribeMessage
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.mqtt.messages.MqttUnsubscribeMessage
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.mqtt.MqttClient
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.mqtt.MqttEndpoint
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.mqtt.MqttServer
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.mqtt.MqttTopicSubscription
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.mssqlclient.MSSQLBuilder
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.mssqlclient.MSSQLConnection
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.mysqlclient.MySQLBuilder
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.mysqlclient.MySQLClient
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.mysqlclient.MySQLConnection
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.openapi.contract.MediaType
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.openapi.contract.OAuthFlow
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.openapi.contract.OAuthFlows
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.openapi.contract.OpenAPIContract
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.openapi.contract.Operation
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.openapi.contract.Parameter
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.openapi.contract.Path
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.openapi.contract.RequestBody
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.openapi.contract.Response
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.openapi.contract.SecurityRequirement
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.openapi.contract.SecurityScheme
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.openapi.contract.Server
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.openapi.validation.RequestParameter
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.openapi.validation.RequestValidator
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.openapi.validation.ResponseParameter
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.openapi.validation.ValidatableRequest
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.openapi.validation.ValidatableResponse
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.openapi.validation.ValidatedRequest
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.openapi.validation.ValidatedResponse
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.oracleclient.OracleBuilder
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.oracleclient.OracleClient
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.oracleclient.OracleConnection
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.pgclient.PgBuilder
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.pgclient.PgConnection
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.pgclient.pubsub.PgChannel
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.pgclient.pubsub.PgSubscriber
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.rabbitmq.RabbitMQClient
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.rabbitmq.RabbitMQConsumer
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.rabbitmq.RabbitMQMessage
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.rabbitmq.RabbitMQPublisher
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.redis.client.Redis
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.redis.client.RedisAPI
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.redis.client.RedisCluster
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.redis.client.RedisConnection
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.servicediscovery.ServiceReference
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.servicediscovery.spi.ServiceExporter
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.servicediscovery.spi.ServiceImporter
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.servicediscovery.spi.ServicePublisher
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.servicediscovery.types.EventBusService
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.servicediscovery.types.HttpEndpoint
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.servicediscovery.types.MessageSource
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.servicediscovery.types.MongoDataSource
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.servicediscovery.types.RedisDataSource
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.sqlclient.ClientBuilder
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.sqlclient.Cursor
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.sqlclient.desc.ColumnDescriptor
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.sqlclient.Pool
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.sqlclient.PreparedQuery
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.sqlclient.PreparedStatement
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.sqlclient.PropertyKind
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.sqlclient.Query
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.sqlclient.Row
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.sqlclient.RowIterator
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.sqlclient.RowSet
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.sqlclient.RowStream
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.sqlclient.spi.DatabaseMetadata
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.sqlclient.SqlClient
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.sqlclient.SqlConnection
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.sqlclient.SqlResult
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.sqlclient.templates.RowMapper
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.sqlclient.templates.SqlTemplate
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.sqlclient.templates.TupleMapper
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.sqlclient.Transaction
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.sqlclient.Tuple
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.uritemplate.UriTemplate
 
__TYPE_ARG - Static variable in class io.vertx.reactivex.uritemplate.Variables
 
__typeArg_0 - Variable in class io.vertx.reactivex.circuitbreaker.FailurePolicy
 
__typeArg_0 - Variable in class io.vertx.reactivex.core.eventbus.DeliveryContext
 
__typeArg_0 - Variable in class io.vertx.reactivex.core.eventbus.Message
 
__typeArg_0 - Variable in class io.vertx.reactivex.core.eventbus.MessageConsumer
 
__typeArg_0 - Variable in class io.vertx.reactivex.core.eventbus.MessageProducer
 
__typeArg_0 - Variable in class io.vertx.reactivex.core.shareddata.AsyncMap
 
__typeArg_0 - Variable in class io.vertx.reactivex.core.shareddata.LocalMap
 
__typeArg_0 - Variable in class io.vertx.reactivex.core.streams.Pipe
 
__typeArg_0 - Variable in class io.vertx.reactivex.ext.consul.Watch
 
__typeArg_0 - Variable in class io.vertx.reactivex.ext.consul.WatchResult
 
__typeArg_0 - Variable in class io.vertx.reactivex.ext.unit.Completion
 
__typeArg_0 - Variable in class io.vertx.reactivex.ext.web.client.HttpRequest
 
__typeArg_0 - Variable in class io.vertx.reactivex.ext.web.client.HttpResponse
 
__typeArg_0 - Variable in class io.vertx.reactivex.ext.web.codec.BodyCodec
 
__typeArg_0 - Variable in class io.vertx.reactivex.ext.web.handler.graphql.ExecutionInputBuilderWithContext
 
__typeArg_0 - Variable in class io.vertx.reactivex.grpc.client.GrpcClientBuilder
 
__typeArg_0 - Variable in class io.vertx.reactivex.grpc.client.GrpcClientRequest
 
__typeArg_0 - Variable in class io.vertx.reactivex.grpc.client.GrpcClientResponse
 
__typeArg_0 - Variable in class io.vertx.reactivex.grpc.common.GrpcReadStream
 
__typeArg_0 - Variable in class io.vertx.reactivex.grpc.common.GrpcWriteStream
 
__typeArg_0 - Variable in class io.vertx.reactivex.grpc.server.GrpcServerRequest
 
__typeArg_0 - Variable in class io.vertx.reactivex.grpc.server.GrpcServerResponse
 
__typeArg_0 - Variable in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
 
__typeArg_0 - Variable in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumerRecord
 
__typeArg_0 - Variable in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumerRecords
 
__typeArg_0 - Variable in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
 
__typeArg_0 - Variable in class io.vertx.reactivex.kafka.client.producer.KafkaProducerRecord
 
__typeArg_0 - Variable in class io.vertx.reactivex.sqlclient.ClientBuilder
 
__typeArg_0 - Variable in class io.vertx.reactivex.sqlclient.PreparedQuery
 
__typeArg_0 - Variable in class io.vertx.reactivex.sqlclient.PropertyKind
 
__typeArg_0 - Variable in class io.vertx.reactivex.sqlclient.Query
 
__typeArg_0 - Variable in class io.vertx.reactivex.sqlclient.RowIterator
 
__typeArg_0 - Variable in class io.vertx.reactivex.sqlclient.RowSet
 
__typeArg_0 - Variable in class io.vertx.reactivex.sqlclient.RowStream
 
__typeArg_0 - Variable in class io.vertx.reactivex.sqlclient.SqlResult
 
__typeArg_0 - Variable in class io.vertx.reactivex.sqlclient.templates.RowMapper
 
__typeArg_0 - Variable in class io.vertx.reactivex.sqlclient.templates.SqlTemplate
 
__typeArg_0 - Variable in class io.vertx.reactivex.sqlclient.templates.TupleMapper
 
__typeArg_1 - Variable in class io.vertx.reactivex.core.shareddata.AsyncMap
 
__typeArg_1 - Variable in class io.vertx.reactivex.core.shareddata.LocalMap
 
__typeArg_1 - Variable in class io.vertx.reactivex.grpc.client.GrpcClientRequest
 
__typeArg_1 - Variable in class io.vertx.reactivex.grpc.client.GrpcClientResponse
 
__typeArg_1 - Variable in class io.vertx.reactivex.grpc.server.GrpcServerRequest
 
__typeArg_1 - Variable in class io.vertx.reactivex.grpc.server.GrpcServerResponse
 
__typeArg_1 - Variable in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
 
__typeArg_1 - Variable in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumerRecord
 
__typeArg_1 - Variable in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumerRecords
 
__typeArg_1 - Variable in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
 
__typeArg_1 - Variable in class io.vertx.reactivex.kafka.client.producer.KafkaProducerRecord
 
__typeArg_1 - Variable in class io.vertx.reactivex.sqlclient.templates.SqlTemplate
 
A B C D E F G H I J K L M N O P Q R S T U V W X Z _ 
All Classes All Packages