- 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.
- call(String, Handler<AsyncResult<ResultSet>>) - Method in class io.vertx.reactivex.ext.sql.SQLClient
-
Calls the given SQL PROCEDURE
which returns the result from the procedure.
- call(String, Handler<AsyncResult<ResultSet>>) - Method in class io.vertx.reactivex.ext.sql.SQLConnection
-
Calls the given SQL PROCEDURE
which returns the result from the procedure.
- call(String, Handler<AsyncResult<ResultSet>>) - Method in interface io.vertx.reactivex.ext.sql.SQLOperations
-
Calls the given SQL PROCEDURE
which returns the result from the procedure.
- callWithParams(String, JsonArray, JsonArray, Handler<AsyncResult<ResultSet>>) - Method in class io.vertx.reactivex.ext.sql.SQLClient
-
Calls the given SQL PROCEDURE
which returns the result from the procedure.
- callWithParams(String, JsonArray, JsonArray, Handler<AsyncResult<ResultSet>>) - Method in class io.vertx.reactivex.ext.sql.SQLConnection
-
Calls the given SQL PROCEDURE
which returns the result from the procedure.
- callWithParams(String, JsonArray, JsonArray, Handler<AsyncResult<ResultSet>>) - Method in interface io.vertx.reactivex.ext.sql.SQLOperations
-
Calls the given SQL PROCEDURE
which returns the result from the procedure.
- cancel() - Method in class io.vertx.reactivex.core.TimeoutStream
-
Cancels the timeout.
- cancel() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQConsumer
-
Stop message consumption from a queue.
- cancel(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQConsumer
-
Stop message consumption from a queue.
- cancelRequest(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.pgclient.PgConnection
-
Send a request cancellation message to tell the server to cancel processing request in this connection.
- cancelTimer(long) - Method in class io.vertx.reactivex.core.Vertx
-
Cancels the timer with the specified id
.
- caseInsensitiveMultiMap() - Static method in class io.vertx.reactivex.core.MultiMap
-
Create a multi-map implementation with case insensitive keys, for instance it can be used to hold some HTTP headers.
- 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
-
- catalogDatacenters(Handler<AsyncResult<List<String>>>) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Return all the datacenters that are known by the Consul server
- catalogDatacenters(Handler<AsyncResult<List<String>>>) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- catalogNodes(Handler<AsyncResult<NodeList>>) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Returns the nodes registered in a datacenter
- catalogNodes(Handler<AsyncResult<NodeList>>) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- catalogNodeServices(String, Handler<AsyncResult<ServiceList>>) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Returns the node's registered services
- catalogNodeServices(String, Handler<AsyncResult<ServiceList>>) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- catalogNodeServicesWithOptions(String, BlockingQueryOptions, Handler<AsyncResult<ServiceList>>) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
- catalogNodeServicesWithOptions(String, BlockingQueryOptions, Handler<AsyncResult<ServiceList>>) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- catalogNodesWithOptions(NodeQueryOptions, Handler<AsyncResult<NodeList>>) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Returns the nodes registered in a datacenter
- catalogNodesWithOptions(NodeQueryOptions, Handler<AsyncResult<NodeList>>) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- catalogServiceNodes(String, Handler<AsyncResult<ServiceList>>) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Returns the nodes providing a service
- catalogServiceNodes(String, Handler<AsyncResult<ServiceList>>) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- catalogServiceNodesWithOptions(String, ServiceQueryOptions, Handler<AsyncResult<ServiceList>>) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Returns the nodes providing a service
- catalogServiceNodesWithOptions(String, ServiceQueryOptions, Handler<AsyncResult<ServiceList>>) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- catalogServices(Handler<AsyncResult<ServiceList>>) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Returns the services registered in a datacenter
- catalogServices(Handler<AsyncResult<ServiceList>>) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- catalogServicesWithOptions(BlockingQueryOptions, Handler<AsyncResult<ServiceList>>) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
- catalogServicesWithOptions(BlockingQueryOptions, Handler<AsyncResult<ServiceList>>) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- cause(int) - Method in class io.vertx.reactivex.core.CompositeFuture
-
Returns a cause of a wrapped future
- cause() - Method in class io.vertx.reactivex.core.Future
-
A Throwable describing failure.
- cause() - Method in class io.vertx.reactivex.ext.consul.WatchResult
-
A Throwable describing failure.
- certificatePath() - Method in class io.vertx.reactivex.core.net.SelfSignedCertificate
-
Filesystem path to the X.509 certificate file in PEM format .
- ChainAuth - Class in io.vertx.reactivex.ext.auth
-
Chain several auth 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, Handler<AsyncResult<Void>>) - 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
-
- checksum() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumerRecord
-
Deprecated.
- chmod(String, String, Handler<AsyncResult<Void>>) - 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
-
- chmodRecursive(String, String, String, Handler<AsyncResult<Void>>) - 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, Handler<AsyncResult<Void>>) - 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
-
Blocking version of
- CircuitBreaker - Class in io.vertx.reactivex.circuitbreaker
-
An implementation of the circuit breaker pattern for Vert.x
NOTE: This class has been automatically generated from the
original
non RX-ified interface using Vert.x codegen.
- CircuitBreaker(CircuitBreaker) - Constructor for class io.vertx.reactivex.circuitbreaker.CircuitBreaker
-
- CircuitBreaker(Object) - Constructor for class io.vertx.reactivex.circuitbreaker.CircuitBreaker
-
- ckquorum(String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.sentinel.RedisSentinel
-
Check if the current Sentinel configuration is able to reach the quorum needed to failover a master,
and the majority needed to authorize the failover.
- clear() - Method in class io.vertx.reactivex.core.MultiMap
-
Removes all
- clear(Handler<AsyncResult<Void>>) - 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.ChainAuth
-
Clears the chain.
- clear() - Method in class io.vertx.reactivex.ext.web.handler.ChainAuthHandler
-
Clears the chain.
- clear() - Method in class io.vertx.reactivex.ext.web.Router
-
Remove all the routes from this router
- clear(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.web.sstore.SessionStore
-
Remove all sessions from the store.
- clear() - Method in class io.vertx.reactivex.sqlclient.Tuple
-
- clearCache() - Method in class io.vertx.reactivex.ext.auth.User
-
Deprecated.
- clearUser() - Method in class io.vertx.reactivex.ext.web.RoutingContext
-
Clear the current user object in the context.
- CLI - Class in io.vertx.reactivex.core.cli
-
Interface defining a command-line interface (in other words a command such as 'run', 'ls'...).
- CLI(CLI) - Constructor for class io.vertx.reactivex.core.cli.CLI
-
- CLI(Object) - Constructor for class io.vertx.reactivex.core.cli.CLI
-
- cli() - Method in class io.vertx.reactivex.core.cli.CommandLine
-
- cli() - Method in class io.vertx.reactivex.ext.shell.command.Command
-
- CLIENT - Static variable in class io.vertx.reactivex.redis.client.Command
-
- client(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- clientGetname(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get the current connection name
- clientGetname(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get the current connection name
- clientId() - Method in class io.vertx.reactivex.mqtt.MqttClient
-
- clientIdentifier() - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
-
- clientKill(KillFilter, Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Kill the connection of a client
- clientKill(KillFilter, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Kill the connection of a client
- clientList(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get the list of client connections
- clientList(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get the list of client connections
- clientPause(long, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Stop processing commands from clients for some time
- clientPause(long, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Stop processing commands from clients for some time
- clientReply(ClientReplyOptions, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Instruct the server whether to reply to commands.
- clientSetname(String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set the current connection name
- clientSetname(String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Set the current connection name
- CliToken - Class in io.vertx.reactivex.ext.shell.cli
-
A parsed token in the command line interface.
- CliToken(CliToken) - Constructor for class io.vertx.reactivex.ext.shell.cli.CliToken
-
- CliToken(Object) - Constructor for class io.vertx.reactivex.ext.shell.cli.CliToken
-
- cloneAclToken(String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Clone Acl token
- cloneAclToken(String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- close(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.amqp.AmqpClient
-
Closes the client.
- close(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.amqp.AmqpConnection
-
Closes the AMQP connection, i.e.
- close(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.amqp.AmqpReceiver
-
Closes the receiver.
- close(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.amqp.AmqpSender
-
Closes the sender.
- close(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.amqpbridge.AmqpBridge
-
Shuts the bridge down, closing the underlying connection.
- close() - Method in class io.vertx.reactivex.cassandra.CassandraClient
-
Closes this client.
- close(Handler<AsyncResult<Void>>) - 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(Handler<AsyncResult<Void>>) - 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.datagram.DatagramSocket
-
- 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(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.core.eventbus.MessageProducer
-
- close() - Method in class io.vertx.reactivex.core.file.AsyncFile
-
Close the file.
- close(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.core.file.AsyncFile
-
Close the file.
- close() - Method in class io.vertx.reactivex.core.http.HttpClient
-
Close the client.
- close() - Method in class io.vertx.reactivex.core.http.HttpConnection
-
Close the connection and all the currently active streams.
- close() - Method in class io.vertx.reactivex.core.http.HttpServer
-
Close the server.
- close(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.core.http.HttpServer
-
Like
HttpServer.close()
but supplying a handler that will be called when the server is actually closed (or has failed).
- close() - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
Close the underlying TCP connection corresponding to the request.
- close(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
-
- close(short) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
-
Close the WebSocket sending a close frame with specified status code.
- close(short, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
-
- 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, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
-
Same as but with an handler
called when the operation completes
- 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(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.core.http.WebSocket
-
- close(short) - Method in class io.vertx.reactivex.core.http.WebSocket
-
Close the WebSocket sending a close frame with specified status code.
- close(short, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.core.http.WebSocket
-
- 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, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.core.http.WebSocket
-
Same as but with an handler
called when the operation completes
- close() - Method in interface io.vertx.reactivex.core.http.WebSocketBase
-
Close the WebSocket sending the default close frame.
- close(Handler<AsyncResult<Void>>) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
-
- close(short) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
-
Close the WebSocket sending a close frame with specified status code.
- close(short, Handler<AsyncResult<Void>>) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
-
- close(short, String) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
-
Close sending a close frame with specified status code and reason.
- close(short, String, Handler<AsyncResult<Void>>) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
-
Same as but with an handler
called when the operation completes
- close() - Method in class io.vertx.reactivex.core.net.NetClient
-
Close the client.
- close() - Method in class io.vertx.reactivex.core.net.NetServer
-
Close the server.
- close(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.core.net.NetServer
-
Like
NetServer.close()
but supplying a handler that will be notified when close is complete.
- close() - Method in class io.vertx.reactivex.core.net.NetSocket
-
Close the NetSocket
- close(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.core.net.NetSocket
-
Close the NetSocket and notify the handler
when the operation completes.
- 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.core.Vertx
-
Stop the the Vertx instance and release any resources held by it.
- close(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.core.Vertx
-
Like
Vertx.close()
but the completionHandler will be called when the close is complete
- close() - Method in class io.vertx.reactivex.core.WorkerExecutor
-
Close the executor.
- 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.consul.ConsulService
-
- close(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.TcpEventBusBridge
-
Close the current socket.
- 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.mail.MailService
-
- 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.MongoService
-
- close() - Method in class io.vertx.reactivex.ext.shell.Shell
-
Close the shell.
- close() - Method in class io.vertx.reactivex.ext.shell.ShellServer
-
Close the shell server, this is an asynchronous close.
- close(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.shell.ShellServer
-
Close the shell server, this is an asynchronous close.
- close(Handler<Void>) - Method in class io.vertx.reactivex.ext.shell.system.JobController
-
Close the controller and terminate all the underlying jobs, a closed controller does not accept anymore jobs.
- close() - Method in class io.vertx.reactivex.ext.shell.system.JobController
-
Close the shell session and terminate all the underlying jobs.
- close() - Method in class io.vertx.reactivex.ext.shell.term.Term
-
Close the connection to terminal.
- close() - Method in class io.vertx.reactivex.ext.shell.term.TermServer
-
Close the server.
- close(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.shell.term.TermServer
-
Like
TermServer.close()
but supplying a handler that will be notified when close is complete.
- close(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.sql.SQLClient
-
Close the client and release all resources.
- close() - Method in class io.vertx.reactivex.ext.sql.SQLClient
-
Close the client
- close(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.sql.SQLConnection
-
Closes the connection.
- close() - Method in class io.vertx.reactivex.ext.sql.SQLConnection
-
Closes the connection.
- close() - Method in class io.vertx.reactivex.ext.sql.SQLRowStream
-
Closes the stream/underlying cursor(s).
- close(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.sql.SQLRowStream
-
Closes the stream/underlying cursor(s).
- 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(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.stomp.StompServer
-
Closes the server.
- 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(int, String) - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
-
Close it giving a status code and reason.
- close() - Method in class io.vertx.reactivex.ext.web.sstore.SessionStore
-
Close the store
- close() - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
-
Close the admin client
- close(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
-
Close the admin client
- close(long, Handler<AsyncResult<Void>>) - 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(Handler<AsyncResult<Void>>) - 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(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
-
Close the producer
- close(long, Handler<AsyncResult<Void>>) - 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(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.mqtt.MqttServer
-
Close the server supplying an handler that will be called when the server is actually closed (or has failed).
- 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(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Close the client - when it is fully closed the handler will be called.
- close(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Close the client - when it is fully closed the handler will be called.
- close(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.redis.sentinel.RedisSentinel
-
Close the client - when it is fully closed the handler will be called.
- close() - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
-
Closes the service discovery
- 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() - Method in class io.vertx.reactivex.sqlclient.Cursor
-
Release the cursor.
- close(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.sqlclient.Cursor
-
Like
Cursor.close()
but with a
completionHandler
called when the cursor has been released.
- close() - Method in class io.vertx.reactivex.sqlclient.Pool
-
Close the pool and release the associated resources.
- close() - Method in class io.vertx.reactivex.sqlclient.PreparedStatement
-
Close the prepared query and release its resources.
- close(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.sqlclient.PreparedStatement
-
- close() - Method in class io.vertx.reactivex.sqlclient.RowStream
-
Close the stream and release the resources.
- close(Handler<AsyncResult<Void>>) - 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() - Method in class io.vertx.reactivex.sqlclient.SqlConnection
-
Close the current connection after all the pending commands have been processed.
- close() - Method in class io.vertx.reactivex.sqlclient.Transaction
-
Rollback the transaction and release the associated resources.
- closed() - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
- closed() - Method in class io.vertx.reactivex.pgclient.pubsub.PgSubscriber
-
- closeHandler(Handler<Void>) - Method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
-
Sets a invoked when the circuit breaker state switches to close.
- 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 that will be called when the NetSocket is closed
- closeHandler(Handler<Void>) - Method in class io.vertx.reactivex.db2client.DB2Connection
-
- closeHandler(Handler<Void>) - Method in class io.vertx.reactivex.ext.shell.term.Term
-
Set a handler that will be called when the terminal is closed.
- 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.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.mysqlclient.MySQLConnection
-
- 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.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.
- closeReason() - Method in class io.vertx.reactivex.core.http.WebSocketFrame
-
- 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.
- closeStatusCode() - Method in class io.vertx.reactivex.core.http.WebSocketFrame
-
- 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 - Static variable in class io.vertx.reactivex.redis.client.Command
-
- cluster(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- clusterAddslots(List<Long>, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Assign new hash slots to receiving node.
- clusterAddslots(List<String>, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Assign new hash slots to receiving node.
- clusterCountFailureReports(String, Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Return the number of failure reports active for a given node.
- clusterCountFailureReports(String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return the number of failure reports active for a given node.
- clusterCountkeysinslot(long, Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Return the number of local keys in the specified hash slot.
- clusterCountkeysinslot(long, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return the number of local keys in the specified hash slot.
- clusterDelslots(long, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set hash slots as unbound in receiving node.
- clusterDelslots(long, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Set hash slots as unbound in receiving node.
- clusterDelslotsMany(List<Long>, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set hash slots as unbound in receiving node.
- clusterDelslotsMany(List<String>, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Set hash slots as unbound in receiving node.
- 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
-
- clusteredVertx(VertxOptions, Handler<AsyncResult<Vertx>>) - Static method in class io.vertx.reactivex.core.Vertx
-
Creates a clustered instance using the specified options.
- clusterFailover(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Forces a slave to perform a manual failover of its master.
- clusterFailover(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Forces a slave to perform a manual failover of its master.
- clusterFailOverWithOptions(FailoverOptions, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Forces a slave to perform a manual failover of its master.
- clusterFailOverWithOptions(FailoverOptions, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Forces a slave to perform a manual failover of its master.
- clusterForget(String, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Remove a node from the nodes table.
- clusterForget(String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Remove a node from the nodes table.
- clusterGetkeysinslot(long, long, Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Return local key names in the specified hash slot.
- clusterGetkeysinslot(long, long, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return local key names in the specified hash slot.
- clusterId() - Method in class io.vertx.reactivex.rabbitmq.BasicProperties
-
- clusterInfo(Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Provides info about Redis Cluster node state.
- clusterInfo(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Provides info about Redis Cluster node state.
- clusterKeyslot(String, Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Returns the hash slot of the specified key.
- clusterKeyslot(String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Returns the hash slot of the specified key.
- clusterMeet(String, long, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Force a node cluster to handshake with another node.
- clusterMeet(String, long, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Force a node cluster to handshake with another node.
- clusterNodes(Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get Cluster config for the node.
- clusterNodes(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get Cluster config for the node.
- clusterReplicate(String, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Reconfigure a node as a slave of the specified master node.
- clusterReplicate(String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Reconfigure a node as a slave of the specified master node.
- clusterReset(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Reset a Redis Cluster node.
- clusterReset(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Reset a Redis Cluster node.
- clusterResetWithOptions(ResetOptions, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Reset a Redis Cluster node.
- clusterResetWithOptions(ResetOptions, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Reset a Redis Cluster node.
- clusterSaveconfig(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Forces the node to save cluster state on disk.
- clusterSaveconfig(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Forces the node to save cluster state on disk.
- clusterSetConfigEpoch(long, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set the configuration epoch in a new node.
- clusterSetConfigEpoch(long, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Set the configuration epoch in a new node.
- clusterSetslot(long, SlotCmd, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Bind an hash slot to a specific node.
- clusterSetslot(long, SlotCmd, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Bind an hash slot to a specific node.
- clusterSetslotWithNode(long, SlotCmd, String, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Bind an hash slot to a specific node.
- clusterSetslotWithNode(long, SlotCmd, String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Bind an hash slot to a specific node.
- clusterSlaves(String, Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
List slave nodes of the specified master node.
- clusterSlaves(String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
List slave nodes of the specified master node.
- clusterSlots(Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get array of Cluster slot to node mappings
- clusterSlots(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get array of Cluster slot to node mappings
- cmd(Command) - Static method in class io.vertx.reactivex.redis.client.Request
-
- code() - Method in class io.vertx.reactivex.mqtt.messages.MqttConnAckMessage
-
- column(String) - Method in class io.vertx.reactivex.ext.sql.SQLRowStream
-
Will convert the column name to the json array index.
- 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.
- columns() - Method in class io.vertx.reactivex.ext.sql.SQLRowStream
-
Returns all column names available in the underlying resultset.
- columnsNames() - Method in class io.vertx.reactivex.sqlclient.SqlResult
-
Get the names of columns in the SqlResult.
- Command - Class in io.vertx.reactivex.ext.shell.command
-
A Vert.x Shell command, it can be created from any language using the
CommandBuilder.command(java.lang.String)
or from a
Java class using
io.vertx.reactivex.ext.shell.command.Command#create
NOTE: This class has been automatically generated from the
original
non RX-ified interface using Vert.x codegen.
- Command(Command) - Constructor for class io.vertx.reactivex.ext.shell.command.Command
-
- Command(Object) - Constructor for class io.vertx.reactivex.ext.shell.command.Command
-
- command(String) - Static method in class io.vertx.reactivex.ext.shell.command.CommandBuilder
-
Create a new commmand builder, the command is responsible for managing the options and arguments via the
#args() arguments
.
- command(CLI) - Static method in class io.vertx.reactivex.ext.shell.command.CommandBuilder
-
Create a new commmand with its
CLI
descriptor.
- Command - Class in io.vertx.reactivex.redis.client
-
Auto generated API Commands to interact with REDIS.
- Command(Command) - Constructor for class io.vertx.reactivex.redis.client.Command
-
- Command(Object) - Constructor for class io.vertx.reactivex.redis.client.Command
-
- COMMAND - Static variable in class io.vertx.reactivex.redis.client.Command
-
- command(Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- command() - Method in class io.vertx.reactivex.redis.client.Request
-
Get the Command that is to be used by this request.
- command(Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get array of Redis command details
- command(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get array of Redis command details
- CommandBuilder - Class in io.vertx.reactivex.ext.shell.command
-
A build for Vert.x Shell command.
- CommandBuilder(CommandBuilder) - Constructor for class io.vertx.reactivex.ext.shell.command.CommandBuilder
-
- CommandBuilder(Object) - Constructor for class io.vertx.reactivex.ext.shell.command.CommandBuilder
-
- commandCount(Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get total number of Redis commands
- commandCount(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get total number of Redis commands
- commandGetkeys(Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Extract keys given a full Redis command
- commandGetkeys(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Extract keys given a full Redis command
- commandInfo(List<String>, Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get array of specific Redis command details
- commandInfo(List<String>, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get array of specific Redis command details
- CommandLine - Class in io.vertx.reactivex.core.cli
-
The parser transforms a CLI (a model) into an
CommandLine
.
- CommandLine(CommandLine) - Constructor for class io.vertx.reactivex.core.cli.CommandLine
-
- CommandLine(Object) - Constructor for class io.vertx.reactivex.core.cli.CommandLine
-
- commandLine() - Method in class io.vertx.reactivex.ext.shell.command.CommandProcess
-
- CommandProcess - Class in io.vertx.reactivex.ext.shell.command
-
The command process provides interaction with the process of the command provided by Vert.x Shell.
- CommandProcess(CommandProcess) - Constructor for class io.vertx.reactivex.ext.shell.command.CommandProcess
-
- CommandProcess(Object) - Constructor for class io.vertx.reactivex.ext.shell.command.CommandProcess
-
- CommandRegistry - Class in io.vertx.reactivex.ext.shell.command
-
A registry that contains the commands known by a shell.
It is a mutable command resolver.
- CommandRegistry(CommandRegistry) - Constructor for class io.vertx.reactivex.ext.shell.command.CommandRegistry
-
- CommandRegistry(Object) - Constructor for class io.vertx.reactivex.ext.shell.command.CommandRegistry
-
- CommandResolver - Class in io.vertx.reactivex.ext.shell.command
-
A resolver for commands, so the shell can discover commands.
- CommandResolver(CommandResolver) - Constructor for class io.vertx.reactivex.ext.shell.command.CommandResolver
-
- CommandResolver(Object) - Constructor for class io.vertx.reactivex.ext.shell.command.CommandResolver
-
- commands() - Method in class io.vertx.reactivex.ext.shell.command.CommandResolver
-
- commit(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.sql.SQLConnection
-
Commits all changes made since the previous commit/rollback.
- commit(String) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
-
Commits a transaction.
- commit(String, Handler<Frame>) - 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.
- commit(String, Map<String, String>, Handler<Frame>) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
-
Commits a transaction.
- commit() - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
-
Commit current offsets for all the subscribed list of topics and partition.
- commit(Handler<AsyncResult<Void>>) - 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(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.sqlclient.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, Handler<AsyncResult<OffsetAndMetadata>>) - 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).
- compareAndSet(long, long, Handler<AsyncResult<Boolean>>) - 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(CompositeFuture) - Method in class io.vertx.reactivex.core.CompositeFuture
-
Deprecated.
- complete() - Method in class io.vertx.reactivex.core.CompositeFuture
-
Set this instance as result.
- complete(T) - Method in class io.vertx.reactivex.core.Future
-
Deprecated.
- complete() - Method in class io.vertx.reactivex.core.Future
-
Deprecated.
- complete(T) - Method in class io.vertx.reactivex.core.Promise
-
Set the result.
- complete() - Method in class io.vertx.reactivex.core.Promise
-
Calls complete(null)
- 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(List<String>) - Method in class io.vertx.reactivex.ext.shell.cli.Completion
-
End the completion with a list of candidates, these candidates will be displayed by the shell on the console.
- complete(String, boolean) - Method in class io.vertx.reactivex.ext.shell.cli.Completion
-
End the completion with a value that will be inserted to complete the line.
- complete(Completion) - Method in class io.vertx.reactivex.ext.shell.command.Command
-
Perform command completion, when the command is done completing it should call
or )} method to signal completion is done.
- 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.web.handler.sockjs.BridgeEvent
-
Set the result.
- completer() - Method in class io.vertx.reactivex.core.CompositeFuture
-
Deprecated.
- completer() - Method in class io.vertx.reactivex.core.Future
-
Deprecated.
- Completion - Class in io.vertx.reactivex.ext.shell.cli
-
The completion object
NOTE: This class has been automatically generated from the
original
non RX-ified interface using Vert.x codegen.
- Completion(Completion) - Constructor for class io.vertx.reactivex.ext.shell.cli.Completion
-
- Completion(Object) - Constructor for class io.vertx.reactivex.ext.shell.cli.Completion
-
- 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
-
- completionHandler(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.core.eventbus.MessageConsumer
-
Optional method which can be called to indicate when the registration has been propagated across the cluster.
- completionHandler(Handler<Completion>) - Method in class io.vertx.reactivex.ext.shell.command.CommandBuilder
-
Set the command completion handler, the completion handler when the user asks for contextual command line
completion, usually hitting the tab key.
- component() - Method in class io.vertx.reactivex.ext.web.MIMEHeader
-
Gets the parsed component part of the MIME.
- compose(Function<CompositeFuture, Future<U>>) - Method in class io.vertx.reactivex.core.CompositeFuture
-
Compose this future with a mapper
function.
- compose(Function<CompositeFuture, Future<U>>, Function<Throwable, Future<U>>) - Method in class io.vertx.reactivex.core.CompositeFuture
-
Compose this future with a successMapper
and failureMapper
functions.
- compose(Function<T, Future<U>>) - Method in class io.vertx.reactivex.core.Future
-
Compose this future with a mapper
function.
- compose(Function<T, Future<U>>, Function<Throwable, Future<U>>) - Method in class io.vertx.reactivex.core.Future
-
Compose this future with a successMapper
and failureMapper
functions.
- CompositeFuture - Class in io.vertx.reactivex.core
-
The composite future wraps a list of
futures
, it is useful when several futures
needs to be coordinated.
- CompositeFuture(CompositeFuture) - Constructor for class io.vertx.reactivex.core.CompositeFuture
-
- CompositeFuture(Object) - Constructor for class io.vertx.reactivex.core.CompositeFuture
-
- computeHash(String, String) - Method in class io.vertx.reactivex.ext.auth.jdbc.JDBCAuth
-
Compute the hashed password given the unhashed password and the salt without nonce
The implementation relays to the JDBCHashStrategy provided.
- computeHash(String, String, int) - Method in class io.vertx.reactivex.ext.auth.jdbc.JDBCAuth
-
Compute the hashed password given the unhashed password and the salt
The implementation relays to the JDBCHashStrategy provided.
- computeHash(String, String, int) - Method in class io.vertx.reactivex.ext.auth.jdbc.JDBCHashStrategy
-
Compute the hashed password given the unhashed password and the salt
- computeHash(String, User) - Method in class io.vertx.reactivex.ext.auth.mongo.HashStrategy
-
Compute the hashed password given the unhashed password and the user
- config() - Method in class io.vertx.reactivex.core.Context
-
If the context is associated with a Verticle deployment, this returns the configuration that was specified when
the verticle was deployed.
- CONFIG - Static variable in class io.vertx.reactivex.redis.client.Command
-
- config(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- configGet(String, Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get the value of a configuration parameter
- configGet(String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get the value of a configuration parameter
- configResetstat(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Reset the stats returned by INFO
- configResetstat(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Reset the stats returned by INFO
- 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
-
- configRewrite(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Rewrite the configuration file with the in memory configuration
- configRewrite(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Rewrite the configuration file with the in memory configuration
- configSet(String, String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set a configuration parameter to the given value
- configSet(String, String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Set a configuration parameter to the given value
- 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(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
-
Enables publisher acknowledgements on this channel.
- connect(Handler<AsyncResult<AmqpConnection>>) - Method in class io.vertx.reactivex.amqp.AmqpClient
-
Connects to the AMQP broker or router.
- connect(int, String, Handler<AsyncResult<NetSocket>>) - 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, Handler<AsyncResult<NetSocket>>) - Method in class io.vertx.reactivex.core.net.NetClient
-
Open a connection to a server at the specific port
and host
.
- connect(SocketAddress, Handler<AsyncResult<NetSocket>>) - Method in class io.vertx.reactivex.core.net.NetClient
-
Open a connection to a server at the specific remoteAddress
.
- connect(SocketAddress, String, Handler<AsyncResult<NetSocket>>) - Method in class io.vertx.reactivex.core.net.NetClient
-
Open a connection to a server at the specific remoteAddress
.
- connect(Vertx, DB2ConnectOptions, Handler<AsyncResult<DB2Connection>>) - Static method in class io.vertx.reactivex.db2client.DB2Connection
-
Create a connection to DB2 server with the given connectOptions
.
- connect(Vertx, String, Handler<AsyncResult<DB2Connection>>) - Static method in class io.vertx.reactivex.db2client.DB2Connection
-
- connect(int, String, Handler<AsyncResult<StompClientConnection>>) - Method in class io.vertx.reactivex.ext.stomp.StompClient
-
Connects to the server.
- connect(NetClient, Handler<AsyncResult<StompClientConnection>>) - Method in class io.vertx.reactivex.ext.stomp.StompClient
-
Connects to the server.
- connect(int, String, NetClient, Handler<AsyncResult<StompClientConnection>>) - Method in class io.vertx.reactivex.ext.stomp.StompClient
-
Connects to the server.
- connect(Handler<AsyncResult<StompClientConnection>>) - 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(String) - Method in class io.vertx.reactivex.ext.web.Router
-
Add a route that matches a HTTP CONNECT request and the specified path
- connect(int, String, Handler<AsyncResult<MqttConnAckMessage>>) - Method in class io.vertx.reactivex.mqtt.MqttClient
-
Connects to an MQTT server calling connectHandler after connection
- connect(int, String, String, Handler<AsyncResult<MqttConnAckMessage>>) - Method in class io.vertx.reactivex.mqtt.MqttClient
-
Connects to an MQTT server calling connectHandler after connection
- connect(Vertx, MySQLConnectOptions, Handler<AsyncResult<MySQLConnection>>) - Static method in class io.vertx.reactivex.mysqlclient.MySQLConnection
-
Create a connection to MySQL server with the given connectOptions
.
- connect(Vertx, String, Handler<AsyncResult<MySQLConnection>>) - Static method in class io.vertx.reactivex.mysqlclient.MySQLConnection
-
- connect(Vertx, PgConnectOptions, Handler<AsyncResult<PgConnection>>) - Static method in class io.vertx.reactivex.pgclient.PgConnection
-
Connects to the database and returns the connection if that succeeds.
- connect(Vertx, Handler<AsyncResult<PgConnection>>) - Static method in class io.vertx.reactivex.pgclient.PgConnection
-
- connect(Vertx, String, Handler<AsyncResult<PgConnection>>) - Static method in class io.vertx.reactivex.pgclient.PgConnection
-
- connect(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.pgclient.pubsub.PgSubscriber
-
Connect the subscriber to Postgres.
- connect(Handler<AsyncResult<RedisConnection>>) - Method in class io.vertx.reactivex.redis.client.Redis
-
Connects to the redis server.
- 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.
- 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
-
- 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.HttpClient
-
Set a connection handler for the client.
- connectionHandler(Handler<HttpConnection>) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
-
Deprecated.
- connectionHandler(Handler<HttpConnection>) - Method in class io.vertx.reactivex.core.http.HttpServer
-
Set a connection handler for the server.
- connectionHandler(Handler<ServerWebSocket>) - Method in class io.vertx.reactivex.ext.web.handler.graphql.ApolloWSHandler
-
Customize the connection .
- connectStream() - Method in class io.vertx.reactivex.core.net.NetServer
-
Return the connect stream for this server.
- 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
- 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
-
- ConsulService - Class in io.vertx.reactivex.ext.consul
-
- ConsulService(ConsulService) - Constructor for class io.vertx.reactivex.ext.consul.ConsulService
-
- ConsulService(Object) - Constructor for class io.vertx.reactivex.ext.consul.ConsulService
-
- 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.
- ContainerDeserializer - Class in io.vertx.reactivex.ext.web.api.validation
-
Interface that define methods for deserialization of array and objects
NOTE: This class has been automatically generated from the
original
non RX-ified interface using Vert.x codegen.
- ContainerDeserializer(ContainerDeserializer) - Constructor for class io.vertx.reactivex.ext.web.api.validation.ContainerDeserializer
-
- ContainerDeserializer(Object) - Constructor for class io.vertx.reactivex.ext.web.api.validation.ContainerDeserializer
-
- contains(String) - Method in class io.vertx.reactivex.core.MultiMap
-
Checks to see if there is a value with the specified name
- contains(String, String, boolean) - Method in class io.vertx.reactivex.core.MultiMap
-
Check if there is a header with the specified name
and value
.
- contains(CharSequence) - Method in class io.vertx.reactivex.core.MultiMap
-
- contains(CharSequence, CharSequence, boolean) - Method in class io.vertx.reactivex.core.MultiMap
-
- containsKey(Object) - Method in class io.vertx.reactivex.core.shareddata.LocalMap
-
Returns true
if this map contains a mapping for the specified
key.
- 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.handler.graphql.ApolloWSMessage
-
- content() - Method in class io.vertx.reactivex.ext.web.multipart.FormDataPart
-
- contentEncoding() - Method in class io.vertx.reactivex.amqp.AmqpMessage
-
- contentEncoding(String) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
-
- contentEncoding() - Method in class io.vertx.reactivex.rabbitmq.BasicProperties
-
- 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(String) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
-
- contentType() - Method in class io.vertx.reactivex.core.http.HttpServerFileUpload
-
- contentType(String) - Static method in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
Creates a predicate validating the response has a content-type
header matching the mimeType
.
- contentType(List<String>) - Static method in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
Creates a predicate validating the response has a content-type
header matching one of the mimeTypes
.
- contentType() - Method in class io.vertx.reactivex.ext.web.FileUpload
-
- contentType() - Method in class io.vertx.reactivex.ext.web.ParsedHeaderValues
-
- contentType() - Method in class io.vertx.reactivex.rabbitmq.BasicProperties
-
- Context - Class in io.vertx.reactivex.core
-
The execution context of a Handler
execution.
- Context(Context) - Constructor for class io.vertx.reactivex.core.Context
-
- Context(Object) - Constructor for class io.vertx.reactivex.core.Context
-
- continuationFrame(Buffer, boolean) - Static method in class io.vertx.reactivex.core.http.WebSocketFrame
-
Create a continuation frame
- 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 - Class in io.vertx.reactivex.core.http
-
Represents an HTTP Cookie.
- Cookie(Cookie) - Constructor for class io.vertx.reactivex.core.http.Cookie
-
- Cookie(Object) - Constructor for class io.vertx.reactivex.core.http.Cookie
-
- cookie(String, String) - Static method in class io.vertx.reactivex.core.http.Cookie
-
Create a new cookie
- Cookie - Class in io.vertx.reactivex.ext.web
-
Represents an HTTP Cookie.
- Cookie(Cookie) - Constructor for class io.vertx.reactivex.ext.web.Cookie
-
- Cookie(Object) - Constructor for class io.vertx.reactivex.ext.web.Cookie
-
- cookie(String, String) - Static method in class io.vertx.reactivex.ext.web.Cookie
-
Deprecated.
- cookieCount() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
-
- cookieCount() - Method in class io.vertx.reactivex.ext.web.RoutingContext
-
- CookieHandler - Class in io.vertx.reactivex.ext.web.handler
-
A handler which decodes cookies from the request, makes them available in the
and writes them back in the response.
- CookieHandler(CookieHandler) - Constructor for class io.vertx.reactivex.ext.web.handler.CookieHandler
-
- CookieHandler(Object) - Constructor for class io.vertx.reactivex.ext.web.handler.CookieHandler
-
- cookieParameter(String) - Method in class io.vertx.reactivex.ext.web.api.RequestParameters
-
Get cookie parameter by name
- cookieParametersNames() - Method in class io.vertx.reactivex.ext.web.api.RequestParameters
-
Get list of all parameter names inside cookie
- cookies() - Method in class io.vertx.reactivex.core.http.HttpClientResponse
-
- cookies() - Method in class io.vertx.reactivex.ext.web.client.HttpResponse
-
- cookies() - Method in class io.vertx.reactivex.ext.web.RoutingContext
-
Deprecated.
- coordinateDatacenters(Handler<AsyncResult<List<DcCoordinates>>>) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Returns the WAN network coordinates for all Consul servers, organized by DCs
- coordinateDatacenters(Handler<AsyncResult<List<DcCoordinates>>>) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- coordinateNodes(Handler<AsyncResult<CoordinateList>>) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Returns the LAN network coordinates for all nodes in a given DC
- coordinateNodes(Handler<AsyncResult<CoordinateList>>) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- coordinateNodesWithOptions(BlockingQueryOptions, Handler<AsyncResult<CoordinateList>>) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
- coordinateNodesWithOptions(BlockingQueryOptions, Handler<AsyncResult<CoordinateList>>) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- copy() - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Returns a copy of the entire Buffer.
- copy(String, String, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.core.file.FileSystem
-
Copy a file from the path from
to path to
, asynchronously.
- copy(String, String, CopyOptions, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.core.file.FileSystem
-
Copy a file from the path from
to path to
, asynchronously.
- 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
- copyBlocking(String, String) - Method in class io.vertx.reactivex.core.file.FileSystem
-
- copyRecursive(String, String, boolean, Handler<AsyncResult<Void>>) - 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
-
- correlationId() - Method in class io.vertx.reactivex.rabbitmq.BasicProperties
-
- 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(String, JsonObject, Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Count matching documents in a collection.
- count(String, JsonObject, Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- count() - Method in class io.vertx.reactivex.ext.unit.Async
-
- 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
-
- country() - Method in class io.vertx.reactivex.ext.web.Locale
-
Deprecated.
- 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(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() - Static method in class io.vertx.reactivex.amqp.AmqpMessage
-
- 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() - Static method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
-
- create(Vertx) - Static method in class io.vertx.reactivex.amqpbridge.AmqpBridge
-
Creates a Bridge.
- create(Vertx, AmqpBridgeOptions) - Static method in class io.vertx.reactivex.amqpbridge.AmqpBridge
-
Creates a Bridge with the given options.
- create(Vertx) - Static method in class io.vertx.reactivex.cassandra.CassandraClient
-
- create(Vertx, CassandraClientOptions) - Static method in class io.vertx.reactivex.cassandra.CassandraClient
-
Create a Cassandra client which maintains its own driver session.
- create(CassandraClient) - Static method in class io.vertx.reactivex.cassandra.MappingManager
-
- create(String, Vertx, CircuitBreakerOptions) - Static method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
-
- create(String, Vertx) - Static method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
-
- create(Vertx) - Static method in class io.vertx.reactivex.circuitbreaker.HystrixMetricHandler
-
Creates the handler, using the default notification address.
- create(Vertx, String) - Static method in class io.vertx.reactivex.circuitbreaker.HystrixMetricHandler
-
Creates the handler.
- create(Vertx, ConfigRetrieverOptions) - Static method in class io.vertx.reactivex.config.ConfigRetriever
-
- 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(String) - Static method in class io.vertx.reactivex.core.cli.CLI
-
Creates an instance of
CLI
using the default implementation.
- create(CLI) - Static method in class io.vertx.reactivex.core.cli.CommandLine
-
Creates a command line object from the
CLI
.
- create() - Static method in class io.vertx.reactivex.core.json.pointer.JsonPointer
-
Build an empty JsonPointer
- create() - Static method in class io.vertx.reactivex.core.net.SelfSignedCertificate
-
Create a new SelfSignedCertificate
instance.
- create(String) - Static method in class io.vertx.reactivex.core.net.SelfSignedCertificate
-
Create a new SelfSignedCertificate
instance with a fully-qualified domain name,
- create() - Static method in class io.vertx.reactivex.ext.auth.ChainAuth
-
Create a Chainable Auth Provider auth provider
- create(Vertx) - Static method in class io.vertx.reactivex.ext.auth.htdigest.HtdigestAuth
-
Creates an instance of HtdigestAuth.
- 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) - Static method in class io.vertx.reactivex.ext.auth.htpasswd.HtpasswdAuth
-
- create(Vertx, HtpasswdAuthOptions) - Static method in class io.vertx.reactivex.ext.auth.htpasswd.HtpasswdAuth
-
- create(Vertx, JDBCClient) - Static method in class io.vertx.reactivex.ext.auth.jdbc.JDBCAuth
-
Create a JDBC auth provider implementation
- create(Vertx, JWTAuthOptions) - Static method in class io.vertx.reactivex.ext.auth.jwt.JWTAuth
-
Create a JWT auth provider
- create(MongoClient, JsonObject) - Static method in class io.vertx.reactivex.ext.auth.mongo.MongoAuth
-
Creates an instance of MongoAuth by using the given and configuration object.
- create(Vertx, OAuth2FlowType, OAuth2ClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
-
Deprecated.
- create(Vertx, OAuth2FlowType) - Static method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
-
Deprecated.
- create(Vertx) - Static method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
-
Create a OAuth2 auth provider
- create(Vertx, OAuth2ClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
-
Create a OAuth2 auth provider
- 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, 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) - 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.BoxAuth
-
Create a OAuth2Auth provider for App.net
- 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, HttpClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.CloudFoundryAuth
-
Create a OAuth2Auth provider for CloudFoundry UAA
- 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, HttpClientOptions) - 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, HttpClientOptions) - 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, HttpClientOptions) - 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.GithubAuth
-
Create a OAuth2Auth provider for Github
- 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) - 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.GoogleAuth
-
Create a OAuth2Auth provider for Google
- 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, 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, String, String) - 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.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, HttpClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.InstagramAuth
-
Create a OAuth2Auth provider for Instagram
- create(Vertx, JsonObject) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.KeycloakAuth
-
Create a OAuth2Auth provider for Keycloak
- create(Vertx, OAuth2FlowType, JsonObject) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.KeycloakAuth
-
Create a OAuth2Auth provider for Keycloak
- create(Vertx, JsonObject, HttpClientOptions) - 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, String, String) - 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.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, HttpClientOptions) - 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, HttpClientOptions) - 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, HttpClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.SalesforceAuth
-
Create a OAuth2Auth provider for Salesforce
- 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.ShopifyAuth
-
Create a OAuth2Auth provider for Shopify
- 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, HttpClientOptions) - 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, HttpClientOptions) - 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, HttpClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.TwitterAuth
-
Create a OAuth2Auth provider for Twitter
- create(OAuth2ClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.rbac.KeycloakRBAC
-
Factory method to create a RBAC handler for tokens adhering to the Keycloak token format.
- create() - Static method in class io.vertx.reactivex.ext.auth.oauth2.rbac.MicroProfileRBAC
-
Factory method to create a RBAC handler for tokens adhering to the MP-JWT 1.1 spec.
- create(Vertx, ShiroAuthRealmType, JsonObject) - Static method in class io.vertx.reactivex.ext.auth.shiro.ShiroAuth
-
Deprecated.
- create(Vertx, ShiroAuthOptions) - Static method in class io.vertx.reactivex.ext.auth.shiro.ShiroAuth
-
Create a Shiro auth provider
- create(Vertx) - Static method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Create a Consul client with default options.
- create(Vertx, ConsulClientOptions) - Static method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Create a Consul client.
- 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, 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, AuthProvider) - Static method in class io.vertx.reactivex.ext.healthchecks.HealthCheckHandler
-
- create(Vertx) - Static method in class io.vertx.reactivex.ext.healthchecks.HealthCheckHandler
-
- create(Vertx) - Static method in class io.vertx.reactivex.ext.healthchecks.HealthChecks
-
Creates a new instance of the default implementation of
HealthChecks
.
- create(Vertx, JsonObject) - Static method in class io.vertx.reactivex.ext.jdbc.JDBCClient
-
Create a JDBC client which maintains its own data source.
- create(Vertx, MailConfig) - Static method in class io.vertx.reactivex.ext.mail.MailClient
-
Create a non shared instance of the mail client.
- 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) - Static method in class io.vertx.reactivex.ext.shell.command.CommandRegistry
-
Create a new registry.
- create() - Static method in class io.vertx.reactivex.ext.shell.session.Session
-
Create a new empty session.
- create(Vertx, ShellServerOptions) - Static method in class io.vertx.reactivex.ext.shell.ShellServer
-
Create a new shell server with default options.
- create(Vertx) - Static method in class io.vertx.reactivex.ext.shell.ShellServer
-
Create a new shell server with specific options.
- create(Vertx) - Static method in class io.vertx.reactivex.ext.shell.ShellService
-
- create(Vertx, ShellServiceOptions) - Static method in class io.vertx.reactivex.ext.shell.ShellService
-
Create a new shell service.
- create() - Static method in class io.vertx.reactivex.ext.shell.term.Pty
-
Create a new pseudo terminal with no terminal type.
- create(String) - Static method in class io.vertx.reactivex.ext.shell.term.Pty
-
Create a new pseudo terminal.
- create(Vertx, String) - Static method in class io.vertx.reactivex.ext.shell.term.SockJSTermHandler
-
- create(Vertx, String) - Method in class io.vertx.reactivex.ext.stomp.DestinationFactory
-
Creates a destination for the given address.
- create(Vertx) - Static method in class io.vertx.reactivex.ext.stomp.StompClient
-
Creates a
StompClient
using the default implementation.
- 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, 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) - 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
-
- 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, Handler<TestSuiteReport>) - Static method in class io.vertx.reactivex.ext.unit.collect.EventBusCollector
-
- create(String, Handler<TestContext>) - Static method in class io.vertx.reactivex.ext.unit.TestCase
-
Create a test case.
- create(String) - Static method in class io.vertx.reactivex.ext.unit.TestSuite
-
Create and return a new test suite.
- create(Vertx, String, Handler<AsyncResult<OpenAPI3RouterFactory>>) - Static method in class io.vertx.reactivex.ext.web.api.contract.openapi3.OpenAPI3RouterFactory
-
Create a new OpenAPI3RouterFactory
- create(Vertx, String, List<JsonObject>, Handler<AsyncResult<OpenAPI3RouterFactory>>) - Static method in class io.vertx.reactivex.ext.web.api.contract.openapi3.OpenAPI3RouterFactory
-
Create a new OpenAPI3RouterFactory
- create(String, Object) - Static method in class io.vertx.reactivex.ext.web.api.RequestParameter
-
- create(Object) - Static method in class io.vertx.reactivex.ext.web.api.RequestParameter
-
- create() - Static method in class io.vertx.reactivex.ext.web.api.validation.HTTPRequestValidationHandler
-
Factory method to create an HTTPRequestValidationHandler
- create(Function<ResponsePredicateResult, Throwable>) - Static method in class io.vertx.reactivex.ext.web.client.predicate.ErrorConverter
-
Creates a full
ErrorConverter
, that will passed a predicate result with the response body.
- create(Function<HttpResponse<Void>, ResponsePredicateResult>) - Static method in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
- create(Function<HttpResponse<Void>, ResponsePredicateResult>, ErrorConverter) - Static method in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
- 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, WebClientOptions) - Static method in class io.vertx.reactivex.ext.web.client.WebClient
-
Create a web client using the provided vertx
instance.
- 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(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.
- create(AuthProvider) - Static method in class io.vertx.reactivex.ext.web.handler.BasicAuthHandler
-
Create a basic auth handler
- create(AuthProvider, String) - Static method in class io.vertx.reactivex.ext.web.handler.BasicAuthHandler
-
Create a basic auth handler, specifying realm
- create() - Static method in class io.vertx.reactivex.ext.web.handler.BodyHandler
-
Create a body handler with defaults
- 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(String) - Static method in class io.vertx.reactivex.ext.web.handler.BodyHandler
-
Create a body handler and use the given upload directory.
- create() - Static method in class io.vertx.reactivex.ext.web.handler.ChainAuthHandler
-
- create() - Static method in class io.vertx.reactivex.ext.web.handler.CookieHandler
-
Deprecated.
- create(String) - Static method in class io.vertx.reactivex.ext.web.handler.CorsHandler
-
Create a CORS handler
- create(String) - Static method in class io.vertx.reactivex.ext.web.handler.CSRFHandler
-
Instantiate a new CSRFHandlerImpl with a secret
- create(HtdigestAuth) - Static method in class io.vertx.reactivex.ext.web.handler.DigestAuthHandler
-
Create a digest auth handler
- create(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() - Static method in class io.vertx.reactivex.ext.web.handler.ErrorHandler
-
Create an error handler using defaults
- create(String, boolean) - Static method in class io.vertx.reactivex.ext.web.handler.ErrorHandler
-
Create an error handler
- create(boolean) - Static method in class io.vertx.reactivex.ext.web.handler.ErrorHandler
-
Create an error handler
- create(String) - Static method in class io.vertx.reactivex.ext.web.handler.ErrorHandler
-
Create an error handler
- create() - Static method in class io.vertx.reactivex.ext.web.handler.FaviconHandler
-
Create a handler with defaults
- create(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(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(long) - Static method in class io.vertx.reactivex.ext.web.handler.FaviconHandler
-
Create a handler with the specified max cache time
- create(AuthProvider) - Static method in class io.vertx.reactivex.ext.web.handler.FormLoginHandler
-
Create a handler
- create(AuthProvider, String, String, String, String) - Static method in class io.vertx.reactivex.ext.web.handler.FormLoginHandler
-
Create a handler
- create(GraphQL) - Static method in class io.vertx.reactivex.ext.web.handler.graphql.ApolloWSHandler
-
Create a new
ApolloWSHandler
that will use the provided
graphQL
object to execute requests.
- create(GraphQL, ApolloWSOptions) - Static method in class io.vertx.reactivex.ext.web.handler.graphql.ApolloWSHandler
-
Create a new
ApolloWSHandler
that will use the provided
graphQL
object to execute requests.
- create() - Static method in class io.vertx.reactivex.ext.web.handler.graphql.GraphiQLHandler
-
- create(GraphiQLHandlerOptions) - Static method in class io.vertx.reactivex.ext.web.handler.graphql.GraphiQLHandler
-
- 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, 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(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() - Static method in class io.vertx.reactivex.ext.web.handler.LoggerHandler
-
Create a handler with default format
- create(LoggerFormat) - Static method in class io.vertx.reactivex.ext.web.handler.LoggerHandler
-
Create a handler with he specified format
- create(boolean, LoggerFormat) - Static method in class io.vertx.reactivex.ext.web.handler.LoggerHandler
-
Create a handler with he specified format
- 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(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.
- create(OAuth2Auth, String) - Static method in class io.vertx.reactivex.ext.web.handler.OAuth2AuthHandler
-
Create a OAuth2 auth handler with host pinning
- create(OAuth2Auth) - Static method in class io.vertx.reactivex.ext.web.handler.OAuth2AuthHandler
-
Create a OAuth2 auth handler without host pinning.
- create(AuthProvider) - Static method in class io.vertx.reactivex.ext.web.handler.RedirectAuthHandler
-
Create a handler
- create(AuthProvider, String) - Static method in class io.vertx.reactivex.ext.web.handler.RedirectAuthHandler
-
Create a handler
- create(AuthProvider, String, String) - Static method in class io.vertx.reactivex.ext.web.handler.RedirectAuthHandler
-
Create a handler
- create() - Static method in class io.vertx.reactivex.ext.web.handler.ResponseContentTypeHandler
-
Create a response content type handler.
- 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() - Static method in class io.vertx.reactivex.ext.web.handler.ResponseTimeHandler
-
Create a handler
- create(SessionStore) - Static method in class io.vertx.reactivex.ext.web.handler.SessionHandler
-
Create a session handler
- create(Vertx) - Static method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSHandler
-
Create a SockJS handler
- create(Vertx, SockJSHandlerOptions) - Static method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSHandler
-
Create a SockJS handler
- create() - Static method in class io.vertx.reactivex.ext.web.handler.StaticHandler
-
Create a handler using defaults
- create(String) - Static method in class io.vertx.reactivex.ext.web.handler.StaticHandler
-
Create a handler, specifying web-root
- 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() - Static method in class io.vertx.reactivex.ext.web.handler.TimeoutHandler
-
Create a handler
- create(long) - Static method in class io.vertx.reactivex.ext.web.handler.TimeoutHandler
-
Create a handler
- create(long, int) - Static method in class io.vertx.reactivex.ext.web.handler.TimeoutHandler
-
Create a handler
- create(AuthProvider) - Static method in class io.vertx.reactivex.ext.web.handler.UserSessionHandler
-
Deprecated.
- create(String, Handler<RoutingContext>) - Static method in class io.vertx.reactivex.ext.web.handler.VirtualHostHandler
-
Create a handler
- create() - Static method in class io.vertx.reactivex.ext.web.Locale
-
Deprecated.
- create(String) - Static method in class io.vertx.reactivex.ext.web.Locale
-
Deprecated.
- create(String, String) - Static method in class io.vertx.reactivex.ext.web.Locale
-
Deprecated.
- create(String, String, String) - Static method in class io.vertx.reactivex.ext.web.Locale
-
Deprecated.
- create() - Static method in class io.vertx.reactivex.ext.web.multipart.MultipartForm
-
- create(Vertx, String) - 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.ClusteredSessionStore
-
Create a session store.
The retry timeout value, configures how long the session handler will retry to get a session from the store
when it is not found.
- create(Vertx) - Static method in class io.vertx.reactivex.ext.web.sstore.ClusteredSessionStore
-
Create a session store
- create(Vertx, long) - Static method in class io.vertx.reactivex.ext.web.sstore.ClusteredSessionStore
-
Create a session store.
The retry timeout value, configures how long the session handler will retry to get a session from the store
when it is not found.
- create(Vertx) - 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.sstore.LocalSessionStore
-
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) - Static method in class io.vertx.reactivex.ext.web.sstore.SessionStore
-
Create a Session store given a backend and configuration JSON.
- 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) - 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.jade.JadeTemplateEngine
-
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() - Static method in class io.vertx.reactivex.ext.web.templ.rocker.RockerTemplateEngine
-
- create(Vertx) - Static method in class io.vertx.reactivex.ext.web.templ.thymeleaf.ThymeleafTemplateEngine
-
Create a template engine using defaults
- 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>, 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>) - 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.producer.KafkaProducer
-
Create a new KafkaProducer instance
- 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, 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, V) - Static method in class io.vertx.reactivex.kafka.client.producer.KafkaProducerRecord
-
Create a concrete instance of a Vert.x producer record
- create(Measured) - Static method in class io.vertx.reactivex.micrometer.MetricsService
-
Creates a metric service for a given object.
- create() - Static method in class io.vertx.reactivex.micrometer.PrometheusScrapingHandler
-
Creates a Vert.x Web
Route
handler for Prometheus metrics scraping.
- create(String) - Static method in class io.vertx.reactivex.micrometer.PrometheusScrapingHandler
-
Creates a Vert.x Web
Route
handler for Prometheus metrics scraping.
- create(MqttConnectReturnCode, boolean) - Static method in class io.vertx.reactivex.mqtt.messages.MqttConnAckMessage
-
Create a concrete instance of a Vert.x connack message
- create(Vertx, MqttClientOptions) - Static method in class io.vertx.reactivex.mqtt.MqttClient
-
Return an MQTT client instance
- create(Vertx) - Static method in class io.vertx.reactivex.mqtt.MqttClient
-
Return an MQTT client instance using the default options
- create(Vertx, MqttServerOptions) - Static method in class io.vertx.reactivex.mqtt.MqttServer
-
Return an MQTT server instance
- 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, RabbitMQOptions) - Static method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
-
Create and return a client.
- create(String, int, int, int, int, boolean, boolean) - Static method in class io.vertx.reactivex.redis.client.Command
-
Creates a Redis Command from METADATA.
- create(Vertx) - Static method in class io.vertx.reactivex.redis.RedisClient
-
- create(Vertx, JsonObject) - Static method in class io.vertx.reactivex.redis.RedisClient
-
- create(String) - Static method in class io.vertx.reactivex.redis.Script
-
- create(String, String) - Static method in class io.vertx.reactivex.redis.Script
-
- create(Vertx) - Static method in class io.vertx.reactivex.redis.sentinel.RedisSentinel
-
- create(Vertx, JsonObject) - Static method in class io.vertx.reactivex.redis.sentinel.RedisSentinel
-
- create(Vertx, ServiceDiscoveryOptions) - Static method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
-
- create(Vertx) - Static method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
-
- create(Vertx, ServiceDiscoveryOptions, Handler<ServiceDiscovery>) - Static method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
-
Deprecated.
- create(Vertx, Handler<ServiceDiscovery>) - Static method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
-
Deprecated.
- create(String, Class<T>) - Static method in class io.vertx.reactivex.sqlclient.PropertyKind
-
- createAclToken(AclToken, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Create new Acl token
- createAclToken(AclToken, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- createAnonymousSender(Handler<AsyncResult<AmqpSender>>) - Method in class io.vertx.reactivex.amqp.AmqpConnection
-
Creates an anonymous sender.
- createArrayTypeValidator(ParameterTypeValidator) - Static method in class io.vertx.reactivex.ext.web.api.validation.ParameterTypeValidator
-
Create an array type validator
- createArrayTypeValidator(ParameterTypeValidator, String, Integer, Integer) - Static method in class io.vertx.reactivex.ext.web.api.validation.ParameterTypeValidator
-
Create an array type validator
- createBlank(String) - Static method in class io.vertx.reactivex.ext.shell.cli.CliToken
-
Create a new blank token.
- createBooleanTypeValidator(Object) - Static method in class io.vertx.reactivex.ext.web.api.validation.ParameterTypeValidator
-
Create a boolean type validator
- createClient(Vertx) - Static method in class io.vertx.reactivex.redis.client.Redis
-
Create a new redis client using the default 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.
- createClient(Vertx, RedisOptions) - Static method in class io.vertx.reactivex.redis.client.Redis
-
Create a new redis client using the given client options.
- createCollection(String, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Create a new collection
- createCollection(String, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- createConsumer(String) - Method in class io.vertx.reactivex.amqpbridge.AmqpBridge
-
Creates a consumer on the given AMQP address.
- createDatagramSocket(DatagramSocketOptions) - Method in class io.vertx.reactivex.core.Vertx
-
Create a datagram socket using the specified options
- createDatagramSocket() - Method in class io.vertx.reactivex.core.Vertx
-
Create a datagram socket using default options
- createDnsClient(int, String) - Method in class io.vertx.reactivex.core.Vertx
-
Create a DNS client to connect to a DNS server at the specified host and port, with the default query timeout (5 seconds)
- createDnsClient() - Method in class io.vertx.reactivex.core.Vertx
-
Create a DNS client to connect to the DNS server configured by VertxOptions
- createDnsClient(DnsClientOptions) - Method in class io.vertx.reactivex.core.Vertx
-
Create a DNS client to connect to a DNS server
- createDoubleTypeValidator(Double) - Static method in class io.vertx.reactivex.ext.web.api.validation.ParameterTypeValidator
-
Create a new type validator for double values
- createDoubleTypeValidator(Double, Double, Double, Double) - Static method in class io.vertx.reactivex.ext.web.api.validation.ParameterTypeValidator
-
Create a new type validator for double values
- createDoubleTypeValidator(Boolean, Double, Boolean, Double, Double, Object) - Static method in class io.vertx.reactivex.ext.web.api.validation.ParameterTypeValidator
-
Create a new type validator for double values
- createDynamicReceiver(Handler<AsyncResult<AmqpReceiver>>) - Method in class io.vertx.reactivex.amqp.AmqpConnection
-
Creates a dynamic receiver.
- createEnumTypeValidatorWithInnerValidator(List<Object>, ParameterTypeValidator) - Static method in class io.vertx.reactivex.ext.web.api.validation.ParameterTypeValidator
-
Create an enum type validator
- createErrorFrame(String, Map<String, String>, String) - Static method in class io.vertx.reactivex.ext.stomp.Frames
-
- createEventBusProxy(Vertx, String) - Static method in class io.vertx.reactivex.ext.consul.ConsulService
-
Create a proxy to a service that is deployed somewhere on the event bus
- createEventBusProxy(Vertx, String) - Static method in class io.vertx.reactivex.ext.mail.MailService
-
create a proxy of MailService that delegates to the mail service running somewhere else via the event bus
- createEventBusProxy(Vertx, String) - Static method in class io.vertx.reactivex.ext.mongo.MongoService
-
Create a proxy to a service that is deployed somewhere on the event bus
- createFile(String, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.core.file.FileSystem
-
Creates an empty file with the specified path
, asynchronously.
- createFile(String, String, Handler<AsyncResult<Void>>) - 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
-
- createFloatTypeValidator(Float) - Static method in class io.vertx.reactivex.ext.web.api.validation.ParameterTypeValidator
-
Create a new type validator for float values
- createFloatTypeValidator(Double, Double, Double, Float) - Static method in class io.vertx.reactivex.ext.web.api.validation.ParameterTypeValidator
-
Create a new type validator for float values
- createFloatTypeValidator(Boolean, Double, Boolean, Double, Double, Object) - Static method in class io.vertx.reactivex.ext.web.api.validation.ParameterTypeValidator
-
Create a new type validator for float values
- createFullBody(Function<ResponsePredicateResult, Throwable>) - Static method in class io.vertx.reactivex.ext.web.client.predicate.ErrorConverter
-
Creates a full
ErrorConverter
, that will passed a predicate result with the response body.
- createHttpClient(HttpClientOptions) - Method in class io.vertx.reactivex.core.Vertx
-
Create a HTTP/HTTPS client using the specified options
- createHttpClient() - Method in class io.vertx.reactivex.core.Vertx
-
Create a HTTP/HTTPS client using default options
- createHttpServer(HttpServerOptions) - Method in class io.vertx.reactivex.core.Vertx
-
Create an HTTP/HTTPS server using the specified options
- createHttpServer() - Method in class io.vertx.reactivex.core.Vertx
-
Create an HTTP/HTTPS server using default options
- createHttpTermServer(Vertx) - Static method in class io.vertx.reactivex.ext.shell.term.TermServer
-
Create a term server for the HTTP protocol.
- createHttpTermServer(Vertx, HttpTermOptions) - Static method in class io.vertx.reactivex.ext.shell.term.TermServer
-
Create a term server for the HTTP protocol.
- createHttpTermServer(Vertx, Router) - Static method in class io.vertx.reactivex.ext.shell.term.TermServer
-
Create a term server for the HTTP protocol, using an existing router.
- createHttpTermServer(Vertx, Router, HttpTermOptions) - Static method in class io.vertx.reactivex.ext.shell.term.TermServer
-
Create a term server for the HTTP protocol, using an existing router.
- createIndex(String, JsonObject, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Creates an index.
- createIndex(String, JsonObject, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- createIndexWithOptions(String, JsonObject, IndexOptions, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Creates an index.
- createIndexWithOptions(String, JsonObject, IndexOptions, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- createIntegerTypeValidator(Integer) - Static method in class io.vertx.reactivex.ext.web.api.validation.ParameterTypeValidator
-
Create a new type validator for integer values
- createIntegerTypeValidator(Double, Double, Double, Integer) - Static method in class io.vertx.reactivex.ext.web.api.validation.ParameterTypeValidator
-
Create a new type validator for integer values
- createIntegerTypeValidator(Boolean, Double, Boolean, Double, Double, Object) - Static method in class io.vertx.reactivex.ext.web.api.validation.ParameterTypeValidator
-
Create a new type validator for integer values
- createJob(List<CliToken>) - Method in class io.vertx.reactivex.ext.shell.Shell
-
Create a job, the created job should then be executed with the
Job.run()
method.
- createJob(String) - Method in class io.vertx.reactivex.ext.shell.Shell
-
- createJob(Process, String) - Method in class io.vertx.reactivex.ext.shell.system.JobController
-
Create a job wrapping a process.
- createKeycloak(Vertx, OAuth2FlowType, JsonObject) - Static method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
-
Deprecated.
- createLongTypeValidator(Long) - Static method in class io.vertx.reactivex.ext.web.api.validation.ParameterTypeValidator
-
Create a new type validator for long integer values
- createLongTypeValidator(Double, Double, Double, Long) - Static method in class io.vertx.reactivex.ext.web.api.validation.ParameterTypeValidator
-
Create a new type validator for long integer values
- createLongTypeValidator(Boolean, Double, Boolean, Double, Double, Object) - Static method in class io.vertx.reactivex.ext.web.api.validation.ParameterTypeValidator
-
Create a new type validator for long integer values
- createNetClient(NetClientOptions) - Method in class io.vertx.reactivex.core.Vertx
-
Create a TCP/SSL client using the specified options
- createNetClient() - Method in class io.vertx.reactivex.core.Vertx
-
Create a TCP/SSL client using default options
- createNetServer(NetServerOptions) - Method in class io.vertx.reactivex.core.Vertx
-
Create a TCP/SSL server using the specified options
- createNetServer() - Method in class io.vertx.reactivex.core.Vertx
-
Create a TCP/SSL server using default options
- createNonShared(Vertx) - Static method in class io.vertx.reactivex.cassandra.CassandraClient
-
Deprecated.
- createNonShared(Vertx, CassandraClientOptions) - Static method in class io.vertx.reactivex.cassandra.CassandraClient
-
Deprecated.
- createNonShared(Vertx, JsonObject) - Static method in class io.vertx.reactivex.ext.asyncsql.MySQLClient
-
Create a MySQL client which maintains its own pool.
- createNonShared(Vertx, JsonObject) - Static method in class io.vertx.reactivex.ext.asyncsql.PostgreSQLClient
-
Create a PostgreSQL client which maintains its own pool.
- createNonShared(Vertx, JsonObject) - Static method in class io.vertx.reactivex.ext.jdbc.JDBCClient
-
Deprecated.
- createNonShared(Vertx, MailConfig) - Static method in class io.vertx.reactivex.ext.mail.MailClient
-
Deprecated.
- createNonShared(Vertx, JsonObject) - Static method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Deprecated.
- createPBKDF2(Vertx) - Static method in class io.vertx.reactivex.ext.auth.jdbc.JDBCHashStrategy
-
Implements a Hashing Strategy as per https://www.owasp.org/index.php/Password_Storage_Cheat_Sheet (2018-01-17).
- createPreparedQuery(PreparedQueryDefinition, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
- createPreparedQuery(PreparedQueryDefinition, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- createProcess() - Method in class io.vertx.reactivex.ext.shell.command.Command
-
Create a new process with empty arguments.
- createProcess(List<CliToken>) - Method in class io.vertx.reactivex.ext.shell.command.Command
-
Create a new process with the passed arguments.
- createProducer(String) - Method in class io.vertx.reactivex.amqpbridge.AmqpBridge
-
Creates a producer to the given AMQP address.
- createReceiptFrame(String, Map<String, String>) - Static method in class io.vertx.reactivex.ext.stomp.Frames
-
- createReceiver(String, Handler<AsyncResult<AmqpReceiver>>) - Method in class io.vertx.reactivex.amqp.AmqpClient
-
Creates a receiver used to consume messages from the given address.
- createReceiver(String, AmqpReceiverOptions, Handler<AsyncResult<AmqpReceiver>>) - Method in class io.vertx.reactivex.amqp.AmqpClient
-
Creates a receiver used to consumer messages from the given address.
- createReceiver(String, Handler<AsyncResult<AmqpReceiver>>) - Method in class io.vertx.reactivex.amqp.AmqpConnection
-
Creates a receiver used to consume messages from the given address.
- createReceiver(String, AmqpReceiverOptions, Handler<AsyncResult<AmqpReceiver>>) - Method in class io.vertx.reactivex.amqp.AmqpConnection
-
Creates a receiver used to consumer messages from the given address.
- 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) - Static method in class io.vertx.reactivex.servicediscovery.types.EventBusService
-
Creates a record based on the parameters.
- 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, boolean, String, int, String, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.HttpEndpoint
-
- createRecord(String, String, int, String) - Static method in class io.vertx.reactivex.servicediscovery.types.HttpEndpoint
-
- createRecord(String, String) - Static method in class io.vertx.reactivex.servicediscovery.types.HttpEndpoint
-
- createRecord(String, JsonObject, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.JDBCDataSource
-
- createRecord(String, String, String, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.MessageSource
-
Create a record representing a data producer.
- createRecord(String, String, String) - Static method in class io.vertx.reactivex.servicediscovery.types.MessageSource
-
- createRecord(String, String) - Static method in class io.vertx.reactivex.servicediscovery.types.MessageSource
-
- 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.
- createSender(String, Handler<AsyncResult<AmqpSender>>) - Method in class io.vertx.reactivex.amqp.AmqpClient
-
Creates a sender used to send messages to the given address.
- createSender(String, AmqpSenderOptions, Handler<AsyncResult<AmqpSender>>) - Method in class io.vertx.reactivex.amqp.AmqpClient
-
Creates a sender used to send messages to the given address.
- createSender(String, Handler<AsyncResult<AmqpSender>>) - Method in class io.vertx.reactivex.amqp.AmqpConnection
-
Creates a sender used to send messages to the given address.
- createSender(String, AmqpSenderOptions, Handler<AsyncResult<AmqpSender>>) - Method in class io.vertx.reactivex.amqp.AmqpConnection
-
Creates a sender used to send messages to the given address.
- createSession(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Initialize a new session
- createSession(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- 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, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Initialize a new session
- createSessionWithOptions(SessionOptions, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- createSHA512(Vertx) - Static method in class io.vertx.reactivex.ext.auth.jdbc.JDBCHashStrategy
-
This is the current backwards compatible hashing implementation, new applications should prefer the
PBKDF2 implementation, unless the tradeoff between security and CPU usage is an option.
- createShared(Vertx) - Static method in class io.vertx.reactivex.cassandra.CassandraClient
-
- createShared(Vertx, String) - Static method in class io.vertx.reactivex.cassandra.CassandraClient
-
- createShared(Vertx, CassandraClientOptions) - 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, JsonObject, String) - Static method in class io.vertx.reactivex.ext.asyncsql.MySQLClient
-
Create a MySQL client which shares its data source with any other MySQL clients created with the same
data source name
- createShared(Vertx, JsonObject) - Static method in class io.vertx.reactivex.ext.asyncsql.MySQLClient
-
- createShared(Vertx, JsonObject, String) - Static method in class io.vertx.reactivex.ext.asyncsql.PostgreSQLClient
-
Create a PostgreSQL client which shares its pool with any other MySQL clients created with the same pool name.
- createShared(Vertx, JsonObject) - Static method in class io.vertx.reactivex.ext.asyncsql.PostgreSQLClient
-
- createShared(Vertx, JsonObject, String) - Static method in class io.vertx.reactivex.ext.jdbc.JDBCClient
-
Create a JDBC client which shares its data source with any other JDBC clients created with the same
data source name
- createShared(Vertx, JsonObject) - Static method in class io.vertx.reactivex.ext.jdbc.JDBCClient
-
- 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, MailConfig) - Static method in class io.vertx.reactivex.ext.mail.MailClient
-
- 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, JsonObject) - Static method in class io.vertx.reactivex.ext.mongo.MongoClient
-
- 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
- createSharedWorkerExecutor(String) - Method in class io.vertx.reactivex.core.Vertx
-
- createSharedWorkerExecutor(String, int) - Method in class io.vertx.reactivex.core.Vertx
-
- createSharedWorkerExecutor(String, int, long) - Method in class io.vertx.reactivex.core.Vertx
-
- createSharedWorkerExecutor(String, int, long, TimeUnit) - Method in class io.vertx.reactivex.core.Vertx
-
Create a named worker executor, the executor should be closed when it's not needed anymore to release
resources.
This method can be called mutiple times with the same
name
.
- createShell(Term) - Method in class io.vertx.reactivex.ext.shell.ShellServer
-
Create a new shell, the returned shell should be closed explicitely.
- createShell() - Method in class io.vertx.reactivex.ext.shell.ShellServer
-
Create a new shell, the returned shell should be closed explicitely.
- createSSHTermServer(Vertx) - Static method in class io.vertx.reactivex.ext.shell.term.TermServer
-
Create a term server for the SSH protocol.
- createSSHTermServer(Vertx, SSHTermOptions) - Static method in class io.vertx.reactivex.ext.shell.term.TermServer
-
Create a term server for the SSH protocol.
- createStream(int) - Method in class io.vertx.reactivex.sqlclient.PreparedStatement
-
- createStream(int, Tuple) - Method in class io.vertx.reactivex.sqlclient.PreparedStatement
-
Execute the prepared query with a cursor and createStream the result.
- createStringEnumTypeValidator(List<String>) - Static method in class io.vertx.reactivex.ext.web.api.validation.ParameterTypeValidator
-
Create an enum type validator
- createStringTypeValidator(Object) - Static method in class io.vertx.reactivex.ext.web.api.validation.ParameterTypeValidator
-
Create a new string type validator
- createStringTypeValidator(String, Object) - Static method in class io.vertx.reactivex.ext.web.api.validation.ParameterTypeValidator
-
Create a new string type validator
- createStringTypeValidator(String, Integer, Integer, Object) - Static method in class io.vertx.reactivex.ext.web.api.validation.ParameterTypeValidator
-
Create a new string type validator
- createTelnetTermServer(Vertx) - Static method in class io.vertx.reactivex.ext.shell.term.TermServer
-
Create a term server for the Telnet protocol.
- createTelnetTermServer(Vertx, TelnetTermOptions) - Static method in class io.vertx.reactivex.ext.shell.term.TermServer
-
Create a term server for the Telnet protocol.
- createTempDirectory(String, Handler<AsyncResult<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, Handler<AsyncResult<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, Handler<AsyncResult<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, Handler<AsyncResult<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, Handler<AsyncResult<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, Handler<AsyncResult<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
-
- createText(String) - Static method in class io.vertx.reactivex.ext.shell.cli.CliToken
-
Create a text token.
- createTopics(List<NewTopic>, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
-
Creates a batch of new Kafka topics
- createWithHealthChecks(HealthChecks, AuthProvider) - Static method in class io.vertx.reactivex.ext.healthchecks.HealthCheckHandler
-
- createWithHealthChecks(HealthChecks) - Static method in class io.vertx.reactivex.ext.healthchecks.HealthCheckHandler
-
- creationTime() - Method in class io.vertx.reactivex.amqp.AmqpMessage
-
- creationTime(long) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
-
- creationTime() - Method in class io.vertx.reactivex.core.file.FileProps
-
The date the file was created
- 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.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.VertxContextPRNG
-
Get or create a secure non blocking random number generator using the current vert.x instance.
- currentContext() - Static method in class io.vertx.reactivex.core.Vertx
-
Gets the current context
- currentRoute() - Method in class io.vertx.reactivex.ext.web.RoutingContext
-
- 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
-
- cursor() - Method in class io.vertx.reactivex.sqlclient.PreparedStatement
-
- cursor(Tuple) - Method in class io.vertx.reactivex.sqlclient.PreparedStatement
-
Create a cursor with the provided arguments
.
- 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.
- CustomValidator - Class in io.vertx.reactivex.ext.web.api.validation
-
This interface is used to add custom synchronous functions inside validation process.
- CustomValidator(CustomValidator) - Constructor for class io.vertx.reactivex.ext.web.api.validation.CustomValidator
-
- CustomValidator(Object) - Constructor for class io.vertx.reactivex.ext.web.api.validation.CustomValidator
-
- generateSalt() - Method in class io.vertx.reactivex.ext.auth.jdbc.JDBCAuth
-
Compute a salt string.
- generateSalt() - Method in class io.vertx.reactivex.ext.auth.jdbc.JDBCHashStrategy
-
Compute a random salt.
- generateToken(JsonObject, JWTOptions) - Method in class io.vertx.reactivex.ext.auth.jwt.JWTAuth
-
Generate a new JWT token.
- generateToken(JsonObject) - Method in class io.vertx.reactivex.ext.auth.jwt.JWTAuth
-
Generate a new JWT token.
- GEOADD - Static variable in class io.vertx.reactivex.redis.client.Command
-
- geoadd(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- geoadd(String, double, double, String, Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Add one or more geospatial items in the geospatial index represented using a sorted set.
- geoadd(String, double, double, String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Add one or more geospatial items in the geospatial index represented using a sorted set.
- geoaddMany(String, List<GeoMember>, Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Add one or more geospatial items in the geospatial index represented using a sorted set.
- geoaddMany(String, List<GeoMember>, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Add one or more geospatial items in the geospatial index represented using a sorted set.
- GEODIST - Static variable in class io.vertx.reactivex.redis.client.Command
-
- geodist(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- geodist(String, String, String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Return the distance between two members in the geospatial index represented by the sorted set.
- geodist(String, String, String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return the distance between two members in the geospatial index represented by the sorted set.
- geodistWithUnit(String, String, String, GeoUnit, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Return the distance between two members in the geospatial index represented by the sorted set.
- geodistWithUnit(String, String, String, GeoUnit, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return the distance between two members in the geospatial index represented by the sorted set.
- GEOHASH - Static variable in class io.vertx.reactivex.redis.client.Command
-
- geohash(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- geohash(String, String, Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Return valid Geohash strings representing the position of one or more elements in a sorted set value representing
a geospatial index (where elements were added using GEOADD).
- geohash(String, String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return valid Geohash strings representing the position of one or more elements in a sorted set value representing
a geospatial index (where elements were added using GEOADD).
- geohashMany(String, List<String>, Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Return valid Geohash strings representing the position of one or more elements in a sorted set value representing
a geospatial index (where elements were added using GEOADD).
- geohashMany(String, List<String>, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return valid Geohash strings representing the position of one or more elements in a sorted set value representing
a geospatial index (where elements were added using GEOADD).
- GEOPOS - Static variable in class io.vertx.reactivex.redis.client.Command
-
- geopos(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- geopos(String, String, Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Return the positions (longitude,latitude) of all the specified members of the geospatial index represented by the
sorted set at key.
- geopos(String, String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return the positions (longitude,latitude) of all the specified members of the geospatial index represented by the
sorted set at key.
- geoposMany(String, List<String>, Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Return the positions (longitude,latitude) of all the specified members of the geospatial index represented by the
sorted set at key.
- geoposMany(String, List<String>, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return the positions (longitude,latitude) of all the specified members of the geospatial index represented by the
sorted set at key.
- GEORADIUS - Static variable in class io.vertx.reactivex.redis.client.Command
-
- georadius(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- georadius(String, double, double, double, GeoUnit, Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Return the members of a sorted set populated with geospatial information using GEOADD, which are within the borders
of the area specified with the center location and the maximum distance from the center (the radius).
- georadius(String, double, double, double, GeoUnit, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return the members of a sorted set populated with geospatial information using GEOADD, which are within the borders
of the area specified with the center location and the maximum distance from the center (the radius).
- GEORADIUS_RO - Static variable in class io.vertx.reactivex.redis.client.Command
-
- GEORADIUSBYMEMBER - Static variable in class io.vertx.reactivex.redis.client.Command
-
- georadiusbymember(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- georadiusbymember(String, String, double, GeoUnit, Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
This command is exactly like GEORADIUS with the sole difference that instead of taking, as the center of the area
to query, a longitude and latitude value, it takes the name of a member already existing inside the geospatial
index represented by the sorted set.
- georadiusbymember(String, String, double, GeoUnit, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
This command is exactly like GEORADIUS with the sole difference that instead of taking, as the center of the area
to query, a longitude and latitude value, it takes the name of a member already existing inside the geospatial
index represented by the sorted set.
- GEORADIUSBYMEMBER_RO - Static variable in class io.vertx.reactivex.redis.client.Command
-
- georadiusbymemberRo(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- georadiusbymemberWithOptions(String, String, double, GeoUnit, GeoRadiusOptions, Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
This command is exactly like GEORADIUS with the sole difference that instead of taking, as the center of the area
to query, a longitude and latitude value, it takes the name of a member already existing inside the geospatial
index represented by the sorted set.
- georadiusbymemberWithOptions(String, String, double, GeoUnit, GeoRadiusOptions, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
This command is exactly like GEORADIUS with the sole difference that instead of taking, as the center of the area
to query, a longitude and latitude value, it takes the name of a member already existing inside the geospatial
index represented by the sorted set.
- georadiusRo(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- georadiusWithOptions(String, double, double, double, GeoUnit, GeoRadiusOptions, Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Return the members of a sorted set populated with geospatial information using GEOADD, which are within the borders
of the area specified with the center location and the maximum distance from the center (the radius).
- georadiusWithOptions(String, double, double, double, GeoUnit, GeoRadiusOptions, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return the members of a sorted set populated with geospatial information using GEOADD, which are within the borders
of the area specified with the center location and the maximum distance from the center (the radius).
- get(List<Object>, Handler<AsyncResult<T>>) - Method in class io.vertx.reactivex.cassandra.Mapper
-
Asynchronous get method based on the column values of the primary key.
- get(String) - Method in class io.vertx.reactivex.core.Context
-
Get some data from the context.
- get(RequestOptions) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Create an HTTP GET request to send to the server with the specified options.
- get(int, String, String) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Create an HTTP GET request to send to the server at the specified host and port.
- get(String, String) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Create an HTTP GET request to send to the server at the specified host and default port.
- get(RequestOptions, Handler<HttpClientResponse>) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Deprecated.
- get(int, String, String, Handler<HttpClientResponse>) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Deprecated.
- get(String, String, Handler<HttpClientResponse>) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Deprecated.
- get(String) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Create an HTTP GET request to send to the server at the default host and port.
- get(String, Handler<HttpClientResponse>) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Deprecated.
- get(String) - Method in class io.vertx.reactivex.core.MultiMap
-
Returns the value of with the specified name.
- get(CharSequence) - Method in class io.vertx.reactivex.core.MultiMap
-
- get(K, Handler<AsyncResult<V>>) - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
-
Get a value from the map, asynchronously.
- get(Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.core.shareddata.Counter
-
Get the current value of the counter
- 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.HashingStrategy
-
Get an algorithm interface by its Id
- get(String) - Method in class io.vertx.reactivex.ext.shell.session.Session
-
Get some data from the session
- 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(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(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() - Method in class io.vertx.reactivex.ext.web.Router
-
Add a route that matches any HTTP GET request
- 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, Handler<AsyncResult<Session>>) - Method in class io.vertx.reactivex.ext.web.sstore.SessionStore
-
Get the session with the specified ID.
- GET - Static variable in class io.vertx.reactivex.redis.client.Command
-
- get(String, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- get(int) - Method in class io.vertx.reactivex.redis.client.Response
-
Get this multi response value at a numerical index.
- get(String) - Method in class io.vertx.reactivex.redis.client.Response
-
Get this multi response value at a string key.
- get(String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get the value of a key
- get(String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get the value of a key
- get() - Method in class io.vertx.reactivex.servicediscovery.ServiceReference
-
Gets the object to access the service.
- get(Class<T>, int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
- getAbs(String) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Create an HTTP GET request to send to the server using an absolute URI
- getAbs(String, Handler<HttpClientResponse>) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Deprecated.
- 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
- getAcceptableContentType() - Method in class io.vertx.reactivex.ext.web.RoutingContext
-
If the route specifies produces matches, e.g.
- getAll(String) - Method in class io.vertx.reactivex.core.MultiMap
-
Returns the values with the specified name
- getAll(CharSequence) - Method in class io.vertx.reactivex.core.MultiMap
-
- getAllExecutionInfo() - Method in class io.vertx.reactivex.cassandra.ResultSet
-
- getAllPreparedQueries(Handler<AsyncResult<List<PreparedQueryDefinition>>>) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Returns a list of all prepared queries.
- getAllPreparedQueries(Handler<AsyncResult<List<PreparedQueryDefinition>>>) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- getAndAdd(long, Handler<AsyncResult<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(Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.core.shareddata.Counter
-
Increment the counter atomically and return the value before the increment.
- getArgument(String) - Method in class io.vertx.reactivex.core.cli.CLI
-
Gets an Argument
based on its name (argument name).
- getArgument(int) - Method in class io.vertx.reactivex.core.cli.CLI
-
Gets an Argument
based on its index.
- getArguments() - Method in class io.vertx.reactivex.core.cli.CLI
-
Gets the list of defined arguments.
- getArgumentValue(String) - Method in class io.vertx.reactivex.core.cli.CommandLine
-
Gets the value of an argument with the matching name (arg name).
- getArgumentValue(int) - Method in class io.vertx.reactivex.core.cli.CommandLine
-
Gets the value of an argument with the given index.
- getArity() - Method in class io.vertx.reactivex.redis.client.Command
-
- getArray() - Method in class io.vertx.reactivex.ext.web.api.RequestParameter
-
Returns null if value is not a list, otherwise it returns value
- getArrayElement(Object, int) - Method in class io.vertx.reactivex.core.json.pointer.JsonPointerIterator
-
Move the iterator the the array element at specified index
- getArrayOfBigDecimals(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Get an array of value for the given column
.
- getArrayOfBigDecimals(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Get an array of value at pos
.
- getArrayOfBooleans(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Get an array of
Boolean
value for the given
column
.
- getArrayOfBooleans(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Get an array of
Boolean
value at
pos
.
- getArrayOfDoubles(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Get an array of
Double
value for the given
column
.
- getArrayOfDoubles(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Get an array of
Double
value at
pos
.
- getArrayOfFloats(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Get an array of
Float
value for the given
column
.
- getArrayOfFloats(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Get an array of
Float
value at
pos
.
- getArrayOfIntegers(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Get an array of
Integer
value for the given
column
.
- getArrayOfIntegers(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Get an array of
Integer
value at
pos
.
- 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
- 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
- getArrayOfLocalDates(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Get an array of value for the given column
.
- getArrayOfLocalDates(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
.
- getArrayOfLocalDateTimes(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
.
- getArrayOfLocalTimes(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Get an array of value at pos
.
- getArrayOfLongs(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Get an array of
Long
value for the given
column
.
- getArrayOfLongs(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Get an array of
Long
value at
pos
.
- getArrayOfNumerics(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Get an array of value for the given column
.
- getArrayOfNumerics(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
.
- getArrayOfOffsetDateTimes(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
.
- getArrayOfOffsetTimes(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Get an array of value at pos
.
- getArrayOfShorts(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Get an array of
Short
value for the given
column
.
- getArrayOfShorts(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Get an array of
Short
value at
pos
.
- getArrayOfStrings(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Get an array of
String
value for the given
column
.
- getArrayOfStrings(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Get an array of
String
value at
pos
.
- getArrayOfTemporals(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Get an array of value for the given column
.
- getArrayOfTemporals(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
.
- getArrayOfUUIDs(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Get an array of value at pos
.
- getAs(Class<X>) - Method in class io.vertx.reactivex.servicediscovery.ServiceReference
-
Gets the object to access the service.
- getAsyncMap(String, Handler<AsyncResult<AsyncMap<K, V>>>) - Method in class io.vertx.reactivex.core.shareddata.SharedData
-
Get the
AsyncMap
with the specified name.
- getAvailableWithoutFetching() - Method in class io.vertx.reactivex.cassandra.ResultSet
-
- getBaseName(Measured) - Method in class io.vertx.reactivex.ext.dropwizard.MetricsService
-
- getBaseName() - Method in class io.vertx.reactivex.micrometer.MetricsService
-
- getBigDecimal(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Get value for the given column
.
- getBigDecimal(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Get value at pos
.
- getBigDecimalArray(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Deprecated.
- getBigDecimalArray(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Deprecated.
- getBinary(String, Handler<AsyncResult<Buffer>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get the value of a key - without decoding as utf-8
- getBinary(String, Handler<AsyncResult<Buffer>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get the value of a key - without decoding as utf-8
- GETBIT - Static variable in class io.vertx.reactivex.redis.client.Command
-
- getbit(String, String, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- getbit(String, long, Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Returns the bit value at offset in the string value stored at key
- getbit(String, long, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Returns the bit value at offset in the string value stored at key
- getBody() - Method in class io.vertx.reactivex.ext.web.RoutingContext
-
- getBodyAsJson() - Method in class io.vertx.reactivex.ext.web.RoutingContext
-
- getBodyAsJsonArray() - Method in class io.vertx.reactivex.ext.web.RoutingContext
-
- getBodyAsString() - Method in class io.vertx.reactivex.ext.web.RoutingContext
-
- getBodyAsString(String) - Method in class io.vertx.reactivex.ext.web.RoutingContext
-
Get the entire HTTP request body as a string, assuming the specified encoding.
- getBoolean() - Method in class io.vertx.reactivex.ext.web.api.RequestParameter
-
Returns null if value is not a Boolean, otherwise it returns value
- getBoolean(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Get a boolean value for the given column
.
- getBoolean(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Get a boolean value at pos
.
- getBooleanArray(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Deprecated.
- getBooleanArray(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Deprecated.
- getBuffer(int, int) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Returns a copy of a sub-sequence the Buffer as a
Buffer
starting at position
start
and ending at position
end - 1
- getBuffer(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Get a buffer value for the given column
.
- getBuffer(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Get a buffer value at pos
.
- getByte(int) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Returns the byte
at position pos
in the Buffer.
- getByteBuf() - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Returns the Buffer as a Netty ByteBuf
.
- getBytes() - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Returns a copy of the entire Buffer as a byte[]
- getBytes(int, int) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Returns a copy of a sub-sequence the Buffer as a byte[]
starting at position start
and ending at position end - 1
- getBytes(byte[]) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Transfers the content of the Buffer into a byte[]
.
- getBytes(byte[], int) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Transfers the content of the Buffer into a byte[]
at the specific destination.
- getBytes(int, int, byte[]) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Transfers the content of the Buffer starting at position start
and ending at position end - 1
into a byte[]
.
- getBytes(int, int, byte[], int) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Transfers the content of the Buffer starting at position start
and ending at position end - 1
into a byte[]
at the specific destination.
- getBytes() - Method in class io.vertx.reactivex.redis.client.Command
-
- getCachedConfig() - Method in class io.vertx.reactivex.config.ConfigRetriever
-
Gets the last computed configuration.
- getClient(ServiceDiscovery, JsonObject, Handler<AsyncResult<HttpClient>>) - 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, Handler<AsyncResult<HttpClient>>) - 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>, Handler<AsyncResult<HttpClient>>) - 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, Handler<AsyncResult<HttpClient>>) - Static method in class io.vertx.reactivex.servicediscovery.types.HttpEndpoint
-
Convenient method that looks for a HTTP endpoint and provides the configured .
- getClusterWideMap(String, Handler<AsyncResult<AsyncMap<K, V>>>) - Method in class io.vertx.reactivex.core.shareddata.SharedData
-
Get the cluster wide map with the specified name.
- getCollectionName() - Method in class io.vertx.reactivex.ext.auth.mongo.MongoAuth
-
The name of the collection used to store User objects inside.
- getCollections(Handler<AsyncResult<List<String>>>) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Get a list of all collections in the database.
- getCollections(Handler<AsyncResult<List<String>>>) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- 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 column name
.
- getColumnName(int) - Method in class io.vertx.reactivex.sqlclient.Row
-
Get a column name for the given column
.
- getCommand(String) - Method in class io.vertx.reactivex.ext.shell.command.CommandResolver
-
Returns a single command by its name.
- getConfig(Handler<AsyncResult<JsonObject>>) - Method in class io.vertx.reactivex.config.ConfigRetriever
-
Reads the configuration from the different
and computes the final configuration.
- getConfigAsFuture(ConfigRetriever) - Static method in class io.vertx.reactivex.config.ConfigRetriever
-
Deprecated.
- getConnection(Handler<AsyncResult<SQLConnection>>) - Method in class io.vertx.reactivex.ext.sql.SQLClient
-
Returns a connection that can be used to perform SQL operations on.
- getConnection(Handler<AsyncResult<SqlConnection>>) - Method in class io.vertx.reactivex.sqlclient.Pool
-
Get a connection from the pool.
- getConsumer(ServiceDiscovery, JsonObject, Handler<AsyncResult<MessageConsumer<T>>>) - 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>, Handler<AsyncResult<MessageConsumer<T>>>) - Static method in class io.vertx.reactivex.servicediscovery.types.MessageSource
-
Convenient method that looks for a message source and provides the configured .
- getCookie(String) - Method in class io.vertx.reactivex.core.http.HttpServerRequest
-
Get the cookie with the specified name.
- getCookie(String) - Method in class io.vertx.reactivex.ext.web.RoutingContext
-
Get the cookie with the specified name.
- getCounter(String, Handler<AsyncResult<Counter>>) - Method in class io.vertx.reactivex.core.shareddata.SharedData
-
Get an asynchronous counter.
- getDefault() - Method in class io.vertx.reactivex.ext.web.api.validation.ParameterTypeValidator
-
Returns default value of parameter
- 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.amqpbridge.AmqpBridge
-
- 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.Mapper
-
- getDelegate() - Method in class io.vertx.reactivex.cassandra.MappingManager
-
- 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.HystrixMetricHandler
-
- getDelegate() - Method in class io.vertx.reactivex.config.ConfigRetriever
-
- getDelegate() - Method in class io.vertx.reactivex.core.buffer.Buffer
-
- getDelegate() - Method in class io.vertx.reactivex.core.cli.CLI
-
- getDelegate() - Method in class io.vertx.reactivex.core.cli.CommandLine
-
- getDelegate() - Method in class io.vertx.reactivex.core.CompositeFuture
-
- getDelegate() - Method in class io.vertx.reactivex.core.Context
-
- getDelegate() - Method in class io.vertx.reactivex.core.datagram.DatagramPacket
-
- 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.dns.MxRecord
-
- getDelegate() - Method in class io.vertx.reactivex.core.dns.SrvRecord
-
- 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.FileProps
-
- getDelegate() - Method in class io.vertx.reactivex.core.file.FileSystem
-
- getDelegate() - Method in class io.vertx.reactivex.core.file.FileSystemProps
-
- getDelegate() - Method in class io.vertx.reactivex.core.Future
-
- getDelegate() - Method in class io.vertx.reactivex.core.http.Cookie
-
- getDelegate() - Method in class io.vertx.reactivex.core.http.HttpClient
-
- 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.HttpFrame
-
- 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.WebSocket
-
- getDelegate() - Method in interface io.vertx.reactivex.core.http.WebSocketBase
-
- getDelegate() - Method in class io.vertx.reactivex.core.http.WebSocketFrame
-
- 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.MultiMap
-
- 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.net.SelfSignedCertificate
-
- getDelegate() - Method in class io.vertx.reactivex.core.net.SocketAddress
-
- getDelegate() - Method in class io.vertx.reactivex.core.parsetools.JsonEvent
-
- 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.Promise
-
- 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 class io.vertx.reactivex.core.streams.Pump
-
- 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.core.TimeoutStream
-
- getDelegate() - Method in class io.vertx.reactivex.core.Vertx
-
- getDelegate() - Method in class io.vertx.reactivex.core.WorkerExecutor
-
- getDelegate() - Method in class io.vertx.reactivex.db2client.DB2Connection
-
- getDelegate() - Method in class io.vertx.reactivex.db2client.DB2Pool
-
- getDelegate() - Method in class io.vertx.reactivex.ext.asyncsql.AsyncSQLClient
-
- getDelegate() - Method in class io.vertx.reactivex.ext.asyncsql.MySQLClient
-
- getDelegate() - Method in class io.vertx.reactivex.ext.asyncsql.PostgreSQLClient
-
- getDelegate() - Method in class io.vertx.reactivex.ext.auth.AuthProvider
-
- getDelegate() - Method in class io.vertx.reactivex.ext.auth.ChainAuth
-
- getDelegate() - Method in class io.vertx.reactivex.ext.auth.HashingAlgorithm
-
- getDelegate() - Method in class io.vertx.reactivex.ext.auth.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.jdbc.JDBCAuth
-
- getDelegate() - Method in class io.vertx.reactivex.ext.auth.jdbc.JDBCHashStrategy
-
- getDelegate() - Method in class io.vertx.reactivex.ext.auth.jwt.JWTAuth
-
- getDelegate() - Method in class io.vertx.reactivex.ext.auth.mongo.HashStrategy
-
- getDelegate() - Method in class io.vertx.reactivex.ext.auth.mongo.MongoAuth
-
- getDelegate() - Method in class io.vertx.reactivex.ext.auth.oauth2.AccessToken
-
- getDelegate() - Method in class io.vertx.reactivex.ext.auth.oauth2.KeycloakHelper
-
- getDelegate() - Method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
-
- getDelegate() - Method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2RBAC
-
- getDelegate() - Method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Response
-
- 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.GithubAuth
-
- 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.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.oauth2.rbac.KeycloakRBAC
-
- getDelegate() - Method in class io.vertx.reactivex.ext.auth.oauth2.rbac.MicroProfileRBAC
-
- getDelegate() - Method in class io.vertx.reactivex.ext.auth.shiro.ShiroAuth
-
- getDelegate() - Method in class io.vertx.reactivex.ext.auth.User
-
- getDelegate() - Method in class io.vertx.reactivex.ext.auth.VertxContextPRNG
-
- 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.ConsulService
-
- 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.HealthCheckHandler
-
- getDelegate() - Method in class io.vertx.reactivex.ext.healthchecks.HealthChecks
-
- getDelegate() - Method in class io.vertx.reactivex.ext.jdbc.JDBCClient
-
- getDelegate() - Method in class io.vertx.reactivex.ext.mail.MailClient
-
- getDelegate() - Method in class io.vertx.reactivex.ext.mail.MailService
-
- getDelegate() - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
- getDelegate() - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- getDelegate() - Method in class io.vertx.reactivex.ext.shell.cli.CliToken
-
- getDelegate() - Method in class io.vertx.reactivex.ext.shell.cli.Completion
-
- getDelegate() - Method in class io.vertx.reactivex.ext.shell.command.Command
-
- getDelegate() - Method in class io.vertx.reactivex.ext.shell.command.CommandBuilder
-
- getDelegate() - Method in class io.vertx.reactivex.ext.shell.command.CommandProcess
-
- getDelegate() - Method in class io.vertx.reactivex.ext.shell.command.CommandRegistry
-
- getDelegate() - Method in class io.vertx.reactivex.ext.shell.command.CommandResolver
-
- getDelegate() - Method in class io.vertx.reactivex.ext.shell.session.Session
-
- getDelegate() - Method in class io.vertx.reactivex.ext.shell.Shell
-
- getDelegate() - Method in class io.vertx.reactivex.ext.shell.ShellServer
-
- getDelegate() - Method in class io.vertx.reactivex.ext.shell.ShellService
-
- getDelegate() - Method in class io.vertx.reactivex.ext.shell.system.Job
-
- getDelegate() - Method in class io.vertx.reactivex.ext.shell.system.JobController
-
- getDelegate() - Method in class io.vertx.reactivex.ext.shell.system.Process
-
- getDelegate() - Method in class io.vertx.reactivex.ext.shell.term.Pty
-
- getDelegate() - Method in class io.vertx.reactivex.ext.shell.term.SignalHandler
-
- getDelegate() - Method in class io.vertx.reactivex.ext.shell.term.SockJSTermHandler
-
- getDelegate() - Method in class io.vertx.reactivex.ext.shell.term.Term
-
- getDelegate() - Method in class io.vertx.reactivex.ext.shell.term.TermServer
-
- getDelegate() - Method in class io.vertx.reactivex.ext.shell.term.Tty
-
- getDelegate() - Method in class io.vertx.reactivex.ext.sql.SQLClient
-
- getDelegate() - Method in class io.vertx.reactivex.ext.sql.SQLConnection
-
- getDelegate() - Method in interface io.vertx.reactivex.ext.sql.SQLOperations
-
- getDelegate() - Method in class io.vertx.reactivex.ext.sql.SQLRowStream
-
- 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 interface io.vertx.reactivex.ext.web.api.contract.HTTPOperationRequestValidationHandler
-
- getDelegate() - Method in class io.vertx.reactivex.ext.web.api.contract.openapi3.OpenAPI3RequestValidationHandler
-
- getDelegate() - Method in class io.vertx.reactivex.ext.web.api.contract.openapi3.OpenAPI3RouterFactory
-
- getDelegate() - Method in interface io.vertx.reactivex.ext.web.api.contract.RouterFactory
-
- getDelegate() - Method in class io.vertx.reactivex.ext.web.api.RequestParameter
-
- getDelegate() - Method in class io.vertx.reactivex.ext.web.api.RequestParameters
-
- getDelegate() - Method in class io.vertx.reactivex.ext.web.api.validation.ContainerDeserializer
-
- getDelegate() - Method in class io.vertx.reactivex.ext.web.api.validation.CustomValidator
-
- getDelegate() - Method in class io.vertx.reactivex.ext.web.api.validation.HTTPRequestValidationHandler
-
- getDelegate() - Method in class io.vertx.reactivex.ext.web.api.validation.ParameterTypeValidator
-
- getDelegate() - Method in class io.vertx.reactivex.ext.web.api.validation.ParameterValidationRule
-
- getDelegate() - Method in interface io.vertx.reactivex.ext.web.api.validation.ValidationHandler
-
- 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.predicate.ErrorConverter
-
- getDelegate() - Method in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
- getDelegate() - Method in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicateResult
-
- 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.Cookie
-
- getDelegate() - Method in class io.vertx.reactivex.ext.web.FileUpload
-
- getDelegate() - Method in interface io.vertx.reactivex.ext.web.handler.AuthHandler
-
- 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.CookieHandler
-
- getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.CorsHandler
-
- 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.ApolloWSHandler
-
- getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.graphql.ApolloWSMessage
-
- getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.graphql.GraphiQLHandler
-
- getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.graphql.GraphQLHandler
-
- getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.JWTAuthHandler
-
- getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.LoggerHandler
-
- 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.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.SessionHandler
-
- 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.UserSessionHandler
-
- getDelegate() - Method in class io.vertx.reactivex.ext.web.handler.VirtualHostHandler
-
- getDelegate() - Method in class io.vertx.reactivex.ext.web.LanguageHeader
-
- getDelegate() - Method in class io.vertx.reactivex.ext.web.Locale
-
- 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 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.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.LocalSessionStore
-
- 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.jade.JadeTemplateEngine
-
- 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.rocker.RockerTemplateEngine
-
- getDelegate() - Method in class io.vertx.reactivex.ext.web.templ.TemplateEngine
-
- getDelegate() - Method in class io.vertx.reactivex.ext.web.templ.thymeleaf.ThymeleafTemplateEngine
-
- 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.PrometheusScrapingHandler
-
- getDelegate() - Method in class io.vertx.reactivex.mqtt.messages.MqttConnAckMessage
-
- getDelegate() - Method in interface io.vertx.reactivex.mqtt.messages.MqttMessage
-
- getDelegate() - Method in class io.vertx.reactivex.mqtt.messages.MqttPublishMessage
-
- 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.mysqlclient.MySQLClient
-
- getDelegate() - Method in class io.vertx.reactivex.mysqlclient.MySQLConnection
-
- getDelegate() - Method in class io.vertx.reactivex.mysqlclient.MySQLPool
-
- getDelegate() - Method in class io.vertx.reactivex.pgclient.PgConnection
-
- getDelegate() - Method in class io.vertx.reactivex.pgclient.PgPool
-
- 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.BasicProperties
-
- getDelegate() - Method in class io.vertx.reactivex.rabbitmq.Envelope
-
- 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.redis.client.Command
-
- 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.RedisConnection
-
- getDelegate() - Method in class io.vertx.reactivex.redis.client.Request
-
- getDelegate() - Method in class io.vertx.reactivex.redis.client.Response
-
- getDelegate() - Method in class io.vertx.reactivex.redis.RedisClient
-
- getDelegate() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
- getDelegate() - Method in class io.vertx.reactivex.redis.Script
-
- getDelegate() - Method in class io.vertx.reactivex.redis.sentinel.RedisSentinel
-
- 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.JDBCDataSource
-
- 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.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.Transaction
-
- getDelegate() - Method in class io.vertx.reactivex.sqlclient.Tuple
-
- getDescription() - Method in class io.vertx.reactivex.core.cli.CLI
-
- 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
-
- getDomain() - Method in class io.vertx.reactivex.core.http.Cookie
-
- getDouble(int) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Returns the double
at position pos
in the Buffer.
- getDouble() - Method in class io.vertx.reactivex.ext.web.api.RequestParameter
-
Returns null if value is not a Double, otherwise it returns value
- getDouble(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Get a double value for the given column
.
- getDouble(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Get a double value at pos
.
- getDoubleArray(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Deprecated.
- getDoubleArray(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Deprecated.
- getExecutionInfo() - Method in class io.vertx.reactivex.cassandra.ResultSet
-
- getFirstKey() - Method in class io.vertx.reactivex.redis.client.Command
-
- getFloat(int) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Returns the float
at position pos
in the Buffer.
- getFloat() - Method in class io.vertx.reactivex.ext.web.api.RequestParameter
-
Returns null if value is not a Float, otherwise it returns value
- getFloat(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Get a float value for the given column
.
- getFloat(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Get a float value at pos
.
- getFloatArray(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Deprecated.
- getFloatArray(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Deprecated.
- getFlowType() - Method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
-
Deprecated.
- getFormAttribute(String) - Method in class io.vertx.reactivex.core.http.HttpServerRequest
-
Return the first form attribute value with the specified name
- getHashedStoredPwd(JsonArray) - Method in class io.vertx.reactivex.ext.auth.jdbc.JDBCHashStrategy
-
Retrieve the hashed password from the result of the authentication query
- getHashStrategy() - Method in class io.vertx.reactivex.ext.auth.mongo.MongoAuth
-
The HashStrategy which is used by the current instance
- getHeader(String) - 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.HttpClientResponse
-
Return the first header value with the specified name
- getHeader(String) - Method in class io.vertx.reactivex.core.http.HttpServerRequest
-
Return the first header value with the specified name
- getHeader(CharSequence) - Method in class io.vertx.reactivex.core.http.HttpServerRequest
-
Return the first header value with the specified name
- getHeader(String) - Method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Response
-
Looks up a HTTP response header by name, in case where the response is a list of headers,
the first one is returned.
- getHeader(String) - Method in class io.vertx.reactivex.ext.web.client.HttpResponse
-
Return the first header value with the specified name
- getHost() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
-
- getInstanceCount() - Method in class io.vertx.reactivex.core.Context
-
- getInt(int) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Returns the int
at position pos
in the Buffer.
- getInteger() - Method in class io.vertx.reactivex.ext.web.api.RequestParameter
-
Returns null if value is not an Integer, otherwise it returns value
- getInteger(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Get an integer value for the given column
.
- getInteger(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Get an integer value at pos
.
- getIntegerArray(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Deprecated.
- getIntegerArray(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Deprecated.
- getInternalStatistics(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.mysqlclient.MySQLConnection
-
Send a STATISTICS command to get a human readable string of the server internal status.
- getInterval() - Method in class io.vertx.reactivex.redis.client.Command
-
- getIntLE(int) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Gets a 32-bit integer at the specified absolute index
in this buffer with Little Endian Byte Order.
- getJDBCClient(ServiceDiscovery, JsonObject, Handler<AsyncResult<JDBCClient>>) - Static method in class io.vertx.reactivex.servicediscovery.types.JDBCDataSource
-
Convenient method that looks for a JDBC datasource source and provides the configured
JDBCClient
.
- getJDBCClient(ServiceDiscovery, Function<Record, Boolean>, Handler<AsyncResult<JDBCClient>>) - Static method in class io.vertx.reactivex.servicediscovery.types.JDBCDataSource
-
Convenient method that looks for a JDBC datasource source and provides the configured
JDBCClient
.
- getJDBCClient(ServiceDiscovery, JsonObject, JsonObject, Handler<AsyncResult<JDBCClient>>) - Static method in class io.vertx.reactivex.servicediscovery.types.JDBCDataSource
-
Convenient method that looks for a JDBC datasource source and provides the configured
JDBCClient
.
- getJDBCClient(ServiceDiscovery, Function<Record, Boolean>, JsonObject, Handler<AsyncResult<JDBCClient>>) - Static method in class io.vertx.reactivex.servicediscovery.types.JDBCDataSource
-
Convenient method that looks for a JDBC datasource source and provides the configured
JDBCClient
.
- getJob(int) - Method in class io.vertx.reactivex.ext.shell.system.JobController
-
Returns an active job in this session by its .
- 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
- 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
- getJsonArray() - Method in class io.vertx.reactivex.ext.web.api.RequestParameter
-
Returns null if value is not a JsonArray, otherwise it returns value
- getJsonObject() - Method in class io.vertx.reactivex.ext.web.api.RequestParameter
-
Returns null if value is not a JsonObject, otherwise it returns value
- getKeys(String, Handler<AsyncResult<List<String>>>) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Returns the list of keys that corresponding to the specified key prefix.
- getKeys(String, Handler<AsyncResult<List<String>>>) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- getKeys() - Method in class io.vertx.reactivex.redis.client.Response
-
Get this multi response keys from a hash.
- getKeysWithOptions(String, BlockingQueryOptions, Handler<AsyncResult<List<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, Handler<AsyncResult<List<String>>>) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- getLastKey() - Method in class io.vertx.reactivex.redis.client.Command
-
- getLocalAsyncMap(String, Handler<AsyncResult<AsyncMap<K, V>>>) - Method in class io.vertx.reactivex.core.shareddata.SharedData
-
Get the
AsyncMap
with the specified name.
- getLocalCounter(String, Handler<AsyncResult<Counter>>) - Method in class io.vertx.reactivex.core.shareddata.SharedData
-
Get an asynchronous local counter.
- getLocalDate(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
- getLocalDate(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
- getLocalDateArray(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Deprecated.
- getLocalDateArray(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Deprecated.
- getLocalDateTime(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
- getLocalDateTime(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
- getLocalDateTimeArray(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Deprecated.
- getLocalDateTimeArray(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Deprecated.
- getLocalLock(String, Handler<AsyncResult<Lock>>) - Method in class io.vertx.reactivex.core.shareddata.SharedData
-
Get an asynchronous local lock with the specified name.
- getLocalLockWithTimeout(String, long, Handler<AsyncResult<Lock>>) - Method in class io.vertx.reactivex.core.shareddata.SharedData
-
- getLocalMap(String) - Method in class io.vertx.reactivex.core.shareddata.SharedData
-
Return a LocalMap
with the specific name
.
- getLocalTime(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
- getLocalTime(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
- getLocalTimeArray(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Deprecated.
- getLocalTimeArray(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Deprecated.
- getLock(String, Handler<AsyncResult<Lock>>) - Method in class io.vertx.reactivex.core.shareddata.SharedData
-
Get an asynchronous lock with the specified name.
- getLockWithTimeout(String, long, Handler<AsyncResult<Lock>>) - Method in class io.vertx.reactivex.core.shareddata.SharedData
-
- getLong(int) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Returns the long
at position pos
in the Buffer.
- getLong() - Method in class io.vertx.reactivex.ext.web.api.RequestParameter
-
Returns null if value is not a Long, otherwise it returns value
- getLong(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Get a long value for the given column
.
- getLong(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Get a long value at pos
.
- getLongArray(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Deprecated.
- getLongArray(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Deprecated.
- getLongLE(int) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Gets a 64-bit long integer at the specified absolute index
in this buffer in Little Endian Byte Order.
- getMasterAddrByName(String, Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.sentinel.RedisSentinel
-
Return the ip and port number of the master with that name.
- getMaxBufferedMessages() - Method in class io.vertx.reactivex.core.eventbus.MessageConsumer
-
- getMedium(int) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Gets a 24-bit medium integer at the specified absolute index
in this buffer.
- getMediumLE(int) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Gets a 24-bit medium integer at the specified absolute index
in this buffer in the Little Endian Byte Order.
- 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.
Note: in the case of scaled servers, the JsonObject returns an aggregation of the metrics as the
dropwizard backend reports to a single server.
- 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.
Note: in the case of scaled servers, the JsonObject returns an aggregation of the metrics as the
dropwizard backend reports to a single server.
- 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(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, Handler<AsyncResult<MongoClient>>) - 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>, Handler<AsyncResult<MongoClient>>) - 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, Handler<AsyncResult<MongoClient>>) - 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.core.cli.CLI
-
- getName() - Method in class io.vertx.reactivex.core.http.Cookie
-
- getName() - Method in class io.vertx.reactivex.ext.web.api.RequestParameter
-
Get parameter name
- getName() - Method in class io.vertx.reactivex.ext.web.api.validation.ParameterValidationRule
-
This function return the name of the parameter expected into parameter lists
- getNow(RequestOptions, Handler<HttpClientResponse>) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Deprecated.
- getNow(int, String, String, Handler<HttpClientResponse>) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Deprecated.
- getNow(String, String, Handler<HttpClientResponse>) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Deprecated.
- getNow(String, Handler<HttpClientResponse>) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Deprecated.
- getNumeric(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Get a numeric value for the given column
.
- getNumeric(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Get value at pos
.
- getNumericArray(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Deprecated.
- getNumericArray(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Deprecated.
- getObjectKeys() - Method in class io.vertx.reactivex.ext.web.api.RequestParameter
-
If value is a map of fields, it returns keys of map, otherwise it returns null
- getObjectParameter(Object, String, boolean) - Method in class io.vertx.reactivex.core.json.pointer.JsonPointerIterator
-
Returns the object parameter with specified key.
- getObjectValue(String) - Method in class io.vertx.reactivex.ext.web.api.RequestParameter
-
If value is a map of fields, it returns value of field with key provided, otherwise it returns null
- getOffsetDateTime(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
- getOffsetDateTime(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
- getOffsetDateTimeArray(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Deprecated.
- getOffsetDateTimeArray(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Deprecated.
- getOffsetTime(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
- getOffsetTime(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
- getOffsetTimeArray(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Deprecated.
- getOffsetTimeArray(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Deprecated.
- getOption(String) - Method in class io.vertx.reactivex.core.cli.CLI
-
Gets an Option
based on its name (short name, long name or argument name).
- getOptions() - Method in class io.vertx.reactivex.core.cli.CLI
-
Gets the list of options.
- getOptions() - Method in class io.vertx.reactivex.ext.web.api.contract.openapi3.OpenAPI3RouterFactory
-
Get options of router factory.
- getOptions() - Method in interface io.vertx.reactivex.ext.web.api.contract.RouterFactory
-
Get options of router factory.
- getOptionValue(String) - Method in class io.vertx.reactivex.core.cli.CommandLine
-
Gets the value of an option with the matching name (can be the long name, short name or arg name).
- getOrCreateContext() - Method in class io.vertx.reactivex.core.Vertx
-
Gets the current context, or creates one if there isn't one
- 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.
- getParam(String) - Method in class io.vertx.reactivex.core.http.HttpServerRequest
-
Return the first param value with the specified name
- getPasswordCredentialField() - Method in class io.vertx.reactivex.ext.auth.mongo.MongoAuth
-
- getPasswordField() - Method in class io.vertx.reactivex.ext.auth.mongo.MongoAuth
-
Get the name of the field to be used for the password Defaults to
MongoAuth
- getPath() - Method in class io.vertx.reactivex.core.http.Cookie
-
- getPath() - Method in class io.vertx.reactivex.ext.web.Route
-
- getPermissionField() - Method in class io.vertx.reactivex.ext.auth.mongo.MongoAuth
-
Get the name of the field to be used for the permissions.
- getPreparedQuery(String, Handler<AsyncResult<PreparedQueryDefinition>>) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Returns an existing prepared query
- getPreparedQuery(String, Handler<AsyncResult<PreparedQueryDefinition>>) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- getPriority() - Method in class io.vertx.reactivex.core.cli.CLI
-
- GETRANGE - Static variable in class io.vertx.reactivex.redis.client.Command
-
- getrange(String, String, String, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- getrange(String, long, long, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get a substring of the string stored at a key
- getrange(String, long, long, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get a substring of the string stored at a key
- getRawMessage() - Method in class io.vertx.reactivex.ext.bridge.BaseBridgeEvent
-
Get the raw JSON message for the event.
- getRawMethod() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
-
- getRawValueForArgument(Argument) - Method in class io.vertx.reactivex.core.cli.CommandLine
-
Gets the raw value of the given argument.
- getRawValueForOption(Option) - Method in class io.vertx.reactivex.core.cli.CommandLine
-
Gets the raw value of the given option.
- getRawValues(Option) - Method in class io.vertx.reactivex.core.cli.CommandLine
-
Deprecated.
- getRawValuesForArgument(Argument) - Method in class io.vertx.reactivex.core.cli.CommandLine
-
Gets the raw values of the given argument.
- getRawValuesForOption(Option) - Method in class io.vertx.reactivex.core.cli.CommandLine
-
Gets the raw values of the given option.
- getRecord(JsonObject, Handler<AsyncResult<Record>>) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
-
Lookups for a single record.
- getRecord(Function<Record, Boolean>, Handler<AsyncResult<Record>>) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
-
Lookups for a single record.
- getRecord(Function<Record, Boolean>, boolean, Handler<AsyncResult<Record>>) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
-
Lookups for a single record.
- getRecords(JsonObject, Handler<AsyncResult<List<Record>>>) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
-
Lookups for a set of records.
- getRecords(Function<Record, Boolean>, Handler<AsyncResult<List<Record>>>) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
-
Lookups for a set of records.
- getRecords(Function<Record, Boolean>, boolean, Handler<AsyncResult<List<Record>>>) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
-
Lookups for a set of records.
- getRedisClient(ServiceDiscovery, JsonObject, Handler<AsyncResult<RedisClient>>) - Static method in class io.vertx.reactivex.servicediscovery.types.RedisDataSource
-
Convenient method that looks for a Redis data source and provides the configured
RedisClient
.
- getRedisClient(ServiceDiscovery, Function<Record, Boolean>, Handler<AsyncResult<RedisClient>>) - Static method in class io.vertx.reactivex.servicediscovery.types.RedisDataSource
-
Convenient method that looks for a Redis data source and provides the configured
RedisClient
.
- getRedisClient(ServiceDiscovery, JsonObject, JsonObject, Handler<AsyncResult<RedisClient>>) - Static method in class io.vertx.reactivex.servicediscovery.types.RedisDataSource
-
Convenient method that looks for a Redis data source and provides the configured
RedisClient
.
- getRedisClient(ServiceDiscovery, Function<Record, Boolean>, JsonObject, Handler<AsyncResult<RedisClient>>) - Static method in class io.vertx.reactivex.servicediscovery.types.RedisDataSource
-
Convenient method that looks for a Redis data source and provides the configured
RedisClient
.
- 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.
- getRoleField() - Method in class io.vertx.reactivex.ext.auth.mongo.MongoAuth
-
Get the name of the field to be used for the roles.
- getRouter() - Method in class io.vertx.reactivex.ext.web.api.contract.openapi3.OpenAPI3RouterFactory
-
Construct a new router based on spec.
- getRouter() - Method in interface io.vertx.reactivex.ext.web.api.contract.RouterFactory
-
Construct a new router based on spec.
- getRoutes() - Method in class io.vertx.reactivex.ext.web.Router
-
- getSalt(JsonArray) - Method in class io.vertx.reactivex.ext.auth.jdbc.JDBCHashStrategy
-
Retrieve the salt from the result of the authentication query
- getSalt(User) - Method in class io.vertx.reactivex.ext.auth.mongo.HashStrategy
-
Retrieve the salt.
- getSaltField() - Method in class io.vertx.reactivex.ext.auth.mongo.MongoAuth
-
Get the name of the field to be used for the salt.
- getSaltStyle() - Method in class io.vertx.reactivex.ext.auth.mongo.HashStrategy
-
Get the defined HashSaltStyle
of the current instance
- getSameSite() - Method in class io.vertx.reactivex.core.http.Cookie
-
- getScopeSeparator() - Method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
-
Deprecated.
- getScript() - Method in class io.vertx.reactivex.redis.Script
-
- getServiceProxy(ServiceDiscovery, Function<Record, Boolean>, Class<T>, Handler<AsyncResult<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, Handler<AsyncResult<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>, Handler<AsyncResult<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, Handler<AsyncResult<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).
- getSession() - Method in class io.vertx.reactivex.ext.shell.system.Process
-
- GETSET - Static variable in class io.vertx.reactivex.redis.client.Command
-
- getset(String, String, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- getset(String, String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set the string value of a key and return its old value
- getset(String, String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Set the string value of a key and return its old value
- getSha1() - Method in class io.vertx.reactivex.redis.Script
-
- getShared(Vertx) - Static method in class io.vertx.reactivex.ext.shell.command.CommandRegistry
-
Get the shared registry for the Vert.x instance.
- getShort(int) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Returns the short
at position pos
in the Buffer.
- getShort(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Get a short value for the given column
.
- getShort(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Get a short value at pos
.
- getShortArray(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Deprecated.
- getShortArray(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Deprecated.
- getShortLE(int) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Gets a 16-bit short integer at the specified absolute index
in this buffer in Little Endian Byte Order.
- getStatusCode() - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
- getStatusMessage() - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
- getStoredPwd(User) - Method in class io.vertx.reactivex.ext.auth.mongo.HashStrategy
-
Retrieve the password from the user, or as clear text or as hashed version, depending on the definition
- getStreamPriority() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
-
- getString(int, int, String) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Returns a copy of a sub-sequence the Buffer as a String
starting at position start
and ending at position end - 1
interpreted as a String in the specified encoding
- getString(int, int) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Returns a copy of a sub-sequence the Buffer as a String
starting at position start
and ending at position end - 1
interpreted as a String in UTF-8 encoding
- getString() - Method in class io.vertx.reactivex.ext.web.api.RequestParameter
-
Returns null if value is not a String, otherwise it returns value
- getString(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Get a string value for the given column
.
- getString(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Get a string value at pos
.
- getStringArray(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Deprecated.
- getStringArray(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Deprecated.
- getSubscriptions(StompServerConnection) - Method in class io.vertx.reactivex.ext.stomp.Destination
-
Gets all subscription ids for the given destination hold by the given client
- getSummary() - Method in class io.vertx.reactivex.core.cli.CLI
-
- getTemporal(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Get a temporal value for the given column
.
- getTemporal(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
- getTemporalArray(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Deprecated.
- getTemporalArray(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Deprecated.
- getToken(JsonObject, Handler<AsyncResult<AccessToken>>) - Method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
-
Deprecated.
- 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(Handler<AsyncResult<TransactionIsolation>>) - Method in class io.vertx.reactivex.ext.sql.SQLConnection
-
Attempts to return the transaction isolation level for this Connection object to the one given.
- getTty() - Method in class io.vertx.reactivex.ext.shell.system.Process
-
- getUnsignedByte(int) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Returns the unsigned byte
at position pos
in the Buffer, as a short
.
- getUnsignedInt(int) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Returns the unsigned int
at position pos
in the Buffer, as a long
.
- getUnsignedIntLE(int) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Returns the unsigned int
at position pos
in the Buffer, as a long
in Little Endian Byte Order.
- getUnsignedMedium(int) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Gets an unsigned 24-bit medium integer at the specified absolute index
in this buffer.
- getUnsignedMediumLE(int) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Gets an unsigned 24-bit medium integer at the specified absolute index
in this buffer in Little Endian Byte Order.
- getUnsignedShort(int) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Returns the unsigned short
at position pos
in the Buffer, as an int
.
- getUnsignedShortLE(int) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Gets an unsigned 16-bit short integer at the specified absolute index
in this buffer in Little Endian Byte Order.
- getURIWithoutFragment() - Method in class io.vertx.reactivex.core.json.pointer.JsonPointer
-
Return the underlying URI without the fragment
- 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 .
- getUsernameCredentialField() - Method in class io.vertx.reactivex.ext.auth.mongo.MongoAuth
-
- getUsernameField() - Method in class io.vertx.reactivex.ext.auth.mongo.MongoAuth
-
Get the name of the field to be used for the username.
- getUUID(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Get
UUID
value for the given
column
.
- getUUID(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
- getUUIDArray(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Deprecated.
- getUUIDArray(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Deprecated.
- getValidationFailureHandler() - Method in class io.vertx.reactivex.ext.web.api.contract.openapi3.OpenAPI3RouterFactory
-
Deprecated.
- getValidationFailureHandler() - Method in interface io.vertx.reactivex.ext.web.api.contract.RouterFactory
-
Deprecated.
- getValue() - Method in class io.vertx.reactivex.core.http.Cookie
-
- getValue(String, Handler<AsyncResult<KeyValue>>) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Returns key/value pair that corresponding to the specified key.
- getValue(String, Handler<AsyncResult<KeyValue>>) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- getValue(String) - Method in class io.vertx.reactivex.sqlclient.Row
-
Get an object value for the given column
.
- getValue(int) - Method in class io.vertx.reactivex.sqlclient.Tuple
-
Get an object value at pos
.
- getValues(String, Handler<AsyncResult<KeyValueList>>) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Returns the list of key/value pairs that corresponding to the specified key prefix.
- getValues(String, Handler<AsyncResult<KeyValueList>>) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- getValuesWithOptions(String, BlockingQueryOptions, Handler<AsyncResult<KeyValueList>>) - 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, Handler<AsyncResult<KeyValueList>>) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- getValueWithOptions(String, BlockingQueryOptions, Handler<AsyncResult<KeyValue>>) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Returns key/value pair that corresponding to the specified key.
- getValueWithOptions(String, BlockingQueryOptions, Handler<AsyncResult<KeyValue>>) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- getWebClient(ServiceDiscovery, JsonObject, Handler<AsyncResult<WebClient>>) - 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, Handler<AsyncResult<WebClient>>) - 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>, Handler<AsyncResult<WebClient>>) - 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, Handler<AsyncResult<WebClient>>) - 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
-
- 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
-
- goAway(long) - Method in class io.vertx.reactivex.core.http.HttpConnection
-
- goAway(long, int) - Method in class io.vertx.reactivex.core.http.HttpConnection
-
- 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
-
- GraphiQLHandler - Class in io.vertx.reactivex.ext.web.handler.graphql
-
A
Route
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
-
- graphiQLRequestHeaders(Function<RoutingContext, MultiMap>) - Method in class io.vertx.reactivex.ext.web.handler.graphql.GraphiQLHandler
-
Customize the HTTP headers to add to GraphQL requests sent by the GraphiQL user interface.
- 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
-
- 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
-
- 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.
- 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.
- ParameterTypeValidator - Class in io.vertx.reactivex.ext.web.api.validation
-
Interface for declaration of method for validate a specific parameter type.
If you want to implement your own type validator, you need only to implement
ParameterTypeValidator.isValid(java.lang.String)
:
If parameter is valid, call to put value (maybe modified) inside
RequestParameters.
- ParameterTypeValidator(ParameterTypeValidator) - Constructor for class io.vertx.reactivex.ext.web.api.validation.ParameterTypeValidator
-
- ParameterTypeValidator(Object) - Constructor for class io.vertx.reactivex.ext.web.api.validation.ParameterTypeValidator
-
- parameterTypeValidator() - Method in class io.vertx.reactivex.ext.web.api.validation.ParameterValidationRule
-
Return ParameterTypeValidator instance used inside this parameter validation rule
- ParameterValidationRule - Class in io.vertx.reactivex.ext.web.api.validation
-
This function is an inner wrapper for ParameterTypeValidator inside ValidationHandler parameter maps.
- ParameterValidationRule(ParameterValidationRule) - Constructor for class io.vertx.reactivex.ext.web.api.validation.ParameterValidationRule
-
- ParameterValidationRule(Object) - Constructor for class io.vertx.reactivex.ext.web.api.validation.ParameterValidationRule
-
- params() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
-
- params() - Method in class io.vertx.reactivex.ext.auth.HashingAlgorithm
-
return the list of param names required for this algorithm.
- parent() - Method in class io.vertx.reactivex.core.json.pointer.JsonPointer
-
Remove last reference token of this pointer
- parse(List<String>) - Method in class io.vertx.reactivex.core.cli.CLI
-
Parses the user command line interface and create a new
CommandLine
containing extracting values.
- parse(List<String>, boolean) - Method in class io.vertx.reactivex.core.cli.CLI
-
Parses the user command line interface and create a new
CommandLine
containing extracting values.
- parseCredentials(RoutingContext, Handler<AsyncResult<JsonObject>>) - Method in interface io.vertx.reactivex.ext.web.handler.AuthHandler
-
Parses the credentials from the request into a JsonObject.
- parseCredentials(RoutingContext, Handler<AsyncResult<JsonObject>>) - Method in class io.vertx.reactivex.ext.web.handler.BasicAuthHandler
-
Parses the credentials from the request into a JsonObject.
- parseCredentials(RoutingContext, Handler<AsyncResult<JsonObject>>) - Method in class io.vertx.reactivex.ext.web.handler.ChainAuthHandler
-
Parses the credentials from the request into a JsonObject.
- parseCredentials(RoutingContext, Handler<AsyncResult<JsonObject>>) - Method in class io.vertx.reactivex.ext.web.handler.DigestAuthHandler
-
Parses the credentials from the request into a JsonObject.
- parseCredentials(RoutingContext, Handler<AsyncResult<JsonObject>>) - Method in class io.vertx.reactivex.ext.web.handler.JWTAuthHandler
-
Parses the credentials from the request into a JsonObject.
- parseCredentials(RoutingContext, Handler<AsyncResult<JsonObject>>) - Method in class io.vertx.reactivex.ext.web.handler.OAuth2AuthHandler
-
Parses the credentials from the request into a JsonObject.
- parseCredentials(RoutingContext, Handler<AsyncResult<JsonObject>>) - Method in class io.vertx.reactivex.ext.web.handler.RedirectAuthHandler
-
Parses the credentials from the request into a JsonObject.
- 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
NOTE: This class has been automatically generated from the
original
non RX-ified interface using Vert.x codegen.
- ParsedHeaderValues(ParsedHeaderValues) - Constructor for class io.vertx.reactivex.ext.web.ParsedHeaderValues
-
- ParsedHeaderValues(Object) - Constructor for class io.vertx.reactivex.ext.web.ParsedHeaderValues
-
- parseOperationSpec() - Method in interface io.vertx.reactivex.ext.web.api.contract.HTTPOperationRequestValidationHandler
-
Function that parse the operation specification and generate validation rules
- parseOperationSpec() - Method in class io.vertx.reactivex.ext.web.api.contract.openapi3.OpenAPI3RequestValidationHandler
-
Function that parse the operation specification and generate validation rules
- parseToken(String) - Static method in class io.vertx.reactivex.ext.auth.oauth2.KeycloakHelper
-
Parse the token string with base64 decoder.
- 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, Handler<AsyncResult<List<PartitionInfo>>>) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
-
Get metadata about the partitions for a given topic.
- partitionsFor(String, Handler<AsyncResult<List<PartitionInfo>>>) - 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, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Set status of the check to "passing".
- passCheck(String, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- passCheckWithNote(String, String, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Set status of the check to "passing".
- passCheckWithNote(String, String, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- 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(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(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.
- patch() - Method in class io.vertx.reactivex.ext.web.Router
-
Add a route that matches any HTTP PATCH request
- patch(String) - Method in class io.vertx.reactivex.ext.web.Router
-
Add a route that matches a HTTP PATCH request and the specified path
- 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.HttpServerRequest
-
- path() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
-
- path() - Method in class io.vertx.reactivex.core.net.SocketAddress
-
- path(String) - Method in class io.vertx.reactivex.ext.web.Route
-
Set the path prefix for this route.
- 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(String) - Method in class io.vertx.reactivex.ext.web.api.RequestParameters
-
Get path parameter by name
- pathParametersNames() - Method in class io.vertx.reactivex.ext.web.api.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.datagram.DatagramSocket
-
- 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.HttpClientRequest
-
Deprecated.
- 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.core.TimeoutStream
-
- pause() - Method in class io.vertx.reactivex.ext.sql.SQLRowStream
-
- 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.kafka.client.consumer.KafkaConsumer
-
- 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.
- pause(TopicPartition, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
-
Suspend fetching from the requested partition.
- pause(Set<TopicPartition>, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
-
Suspend fetching from the requested partitions.
- 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
-
- paused(Handler<AsyncResult<Set<TopicPartition>>>) - 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.core.http.HttpFrame
-
- 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(Handler<AsyncResult<List<String>>>) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Retrieves the Raft peers for the datacenter in which the the agent is running.
- peersStatus(Handler<AsyncResult<List<String>>>) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- pendingQueueFull() - Method in class io.vertx.reactivex.redis.client.RedisConnection
-
Flag to notify if the pending message queue (commands in transit) is full.
- periodicStream(long) - Method in class io.vertx.reactivex.core.Vertx
-
Returns a periodic timer as a read stream.
- PERSIST - Static variable in class io.vertx.reactivex.redis.client.Command
-
- persist(String, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- persist(String, Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Remove the expiration from a key
- persist(String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Remove the expiration from a key
- PEXPIRE - Static variable in class io.vertx.reactivex.redis.client.Command
-
- pexpire(String, String, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- pexpire(String, long, Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set a key's time to live in milliseconds
- pexpire(String, long, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Set a key's time to live in milliseconds
- PEXPIREAT - Static variable in class io.vertx.reactivex.redis.client.Command
-
- pexpireat(String, String, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- pexpireat(String, long, Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set the expiration for a key as a UNIX timestamp specified in milliseconds
- pexpireat(String, long, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Set the expiration for a key as a UNIX timestamp specified in milliseconds
- PFADD - Static variable in class io.vertx.reactivex.redis.client.Command
-
- pfadd(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- pfadd(String, String, Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Adds the specified element to the specified HyperLogLog.
- pfadd(String, String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Adds the specified element to the specified HyperLogLog.
- pfaddMany(String, List<String>, Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Adds the specified elements to the specified HyperLogLog.
- pfaddMany(String, List<String>, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Adds the specified elements to the specified HyperLogLog.
- PFCOUNT - Static variable in class io.vertx.reactivex.redis.client.Command
-
- pfcount(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- pfcount(String, Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Return the approximated cardinality of the set observed by the HyperLogLog at key.
- pfcount(String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return the approximated cardinality of the set observed by the HyperLogLog at key.
- pfcountMany(List<String>, Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Return the approximated cardinality of the set(s) observed by the HyperLogLog at key(s).
- pfcountMany(List<String>, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return the approximated cardinality of the set(s) observed by the HyperLogLog at key(s).
- PFDEBUG - Static variable in class io.vertx.reactivex.redis.client.Command
-
- pfdebug(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- PFMERGE - Static variable in class io.vertx.reactivex.redis.client.Command
-
- pfmerge(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- pfmerge(String, List<String>, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Merge N different HyperLogLogs into a single one.
- pfmerge(String, List<String>, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Merge N different HyperLogLogs into a single one.
- PFSELFTEST - Static variable in class io.vertx.reactivex.redis.client.Command
-
- pfselftest(Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- 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
-
- PgPool - Class in io.vertx.reactivex.pgclient
-
A pool of PostgreSQL connections.
- PgPool(PgPool) - Constructor for class io.vertx.reactivex.pgclient.PgPool
-
- PgPool(Object) - Constructor for class io.vertx.reactivex.pgclient.PgPool
-
- 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(Buffer, Handler<AsyncResult<Buffer>>) - Method in class io.vertx.reactivex.core.http.HttpConnection
-
Send a frame to the remote endpoint.
- ping(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.db2client.DB2Connection
-
Send a PING command to check if the server is alive.
- PING - Static variable in class io.vertx.reactivex.ext.stomp.Frames
-
- 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(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.mysqlclient.MySQLConnection
-
Send a PING command to check if the server is alive.
- PING - Static variable in class io.vertx.reactivex.redis.client.Command
-
- ping(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- ping(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Ping the server
- ping(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Ping the server
- pingFrame(Buffer) - Static method in class io.vertx.reactivex.core.http.WebSocketFrame
-
Create a ping WebSocket frame.
- 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.datagram.DatagramSocket
-
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.HttpClientRequest
-
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<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
-
- 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.core.TimeoutStream
-
Pause this stream and return a to transfer the elements of this stream to a destination .
- pipe() - Method in class io.vertx.reactivex.ext.sql.SQLRowStream
-
Pause this stream and return a to transfer the elements of this stream to a destination .
- 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(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() - 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.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 .
- pipeTo(WriteStream<AmqpMessage>) - Method in class io.vertx.reactivex.amqp.AmqpReceiver
-
- pipeTo(WriteStream<AmqpMessage>, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.amqp.AmqpReceiver
-
Pipe this ReadStream
to the WriteStream
.
- pipeTo(WriteStream<Row>) - Method in class io.vertx.reactivex.cassandra.CassandraRowStream
-
- pipeTo(WriteStream<Row>, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.cassandra.CassandraRowStream
-
Pipe this ReadStream
to the WriteStream
.
- pipeTo(WriteStream<DatagramPacket>) - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
-
- pipeTo(WriteStream<DatagramPacket>, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
-
Pipe this ReadStream
to the WriteStream
.
- pipeTo(WriteStream<Message<T>>) - Method in class io.vertx.reactivex.core.eventbus.MessageConsumer
-
- pipeTo(WriteStream<Message<T>>, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.core.eventbus.MessageConsumer
-
Pipe this ReadStream
to the WriteStream
.
- pipeTo(WriteStream<Buffer>) - Method in class io.vertx.reactivex.core.file.AsyncFile
-
- pipeTo(WriteStream<Buffer>, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.core.file.AsyncFile
-
Pipe this ReadStream
to the WriteStream
.
- pipeTo(WriteStream<HttpClientResponse>) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
-
- pipeTo(WriteStream<HttpClientResponse>, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
-
Pipe this ReadStream
to the WriteStream
.
- pipeTo(WriteStream<Buffer>) - Method in class io.vertx.reactivex.core.http.HttpClientResponse
-
- pipeTo(WriteStream<Buffer>, Handler<AsyncResult<Void>>) - 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
-
- pipeTo(WriteStream<Buffer>, Handler<AsyncResult<Void>>) - 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
-
- pipeTo(WriteStream<Buffer>, Handler<AsyncResult<Void>>) - 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
-
- pipeTo(WriteStream<Buffer>, Handler<AsyncResult<Void>>) - 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
-
- pipeTo(WriteStream<Buffer>, Handler<AsyncResult<Void>>) - 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
-
- pipeTo(WriteStream<Buffer>, Handler<AsyncResult<Void>>) - 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
-
- pipeTo(WriteStream<Buffer>, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.core.net.NetSocket
-
Pipe this ReadStream
to the WriteStream
.
- pipeTo(WriteStream<JsonEvent>) - Method in class io.vertx.reactivex.core.parsetools.JsonParser
-
- pipeTo(WriteStream<JsonEvent>, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.core.parsetools.JsonParser
-
Pipe this ReadStream
to the WriteStream
.
- pipeTo(WriteStream<Buffer>) - Method in class io.vertx.reactivex.core.parsetools.RecordParser
-
- pipeTo(WriteStream<Buffer>, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.core.parsetools.RecordParser
-
Pipe this ReadStream
to the WriteStream
.
- pipeTo(WriteStream<T>) - Method in interface io.vertx.reactivex.core.streams.ReadStream
-
- pipeTo(WriteStream<T>, Handler<AsyncResult<Void>>) - Method in interface io.vertx.reactivex.core.streams.ReadStream
-
Pipe this ReadStream
to the WriteStream
.
- pipeTo(WriteStream<Long>) - Method in class io.vertx.reactivex.core.TimeoutStream
-
- pipeTo(WriteStream<Long>, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.core.TimeoutStream
-
Pipe this ReadStream
to the WriteStream
.
- pipeTo(WriteStream<JsonArray>) - Method in class io.vertx.reactivex.ext.sql.SQLRowStream
-
- pipeTo(WriteStream<JsonArray>, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.sql.SQLRowStream
-
Pipe this ReadStream
to the WriteStream
.
- pipeTo(WriteStream<TestCaseReport>) - Method in class io.vertx.reactivex.ext.unit.report.TestSuiteReport
-
- pipeTo(WriteStream<TestCaseReport>, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.unit.report.TestSuiteReport
-
Pipe this ReadStream
to the WriteStream
.
- pipeTo(WriteStream<Buffer>) - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
-
- pipeTo(WriteStream<Buffer>, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
-
Pipe this ReadStream
to the WriteStream
.
- pipeTo(WriteStream<KafkaConsumerRecord<K, V>>) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
-
- pipeTo(WriteStream<KafkaConsumerRecord<K, V>>, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
-
Pipe this ReadStream
to the WriteStream
.
- pipeTo(WriteStream<String>) - Method in class io.vertx.reactivex.pgclient.pubsub.PgChannel
-
- pipeTo(WriteStream<String>, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.pgclient.pubsub.PgChannel
-
Pipe this ReadStream
to the WriteStream
.
- pipeTo(WriteStream<RabbitMQMessage>) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQConsumer
-
- pipeTo(WriteStream<RabbitMQMessage>, Handler<AsyncResult<Void>>) - 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
-
- pipeTo(WriteStream<Response>, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.redis.client.RedisConnection
-
Pipe this ReadStream
to the WriteStream
.
- pipeTo(WriteStream<T>) - Method in class io.vertx.reactivex.sqlclient.RowStream
-
- pipeTo(WriteStream<T>, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.sqlclient.RowStream
-
Pipe this ReadStream
to the WriteStream
.
- poll(long, Handler<AsyncResult<KafkaConsumerRecords<K, V>>>) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
-
Deprecated.
- poll(Duration, Handler<AsyncResult<KafkaConsumerRecords<K, V>>>) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
-
Executes a poll for getting messages from Kafka.
- pollTimeout(long) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
-
Deprecated.
- 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
- pongFrame(Buffer) - Static method in class io.vertx.reactivex.core.http.WebSocketFrame
-
Create a pong WebSocket frame.
- pongHandler(Handler<Buffer>) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
-
Set a pong frame handler on the connection.
- pongHandler(Handler<Buffer>) - Method in class io.vertx.reactivex.core.http.WebSocket
-
Set a pong frame handler on the connection.
- pongHandler(Handler<Buffer>) - Method in interface io.vertx.reactivex.core.http.WebSocketBase
-
Set a pong frame handler on the connection.
- pool(String) - Static method in class io.vertx.reactivex.db2client.DB2Pool
-
- pool(String, PoolOptions) - Static method in class io.vertx.reactivex.db2client.DB2Pool
-
- pool(Vertx, String) - Static method in class io.vertx.reactivex.db2client.DB2Pool
-
- pool(Vertx, String, PoolOptions) - Static method in class io.vertx.reactivex.db2client.DB2Pool
-
- pool(DB2ConnectOptions, PoolOptions) - Static method in class io.vertx.reactivex.db2client.DB2Pool
-
Create a connection pool to the DB2 server configured with the given
connectOptions
and poolOptions
.
- pool(Vertx, DB2ConnectOptions, PoolOptions) - Static method in class io.vertx.reactivex.db2client.DB2Pool
-
- pool(String) - Static method in class io.vertx.reactivex.mysqlclient.MySQLPool
-
- pool(String, PoolOptions) - Static method in class io.vertx.reactivex.mysqlclient.MySQLPool
-
- pool(Vertx, String) - Static method in class io.vertx.reactivex.mysqlclient.MySQLPool
-
- pool(Vertx, String, PoolOptions) - Static method in class io.vertx.reactivex.mysqlclient.MySQLPool
-
- pool(MySQLConnectOptions, PoolOptions) - Static method in class io.vertx.reactivex.mysqlclient.MySQLPool
-
Create a connection pool to the MySQL server configured with the given connectOptions
and poolOptions
.
- pool(Vertx, MySQLConnectOptions, PoolOptions) - Static method in class io.vertx.reactivex.mysqlclient.MySQLPool
-
- pool() - Static method in class io.vertx.reactivex.pgclient.PgPool
-
- pool(PoolOptions) - Static method in class io.vertx.reactivex.pgclient.PgPool
-
Like
PgPool.pool()
with
connectOptions
build from the environment variables.
- pool(String) - Static method in class io.vertx.reactivex.pgclient.PgPool
-
- pool(String, PoolOptions) - Static method in class io.vertx.reactivex.pgclient.PgPool
-
- pool(Vertx, String) - Static method in class io.vertx.reactivex.pgclient.PgPool
-
- pool(Vertx, PoolOptions) - Static method in class io.vertx.reactivex.pgclient.PgPool
-
Like
PgPool.pool()
with
connectOptions
build from the environment variables.
- pool(Vertx, String, PoolOptions) - Static method in class io.vertx.reactivex.pgclient.PgPool
-
- pool(PgConnectOptions, PoolOptions) - Static method in class io.vertx.reactivex.pgclient.PgPool
-
Create a connection pool to the database configured with the given connectOptions
and poolOptions
.
- pool(Vertx, PgConnectOptions, PoolOptions) - Static method in class io.vertx.reactivex.pgclient.PgPool
-
- Pool - Class in io.vertx.reactivex.sqlclient
-
A pool of SQL connections.
- Pool(Pool) - Constructor for class io.vertx.reactivex.sqlclient.Pool
-
- Pool(Object) - Constructor for class io.vertx.reactivex.sqlclient.Pool
-
- pool(SqlConnectOptions) - Static method in class io.vertx.reactivex.sqlclient.Pool
-
Create a connection pool to the database configured with the given connectOptions
and default PoolOptions
- pool(SqlConnectOptions, PoolOptions) - Static method in class io.vertx.reactivex.sqlclient.Pool
-
Create a connection pool to the database configured with the given connectOptions
and poolOptions
.
- pool(Vertx, SqlConnectOptions, PoolOptions) - Static method in class io.vertx.reactivex.sqlclient.Pool
-
Create a connection pool to the database configured with the given connectOptions
and poolOptions
.
- port() - Method in class io.vertx.reactivex.core.dns.SrvRecord
-
Returns the port the service is running on.
- port() - Method in class io.vertx.reactivex.core.net.SocketAddress
-
- port(int) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
-
Configure the request to use a new port value
.
- position(TopicPartition, Handler<AsyncResult<Long>>) - 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(RequestOptions) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Create an HTTP POST request to send to the server with the specified options.
- post(int, String, String) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Create an HTTP POST request to send to the server at the specified host and port.
- post(String, String) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Create an HTTP POST request to send to the server at the specified host and default port.
- post(RequestOptions, Handler<HttpClientResponse>) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Deprecated.
- post(int, String, String, Handler<HttpClientResponse>) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Deprecated.
- post(String, String, Handler<HttpClientResponse>) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Deprecated.
- post(String) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Create an HTTP POST request to send to the server at the default host and port.
- post(String, Handler<HttpClientResponse>) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Deprecated.
- 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(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(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.
- post() - Method in class io.vertx.reactivex.ext.web.Router
-
Add a route that matches any HTTP POST request
- 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 - Static variable in class io.vertx.reactivex.redis.client.Command
-
- post(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- postAbs(String) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Create an HTTP POST request to send to the server using an absolute URI
- postAbs(String, Handler<HttpClientResponse>) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Deprecated.
- 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
- PostgreSQLClient - Class in io.vertx.reactivex.ext.asyncsql
-
Represents an PostgreSQL client
NOTE: This class has been automatically generated from the
original
non RX-ified interface using Vert.x codegen.
- PostgreSQLClient(PostgreSQLClient) - Constructor for class io.vertx.reactivex.ext.asyncsql.PostgreSQLClient
-
- PostgreSQLClient(Object) - Constructor for class io.vertx.reactivex.ext.asyncsql.PostgreSQLClient
-
- 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
- preferredLanguage() - Method in class io.vertx.reactivex.ext.web.RoutingContext
-
Helper to return the user preferred language.
- preferredLocale() - Method in class io.vertx.reactivex.ext.web.RoutingContext
-
Deprecated.
- preferredUsername(JsonObject) - Static method in class io.vertx.reactivex.ext.auth.oauth2.KeycloakHelper
-
- prepare(String, Handler<AsyncResult<PreparedStatement>>) - Method in class io.vertx.reactivex.cassandra.CassandraClient
-
Prepares the provided query string.
- prepare(String, Handler<AsyncResult<PreparedStatement>>) - Method in class io.vertx.reactivex.db2client.DB2Connection
-
- prepare(String, Handler<AsyncResult<PreparedStatement>>) - Method in class io.vertx.reactivex.mysqlclient.MySQLConnection
-
- prepare(String, Handler<AsyncResult<PreparedStatement>>) - Method in class io.vertx.reactivex.pgclient.PgConnection
-
- prepare(String, Handler<AsyncResult<PreparedStatement>>) - Method in class io.vertx.reactivex.sqlclient.SqlConnection
-
Create a prepared query.
- prepare(String, Handler<AsyncResult<PreparedStatement>>) - Method in class io.vertx.reactivex.sqlclient.Transaction
-
Create a prepared query.
- 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<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
-
- preparedQuery(String) - Method in class io.vertx.reactivex.sqlclient.SqlClient
-
- 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
-
- priority() - Method in class io.vertx.reactivex.core.dns.MxRecord
-
The priority of the MX record.
- priority() - Method in class io.vertx.reactivex.core.dns.SrvRecord
-
Returns the priority for this service record.
- priority() - Method in class io.vertx.reactivex.rabbitmq.BasicProperties
-
Retrieve the value in the priority field.
- privateKeyPath() - Method in class io.vertx.reactivex.core.net.SelfSignedCertificate
-
Filesystem path to the RSA private key file in PEM format
- process() - Method in class io.vertx.reactivex.ext.shell.system.Job
-
- Process - Class in io.vertx.reactivex.ext.shell.system
-
A process managed by the shell.
- Process(Process) - Constructor for class io.vertx.reactivex.ext.shell.system.Process
-
- Process(Object) - Constructor for class io.vertx.reactivex.ext.shell.system.Process
-
- processArgs() - Method in class io.vertx.reactivex.core.Context
-
The process args
- processHandler(Handler<CommandProcess>) - Method in class io.vertx.reactivex.ext.shell.command.CommandBuilder
-
Set the command process handler, the process handler is called when the command is executed.
- 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
-
- 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
-
- Promise<T> - Class in io.vertx.reactivex.core
-
Represents the writable side of an action that may, or may not, have occurred yet.
- Promise(Promise) - Constructor for class io.vertx.reactivex.core.Promise
-
- Promise(Object, TypeArg<T>) - Constructor for class io.vertx.reactivex.core.Promise
-
- promise() - Static method in class io.vertx.reactivex.core.Promise
-
Create a promise that hasn't completed yet
- properties() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQMessage
-
- property(PropertyKind<V>) - Method in class io.vertx.reactivex.sqlclient.SqlResult
-
- PROPERTY_COLLECTION_NAME - Static variable in class io.vertx.reactivex.ext.auth.mongo.MongoAuth
-
The property name to be used to set the name of the collection inside the config
- PROPERTY_CREDENTIAL_PASSWORD_FIELD - Static variable in class io.vertx.reactivex.ext.auth.mongo.MongoAuth
-
The property name to be used to set the name of the field, where the password for the credentials is stored inside
- PROPERTY_CREDENTIAL_USERNAME_FIELD - Static variable in class io.vertx.reactivex.ext.auth.mongo.MongoAuth
-
The property name to be used to set the name of the field, where the username for the credentials is stored inside
- PROPERTY_PASSWORD_FIELD - Static variable in class io.vertx.reactivex.ext.auth.mongo.MongoAuth
-
The property name to be used to set the name of the field, where the password is stored inside
- PROPERTY_PERMISSION_FIELD - Static variable in class io.vertx.reactivex.ext.auth.mongo.MongoAuth
-
The property name to be used to set the name of the field, where the permissions are stored inside
- PROPERTY_ROLE_FIELD - Static variable in class io.vertx.reactivex.ext.auth.mongo.MongoAuth
-
The property name to be used to set the name of the field, where the roles are stored inside
- PROPERTY_SALT_FIELD - Static variable in class io.vertx.reactivex.ext.auth.mongo.MongoAuth
-
The property name to be used to set the name of the field, where the SALT is stored inside
- PROPERTY_SALT_STYLE - Static variable in class io.vertx.reactivex.ext.auth.mongo.MongoAuth
-
The property name to be used to set the name of the field, where the salt style is stored inside
- PROPERTY_USERNAME_FIELD - Static variable in class io.vertx.reactivex.ext.auth.mongo.MongoAuth
-
The property name to be used to set the name of the field, where the username is stored inside
- PropertyKind<T> - Class in io.vertx.reactivex.sqlclient
-
Represents which kind the property is.
- PropertyKind(PropertyKind) - Constructor for class io.vertx.reactivex.sqlclient.PropertyKind
-
- PropertyKind(Object, TypeArg<T>) - Constructor for class io.vertx.reactivex.sqlclient.PropertyKind
-
- props(String, Handler<AsyncResult<FileProps>>) - 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
-
- protocol() - Method in class io.vertx.reactivex.core.dns.SrvRecord
-
Returns the protocol for the service being queried (i.e.
- protocolName() - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
-
- protocolVersion() - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
-
- PSETEX - Static variable in class io.vertx.reactivex.redis.client.Command
-
- psetex(String, String, String, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- psetex(String, long, String, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set the value and expiration in milliseconds of a key
- psetex(String, long, String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Set the value and expiration in milliseconds of a key
- PSUBSCRIBE - Static variable in class io.vertx.reactivex.redis.client.Command
-
- psubscribe(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- psubscribe(String, Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Listen for messages published to channels matching the given pattern
- psubscribe(String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Listen for messages published to channels matching the given pattern
- psubscribeMany(List<String>, Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Listen for messages published to channels matching the given patterns
- psubscribeMany(List<String>, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Listen for messages published to channels matching the given patterns
- PSYNC - Static variable in class io.vertx.reactivex.redis.client.Command
-
- psync(String, String, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- PTTL - Static variable in class io.vertx.reactivex.redis.client.Command
-
- pttl(String, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- pttl(String, Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get the time to live for a key in milliseconds
- pttl(String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get the time to live for a key in milliseconds
- Pty - Class in io.vertx.reactivex.ext.shell.term
-
A pseudo terminal used for controlling a
Tty
.
- Pty(Pty) - Constructor for class io.vertx.reactivex.ext.shell.term.Pty
-
- Pty(Object) - Constructor for class io.vertx.reactivex.ext.shell.term.Pty
-
- 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 but specifying options
that can be used to configure the delivery.
- 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, Handler<AsyncResult<Integer>>) - 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, Handler<AsyncResult<Integer>>) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
-
Sends the PUBLISH message to the remote MQTT server
- publish(String, Buffer, MqttQoS, boolean, boolean, int, Handler<AsyncResult<Integer>>) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
-
Sends the PUBLISH message to the remote MQTT server explicitly specifying the messageId
- PUBLISH - Static variable in class io.vertx.reactivex.redis.client.Command
-
- publish(String, String, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- publish(String, String, Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Post a message to a channel
- publish(String, String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Post a message to a channel
- publish(Record, Handler<AsyncResult<Record>>) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
-
Publishes a record.
- publish(Record, Handler<AsyncResult<Record>>) - Method in class io.vertx.reactivex.servicediscovery.spi.ServicePublisher
-
Publishes a record.
- publishAcknowledge(int) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
-
Sends the PUBACK message to the remote MQTT client
- publishAcknowledgeHandler(Handler<Integer>) - 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
- 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.
- 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.
- 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
-
- 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
- publishReceivedHandler(Handler<Integer>) - 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
- publishReleaseHandler(Handler<Integer>) - Method in class io.vertx.reactivex.mqtt.MqttEndpoint
-
Set the pubrel handler on the MQTT endpoint.
- PUBSUB - Static variable in class io.vertx.reactivex.redis.client.Command
-
- pubsub(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- pubsubChannels(String, Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Lists the currently active channels - only those matching the pattern
- pubsubChannels(String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Lists the currently active channels - only those matching the pattern
- pubsubNumpat(Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Returns the number of subscriptions to patterns (that are performed using the PSUBSCRIBE command)
- pubsubNumpat(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Returns the number of subscriptions to patterns (that are performed using the PSUBSCRIBE command)
- pubsubNumsub(List<String>, Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Returns the number of subscribers (not counting clients subscribed to patterns) for the specified channels
- pubsubNumsub(List<String>, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Returns the number of subscribers (not counting clients subscribed to patterns) for the specified channels
- Pump - Class in io.vertx.reactivex.core.streams
-
Pumps data from a
ReadStream
to a
WriteStream
and performs flow control where necessary to
prevent the write stream buffer from getting overfull.
- Pump(Pump) - Constructor for class io.vertx.reactivex.core.streams.Pump
-
- Pump(Object) - Constructor for class io.vertx.reactivex.core.streams.Pump
-
- pump(ReadStream<T>, WriteStream<T>) - Static method in class io.vertx.reactivex.core.streams.Pump
-
Create a new Pump
with the given ReadStream
and WriteStream
- pump(Flowable<T>, WriteStream<T>) - Static method in class io.vertx.reactivex.core.streams.Pump
-
Create a new Pump
with the given ReadStream
and WriteStream
- pump(Observable<T>, WriteStream<T>) - Static method in class io.vertx.reactivex.core.streams.Pump
-
Create a new Pump
with the given ReadStream
and WriteStream
- pump(ReadStream<T>, WriteStream<T>, int) - Static method in class io.vertx.reactivex.core.streams.Pump
-
Create a new Pump
with the given ReadStream
and WriteStream
and
writeQueueMaxSize
- pump(Flowable<T>, WriteStream<T>, int) - Static method in class io.vertx.reactivex.core.streams.Pump
-
Create a new Pump
with the given ReadStream
and WriteStream
and
writeQueueMaxSize
- pump(Observable<T>, WriteStream<T>, int) - Static method in class io.vertx.reactivex.core.streams.Pump
-
Create a new Pump
with the given ReadStream
and WriteStream
and
writeQueueMaxSize
- PUNSUBSCRIBE - Static variable in class io.vertx.reactivex.redis.client.Command
-
- punsubscribe(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- punsubscribe(List<String>, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Stop listening for messages posted to channels matching the given patterns
- punsubscribe(List<String>, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Stop listening for messages posted to channels matching the given patterns
- push(HttpMethod, String, String, Handler<AsyncResult<HttpServerResponse>>) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
- push(HttpMethod, String, MultiMap, Handler<AsyncResult<HttpServerResponse>>) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
- push(HttpMethod, String, Handler<AsyncResult<HttpServerResponse>>) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
- push(HttpMethod, String, String, MultiMap, Handler<AsyncResult<HttpServerResponse>>) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
Push a response to the client.
The
handler
will be notified with a
success when the push can be sent and with
a
failure when the client has disabled push or reset the push before it has been sent.
The
handler
may be queued if the client has reduced the maximum number of streams the server can push
concurrently.
Push can be sent only for peer initiated streams and if the response is not ended.
- pushHandler(Handler<HttpClientRequest>) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
-
Set a push handler for this request.
The handler is called when the client receives a
push promise from the server.
- put(String, Object) - Method in class io.vertx.reactivex.core.Context
-
Put some data in the context.
- put(RequestOptions) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Create an HTTP PUT request to send to the server with the specified options.
- put(int, String, String) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Create an HTTP PUT request to send to the server at the specified host and port.
- put(String, String) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Create an HTTP PUT request to send to the server at the specified host and default port.
- put(RequestOptions, Handler<HttpClientResponse>) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Deprecated.
- put(int, String, String, Handler<HttpClientResponse>) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Deprecated.
- put(String, String, Handler<HttpClientResponse>) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Deprecated.
- put(String) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Create an HTTP PUT request to send to the server at the default host and port.
- put(String, Handler<HttpClientResponse>) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Deprecated.
- put(K, V, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
-
Put a value in the map, asynchronously.
- put(K, V, long, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
-
- put(K, V) - Method in class io.vertx.reactivex.core.shareddata.LocalMap
-
Put an entry in the map
- put(String, HashingAlgorithm) - Method in class io.vertx.reactivex.ext.auth.HashingStrategy
-
Put or replace an algorithm into the list of system loaded algorithms.
- put(String, Object) - Method in class io.vertx.reactivex.ext.shell.session.Session
-
Put some data in a session
- put(String, Object) - Method in class io.vertx.reactivex.ext.unit.TestContext
-
Put some data in the context.
- 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(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(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() - Method in class io.vertx.reactivex.ext.web.Router
-
Add a route that matches any HTTP PUT request
- 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, 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(Session, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.web.sstore.SessionStore
-
Add a session with the specified ID.
- putAbs(String) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Create an HTTP PUT request to send to the server using an absolute URI
- putAbs(String, Handler<HttpClientResponse>) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Deprecated.
- 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(String, String) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
-
Put an HTTP header
- putHeader(CharSequence, CharSequence) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
-
- putHeader(String, Iterable<String>) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
-
Put an HTTP header with multiple values
- putHeader(CharSequence, Iterable<CharSequence>) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
-
- putHeader(String, String) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
Put an HTTP header
- putHeader(CharSequence, CharSequence) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
- putHeader(String, Iterable<String>) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
- putHeader(CharSequence, Iterable<CharSequence>) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
- putHeader(String, String) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
-
Configure the request to set a new HTTP header.
- 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.
- putHeaders(MultiMap) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
-
Configure the request to add multiple HTTP headers .
- putIfAbsent(K, V, Handler<AsyncResult<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, long, Handler<AsyncResult<V>>) - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
-
- 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
- putTrailer(String, String) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
Put an HTTP trailer
- putTrailer(CharSequence, CharSequence) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
- putTrailer(String, Iterable<String>) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
- putTrailer(CharSequence, Iterable<CharSequence>) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
- putValue(String, String, Handler<AsyncResult<Boolean>>) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Adds specified key/value pair
- putValue(String, String, Handler<AsyncResult<Boolean>>) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- putValueWithOptions(String, String, KeyValueOptions, Handler<AsyncResult<Boolean>>) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
- putValueWithOptions(String, String, KeyValueOptions, Handler<AsyncResult<Boolean>>) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- 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
- 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
-
- RANDOMKEY - Static variable in class io.vertx.reactivex.redis.client.Command
-
- randomkey(Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- randomkey(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Return a random key from the keyspace
- randomkey(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return a random key from the keyspace
- raw() - Method in class io.vertx.reactivex.ext.shell.cli.CliToken
-
- raw(String, String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
-
Create a request with a custom HTTP method to send to the server at the default host and port.
- raw(String, int, String, String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
-
Create a request with a custom HTTP method to send to the server at the specified host and port.
- raw(String, String, String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
-
Create a request with a custom HTTP method to send to the server at the specified host and default port.
- rawAbs(String, String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
-
Create a request with a custom HTTP method to send to the server using an absolute URI, specifying a response handler to receive
the response
- rawAccessToken(JsonObject) - Static method in class io.vertx.reactivex.ext.auth.oauth2.KeycloakHelper
-
Get raw `access_token` string from the principal.
- rawIdToken(JsonObject) - Static method in class io.vertx.reactivex.ext.auth.oauth2.KeycloakHelper
-
Get raw `id_token` string from the principal.
- rawLine() - Method in class io.vertx.reactivex.ext.shell.cli.Completion
-
- rawMethod() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
-
- rawMethod(String) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
-
Configure the request to use a custom HTTP method
- 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
- rbacHandler(OAuth2RBAC) - Method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
-
Deprecated.
- read(Buffer, int, long, int, Handler<AsyncResult<Buffer>>) - Method in class io.vertx.reactivex.core.file.AsyncFile
-
Reads length
bytes of data from the file at position position
in the file, asynchronously.
- read(int, Handler<AsyncResult<RowSet<Row>>>) - Method in class io.vertx.reactivex.sqlclient.Cursor
-
Read rows from the cursor, the result is provided asynchronously to the handler
.
- readDir(String, Handler<AsyncResult<List<String>>>) - Method in class io.vertx.reactivex.core.file.FileSystem
-
Read the contents of the directory specified by path
, asynchronously.
- readDir(String, String, Handler<AsyncResult<List<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, Handler<AsyncResult<Buffer>>) - 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
-
- readFromBuffer(int, Buffer) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
- readline(String, Handler<String>) - Method in class io.vertx.reactivex.ext.shell.term.Term
-
Prompt the user a line of text.
- readline(String, Handler<String>, Handler<Completion>) - Method in class io.vertx.reactivex.ext.shell.term.Term
-
Prompt the user a line of text, providing a completion handler to handle user's completion.
- READONLY - Static variable in class io.vertx.reactivex.redis.client.Command
-
- readonly(Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- ReadStream<T> - Interface in io.vertx.reactivex.core.streams
-
Represents a stream of items that can be read from.
- readSymlink(String, Handler<AsyncResult<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 - Static variable in class io.vertx.reactivex.redis.client.Command
-
- readwrite(Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- realm() - Method in class io.vertx.reactivex.ext.auth.htdigest.HtdigestAuth
-
Return the currently used realm
- 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
-
- recover(Function<Throwable, Future<CompositeFuture>>) - Method in class io.vertx.reactivex.core.CompositeFuture
-
Handles a failure of this Future by returning the result of another Future.
- recover(Function<Throwable, Future<T>>) - Method in class io.vertx.reactivex.core.Future
-
Handles a failure of this Future by returning the result of another Future.
- 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, Future<HttpClientRequest>>) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Set a redirect handler for the http client.
- 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
-
- RedisClient - Class in io.vertx.reactivex.redis
-
This factory is deprecated use
Redis
instead,
or for a typed API
RedisAPI
.
- RedisClient(RedisClient) - Constructor for class io.vertx.reactivex.redis.RedisClient
-
- RedisClient(Object) - Constructor for class io.vertx.reactivex.redis.RedisClient
-
- 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
-
- RedisSentinel - Class in io.vertx.reactivex.redis.sentinel
-
This factory is deprecated use
Redis
instead,
or for a typed API
RedisAPI
.
- RedisSentinel(RedisSentinel) - Constructor for class io.vertx.reactivex.redis.sentinel.RedisSentinel
-
- RedisSentinel(Object) - Constructor for class io.vertx.reactivex.redis.sentinel.RedisSentinel
-
- RedisTransaction - Class in io.vertx.reactivex.redis
-
This factory is deprecated use
Redis
instead,
or for a typed API
RedisAPI
.
- RedisTransaction(RedisTransaction) - Constructor for class io.vertx.reactivex.redis.RedisTransaction
-
- RedisTransaction(Object) - Constructor for class io.vertx.reactivex.redis.RedisTransaction
-
- refresh(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.auth.oauth2.AccessToken
-
Refresh the access token
- refreshToken() - Method in class io.vertx.reactivex.ext.auth.oauth2.AccessToken
-
Deprecated.
- regenerateId() - Method in class io.vertx.reactivex.ext.web.Session
-
- register(String, Handler<Promise<Status>>) - Method in class io.vertx.reactivex.ext.healthchecks.HealthCheckHandler
-
Registers a health check procedure.
- register(String, long, Handler<Promise<Status>>) - Method in class io.vertx.reactivex.ext.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, long, Handler<Promise<Status>>) - Method in class io.vertx.reactivex.ext.healthchecks.HealthChecks
-
Registers a health check procedure.
- 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.
- registerCheck(CheckOptions, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Add a new check to the local agent.
- registerCheck(CheckOptions, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- registerCodec(MessageCodec) - Method in class io.vertx.reactivex.core.eventbus.EventBus
-
Register a message codec.
- registerCommand(Command) - Method in class io.vertx.reactivex.ext.shell.command.CommandRegistry
-
- registerCommand(Command, Handler<AsyncResult<Command>>) - Method in class io.vertx.reactivex.ext.shell.command.CommandRegistry
-
Register a command
- registerCommandResolver(CommandResolver) - Method in class io.vertx.reactivex.ext.shell.ShellServer
-
Register a command resolver for this server.
- registerCommands(List<Command>) - Method in class io.vertx.reactivex.ext.shell.command.CommandRegistry
-
- registerCommands(List<Command>, Handler<AsyncResult<List<Command>>>) - Method in class io.vertx.reactivex.ext.shell.command.CommandRegistry
-
Register a list of commands.
- registerService(ServiceOptions, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Adds a new service, with an optional health check, to the local agent.
- registerService(ServiceOptions, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- registerServiceExporter(ServiceExporter, JsonObject) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
-
Registers a discovery bridge.
- registerServiceExporter(ServiceExporter, JsonObject, Handler<AsyncResult<Void>>) - 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.
- registerServiceImporter(ServiceImporter, JsonObject, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
-
Registers a discovery service importer.
- registerTermServer(TermServer) - Method in class io.vertx.reactivex.ext.shell.ShellServer
-
Register a term server to this shell server, the term server lifecycle methods are managed by this shell server.
- registerVerticleFactory(VerticleFactory) - Method in class io.vertx.reactivex.core.Vertx
-
Register a VerticleFactory
that can be used for deploying Verticles based on an identifier.
- reject() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
-
Reject the WebSocket.
- reject(int) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
-
- 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.
- 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.shareddata.Lock
-
Release the lock.
- release(ServiceReference) - Method in class io.vertx.reactivex.servicediscovery.ServiceDiscovery
-
Releases the service reference.
- release() - Method in class io.vertx.reactivex.servicediscovery.ServiceReference
-
Releases the reference.
- 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.
- remainingCredits() - Method in class io.vertx.reactivex.amqp.AmqpSender
-
- 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.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
-
- 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(String) - Method in class io.vertx.reactivex.core.Context
-
Remove some data from the context.
- remove(String) - Method in class io.vertx.reactivex.core.MultiMap
-
Removes the value with the given name
- remove(CharSequence) - Method in class io.vertx.reactivex.core.MultiMap
-
- remove(K, Handler<AsyncResult<V>>) - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
-
Remove a value from the map, asynchronously.
- remove(Object) - Method in class io.vertx.reactivex.core.shareddata.LocalMap
-
Remove an entry from the map
- remove(AuthProvider) - Method in class io.vertx.reactivex.ext.auth.ChainAuth
-
Removes a provider from the chain.
- remove(String, JsonObject, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Deprecated.
- remove(String, JsonObject, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
Deprecated.
- remove(String) - Method in class io.vertx.reactivex.ext.shell.session.Session
-
Remove some data from the session
- remove(String) - Method in class io.vertx.reactivex.ext.unit.TestContext
-
Remove some data from the context.
- remove(AuthHandler) - Method in class io.vertx.reactivex.ext.web.handler.ChainAuthHandler
-
Removes a provider from the chain.
- remove() - Method in class io.vertx.reactivex.ext.web.Route
-
Remove this route from the router
- 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
- removeArgument(int) - Method in class io.vertx.reactivex.core.cli.CLI
-
Removes an argument identified by its index.
- removeBodyEndHandler(int) - Method in class io.vertx.reactivex.ext.web.RoutingContext
-
Remove a body end handler
- removeCloseHook(Closeable) - Method in class io.vertx.reactivex.core.Context
-
- 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) - Method in class io.vertx.reactivex.ext.web.RoutingContext
-
Expire a cookie, notifying a User Agent to remove it from its cookie jar.
- removeCookie(String, boolean) - Method in class io.vertx.reactivex.ext.web.RoutingContext
-
Remove a cookie from the cookie set.
- removeDocument(String, JsonObject, Handler<AsyncResult<MongoClientDeleteResult>>) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Remove a single matching document from a collection and return the handler with MongoClientDeleteResult result
- removeDocument(String, JsonObject, Handler<AsyncResult<MongoClientDeleteResult>>) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- removeDocuments(String, JsonObject, Handler<AsyncResult<MongoClientDeleteResult>>) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Remove matching documents from a collection and return the handler with MongoClientDeleteResult result
- removeDocuments(String, JsonObject, Handler<AsyncResult<MongoClientDeleteResult>>) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- removeDocumentsWithOptions(String, JsonObject, WriteOption, Handler<AsyncResult<MongoClientDeleteResult>>) - 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
- removeDocumentsWithOptions(String, JsonObject, WriteOption, Handler<AsyncResult<MongoClientDeleteResult>>) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- removeDocumentWithOptions(String, JsonObject, WriteOption, Handler<AsyncResult<MongoClientDeleteResult>>) - 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
- removeDocumentWithOptions(String, JsonObject, WriteOption, Handler<AsyncResult<MongoClientDeleteResult>>) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- removeEndHandler(int) - Method in class io.vertx.reactivex.ext.web.RoutingContext
-
Remove an end handler
- 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, Handler<AsyncResult<Boolean>>) - 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
-
- removeOne(String, JsonObject, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Deprecated.
- removeOne(String, JsonObject, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
Deprecated.
- removeOneWithOptions(String, JsonObject, WriteOption, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Deprecated.
- removeOneWithOptions(String, JsonObject, WriteOption, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
Deprecated.
- removeOption(String) - Method in class io.vertx.reactivex.core.cli.CLI
-
Removes an option identified by its name.
- 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.
- removeWithOptions(String, JsonObject, WriteOption, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Deprecated.
- removeWithOptions(String, JsonObject, WriteOption, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
Deprecated.
- RENAME - Static variable in class io.vertx.reactivex.redis.client.Command
-
- rename(String, String, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rename(String, String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Rename a key
- rename(String, String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Rename a key
- RENAMENX - Static variable in class io.vertx.reactivex.redis.client.Command
-
- renamenx(String, String, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- renamenx(String, String, Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Rename a key, only if the new key does not exist
- renamenx(String, String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Rename a key, only if the new key does not exist
- render(JsonObject, String, Handler<AsyncResult<Buffer>>) - Method in class io.vertx.reactivex.ext.web.common.template.TemplateEngine
-
Render the template.
- render(Map<String, Object>, String, Handler<AsyncResult<Buffer>>) - Method in class io.vertx.reactivex.ext.web.common.template.TemplateEngine
-
Render the template.
- render(RoutingContext, String, Handler<AsyncResult<Buffer>>) - Method in class io.vertx.reactivex.ext.web.templ.TemplateEngine
-
Deprecated.
- render(RoutingContext, String, String, Handler<AsyncResult<Buffer>>) - Method in class io.vertx.reactivex.ext.web.templ.TemplateEngine
-
Deprecated.
- renewSession(String, Handler<AsyncResult<Session>>) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Renews the given session.
- renewSession(String, Handler<AsyncResult<Session>>) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- replace(K, V, Handler<AsyncResult<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(String, JsonObject, JsonObject, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Deprecated.
- replace(String, JsonObject, JsonObject, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
Deprecated.
- replaceDocuments(String, JsonObject, JsonObject, Handler<AsyncResult<MongoClientUpdateResult>>) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Replace matching documents in the specified collection and return the handler with MongoClientUpdateResult result
- replaceDocuments(String, JsonObject, JsonObject, Handler<AsyncResult<MongoClientUpdateResult>>) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- replaceDocumentsWithOptions(String, JsonObject, JsonObject, UpdateOptions, Handler<AsyncResult<MongoClientUpdateResult>>) - 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
- replaceDocumentsWithOptions(String, JsonObject, JsonObject, UpdateOptions, Handler<AsyncResult<MongoClientUpdateResult>>) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- replaceIfPresent(K, V, V, Handler<AsyncResult<Boolean>>) - 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.
- replaceWithOptions(String, JsonObject, JsonObject, UpdateOptions, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Deprecated.
- replaceWithOptions(String, JsonObject, JsonObject, UpdateOptions, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
Deprecated.
- REPLCONF - Static variable in class io.vertx.reactivex.redis.client.Command
-
- replconf(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- REPLICAOF - Static variable in class io.vertx.reactivex.redis.client.Command
-
- replicaof(String, String, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- reply(Object) - Method in class io.vertx.reactivex.core.eventbus.Message
-
Reply to this message.
- reply(Object, Handler<AsyncResult<Message<R>>>) - Method in class io.vertx.reactivex.core.eventbus.Message
-
Deprecated.
- reply(Object, DeliveryOptions) - Method in class io.vertx.reactivex.core.eventbus.Message
-
- reply(Object, DeliveryOptions, Handler<AsyncResult<Message<R>>>) - Method in class io.vertx.reactivex.core.eventbus.Message
-
Deprecated.
- replyAddress() - Method in class io.vertx.reactivex.core.eventbus.Message
-
The reply address.
- replyAndRequest(Object, Handler<AsyncResult<Message<R>>>) - Method in class io.vertx.reactivex.core.eventbus.Message
-
Reply to this message, specifying a replyHandler
for the reply - i.e.
- replyAndRequest(Object, DeliveryOptions, Handler<AsyncResult<Message<R>>>) - Method in class io.vertx.reactivex.core.eventbus.Message
-
Like 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
-
- replyTo() - Method in class io.vertx.reactivex.rabbitmq.BasicProperties
-
- replyToGroupId() - Method in class io.vertx.reactivex.amqp.AmqpMessage
-
- replyToGroupId(String) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
-
- request(String, Object, Handler<AsyncResult<Message<T>>>) - Method in class io.vertx.reactivex.core.eventbus.EventBus
-
Sends a message and and specify a replyHandler
that will be called if the recipient
subsequently replies to the message.
- request(String, Object, DeliveryOptions, Handler<AsyncResult<Message<T>>>) - Method in class io.vertx.reactivex.core.eventbus.EventBus
-
Like but specifying options
that can be used to configure the delivery.
- request(HttpMethod, SocketAddress, RequestOptions) - Method in class io.vertx.reactivex.core.http.HttpClient
-
- request(HttpMethod, RequestOptions) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Create an HTTP request to send to the server with the specified options.
- request(HttpMethod, int, String, String) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Create an HTTP request to send to the server at the specified host and port.
- request(HttpMethod, SocketAddress, int, String, String) - Method in class io.vertx.reactivex.core.http.HttpClient
-
- request(HttpMethod, String, String) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Create an HTTP request to send to the server at the specified host and default port.
- request(HttpMethod, RequestOptions, Handler<HttpClientResponse>) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Deprecated.
- request(HttpMethod, SocketAddress, RequestOptions, Handler<HttpClientResponse>) - Method in class io.vertx.reactivex.core.http.HttpClient
-
- request(HttpMethod, int, String, String, Handler<HttpClientResponse>) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Deprecated.
- request(HttpMethod, SocketAddress, int, String, String, Handler<HttpClientResponse>) - Method in class io.vertx.reactivex.core.http.HttpClient
-
- request(HttpMethod, String, String, Handler<HttpClientResponse>) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Deprecated.
- request(HttpMethod, String) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Create an HTTP request to send to the server at the default host and port.
- request(HttpMethod, String, Handler<HttpClientResponse>) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Deprecated.
- request() - Method in class io.vertx.reactivex.core.http.HttpClientResponse
-
- 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, SocketAddress, int, String, String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
-
- 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(HttpMethod, SocketAddress, String, String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
-
- 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, SocketAddress, String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
-
- 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, RequestOptions) - Method in class io.vertx.reactivex.ext.web.client.WebClient
-
- request() - Method in class io.vertx.reactivex.ext.web.RoutingContext
-
- Request - Class in io.vertx.reactivex.redis.client
-
Builder for REDIS requests that will be encoded according to the RESP protocol was introduced in Redis 1.2.
- Request(Request) - Constructor for class io.vertx.reactivex.redis.client.Request
-
- Request(Object) - Constructor for class io.vertx.reactivex.redis.client.Request
-
- requestAbs(HttpMethod, String) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Create an HTTP request to send to the server using an absolute URI
- requestAbs(HttpMethod, SocketAddress, String) - Method in class io.vertx.reactivex.core.http.HttpClient
-
- requestAbs(HttpMethod, String, Handler<HttpClientResponse>) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Deprecated.
- requestAbs(HttpMethod, SocketAddress, String, Handler<HttpClientResponse>) - Method in class io.vertx.reactivex.core.http.HttpClient
-
- 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
- requestAbs(HttpMethod, SocketAddress, String) - Method in class io.vertx.reactivex.ext.web.client.WebClient
-
- 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.api
-
Request parameter holder
NOTE: This class has been automatically generated from the
original
non RX-ified interface using Vert.x codegen.
- RequestParameter(RequestParameter) - Constructor for class io.vertx.reactivex.ext.web.api.RequestParameter
-
- RequestParameter(Object) - Constructor for class io.vertx.reactivex.ext.web.api.RequestParameter
-
- RequestParameters - Class in io.vertx.reactivex.ext.web.api
-
Container for request parameters
NOTE: This class has been automatically generated from the
original
non RX-ified interface using Vert.x codegen.
- RequestParameters(RequestParameters) - Constructor for class io.vertx.reactivex.ext.web.api.RequestParameters
-
- RequestParameters(Object) - Constructor for class io.vertx.reactivex.ext.web.api.RequestParameters
-
- requestStream() - Method in class io.vertx.reactivex.core.http.HttpServer
-
Return the request stream for the server.
- requiresBody() - Method in class io.vertx.reactivex.ext.web.client.predicate.ErrorConverter
-
- reroute(String) - Method in class io.vertx.reactivex.ext.web.RoutingContext
-
Restarts the current router with a new path and reusing the original method.
- reroute(HttpMethod, String) - Method in class io.vertx.reactivex.ext.web.RoutingContext
-
Restarts the current router with a new method and path.
- reset() - Method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
-
Resets the circuit breaker state (number of failure set to 0 and state set to closed).
- reset() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
-
Reset this stream with the error code 0
.
- reset(long) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
-
Reset this request:
for HTTP/2, this performs send an HTTP/2 reset frame with the specified error
code
for HTTP/1.x, this closes the connection when the current request is inflight
When the request has not yet been sent, the request will be aborted and false is returned as indicator.
- reset() - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
Reset this HTTP/2 stream with the error code 0
.
- reset(long) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
Reset this HTTP/2 stream with the error code
.
- reset(String, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.redis.sentinel.RedisSentinel
-
Reset all the masters with matching name.
- resetConnection(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.mysqlclient.MySQLConnection
-
Send a RESET_CONNECTION command to reset the session state.
- resizehandler(Handler<Void>) - Method in class io.vertx.reactivex.ext.shell.command.CommandProcess
-
- resizehandler(Handler<Void>) - Method in class io.vertx.reactivex.ext.shell.term.Term
-
- resizehandler(Handler<Void>) - Method in class io.vertx.reactivex.ext.shell.term.Tty
-
Set a resize handler, the handler is called when the tty size changes.
- resolve(Promise<Void>) - Method in class io.vertx.reactivex.ext.unit.Async
-
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.
- resolve(Promise<Void>) - Method in class io.vertx.reactivex.ext.unit.TestCompletion
-
Completes the future upon completion, otherwise fails it.
- resolveA(String, Handler<AsyncResult<List<String>>>) - Method in class io.vertx.reactivex.core.dns.DnsClient
-
Try to resolve all A (ipv4) records for the given name.
- resolveAAAA(String, Handler<AsyncResult<List<String>>>) - Method in class io.vertx.reactivex.core.dns.DnsClient
-
Try to resolve all AAAA (ipv6) records for the given name.
- resolveCNAME(String, Handler<AsyncResult<List<String>>>) - Method in class io.vertx.reactivex.core.dns.DnsClient
-
Try to resolve the CNAME record for the given name.
- resolveMX(String, Handler<AsyncResult<List<MxRecord>>>) - Method in class io.vertx.reactivex.core.dns.DnsClient
-
Try to resolve the MX records for the given name.
- resolveNS(String, Handler<AsyncResult<List<String>>>) - Method in class io.vertx.reactivex.core.dns.DnsClient
-
Try to resolve the NS records for the given name.
- resolvePTR(String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.core.dns.DnsClient
-
Try to resolve the PTR record for the given name.
- resolveSRV(String, Handler<AsyncResult<List<SrvRecord>>>) - Method in class io.vertx.reactivex.core.dns.DnsClient
-
Try to resolve the SRV records for the given name.
- resolveTXT(String, Handler<AsyncResult<List<String>>>) - Method in class io.vertx.reactivex.core.dns.DnsClient
-
Try to resolve the TXT records for the given name.
- response() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
-
- response() - Method in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicateResult
-
The which has been tested.
- response() - Method in class io.vertx.reactivex.ext.web.RoutingContext
-
- Response - Class in io.vertx.reactivex.redis.client
-
The response received from the REDIS server.
- Response(Response) - Constructor for class io.vertx.reactivex.redis.client.Response
-
- Response(Object) - Constructor for class io.vertx.reactivex.redis.client.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
-
- ResponsePredicate - Class in io.vertx.reactivex.ext.web.client.predicate
-
A predicate on .
- ResponsePredicate(ResponsePredicate) - Constructor for class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
- ResponsePredicate(Object) - Constructor for class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
- ResponsePredicateResult - Class in io.vertx.reactivex.ext.web.client.predicate
-
- ResponsePredicateResult(ResponsePredicateResult) - Constructor for class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicateResult
-
- ResponsePredicateResult(Object) - Constructor for class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicateResult
-
- 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
-
- RESTORE - Static variable in class io.vertx.reactivex.redis.client.Command
-
- restore(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- restore(String, long, String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Create a key using the provided serialized value, previously obtained using DUMP.
- restore(String, long, String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Create a key using the provided serialized value, previously obtained using DUMP.
- RESTORE_ASKING - Static variable in class io.vertx.reactivex.redis.client.Command
-
- restoreAsking(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- result() - Method in class io.vertx.reactivex.core.CompositeFuture
-
The result of the operation.
- result() - Method in class io.vertx.reactivex.core.Future
-
The result of the operation.
- resultAt(int) - Method in class io.vertx.reactivex.core.CompositeFuture
-
Returns the result of a wrapped future
- ResultSet - Class in io.vertx.reactivex.cassandra
-
It is like ResultSet
, 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
-
- resultSetClosedHandler(Handler<Void>) - Method in class io.vertx.reactivex.ext.sql.SQLRowStream
-
Event handler when a resultset is closed.
- 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.datagram.DatagramSocket
-
- 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.HttpClientRequest
-
Deprecated.
- 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.core.TimeoutStream
-
- resume() - Method in class io.vertx.reactivex.ext.shell.system.Job
-
Resume the job to foreground.
- resume(boolean) - Method in class io.vertx.reactivex.ext.shell.system.Job
-
Resume the job.
- resume() - Method in class io.vertx.reactivex.ext.shell.system.Process
-
Suspend the process.
- resume(boolean) - Method in class io.vertx.reactivex.ext.shell.system.Process
-
Suspend the process.
- resume(Handler<Void>) - Method in class io.vertx.reactivex.ext.shell.system.Process
-
Suspend the process.
- resume(boolean, Handler<Void>) - Method in class io.vertx.reactivex.ext.shell.system.Process
-
Suspend the process.
- resume() - Method in class io.vertx.reactivex.ext.sql.SQLRowStream
-
- 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.kafka.client.consumer.KafkaConsumer
-
- 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.
- resume(TopicPartition, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
-
Resume specified partition which have been paused with pause.
- resume(Set<TopicPartition>, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
-
Resume specified partitions which have been paused with pause.
- 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
-
- resumeHandler(Handler<Void>) - Method in class io.vertx.reactivex.ext.shell.command.CommandProcess
-
Set a resume handler, this handler is called when the command is resumed, for instance user
types bg
or fg
to resume the command.
- retryPolicy(Function<Integer, Long>) - Method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
-
- 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.
A non positive value means there is no retry at all.
- reverseLookup(String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.core.dns.DnsClient
-
Try to do a reverse lookup of an IP address.
- revoke(String, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.auth.oauth2.AccessToken
-
Revoke 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 - Static variable in class io.vertx.reactivex.redis.client.Command
-
- role(Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- role(Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Return the role of the instance in the context of replication
- role(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return the role of the instance in the context of replication
- ROLE_PREFIX - Static variable in class io.vertx.reactivex.ext.auth.mongo.MongoAuth
-
The prefix which is used by the method when checking for role access
- rollback(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.sql.SQLConnection
-
Rolls back all changes made since the previous commit/rollback.
- rollback() - Method in class io.vertx.reactivex.sqlclient.Transaction
-
Rollback the current transaction.
- rollback(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.sqlclient.Transaction
-
- 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
-
- route() - Method in class io.vertx.reactivex.ext.web.Router
-
Add a route with no matching criteria, i.e.
- 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
- 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
-
- router(Vertx) - Static method in class io.vertx.reactivex.ext.web.Router
-
Create a router
- RouterFactory<Specification> - Interface in io.vertx.reactivex.ext.web.api.contract
-
Main interface for Design Driven Router factory
Author: Francesco Guardiani @slinkydeveloper
NOTE: This class has been automatically generated from the
original
non RX-ified interface using Vert.x codegen.
- 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 - 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.rabbitmq.Envelope
-
Get the routing key included in this parameter envelope
- Row - Class in io.vertx.reactivex.sqlclient
-
Represents single row of the result set.
- 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
-
- RowSet<R> - Class in io.vertx.reactivex.sqlclient
-
A set of rows.
- 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 - Static variable in class io.vertx.reactivex.redis.client.Command
-
- rpop(String, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rpop(String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Remove and get the last element in a list
- rpop(String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Remove and get the last element in a list
- RPOPLPUSH - Static variable in class io.vertx.reactivex.redis.client.Command
-
- rpoplpush(String, String, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rpoplpush(String, String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Remove the last element in a list, append it to another list and return it
- rpoplpush(String, String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Remove the last element in a list, append it to another list and return it
- RPUSH - Static variable in class io.vertx.reactivex.redis.client.Command
-
- rpush(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rpush(String, String, Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Append one or multiple values to a list
- rpush(String, String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Append one or multiple values to a list
- rpushMany(String, List<String>, Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Append one or multiple values to a list
- rpushMany(String, List<String>, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Append one or multiple values to a list
- RPUSHX - Static variable in class io.vertx.reactivex.redis.client.Command
-
- rpushx(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rpushx(String, String, Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Append a value to a list, only if the list exists
- rpushx(String, String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Append a value to a list, only if the list exists
- run() - Method in class io.vertx.reactivex.ext.shell.system.Job
-
Run the job, before running the job a must be set.
- run() - Method in class io.vertx.reactivex.ext.shell.system.Process
-
Run the process.
- run(boolean) - Method in class io.vertx.reactivex.ext.shell.system.Process
-
Run the process.
- run() - Method in class io.vertx.reactivex.ext.unit.TestSuite
-
Run the testsuite with the default options.
When the test suite is executed in a Vertx context (i.e `Vertx.currentContext()` returns a context) this
context's event loop is used for running the test suite.
- run(TestOptions) - Method in class io.vertx.reactivex.ext.unit.TestSuite
-
Run the testsuite with the specified
options
.
When the test suite is executed in a Vertx context (i.e `Vertx.currentContext()` returns a context) this
context's event loop is used for running the test suite unless the
TestOptions
is set to
false
.
- run(Vertx) - Method in class io.vertx.reactivex.ext.unit.TestSuite
-
Run the testsuite with the default options and the specified
vertx
instance.
The test suite will be executed on the event loop provided by the
vertx
argument.
- run(Vertx, TestOptions) - Method in class io.vertx.reactivex.ext.unit.TestSuite
-
Run the testsuite with the specified
options
and the specified
vertx
instance.
The test suite will be executed on the event loop provided by the
vertx
argument when
TestOptions
is not set to
false
.
- runCommand(String, JsonObject, Handler<AsyncResult<JsonObject>>) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Run an arbitrary MongoDB command.
- runCommand(String, JsonObject, Handler<AsyncResult<JsonObject>>) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- runOnContext(Handler<Void>) - Method in class io.vertx.reactivex.core.Context
-
Run the specified action asynchronously on the same context, some time after the current execution has completed.
- runOnContext(Handler<Void>) - Method in class io.vertx.reactivex.core.Vertx
-
Puts the handler on the event queue for the current context so it will be run asynchronously ASAP after all
preceeding events have been handled.
- rxAddAndGet(long) - Method in class io.vertx.reactivex.core.shareddata.Counter
-
Add the value to the counter atomically and return the new count
- rxAgentInfo() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Returns the configuration and member information of the local agent
- rxAgentInfo() - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxAll() - Method in class io.vertx.reactivex.cassandra.ResultSet
-
- rxAppend(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxAppend(String, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Append a value to a key
- rxAppend(String, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Append a value to a key
- rxAsking() - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- 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(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxAuth(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Authenticate to the server
- rxAuth(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Authenticate to the server
- rxAuthenticate(JsonObject) - Method in class io.vertx.reactivex.ext.auth.AuthProvider
-
Authenticate a user.
- rxAuthorize(User) - Method in class io.vertx.reactivex.ext.web.handler.BasicAuthHandler
-
Authorizes the given user against all added authorities.
- rxAuthorize(User) - Method in class io.vertx.reactivex.ext.web.handler.ChainAuthHandler
-
Authorizes the given user against all added authorities.
- rxAuthorize(User) - Method in class io.vertx.reactivex.ext.web.handler.DigestAuthHandler
-
Authorizes the given user against all added authorities.
- rxAuthorize(User) - Method in class io.vertx.reactivex.ext.web.handler.JWTAuthHandler
-
Authorizes the given user against all added authorities.
- rxAuthorize(User) - Method in class io.vertx.reactivex.ext.web.handler.OAuth2AuthHandler
-
Authorizes the given user against all added authorities.
- rxAuthorize(User) - Method in class io.vertx.reactivex.ext.web.handler.RedirectAuthHandler
-
Authorizes the given user against all added authorities.
- rxBasicAck(long, boolean) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
-
Acknowledge one or several received messages.
- rxBasicCancel(String) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
-
Deprecated.
- rxBasicConsume(String, String) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
-
Deprecated.
- rxBasicConsume(String, String, boolean) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
-
Deprecated.
- 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, JsonObject) - 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<String>) - Method in class io.vertx.reactivex.ext.sql.SQLConnection
-
Batch simple SQL strings and execute the batch where the async result contains a array of Integers.
- 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.
- rxBatchCallableWithParams(String, List<JsonArray>, List<JsonArray>) - Method in class io.vertx.reactivex.ext.sql.SQLConnection
-
Batch a callable statement with all entries from the args list.
- rxBatchWithParams(String, List<JsonArray>) - Method in class io.vertx.reactivex.ext.sql.SQLConnection
-
Batch a prepared statement with all entries from the args list.
- rxBegin() - Method in class io.vertx.reactivex.sqlclient.Pool
-
Borrow a connection from the pool and begin a transaction, the underlying connection will be returned
to the pool when the transaction ends.
- rxBeginningOffsets(TopicPartition) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
-
Get the first offset for the given partitions.
- rxBgrewriteaof() - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxBgrewriteaof() - Method in class io.vertx.reactivex.redis.RedisClient
-
Asynchronously rewrite the append-only file
- rxBgrewriteaof() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Asynchronously rewrite the append-only file
- rxBgsave(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxBgsave() - Method in class io.vertx.reactivex.redis.RedisClient
-
Asynchronously save the dataset to disk
- rxBgsave() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Asynchronously save the dataset to disk
- rxBitcount(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxBitcount(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Count set bits in a string
- rxBitcount(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Count set bits in a string
- rxBitcountRange(String, long, long) - Method in class io.vertx.reactivex.redis.RedisClient
-
Count set bits in a string
- rxBitcountRange(String, long, long) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Count set bits in a string
- rxBitfield(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxBitfield(String, BitFieldOptions) - Method in class io.vertx.reactivex.redis.RedisClient
-
Perform arbitrary bitfield integer operations on strings.
- rxBitfieldWithOverflow(String, BitFieldOptions, BitFieldOverflowOptions) - Method in class io.vertx.reactivex.redis.RedisClient
-
Perform arbitrary bitfield integer operations on strings.
- rxBitop(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxBitop(BitOperation, String, List<String>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Perform bitwise operations between strings
- rxBitop(BitOperation, String, List<String>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Perform bitwise operations between strings
- rxBitpos(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxBitpos(String, int) - Method in class io.vertx.reactivex.redis.RedisClient
-
Find first bit set or clear in a string
- rxBitpos(String, int) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Find first bit set or clear in a string
- rxBitposFrom(String, int, int) - Method in class io.vertx.reactivex.redis.RedisClient
-
Find first bit set or clear in a string
See also bitposRange() method, which takes start, and stop offset.
- rxBitposFrom(String, int, int) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Find first bit set or clear in a string
- rxBitposRange(String, int, int, int) - Method in class io.vertx.reactivex.redis.RedisClient
-
Find first bit set or clear in a string
Note: when both start, and stop offsets are specified,
behaviour is slightly different than if only start is specified
- rxBitposRange(String, int, int, int) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Find first bit set or clear in a string
- 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
-
- rxBlpop(String, int) - Method in class io.vertx.reactivex.redis.RedisClient
-
Remove and get the first element in a list, or block until one is available
- rxBlpop(String, int) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Remove and get the first element in a list, or block until one is available
- rxBlpopMany(List<String>, int) - Method in class io.vertx.reactivex.redis.RedisClient
-
Remove and get the first element in any of the lists, or block until one is available
- rxBlpopMany(List<String>, int) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Remove and get the first element in any of the lists, or block until one is available
- rxBrpop(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxBrpop(String, int) - Method in class io.vertx.reactivex.redis.RedisClient
-
Remove and get the last element in a list, or block until one is available
- rxBrpop(String, int) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
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
-
- rxBrpoplpush(String, String, int) - Method in class io.vertx.reactivex.redis.RedisClient
-
Pop a value from a list, push it to another list and return it; or block until one is available
- rxBrpoplpush(String, String, int) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Pop a value from a list, push it to another list and return it; or block until one is available
- rxBrpopMany(List<String>, int) - Method in class io.vertx.reactivex.redis.RedisClient
-
Remove and get the last element in any of the lists, or block until one is available
- rxBrpopMany(List<String>, int) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Remove and get the last element in any of the lists, or block until one is available
- rxBulkWrite(String, List<BulkOperation>) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Execute a bulk operation.
- rxBulkWrite(String, List<BulkOperation>) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- rxBulkWriteWithOptions(String, List<BulkOperation>, BulkWriteOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Execute a bulk operation with the specified write options.
- rxBulkWriteWithOptions(String, List<BulkOperation>, BulkWriteOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- rxBzpopmax(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxBzpopmin(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxCall(String) - Method in class io.vertx.reactivex.ext.sql.SQLClient
-
Calls the given SQL PROCEDURE
which returns the result from the procedure.
- rxCall(String) - Method in class io.vertx.reactivex.ext.sql.SQLConnection
-
Calls the given SQL PROCEDURE
which returns the result from the procedure.
- rxCallWithParams(String, JsonArray, JsonArray) - Method in class io.vertx.reactivex.ext.sql.SQLClient
-
Calls the given SQL PROCEDURE
which returns the result from the procedure.
- rxCallWithParams(String, JsonArray, JsonArray) - Method in class io.vertx.reactivex.ext.sql.SQLConnection
-
Calls the given SQL PROCEDURE
which returns the result from the procedure.
- rxCancel() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQConsumer
-
Stop message consumption from a queue.
- rxCatalogDatacenters() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Return all the datacenters that are known by the Consul server
- rxCatalogDatacenters() - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxCatalogNodes() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Returns the nodes registered in a datacenter
- rxCatalogNodes() - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxCatalogNodeServices(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Returns the node's registered services
- rxCatalogNodeServices(String) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxCatalogNodeServicesWithOptions(String, BlockingQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
- rxCatalogNodeServicesWithOptions(String, BlockingQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxCatalogNodesWithOptions(NodeQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Returns the nodes registered in a datacenter
- rxCatalogNodesWithOptions(NodeQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxCatalogServiceNodes(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Returns the nodes providing a service
- rxCatalogServiceNodes(String) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxCatalogServiceNodesWithOptions(String, ServiceQueryOptions) - 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.ConsulService
-
- rxCatalogServices() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Returns the services registered in a datacenter
- rxCatalogServices() - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxCatalogServicesWithOptions(BlockingQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
- rxCatalogServicesWithOptions(BlockingQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- 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.
- 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.
- rxCkquorum(String) - Method in class io.vertx.reactivex.redis.sentinel.RedisSentinel
-
Check if the current Sentinel configuration is able to reach the quorum needed to failover a master,
and the majority needed to authorize the failover.
- 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
-
- rxClientGetname() - Method in class io.vertx.reactivex.redis.RedisClient
-
Get the current connection name
- rxClientGetname() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get the current connection name
- rxClientKill(KillFilter) - Method in class io.vertx.reactivex.redis.RedisClient
-
Kill the connection of a client
- rxClientKill(KillFilter) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Kill the connection of a client
- rxClientList() - Method in class io.vertx.reactivex.redis.RedisClient
-
Get the list of client connections
- rxClientList() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get the list of client connections
- rxClientPause(long) - Method in class io.vertx.reactivex.redis.RedisClient
-
Stop processing commands from clients for some time
- rxClientPause(long) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Stop processing commands from clients for some time
- rxClientReply(ClientReplyOptions) - Method in class io.vertx.reactivex.redis.RedisClient
-
Instruct the server whether to reply to commands.
- rxClientSetname(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set the current connection name
- rxClientSetname(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Set the current connection name
- rxCloneAclToken(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Clone Acl token
- rxCloneAclToken(String) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- 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.
- 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.amqpbridge.AmqpBridge
-
Shuts the bridge down, closing the underlying connection.
- rxClose() - Method in class io.vertx.reactivex.cassandra.CassandraClient
-
Closes this client.
- 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.eventbus.MessageProducer
-
- rxClose() - Method in class io.vertx.reactivex.core.file.AsyncFile
-
Close the file.
- rxClose() - Method in class io.vertx.reactivex.core.http.HttpServer
-
Like
HttpServer.close()
but supplying a handler that will be called when the server is actually closed (or has failed).
- rxClose() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
-
- rxClose(short) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
-
- rxClose(short, String) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
-
Same as but with an handler
called when the operation completes
- rxClose() - Method in class io.vertx.reactivex.core.http.WebSocket
-
- rxClose(short) - Method in class io.vertx.reactivex.core.http.WebSocket
-
- rxClose(short, String) - Method in class io.vertx.reactivex.core.http.WebSocket
-
Same as but with an handler
called when the operation completes
- rxClose() - Method in class io.vertx.reactivex.core.net.NetServer
-
Like
NetServer.close()
but supplying a handler that will be notified when close is complete.
- rxClose() - Method in class io.vertx.reactivex.core.net.NetSocket
-
Close the NetSocket and notify the handler
when the operation completes.
- rxClose() - Method in class io.vertx.reactivex.core.Vertx
-
Like
Vertx.close()
but the completionHandler will be called when the close is complete
- rxClose() - Method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.TcpEventBusBridge
-
Close the current socket.
- rxClose() - Method in class io.vertx.reactivex.ext.shell.ShellServer
-
Close the shell server, this is an asynchronous close.
- rxClose() - Method in class io.vertx.reactivex.ext.shell.term.TermServer
-
Like
TermServer.close()
but supplying a handler that will be notified when close is complete.
- rxClose() - Method in class io.vertx.reactivex.ext.sql.SQLClient
-
Close the client and release all resources.
- rxClose() - Method in class io.vertx.reactivex.ext.sql.SQLConnection
-
Closes the connection.
- rxClose() - Method in class io.vertx.reactivex.ext.sql.SQLRowStream
-
Closes the stream/underlying cursor(s).
- rxClose() - Method in class io.vertx.reactivex.ext.stomp.StompServer
-
Closes the server.
- rxClose() - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
-
Close the admin client
- rxClose(long) - 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(long) - 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 supplying an handler that will be called when the server is actually closed (or has failed).
- rxClose() - Method in class io.vertx.reactivex.redis.RedisClient
-
Close the client - when it is fully closed the handler will be called.
- rxClose() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Close the client - when it is fully closed the handler will be called.
- rxClose() - Method in class io.vertx.reactivex.redis.sentinel.RedisSentinel
-
Close the client - when it is fully closed the handler will be called.
- rxClose() - Method in class io.vertx.reactivex.sqlclient.Cursor
-
Like
Cursor.close()
but with a
completionHandler
called when the cursor has been released.
- rxClose() - Method in class io.vertx.reactivex.sqlclient.PreparedStatement
-
- rxClose() - Method in class io.vertx.reactivex.sqlclient.RowStream
-
Close the stream and release the resources.
- rxCluster(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxClusterAddslots(List<Long>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Assign new hash slots to receiving node.
- rxClusterAddslots(List<String>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Assign new hash slots to receiving node.
- rxClusterCountFailureReports(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Return the number of failure reports active for a given node.
- rxClusterCountFailureReports(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return the number of failure reports active for a given node.
- rxClusterCountkeysinslot(long) - Method in class io.vertx.reactivex.redis.RedisClient
-
Return the number of local keys in the specified hash slot.
- rxClusterCountkeysinslot(long) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return the number of local keys in the specified hash slot.
- rxClusterDelslots(long) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set hash slots as unbound in receiving node.
- rxClusterDelslots(long) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Set hash slots as unbound in receiving node.
- rxClusterDelslotsMany(List<Long>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set hash slots as unbound in receiving node.
- rxClusterDelslotsMany(List<String>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Set hash slots as unbound in receiving node.
- rxClusteredVertx(VertxOptions) - Static method in class io.vertx.reactivex.core.Vertx
-
Creates a clustered instance using the specified options.
- rxClusterFailover() - Method in class io.vertx.reactivex.redis.RedisClient
-
Forces a slave to perform a manual failover of its master.
- rxClusterFailover() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Forces a slave to perform a manual failover of its master.
- rxClusterFailOverWithOptions(FailoverOptions) - Method in class io.vertx.reactivex.redis.RedisClient
-
Forces a slave to perform a manual failover of its master.
- rxClusterFailOverWithOptions(FailoverOptions) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Forces a slave to perform a manual failover of its master.
- rxClusterForget(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Remove a node from the nodes table.
- rxClusterForget(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Remove a node from the nodes table.
- rxClusterGetkeysinslot(long, long) - Method in class io.vertx.reactivex.redis.RedisClient
-
Return local key names in the specified hash slot.
- rxClusterGetkeysinslot(long, long) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return local key names in the specified hash slot.
- rxClusterInfo() - Method in class io.vertx.reactivex.redis.RedisClient
-
Provides info about Redis Cluster node state.
- rxClusterInfo() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Provides info about Redis Cluster node state.
- rxClusterKeyslot(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Returns the hash slot of the specified key.
- rxClusterKeyslot(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Returns the hash slot of the specified key.
- rxClusterMeet(String, long) - Method in class io.vertx.reactivex.redis.RedisClient
-
Force a node cluster to handshake with another node.
- rxClusterMeet(String, long) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Force a node cluster to handshake with another node.
- rxClusterNodes() - Method in class io.vertx.reactivex.redis.RedisClient
-
Get Cluster config for the node.
- rxClusterNodes() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get Cluster config for the node.
- rxClusterReplicate(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Reconfigure a node as a slave of the specified master node.
- rxClusterReplicate(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Reconfigure a node as a slave of the specified master node.
- rxClusterReset() - Method in class io.vertx.reactivex.redis.RedisClient
-
Reset a Redis Cluster node.
- rxClusterReset() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Reset a Redis Cluster node.
- rxClusterResetWithOptions(ResetOptions) - Method in class io.vertx.reactivex.redis.RedisClient
-
Reset a Redis Cluster node.
- rxClusterResetWithOptions(ResetOptions) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Reset a Redis Cluster node.
- rxClusterSaveconfig() - Method in class io.vertx.reactivex.redis.RedisClient
-
Forces the node to save cluster state on disk.
- rxClusterSaveconfig() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Forces the node to save cluster state on disk.
- rxClusterSetConfigEpoch(long) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set the configuration epoch in a new node.
- rxClusterSetConfigEpoch(long) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Set the configuration epoch in a new node.
- rxClusterSetslot(long, SlotCmd) - Method in class io.vertx.reactivex.redis.RedisClient
-
Bind an hash slot to a specific node.
- rxClusterSetslot(long, SlotCmd) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Bind an hash slot to a specific node.
- rxClusterSetslotWithNode(long, SlotCmd, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Bind an hash slot to a specific node.
- rxClusterSetslotWithNode(long, SlotCmd, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Bind an hash slot to a specific node.
- rxClusterSlaves(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
List slave nodes of the specified master node.
- rxClusterSlaves(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
List slave nodes of the specified master node.
- rxClusterSlots() - Method in class io.vertx.reactivex.redis.RedisClient
-
Get array of Cluster slot to node mappings
- rxClusterSlots() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get array of Cluster slot to node mappings
- rxCommand() - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxCommand() - Method in class io.vertx.reactivex.redis.RedisClient
-
Get array of Redis command details
- rxCommand() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get array of Redis command details
- rxCommandCount() - Method in class io.vertx.reactivex.redis.RedisClient
-
Get total number of Redis commands
- rxCommandCount() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get total number of Redis commands
- rxCommandGetkeys() - Method in class io.vertx.reactivex.redis.RedisClient
-
Extract keys given a full Redis command
- rxCommandGetkeys() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Extract keys given a full Redis command
- rxCommandInfo(List<String>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get array of specific Redis command details
- rxCommandInfo(List<String>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get array of specific Redis command details
- rxCommit() - Method in class io.vertx.reactivex.ext.sql.SQLConnection
-
Commits all changes made since the previous commit/rollback.
- 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
-
- 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).
- 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.
- rxCompletionHandler() - Method in class io.vertx.reactivex.core.eventbus.MessageConsumer
-
Optional method which can be called to indicate when the registration has been propagated across the cluster.
- rxConfig(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxConfigGet(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get the value of a configuration parameter
- rxConfigGet(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get the value of a configuration parameter
- rxConfigResetstat() - Method in class io.vertx.reactivex.redis.RedisClient
-
Reset the stats returned by INFO
- rxConfigResetstat() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Reset the stats returned by INFO
- rxConfigRewrite() - Method in class io.vertx.reactivex.redis.RedisClient
-
Rewrite the configuration file with the in memory configuration
- rxConfigRewrite() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Rewrite the configuration file with the in memory configuration
- rxConfigSet(String, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set a configuration parameter to the given value
- rxConfigSet(String, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Set a configuration parameter to the given value
- 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(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, String) - Method in class io.vertx.reactivex.core.net.NetClient
-
Open a connection to a server at the specific port
and host
.
- 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, DB2ConnectOptions) - Static method in class io.vertx.reactivex.db2client.DB2Connection
-
Create a connection to DB2 server with the given connectOptions
.
- rxConnect(Vertx, String) - Static method in class io.vertx.reactivex.db2client.DB2Connection
-
- rxConnect(int, String) - Method in class io.vertx.reactivex.ext.stomp.StompClient
-
Connects to the server.
- rxConnect(NetClient) - Method in class io.vertx.reactivex.ext.stomp.StompClient
-
Connects to the server.
- rxConnect(int, String, NetClient) - Method in class io.vertx.reactivex.ext.stomp.StompClient
-
Connects 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(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.mqtt.MqttClient
-
Connects to an MQTT server calling connectHandler after connection
- rxConnect(Vertx, MySQLConnectOptions) - Static method in class io.vertx.reactivex.mysqlclient.MySQLConnection
-
Create a connection to MySQL server with the given connectOptions
.
- rxConnect(Vertx, String) - Static method in class io.vertx.reactivex.mysqlclient.MySQLConnection
-
- 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) - Static method in class io.vertx.reactivex.pgclient.PgConnection
-
- rxConnect(Vertx, String) - Static method in class io.vertx.reactivex.pgclient.PgConnection
-
- 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.
- rxCoordinateDatacenters() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Returns the WAN network coordinates for all Consul servers, organized by DCs
- rxCoordinateDatacenters() - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxCoordinateNodes() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Returns the LAN network coordinates for all nodes in a given DC
- rxCoordinateNodes() - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxCoordinateNodesWithOptions(BlockingQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
- rxCoordinateNodesWithOptions(BlockingQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- 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.
- 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.
- rxCount(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- rxCreate(Vertx, String) - Static method in class io.vertx.reactivex.ext.web.api.contract.openapi3.OpenAPI3RouterFactory
-
Create a new OpenAPI3RouterFactory
- rxCreate(Vertx, String, List<JsonObject>) - Static method in class io.vertx.reactivex.ext.web.api.contract.openapi3.OpenAPI3RouterFactory
-
Create a new OpenAPI3RouterFactory
- rxCreateAclToken(AclToken) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Create new Acl token
- rxCreateAclToken(AclToken) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxCreateAnonymousSender() - Method in class io.vertx.reactivex.amqp.AmqpConnection
-
Creates an anonymous sender.
- rxCreateCollection(String) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Create a new collection
- rxCreateCollection(String) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- 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.
- rxCreateIndex(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Creates an index.
- rxCreateIndex(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- rxCreateIndexWithOptions(String, JsonObject, IndexOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Creates an index.
- rxCreateIndexWithOptions(String, JsonObject, IndexOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- rxCreatePreparedQuery(PreparedQueryDefinition) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
- rxCreatePreparedQuery(PreparedQueryDefinition) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxCreateReceiver(String) - Method in class io.vertx.reactivex.amqp.AmqpClient
-
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) - 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.AmqpConnection
-
Creates a receiver used to consumer messages from the given address.
- rxCreateSender(String) - 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.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.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
- rxCreateSession() - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxCreateSessionWithOptions(SessionOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Initialize a new session
- rxCreateSessionWithOptions(SessionOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- 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
- rxDbsize() - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxDbsize() - Method in class io.vertx.reactivex.redis.RedisClient
-
Return the number of keys in the selected database
- rxDbsize() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
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
-
- rxDebugObject(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get debugging information about a key
- rxDebugObject(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get debugging information about a key
- rxDebugSegfault() - Method in class io.vertx.reactivex.redis.RedisClient
-
Make the server crash
- rxDebugSegfault() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Make the server crash
- rxDecodeToken(String) - Method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
-
Deprecated.
- rxDecr(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxDecr(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Decrement the integer value of a key by one
- rxDecr(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Decrement the integer value of a key by one
- rxDecrby(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxDecrby(String, long) - Method in class io.vertx.reactivex.redis.RedisClient
-
Decrement the integer value of a key by the given number
- rxDecrby(String, long) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
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
-
- rxDel(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Delete a key
- rxDel(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Delete a key
- rxDelete(List<Object>) - Method in class io.vertx.reactivex.cassandra.Mapper
-
Asynchronous delete method based on the column values of the primary key.
- 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.web.sstore.SessionStore
-
Delete the session with the specified ID.
- 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.
- rxDeletePreparedQuery(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Deletes an existing prepared query
- rxDeletePreparedQuery(String) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxDeleteRecursive(String, boolean) - 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
- rxDeleteValue(String) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxDeleteValues(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Removes all the key/value pair that corresponding to the specified key prefix
- rxDeleteValues(String) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxDelMany(List<String>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Delete many keys
- rxDelMany(List<String>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Delete many keys
- rxDeployVerticle(String) - Method in class io.vertx.reactivex.core.Vertx
-
- rxDeployVerticle(String, DeploymentOptions) - Method in class io.vertx.reactivex.core.Vertx
-
- rxDeployVerticle(Verticle) - Method in class io.vertx.reactivex.core.Vertx
-
- rxDeployVerticle(Verticle, DeploymentOptions) - Method in class io.vertx.reactivex.core.Vertx
-
- rxDeployVerticle(Supplier<Verticle>, DeploymentOptions) - Method in class io.vertx.reactivex.core.Vertx
-
- rxDeregisterCheck(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Remove a check from the local agent.
- rxDeregisterCheck(String) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxDeregisterService(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Remove a service from the local agent.
- rxDeregisterService(String) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxDescribeCluster() - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
-
Describe the nodes in the cluster with the default options
- rxDestroyAclToken(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Destroy Acl token
- rxDestroyAclToken(String) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxDestroySession(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Destroys the given session
- rxDestroySession(String) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxDiscard() - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxDiscard() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Discard all commands issued after MULTI
- rxDisconnect() - Method in class io.vertx.reactivex.mqtt.MqttClient
-
Disconnects from the MQTT server calling disconnectHandler after disconnection
- rxDiscover(Vertx, OAuth2ClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.AzureADAuth
-
Create a OAuth2Auth provider for OpenID Connect Discovery.
- rxDiscover(Vertx, OAuth2ClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.GoogleAuth
-
Create a OAuth2Auth provider for OpenID Connect Discovery.
- rxDiscover(Vertx, OAuth2ClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.KeycloakAuth
-
Create a OAuth2Auth provider for OpenID Connect Discovery.
- rxDiscover(Vertx, OAuth2ClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.OpenIDConnectAuth
-
Create a OAuth2Auth provider for OpenID Connect Discovery.
- rxDiscover(Vertx, OAuth2ClientOptions) - Static method in class io.vertx.reactivex.ext.auth.oauth2.providers.SalesforceAuth
-
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) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- 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) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- rxDropCollection(String) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Drop a collection
- rxDropCollection(String) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- rxDropIndex(String, String) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Drops the index given its name.
- rxDropIndex(String, String) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- rxDump(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxDump(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Return a serialized version of the value stored at the specified key.
- rxDump(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return a serialized version of the value stored at the specified key.
- rxEcho(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxEcho(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Echo the given string
- rxEcho(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Echo the given string
- rxEnd() - Method in class io.vertx.reactivex.amqp.AmqpSender
-
- rxEnd(AmqpMessage) - Method in class io.vertx.reactivex.amqp.AmqpSender
-
Same as but with an handler
called when the operation completes
- rxEnd(T) - Method in class io.vertx.reactivex.core.eventbus.MessageProducer
-
Same as but with an handler
called when the operation completes
- rxEnd() - Method in class io.vertx.reactivex.core.eventbus.MessageProducer
-
- rxEnd(Buffer) - Method in class io.vertx.reactivex.core.file.AsyncFile
-
Same as but with an handler
called when the operation completes
- rxEnd() - Method in class io.vertx.reactivex.core.file.AsyncFile
-
- rxEnd(String) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
-
- rxEnd(String, String) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
-
- rxEnd(Buffer) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
-
- rxEnd() - Method in class io.vertx.reactivex.core.http.HttpClientRequest
-
- rxEnd() - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
- rxEnd(String) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
- rxEnd(String, String) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
- rxEnd(Buffer) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
- rxEnd(Buffer) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
-
Same as but with an handler
called when the operation completes
- rxEnd() - Method in class io.vertx.reactivex.core.http.ServerWebSocket
-
- rxEnd(Buffer) - Method in class io.vertx.reactivex.core.http.WebSocket
-
Same as but with an handler
called when the operation completes
- rxEnd() - Method in class io.vertx.reactivex.core.http.WebSocket
-
- rxEnd(Buffer) - Method in class io.vertx.reactivex.core.net.NetSocket
-
Same as but with an handler
called when the operation completes
- rxEnd() - Method in class io.vertx.reactivex.core.net.NetSocket
-
- rxEnd() - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
-
- rxEnd(Buffer) - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
-
Same as but with an handler
called when the operation completes
- rxEnd() - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
-
- rxEnd(KafkaProducerRecord<K, V>) - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
-
Same as but with an handler
called when the operation completes
- 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
-
- rxEval(String, List<String>, List<String>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Execute a Lua script server side.
- rxEval(String, List<String>, List<String>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Execute a Lua script server side.
- rxEvalScript(Script, List<String>, List<String>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Execute a Lua script server side.
- rxEvalsha(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxEvalsha(String, List<String>, List<String>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Execute a Lua script server side.
- rxEvalsha(String, List<String>, List<String>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Execute a 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
-
- rxExec() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Execute all commands issued after MULTI
- rxExecute(String) - Method in class io.vertx.reactivex.cassandra.CassandraClient
-
Execute the query and provide a handler for consuming results.
- rxExecute(Statement) - Method in class io.vertx.reactivex.cassandra.CassandraClient
-
Execute the statement and provide a handler for consuming results.
- rxExecute(Handler<Promise<T>>) - Method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
-
- rxExecute(String) - Method in class io.vertx.reactivex.ext.sql.SQLConnection
-
Executes the given SQL statement
- rxExecute() - Method in class io.vertx.reactivex.sqlclient.PreparedQuery
-
Execute the query.
- rxExecute(Tuple) - Method in class io.vertx.reactivex.sqlclient.PreparedQuery
-
Execute the query.
- rxExecute() - Method in class io.vertx.reactivex.sqlclient.Query
-
Execute the query.
- rxExecuteBatch(List<Tuple>) - Method in class io.vertx.reactivex.sqlclient.PreparedQuery
-
Execute the query with a batch of tuples.
- rxExecuteBlocking(Handler<Promise<T>>, boolean) - Method in class io.vertx.reactivex.core.Context
-
Safely execute some blocking code.
- rxExecuteBlocking(Handler<Promise<T>>) - Method in class io.vertx.reactivex.core.Context
-
- rxExecuteBlocking(Handler<Promise<T>>, boolean) - Method in class io.vertx.reactivex.core.Vertx
-
Safely execute some blocking code.
- rxExecuteBlocking(Handler<Promise<T>>) - Method in class io.vertx.reactivex.core.Vertx
-
- rxExecuteBlocking(Handler<Promise<T>>, boolean) - Method in class io.vertx.reactivex.core.WorkerExecutor
-
Safely execute some blocking code.
- rxExecuteBlocking(Handler<Promise<T>>) - Method in class io.vertx.reactivex.core.WorkerExecutor
-
- rxExecuteCommand(Handler<Promise<T>>) - Method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
-
Deprecated.
- rxExecuteCommandWithFallback(Handler<Promise<T>>, Function<Throwable, T>) - Method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
-
Deprecated.
- rxExecutePreparedQuery(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Executes an existing prepared query.
- rxExecutePreparedQuery(String) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxExecutePreparedQueryWithOptions(String, PreparedQueryExecuteOptions) - 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.ConsulService
-
- rxExecuteWithFallback(Handler<Promise<T>>, Function<Throwable, T>) - Method in class io.vertx.reactivex.circuitbreaker.CircuitBreaker
-
- rxExecuteWithFullFetch(String) - Method in class io.vertx.reactivex.cassandra.CassandraClient
-
Execute the query and provide a handler for consuming results.
- rxExecuteWithFullFetch(Statement) - 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
-
- rxExists(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Determine if a key exists
- rxExists(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Determine if a key exists
- rxExistsMany(List<String>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Determine if one or many keys exist
- rxExistsMany(List<String>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Determine if one or many keys exist
- rxExpire(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxExpire(String, long) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set a key's time to live in seconds
- rxExpire(String, int) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Set a key's time to live in seconds
- rxExpireat(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxExpireat(String, long) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set the expiration for a key as a UNIX timestamp
- rxExpireat(String, long) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Set the expiration for a key as a UNIX timestamp
- rxFailCheck(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Set status of the check to "critical".
- rxFailCheck(String) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxFailCheckWithNote(String, 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.ConsulService
-
- rxFailover(String) - Method in class io.vertx.reactivex.redis.sentinel.RedisSentinel
-
Force a failover as if the master was not reachable, and without asking for agreement to other Sentinels
(however a new version of the configuration will be published so that the other Sentinels
will update their configurations)
- rxFetch(String) - Method in class io.vertx.reactivex.ext.auth.oauth2.AccessToken
-
Fetches a JSON resource using this Access Token.
- rxFetch(HttpMethod, String, JsonObject, Buffer) - Method in class io.vertx.reactivex.ext.auth.oauth2.AccessToken
-
Fetches a JSON resource using this Access Token.
- rxFetchMoreResults() - 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, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- rxFindOne(String, JsonObject, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Find a single matching document in the specified collection
- rxFindOne(String, JsonObject, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- rxFindOneAndDelete(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Find a single matching document in the specified collection and delete it.
- rxFindOneAndDelete(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- 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.
- rxFindOneAndDeleteWithOptions(String, JsonObject, FindOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- 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.
- rxFindOneAndReplace(String, JsonObject, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- 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.
- rxFindOneAndReplaceWithOptions(String, JsonObject, JsonObject, FindOptions, UpdateOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- 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.
- rxFindOneAndUpdate(String, JsonObject, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- 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.
- rxFindOneAndUpdateWithOptions(String, JsonObject, JsonObject, FindOptions, UpdateOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- rxFindWithOptions(String, JsonObject, FindOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Find matching documents in the specified collection, specifying options
- rxFindWithOptions(String, JsonObject, FindOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- rxFireEvent(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Fires a new user event
- rxFireEvent(String) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxFireEventWithOptions(String, EventOptions) - 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.ConsulService
-
- rxFlush() - Method in class io.vertx.reactivex.core.file.AsyncFile
-
Same as
AsyncFile.flush()
but the handler will be called when the flush is complete or if an error occurs
- 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.
- rxFlushall(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxFlushall() - Method in class io.vertx.reactivex.redis.RedisClient
-
Remove all keys from all databases
- rxFlushall() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Remove all keys from all databases
- rxFlushConfig() - Method in class io.vertx.reactivex.redis.sentinel.RedisSentinel
-
Force Sentinel to rewrite its configuration on disk, including the current Sentinel state.
- rxFlushdb(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxFlushdb() - Method in class io.vertx.reactivex.redis.RedisClient
-
Remove all keys from the current database
- rxFlushdb() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Remove all keys from the current database
- rxFsProps(String) - Method in class io.vertx.reactivex.core.file.FileSystem
-
Returns properties of the file-system being used by the specified path
, asynchronously.
- rxGeoadd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxGeoadd(String, double, double, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Add one or more geospatial items in the geospatial index represented using a sorted set.
- rxGeoadd(String, double, double, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Add one or more geospatial items in the geospatial index represented using a sorted set.
- rxGeoaddMany(String, List<GeoMember>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Add one or more geospatial items in the geospatial index represented using a sorted set.
- rxGeoaddMany(String, List<GeoMember>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
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
-
- rxGeodist(String, String, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Return the distance between two members in the geospatial index represented by the sorted set.
- rxGeodist(String, String, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return the distance between two members in the geospatial index represented by the sorted set.
- rxGeodistWithUnit(String, String, String, GeoUnit) - Method in class io.vertx.reactivex.redis.RedisClient
-
Return the distance between two members in the geospatial index represented by the sorted set.
- rxGeodistWithUnit(String, String, String, GeoUnit) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return the distance between two members in the geospatial index represented by the sorted set.
- rxGeohash(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxGeohash(String, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Return valid Geohash strings representing the position of one or more elements in a sorted set value representing
a geospatial index (where elements were added using GEOADD).
- rxGeohash(String, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return valid Geohash strings representing the position of one or more elements in a sorted set value representing
a geospatial index (where elements were added using GEOADD).
- rxGeohashMany(String, List<String>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Return valid Geohash strings representing the position of one or more elements in a sorted set value representing
a geospatial index (where elements were added using GEOADD).
- rxGeohashMany(String, List<String>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return valid Geohash strings representing the position of one or more elements in a sorted set value representing
a geospatial index (where elements were added using GEOADD).
- rxGeopos(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxGeopos(String, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Return the positions (longitude,latitude) of all the specified members of the geospatial index represented by the
sorted set at key.
- rxGeopos(String, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return the positions (longitude,latitude) of all the specified members of the geospatial index represented by the
sorted set at key.
- rxGeoposMany(String, List<String>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Return the positions (longitude,latitude) of all the specified members of the geospatial index represented by the
sorted set at key.
- rxGeoposMany(String, List<String>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return the positions (longitude,latitude) of all the specified members of the geospatial index represented by the
sorted set at key.
- rxGeoradius(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxGeoradius(String, double, double, double, GeoUnit) - Method in class io.vertx.reactivex.redis.RedisClient
-
Return the members of a sorted set populated with geospatial information using GEOADD, which are within the borders
of the area specified with the center location and the maximum distance from the center (the radius).
- rxGeoradius(String, double, double, double, GeoUnit) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return the members of a sorted set populated with geospatial information using GEOADD, which are within the borders
of the area specified with the center location and the maximum distance from the center (the radius).
- rxGeoradiusbymember(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxGeoradiusbymember(String, String, double, GeoUnit) - Method in class io.vertx.reactivex.redis.RedisClient
-
This command is exactly like GEORADIUS with the sole difference that instead of taking, as the center of the area
to query, a longitude and latitude value, it takes the name of a member already existing inside the geospatial
index represented by the sorted set.
- rxGeoradiusbymember(String, String, double, GeoUnit) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
This command is exactly like GEORADIUS with the sole difference that instead of taking, as the center of the area
to query, a longitude and latitude value, it takes the name of a member already existing inside the geospatial
index represented by the sorted set.
- rxGeoradiusbymemberRo(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxGeoradiusbymemberWithOptions(String, String, double, GeoUnit, GeoRadiusOptions) - Method in class io.vertx.reactivex.redis.RedisClient
-
This command is exactly like GEORADIUS with the sole difference that instead of taking, as the center of the area
to query, a longitude and latitude value, it takes the name of a member already existing inside the geospatial
index represented by the sorted set.
- rxGeoradiusbymemberWithOptions(String, String, double, GeoUnit, GeoRadiusOptions) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
This command is exactly like GEORADIUS with the sole difference that instead of taking, as the center of the area
to query, a longitude and latitude value, it takes the name of a member already existing inside the geospatial
index represented by the sorted set.
- rxGeoradiusRo(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxGeoradiusWithOptions(String, double, double, double, GeoUnit, GeoRadiusOptions) - Method in class io.vertx.reactivex.redis.RedisClient
-
Return the members of a sorted set populated with geospatial information using GEOADD, which are within the borders
of the area specified with the center location and the maximum distance from the center (the radius).
- rxGeoradiusWithOptions(String, double, double, double, GeoUnit, GeoRadiusOptions) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return the members of a sorted set populated with geospatial information using GEOADD, which are within the borders
of the area specified with the center location and the maximum distance from the center (the radius).
- rxGet(List<Object>) - Method in class io.vertx.reactivex.cassandra.Mapper
-
Asynchronous get method based on the column values of the primary key.
- rxGet(K) - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
-
Get a value from the map, asynchronously.
- 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
-
- rxGet(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get the value of a key
- rxGet(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get the value of a key
- rxGetAllPreparedQueries() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Returns a list of all prepared queries.
- rxGetAllPreparedQueries() - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- 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.
- rxGetBinary(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get the value of a key - without decoding as utf-8
- rxGetBinary(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get the value of a key - without decoding as utf-8
- rxGetbit(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxGetbit(String, long) - Method in class io.vertx.reactivex.redis.RedisClient
-
Returns the bit value at offset in the string value stored at key
- rxGetbit(String, long) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
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.
- rxGetCollections() - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- 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.ext.sql.SQLClient
-
Returns a connection that can be used to perform SQL operations on.
- 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.
- rxGetInternalStatistics() - Method in class io.vertx.reactivex.mysqlclient.MySQLConnection
-
Send a STATISTICS command to get a human readable string of the server internal status.
- rxGetJDBCClient(ServiceDiscovery, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.JDBCDataSource
-
Convenient method that looks for a JDBC datasource source and provides the configured
JDBCClient
.
- rxGetJDBCClient(ServiceDiscovery, Function<Record, Boolean>) - Static method in class io.vertx.reactivex.servicediscovery.types.JDBCDataSource
-
Convenient method that looks for a JDBC datasource source and provides the configured
JDBCClient
.
- rxGetJDBCClient(ServiceDiscovery, JsonObject, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.JDBCDataSource
-
Convenient method that looks for a JDBC datasource source and provides the configured
JDBCClient
.
- rxGetJDBCClient(ServiceDiscovery, Function<Record, Boolean>, JsonObject) - Static method in class io.vertx.reactivex.servicediscovery.types.JDBCDataSource
-
Convenient method that looks for a JDBC datasource source and provides the configured
JDBCClient
.
- rxGetKeys(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Returns the list of keys that corresponding to the specified key prefix.
- rxGetKeys(String) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxGetKeysWithOptions(String, BlockingQueryOptions) - 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.ConsulService
-
- 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
-
- 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
-
- rxGetMasterAddrByName(String) - Method in class io.vertx.reactivex.redis.sentinel.RedisSentinel
-
Return the ip and port number of the master with that name.
- 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, 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
.
- 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
.
- rxGetPreparedQuery(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Returns an existing prepared query
- rxGetPreparedQuery(String) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxGetrange(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxGetrange(String, long, long) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get a substring of the string stored at a key
- rxGetrange(String, long, long) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
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(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
RedisClient
.
- 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
RedisClient
.
- 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
RedisClient
.
- 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
RedisClient
.
- rxGetset(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxGetset(String, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set the string value of a key and return its old value
- rxGetset(String, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Set the string value of a key and return its old value
- rxGetToken(JsonObject) - Method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
-
Deprecated.
- rxGetTransactionIsolation() - Method in class io.vertx.reactivex.ext.sql.SQLConnection
-
Attempts to return the transaction isolation level for this Connection object to the one given.
- rxGetValue(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Returns key/value pair that corresponding to the specified key.
- rxGetValue(String) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- 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.
- rxGetValues(String) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- 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.
- rxGetValuesWithOptions(String, BlockingQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxGetValueWithOptions(String, BlockingQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Returns key/value pair that corresponding to the specified key.
- rxGetValueWithOptions(String, BlockingQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- 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 .
- rxHandler() - Method in class io.vertx.reactivex.ext.unit.Async
-
Completion handler to receive a completion signal when this completions completes.
- rxHandler() - Method in class io.vertx.reactivex.ext.unit.Completion
-
Completion handler to receive a completion signal when this completions completes.
- rxHandler() - Method in class io.vertx.reactivex.ext.unit.TestCompletion
-
Completion handler to receive a completion signal when this completions completes.
- rxHdel(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxHdel(String, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Delete one or more hash fields
- rxHdel(String, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Delete one or more hash fields
- rxHdelMany(String, List<String>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Delete one or more hash fields
- rxHdelMany(String, List<String>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Delete one or more hash fields
- rxHealthChecks(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Returns the checks associated with the service
- rxHealthChecks(String) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxHealthChecksWithOptions(String, CheckQueryOptions) - 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.ConsulService
-
- rxHealthServiceNodes(String, boolean) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Returns the nodes providing the service.
- rxHealthServiceNodes(String, boolean) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxHealthServiceNodesWithOptions(String, boolean, ServiceQueryOptions) - 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.ConsulService
-
- rxHealthState(HealthState) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Returns the checks in the specified status
- rxHealthState(HealthState) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxHealthStateWithOptions(HealthState, CheckQueryOptions) - 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.ConsulService
-
- RxHelper - Class in io.vertx.reactivex.core
-
- RxHelper() - Constructor for class io.vertx.reactivex.core.RxHelper
-
- rxHexists(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxHexists(String, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Determine if a hash field exists
- rxHexists(String, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Determine if a hash field exists
- rxHget(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxHget(String, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get the value of a hash field
- rxHget(String, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get the value of a hash field
- rxHgetall(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxHgetall(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get all the fields and values in a hash
- rxHgetall(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get all the fields and values in a hash
- rxHincrby(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxHincrby(String, String, long) - Method in class io.vertx.reactivex.redis.RedisClient
-
Increment the integer value of a hash field by the given number
- rxHincrby(String, String, long) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
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
-
- rxHincrbyfloat(String, String, double) - Method in class io.vertx.reactivex.redis.RedisClient
-
Increment the float value of a hash field by the given amount
- rxHincrbyfloat(String, String, double) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Increment the float value of a hash field by the given amount
- rxHkeys(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxHkeys(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get all the fields in a hash
- rxHkeys(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get all the fields in a hash
- rxHlen(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxHlen(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get the number of fields in a hash
- rxHlen(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get the number of fields in a hash
- rxHmget(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxHmget(String, List<String>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get the values of all the given hash fields
- rxHmget(String, List<String>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get the values of all the given hash fields
- rxHmset(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxHmset(String, JsonObject) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set multiple hash fields to multiple values
- rxHmset(String, JsonObject) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Set multiple hash fields to multiple values
- rxHost(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxHscan(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxHscan(String, String, ScanOptions) - Method in class io.vertx.reactivex.redis.RedisClient
-
Incrementally iterate hash fields and associated values
- rxHscan(String, String, ScanOptions) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Incrementally iterate hash fields and associated values
- rxHset(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxHset(String, String, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set the string value of a hash field
- rxHset(String, String, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Set the string value of a hash field
- rxHsetnx(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxHsetnx(String, String, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set the value of a hash field, only if the field does not exist
- rxHsetnx(String, String, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
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
-
- rxHstrlen(String, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get the length of the value of a hash field.
- rxHvals(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxHvals(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get all the values in a hash
- rxHvals(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get all the values in a hash
- rxIncr(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxIncr(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Increment the integer value of a key by one
- rxIncr(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Increment the integer value of a key by one
- rxIncrby(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxIncrby(String, long) - Method in class io.vertx.reactivex.redis.RedisClient
-
Increment the integer value of a key by the given amount
- rxIncrby(String, long) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Increment the integer value of a key by the given amount
- rxIncrbyfloat(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxIncrbyfloat(String, double) - Method in class io.vertx.reactivex.redis.RedisClient
-
Increment the float value of a key by the given amount
- rxIncrbyfloat(String, double) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
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
-
- rxInfo() - Method in class io.vertx.reactivex.redis.RedisClient
-
Get information and statistics about the server
- rxInfo() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get information and statistics about the server
- rxInfoAclToken(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Get info of Acl token
- rxInfoAclToken(String) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxInfoSection(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get information and statistics about the server
- rxInfoSection(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get information and statistics about the server
- rxInfoSession(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Returns the requested session information
- rxInfoSession(String) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxInfoSessionWithOptions(String, BlockingQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
- rxInfoSessionWithOptions(String, BlockingQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxInsert(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Insert a document in the specified collection
- rxInsert(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- rxInsertUser(String, String, List<String>, List<String>) - Method in class io.vertx.reactivex.ext.auth.mongo.MongoAuth
-
Insert a new user into mongo in the convenient way
- 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
- rxInsertWithOptions(String, JsonObject, WriteOption) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- rxIntrospect() - Method in class io.vertx.reactivex.ext.auth.oauth2.AccessToken
-
Introspect access token.
- rxIntrospect(String) - Method in class io.vertx.reactivex.ext.auth.oauth2.AccessToken
-
Introspect access token.
- rxIntrospectToken(String) - Method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
-
Deprecated.
- rxIntrospectToken(String, String) - Method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
-
Deprecated.
- rxInvoke(String) - Method in class io.vertx.reactivex.ext.healthchecks.HealthChecks
-
Invokes the registered procedure with the given name and sub-procedures.
- rxIsAuthorised(String) - Method in class io.vertx.reactivex.ext.auth.User
-
Deprecated.
- rxIsAuthorized(AccessToken, String) - Method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2RBAC
-
This method should verify if the user has the given authority and return either a boolean value or an error.
- rxIsAuthorized(String) - Method in class io.vertx.reactivex.ext.auth.User
-
Deprecated.
- rxKeys(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxKeys(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Find all keys matching the given pattern
- rxKeys(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Find all keys matching the given pattern
- rxLastsave() - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxLastsave() - Method in class io.vertx.reactivex.redis.RedisClient
-
Get the UNIX time stamp of the last successful save to disk
- rxLastsave() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get the UNIX time stamp of the last successful save to disk
- rxLatency(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxLeaderStatus() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Get the Raft leader for the datacenter in which the agent is running.
- rxLeaderStatus() - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxLindex(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxLindex(String, int) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get an element from a list by its index
- rxLindex(String, int) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
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
-
- rxLinsert(String, InsertOptions, String, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Insert an element before or after another element in a list
- rxLinsert(String, InsertOptions, String, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Insert an element before or after another element in a list
- rxListAclTokens() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Get list of Acl token
- rxListAclTokens() - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxListConsumerGroups() - Method in class io.vertx.reactivex.kafka.admin.KafkaAdminClient
-
Get the the consumer groups available in the cluster with the default options
- 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
-
Like
HttpServer.listen()
but 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.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(int) - Method in class io.vertx.reactivex.core.http.HttpServer
-
Like
HttpServer.listen()
but supplying a handler that will be called when the server is actually listening (or has failed).
- rxListen() - Method in class io.vertx.reactivex.core.http.HttpServer
-
Like
HttpServer.listen()
but supplying a handler that will be called when the server is actually listening (or has failed).
- rxListen() - Method in class io.vertx.reactivex.core.net.NetServer
-
Like
NetServer.listen()
but providing a handler that will be notified when the server is listening, or fails.
- rxListen(int, String) - Method in class io.vertx.reactivex.core.net.NetServer
-
Like
NetServer.listen()
but providing a handler that will be notified when the server is listening, or fails.
- rxListen(int) - Method in class io.vertx.reactivex.core.net.NetServer
-
Like
NetServer.listen()
but providing a handler that will be notified when the server is listening, or fails.
- rxListen(SocketAddress) - Method in class io.vertx.reactivex.core.net.NetServer
-
Like
NetServer.listen()
but providing a handler that will be notified when the server is listening, or fails.
- rxListen() - Method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.TcpEventBusBridge
-
Listen on default port 7000 with a handler to report the state of the socket listen operation.
- rxListen(int, String) - Method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.TcpEventBusBridge
-
Listen on specific port and bind to specific address
- rxListen(int) - Method in class io.vertx.reactivex.ext.eventbus.bridge.tcp.TcpEventBusBridge
-
Listen on specific port
- rxListen() - Method in class io.vertx.reactivex.ext.shell.ShellServer
-
Start the shell service, this is an asynchronous start.
- rxListen() - Method in class io.vertx.reactivex.ext.shell.term.TermServer
-
- 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(int) - Method in class io.vertx.reactivex.ext.stomp.StompServer
-
Connects the STOMP server to the given port.
- 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
It ignores any options specified through the constructor
- 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() - Method in class io.vertx.reactivex.mqtt.MqttServer
-
Start the server listening for incoming connections using the specified options
through the constructor
- 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
- rxListEvents() - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxListEventsWithOptions(EventListOptions) - 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.ConsulService
-
- rxListIndexes(String) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Get all the indexes in this collection.
- rxListIndexes(String) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- rxListNodeSessions(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Returns the active sessions for a given node
- rxListNodeSessions(String) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxListNodeSessionsWithOptions(String, BlockingQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
- rxListNodeSessionsWithOptions(String, BlockingQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxListSessions() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Returns the active sessions
- rxListSessions() - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxListSessionsWithOptions(BlockingQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
- rxListSessionsWithOptions(BlockingQueryOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- 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
-
- rxLlen(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get the length of a list
- rxLlen(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get the length of a list
- rxLoadJWK() - Method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Auth
-
Deprecated.
- rxLocalChecks() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Return all the checks that are registered with the local agent.
- rxLocalChecks() - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxLocalServices() - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Returns list of services registered with the local agent.
- rxLocalServices() - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxLogout() - Method in class io.vertx.reactivex.ext.auth.oauth2.AccessToken
-
Revoke refresh token and calls the logout endpoint.
- rxLolwut(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- 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(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxLpop(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Remove and get the first element in a list
- rxLpop(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Remove and get the first element in 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
-
- rxLpush(String, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Prepend one value to a list
- rxLpush(String, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Prepend one value to a list
- rxLpushMany(String, List<String>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Prepend one or multiple values to a list
- rxLpushMany(String, List<String>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Prepend one or multiple values to a list
- rxLpushx(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxLpushx(String, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Prepend a value to a list, only if the list exists
- rxLpushx(String, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Prepend a value to a list, only if the list exists
- rxLrange(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxLrange(String, long, long) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get a range of elements from a list
- rxLrange(String, long, long) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get a range of elements from a list
- rxLrem(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxLrem(String, long, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Remove elements from a list
- rxLrem(String, long, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Remove elements from a list
- rxLset(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxLset(String, long, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set the value of an element in a list by its index
- rxLset(String, long, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
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
-
- rxLtrim(String, long, long) - Method in class io.vertx.reactivex.redis.RedisClient
-
Trim a list to the specified range
- rxLtrim(String, long, long) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
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"
- rxMaintenanceService(MaintenanceOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxMaster(String) - Method in class io.vertx.reactivex.redis.sentinel.RedisSentinel
-
Show the state and info of the specified master
- rxMasters() - Method in class io.vertx.reactivex.redis.sentinel.RedisSentinel
-
Show a list of monitored masters and their state
- rxMemory(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxMessageCount(String) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
-
Returns the number of messages in a queue ready to be delivered.
- rxMget(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxMget(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get the value of the given key
- rxMget(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get the value of the given key
- rxMgetMany(List<String>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get the values of all the given keys
- rxMgetMany(List<String>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get the values of all the given keys
- rxMigrate(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxMigrate(String, int, String, int, long, MigrateOptions) - Method in class io.vertx.reactivex.redis.RedisClient
-
Atomically transfer a key from a Redis instance to another one.
- rxMigrate(String, int, String, int, long, MigrateOptions) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
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
-
- rxMonitor() - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxMonitor() - Method in class io.vertx.reactivex.redis.RedisClient
-
Listen for all requests received by the server in real time
- rxMonitor() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
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, CopyOptions) - 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
-
- rxMove(String, int) - Method in class io.vertx.reactivex.redis.RedisClient
-
Move a key to another database
- rxMove(String, int) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Move a key to another database
- rxMset(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxMset(JsonObject) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set multiple keys to multiple values
- rxMset(JsonObject) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Set multiple keys to multiple values
- rxMsetnx(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxMsetnx(JsonObject) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set multiple keys to multiple values, only if none of the keys exist
- rxMsetnx(JsonObject) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Set multiple keys to multiple values, only if none of the keys exist
- rxMulti() - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxMulti() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Mark the start of a RedisTransaction block
- rxObject(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxObject(String, ObjectCmd) - Method in class io.vertx.reactivex.redis.RedisClient
-
Inspect the internals of Redis objects
- rxObject(String, ObjectCmd) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Inspect the internals of Redis objects
- rxOffsetsForTimes(TopicPartition, Long) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
-
Look up the offset for the given partition by timestamp.
- rxOnAuthenticationRequest(StompServerConnection, String, String) - Method in class io.vertx.reactivex.ext.stomp.StompServerHandler
-
Called when the client connects to a server requiring authentication.
- rxOnComplete() - Method in class io.vertx.reactivex.core.CompositeFuture
-
- rxOnComplete() - Method in class io.vertx.reactivex.core.Future
-
Add a handler to be notified of the result.
- rxOne() - Method in class io.vertx.reactivex.cassandra.ResultSet
-
- rxOpen(String, OpenOptions) - Method in class io.vertx.reactivex.core.file.FileSystem
-
Open the file represented by path
, asynchronously.
- rxParseCredentials(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.BasicAuthHandler
-
Parses the credentials from the request into a JsonObject.
- rxParseCredentials(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.ChainAuthHandler
-
Parses the credentials from the request into a JsonObject.
- rxParseCredentials(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.DigestAuthHandler
-
Parses the credentials from the request into a JsonObject.
- rxParseCredentials(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.JWTAuthHandler
-
Parses the credentials from the request into a JsonObject.
- rxParseCredentials(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.OAuth2AuthHandler
-
Parses the credentials from the request into a JsonObject.
- rxParseCredentials(RoutingContext) - Method in class io.vertx.reactivex.ext.web.handler.RedirectAuthHandler
-
Parses the credentials from the request into a JsonObject.
- 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".
- rxPassCheck(String) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxPassCheckWithNote(String, 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.ConsulService
-
- 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.
- rxPeersStatus() - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxPersist(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxPersist(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Remove the expiration from a key
- rxPersist(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Remove the expiration from a key
- rxPexpire(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxPexpire(String, long) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set a key's time to live in milliseconds
- rxPexpire(String, long) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Set a key's time to live in milliseconds
- rxPexpireat(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxPexpireat(String, long) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set the expiration for a key as a UNIX timestamp specified in milliseconds
- rxPexpireat(String, long) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Set the expiration for a key as a UNIX timestamp specified in milliseconds
- rxPfadd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxPfadd(String, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Adds the specified element to the specified HyperLogLog.
- rxPfadd(String, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Adds the specified element to the specified HyperLogLog.
- rxPfaddMany(String, List<String>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Adds the specified elements to the specified HyperLogLog.
- rxPfaddMany(String, List<String>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Adds the specified elements to the specified HyperLogLog.
- rxPfcount(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxPfcount(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Return the approximated cardinality of the set observed by the HyperLogLog at key.
- rxPfcount(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return the approximated cardinality of the set observed by the HyperLogLog at key.
- rxPfcountMany(List<String>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Return the approximated cardinality of the set(s) observed by the HyperLogLog at key(s).
- rxPfcountMany(List<String>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return the approximated cardinality of the set(s) observed by the HyperLogLog at key(s).
- rxPfdebug(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxPfmerge(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxPfmerge(String, List<String>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Merge N different HyperLogLogs into a single one.
- rxPfmerge(String, List<String>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Merge N different HyperLogLogs into a single one.
- rxPfselftest() - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxPing(Buffer) - Method in class io.vertx.reactivex.core.http.HttpConnection
-
Send a frame to the remote endpoint.
- 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(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxPing() - Method in class io.vertx.reactivex.redis.RedisClient
-
Ping the server
- rxPing() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Ping the server
- rxPipeTo(WriteStream<AmqpMessage>) - Method in class io.vertx.reactivex.amqp.AmqpReceiver
-
Pipe this ReadStream
to the WriteStream
.
- rxPipeTo(WriteStream<Row>) - Method in class io.vertx.reactivex.cassandra.CassandraRowStream
-
Pipe this ReadStream
to the WriteStream
.
- rxPipeTo(WriteStream<DatagramPacket>) - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
-
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<Buffer>) - Method in class io.vertx.reactivex.core.file.AsyncFile
-
Pipe this ReadStream
to the WriteStream
.
- rxPipeTo(WriteStream<HttpClientResponse>) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
-
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 class io.vertx.reactivex.core.net.NetSocket
-
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<Buffer>) - Method in class io.vertx.reactivex.core.parsetools.RecordParser
-
Pipe this ReadStream
to the WriteStream
.
- rxPipeTo(WriteStream<Long>) - Method in class io.vertx.reactivex.core.TimeoutStream
-
Pipe this ReadStream
to the WriteStream
.
- rxPipeTo(WriteStream<JsonArray>) - Method in class io.vertx.reactivex.ext.sql.SQLRowStream
-
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<Buffer>) - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
-
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<String>) - Method in class io.vertx.reactivex.pgclient.pubsub.PgChannel
-
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<T>) - Method in class io.vertx.reactivex.sqlclient.RowStream
-
Pipe this ReadStream
to the WriteStream
.
- rxPoll(long) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
-
Deprecated.
- 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).
- rxPost(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxPrepare(String) - Method in class io.vertx.reactivex.cassandra.CassandraClient
-
Prepares the provided query string.
- rxPrepare(String) - Method in class io.vertx.reactivex.db2client.DB2Connection
-
- rxPrepare(String) - Method in class io.vertx.reactivex.mysqlclient.MySQLConnection
-
- rxPrepare(String) - Method in class io.vertx.reactivex.pgclient.PgConnection
-
- rxPrepare(String) - Method in class io.vertx.reactivex.sqlclient.SqlConnection
-
Create a prepared query.
- rxPrepare(String) - Method in class io.vertx.reactivex.sqlclient.Transaction
-
Create a prepared query.
- 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
-
- rxPsetex(String, long, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set the value and expiration in milliseconds of a key
- rxPsetex(String, long, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Set the value and expiration in milliseconds of a key
- rxPsubscribe(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxPsubscribe(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Listen for messages published to channels matching the given pattern
- rxPsubscribe(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Listen for messages published to channels matching the given pattern
- rxPsubscribeMany(List<String>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Listen for messages published to channels matching the given patterns
- rxPsubscribeMany(List<String>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Listen for messages published to channels matching the given patterns
- rxPsync(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxPttl(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxPttl(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get the time to live for a key in milliseconds
- rxPttl(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get the time to live for a key in milliseconds
- 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 server
- 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, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxPublish(String, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Post a message to a channel
- rxPublish(String, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Post a message to a channel
- 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.
- rxPubsub(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxPubsubChannels(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Lists the currently active channels - only those matching the pattern
- rxPubsubChannels(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Lists the currently active channels - only those matching the pattern
- rxPubsubNumpat() - Method in class io.vertx.reactivex.redis.RedisClient
-
Returns the number of subscriptions to patterns (that are performed using the PSUBSCRIBE command)
- rxPubsubNumpat() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Returns the number of subscriptions to patterns (that are performed using the PSUBSCRIBE command)
- rxPubsubNumsub(List<String>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Returns the number of subscribers (not counting clients subscribed to patterns) for the specified channels
- rxPubsubNumsub(List<String>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Returns the number of subscribers (not counting clients subscribed to patterns) for the specified channels
- rxPunsubscribe(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxPunsubscribe(List<String>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Stop listening for messages posted to channels matching the given patterns
- rxPunsubscribe(List<String>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Stop listening for messages posted to channels matching the given patterns
- rxPush(HttpMethod, String, String) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
- rxPush(HttpMethod, String, MultiMap) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
- rxPush(HttpMethod, String) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
- rxPush(HttpMethod, String, String, MultiMap) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
Push a response to the client.
The
handler
will be notified with a
success when the push can be sent and with
a
failure when the client has disabled push or reset the push before it has been sent.
The
handler
may be queued if the client has reduced the maximum number of streams the server can push
concurrently.
Push can be sent only for peer initiated streams and if the response is not ended.
- 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
-
- rxPut(Session) - Method in class io.vertx.reactivex.ext.web.sstore.SessionStore
-
Add a session with the specified ID.
- 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
-
- rxPutValue(String, String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Adds specified key/value pair
- rxPutValue(String, String) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxPutValueWithOptions(String, String, KeyValueOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
- rxPutValueWithOptions(String, String, KeyValueOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxQuery(String) - Method in class io.vertx.reactivex.ext.sql.SQLClient
-
Execute a single SQL statement, this method acquires a connection from the the pool and executes the SQL
statement and returns it back after the execution.
- rxQuery(String) - Method in class io.vertx.reactivex.ext.sql.SQLConnection
-
Executes the given SQL SELECT
statement which returns the results of the query.
- rxQuerySingle(String) - Method in class io.vertx.reactivex.ext.asyncsql.AsyncSQLClient
-
Execute a one shot SQL statement that returns a single SQL row.
- rxQuerySingle(String) - Method in class io.vertx.reactivex.ext.asyncsql.MySQLClient
-
Execute a one shot SQL statement that returns a single SQL row.
- rxQuerySingle(String) - Method in class io.vertx.reactivex.ext.asyncsql.PostgreSQLClient
-
Execute a one shot SQL statement that returns a single SQL row.
- rxQuerySingle(String) - Method in class io.vertx.reactivex.ext.jdbc.JDBCClient
-
Execute a one shot SQL statement that returns a single SQL row.
- rxQuerySingle(String) - Method in class io.vertx.reactivex.ext.sql.SQLClient
-
Execute a one shot SQL statement that returns a single SQL row.
- rxQuerySingle(String) - Method in class io.vertx.reactivex.ext.sql.SQLConnection
-
Execute a one shot SQL statement that returns a single SQL row.
- rxQuerySingleWithParams(String, JsonArray) - Method in class io.vertx.reactivex.ext.asyncsql.AsyncSQLClient
-
Execute a one shot SQL statement with arguments that returns a single SQL row.
- rxQuerySingleWithParams(String, JsonArray) - Method in class io.vertx.reactivex.ext.asyncsql.MySQLClient
-
Execute a one shot SQL statement with arguments that returns a single SQL row.
- rxQuerySingleWithParams(String, JsonArray) - Method in class io.vertx.reactivex.ext.asyncsql.PostgreSQLClient
-
Execute a one shot SQL statement with arguments that returns a single SQL row.
- rxQuerySingleWithParams(String, JsonArray) - Method in class io.vertx.reactivex.ext.jdbc.JDBCClient
-
Execute a one shot SQL statement with arguments that returns a single SQL row.
- rxQuerySingleWithParams(String, JsonArray) - Method in class io.vertx.reactivex.ext.sql.SQLClient
-
Execute a one shot SQL statement with arguments that returns a single SQL row.
- rxQuerySingleWithParams(String, JsonArray) - Method in class io.vertx.reactivex.ext.sql.SQLConnection
-
Execute a one shot SQL statement with arguments that returns a single SQL row.
- 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.
- 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.ext.sql.SQLClient
-
Executes the given SQL SELECT
statement which returns the results of the query as a read stream.
- rxQueryStream(String) - Method in class io.vertx.reactivex.ext.sql.SQLConnection
-
Executes the given SQL SELECT
statement which returns the results of the query as a read stream.
- rxQueryStreamWithParams(String, JsonArray) - Method in class io.vertx.reactivex.ext.sql.SQLClient
-
Executes the given SQL SELECT
statement which returns the results of the query as a read stream.
- rxQueryStreamWithParams(String, JsonArray) - Method in class io.vertx.reactivex.ext.sql.SQLConnection
-
Executes the given SQL SELECT
statement which returns the results of the query as a read stream.
- rxQueryWithParams(String, JsonArray) - Method in class io.vertx.reactivex.ext.sql.SQLClient
-
Execute a single SQL prepared statement, this method acquires a connection from the the pool and executes the SQL
prepared statement and returns it back after the execution.
- rxQueryWithParams(String, JsonArray) - Method in class io.vertx.reactivex.ext.sql.SQLConnection
-
Executes the given SQL SELECT
prepared statement which returns the results of the query.
- 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
- rxRandomkey() - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxRandomkey() - Method in class io.vertx.reactivex.redis.RedisClient
-
Return a random key from the keyspace
- rxRandomkey() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return a random key from the keyspace
- 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.
- rxRead(int) - Method in class io.vertx.reactivex.sqlclient.Cursor
-
Read rows from the cursor, the result is provided asynchronously to the handler
.
- 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
-
- 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
-
- rxRefresh() - Method in class io.vertx.reactivex.ext.auth.oauth2.AccessToken
-
Refresh the access token
- rxRegisterCheck(CheckOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Add a new check to the local agent.
- rxRegisterCheck(CheckOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxRegisterCommand(Command) - Method in class io.vertx.reactivex.ext.shell.command.CommandRegistry
-
Register a command
- rxRegisterCommands(List<Command>) - Method in class io.vertx.reactivex.ext.shell.command.CommandRegistry
-
Register a list of commands.
- rxRegisterService(ServiceOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Adds a new service, with an optional health check, to the local agent.
- rxRegisterService(ServiceOptions) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- 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.
- rxRemove(K) - Method in class io.vertx.reactivex.core.shareddata.AsyncMap
-
Remove a value from the map, asynchronously.
- rxRemove(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Deprecated.
- rxRemove(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
Deprecated.
- 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
- rxRemoveDocument(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- 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
- rxRemoveDocuments(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- 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
- rxRemoveDocumentsWithOptions(String, JsonObject, WriteOption) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- 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
- rxRemoveDocumentWithOptions(String, JsonObject, WriteOption) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- 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.
- rxRemoveOne(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Deprecated.
- rxRemoveOne(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
Deprecated.
- rxRemoveOneWithOptions(String, JsonObject, WriteOption) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Deprecated.
- rxRemoveOneWithOptions(String, JsonObject, WriteOption) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
Deprecated.
- rxRemoveWithOptions(String, JsonObject, WriteOption) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Deprecated.
- rxRemoveWithOptions(String, JsonObject, WriteOption) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
Deprecated.
- rxRename(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxRename(String, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Rename a key
- rxRename(String, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Rename a key
- rxRenamenx(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxRenamenx(String, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Rename a key, only if the new key does not exist
- rxRenamenx(String, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
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.
- rxRender(RoutingContext, String) - Method in class io.vertx.reactivex.ext.web.templ.TemplateEngine
-
Deprecated.
- rxRender(RoutingContext, String, String) - Method in class io.vertx.reactivex.ext.web.templ.TemplateEngine
-
Deprecated.
- rxRenewSession(String) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Renews the given session.
- rxRenewSession(String) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- 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(String, JsonObject, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Deprecated.
- rxReplace(String, JsonObject, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
Deprecated.
- 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
- rxReplaceDocuments(String, JsonObject, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- 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
- rxReplaceDocumentsWithOptions(String, JsonObject, JsonObject, UpdateOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- 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
- rxReplaceWithOptions(String, JsonObject, JsonObject, UpdateOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Deprecated.
- rxReplaceWithOptions(String, JsonObject, JsonObject, UpdateOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
Deprecated.
- rxReplconf(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxReplicaof(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxReply(Object) - Method in class io.vertx.reactivex.core.eventbus.Message
-
Deprecated.
- rxReply(Object, DeliveryOptions) - Method in class io.vertx.reactivex.core.eventbus.Message
-
Deprecated.
- 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 but specifying options
that can be used
to configure the delivery.
- rxRequest(String, Object) - Method in class io.vertx.reactivex.core.eventbus.EventBus
-
Sends a message and 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 but specifying options
that can be used to configure the delivery.
- rxReset(String) - Method in class io.vertx.reactivex.redis.sentinel.RedisSentinel
-
Reset all the masters with matching name.
- 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.
- 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.
- rxRestore(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxRestore(String, long, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Create a key using the provided serialized value, previously obtained using DUMP.
- rxRestore(String, long, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Create a key using the provided serialized value, previously obtained using DUMP.
- rxRestoreAsking(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- 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(String) - Method in class io.vertx.reactivex.ext.auth.oauth2.AccessToken
-
Revoke access or refresh token
- rxRole() - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxRole() - Method in class io.vertx.reactivex.redis.RedisClient
-
Return the role of the instance in the context of replication
- rxRole() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return the role of the instance in the context of replication
- rxRollback() - Method in class io.vertx.reactivex.ext.sql.SQLConnection
-
Rolls back all changes made since the previous commit/rollback.
- rxRollback() - Method in class io.vertx.reactivex.sqlclient.Transaction
-
- rxRpop(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxRpop(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Remove and get the last element in a list
- rxRpop(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Remove and get the last element in a list
- rxRpoplpush(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxRpoplpush(String, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Remove the last element in a list, append it to another list and return it
- rxRpoplpush(String, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Remove the last element in a list, append it to another list and return it
- rxRpush(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxRpush(String, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Append one or multiple values to a list
- rxRpush(String, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Append one or multiple values to a list
- rxRpushMany(String, List<String>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Append one or multiple values to a list
- rxRpushMany(String, List<String>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Append one or multiple values to a list
- rxRpushx(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxRpushx(String, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Append a value to a list, only if the list exists
- rxRpushx(String, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Append a value 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.
- rxRunCommand(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- rxSadd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxSadd(String, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Add a member to a set
- rxSadd(String, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Add a member to a set
- rxSaddMany(String, List<String>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Add one or more members to a set
- rxSaddMany(String, List<String>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Add one or more members to a set
- rxSave(T) - Method in class io.vertx.reactivex.cassandra.Mapper
-
Asynchronous save method.
- rxSave(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Save a document in the specified collection
- rxSave(String, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- rxSave() - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxSave() - Method in class io.vertx.reactivex.redis.RedisClient
-
Synchronously save the dataset to disk
- rxSave() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Synchronously save the dataset to disk
- 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
- rxSaveWithOptions(String, JsonObject, WriteOption) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- rxScan(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxScan(String, ScanOptions) - Method in class io.vertx.reactivex.redis.RedisClient
-
Incrementally iterate the keys space
- rxScan(String, ScanOptions) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Incrementally iterate the keys space
- rxScard(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxScard(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get the number of members in a set
- rxScard(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get the number of members in a set
- rxScript(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxScriptDebug(ScriptDebugOptions) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set the debug mode for executed scripts.
- rxScriptExists(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Check existence of script in the script cache.
- rxScriptExists(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Check existence of script in the script cache.
- rxScriptExistsMany(List<String>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Check existence of scripts in the script cache.
- rxScriptExistsMany(List<String>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Check existence of scripts in the script cache.
- rxScriptFlush() - Method in class io.vertx.reactivex.redis.RedisClient
-
Remove all the scripts from the script cache.
- rxScriptFlush() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Remove all the scripts from the script cache.
- rxScriptKill() - Method in class io.vertx.reactivex.redis.RedisClient
-
Kill the script currently in execution.
- rxScriptKill() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Kill the script currently in execution.
- rxScriptLoad(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Load the specified Lua script into the script cache.
- rxScriptLoad(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Load the specified Lua script into the script cache.
- rxSdiff(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxSdiff(String, List<String>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Subtract multiple sets
- rxSdiff(String, List<String>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Subtract multiple sets
- rxSdiffstore(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxSdiffstore(String, String, List<String>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Subtract multiple sets and store the resulting set in a key
- rxSdiffstore(String, String, List<String>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
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.
- 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
-
- rxSelect(int) - Method in class io.vertx.reactivex.redis.RedisClient
-
Change the selected database for the current connection
- rxSelect(int) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Change the selected database for the current connection
- rxSend(Buffer, int, String) - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
-
- rxSend(String, int, String) - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
-
- rxSend(String, String, int, String) - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
-
- rxSend(String, Object) - Method in class io.vertx.reactivex.core.eventbus.EventBus
-
Deprecated.
- rxSend(String, Object, DeliveryOptions) - Method in class io.vertx.reactivex.core.eventbus.EventBus
-
Deprecated.
- rxSend() - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
-
Send a request, the
handler
will receive the response as an
HttpResponse
.
- 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.
- rxSendBuffer(Buffer) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
-
- rxSendFile(String) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
- rxSendFile(String, long) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
- rxSendFile(String, long, long) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
- rxSendFile(String) - Method in class io.vertx.reactivex.core.net.NetSocket
-
- rxSendFile(String, long) - Method in class io.vertx.reactivex.core.net.NetSocket
-
- rxSendFile(String, long, long) - Method in class io.vertx.reactivex.core.net.NetSocket
-
- rxSendForm(MultiMap) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
-
- rxSendJson(Object) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
-
- rxSendJsonObject(JsonObject) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
-
- rxSendMail(MailMessage) - Method in class io.vertx.reactivex.ext.mail.MailClient
-
send a single mail via MailClient
- rxSendMail(MailMessage) - Method in class io.vertx.reactivex.ext.mail.MailService
-
- rxSendMultipartForm(MultipartForm) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
-
- rxSendStream(ReadStream<Buffer>) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
-
- rxSendStream(Flowable<Buffer>) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
-
- rxSendStream(Observable<Buffer>) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
-
- rxSendWithAck(AmqpMessage) - Method in class io.vertx.reactivex.amqp.AmqpSender
-
Sends an AMQP message and waits for an acknowledgement.
- rxSentinels(String) - Method in class io.vertx.reactivex.redis.sentinel.RedisSentinel
-
Show a list of sentinel instances for this master, and their state
- rxSet(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxSet(String, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set the string value of a key
- rxSet(String, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Set the string value of a key
- rxSetAutoCommit(boolean) - Method in class io.vertx.reactivex.ext.sql.SQLConnection
-
Sets the auto commit flag for this connection.
- rxSetBinary(String, Buffer) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set the binary string value of a key - without encoding as utf-8
- rxSetBinary(String, Buffer) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Set the binary string value of a key - without encoding as utf-8
- rxSetBinaryWithOptions(String, Buffer, SetOptions) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set the string value of a key
- rxSetBinaryWithOptions(String, Buffer, SetOptions) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Set the string value of a key
- rxSetbit(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxSetbit(String, long, int) - Method in class io.vertx.reactivex.redis.RedisClient
-
Sets or clears the bit at offset in the string value stored at key
- rxSetbit(String, long, int) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
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
-
- rxSetex(String, long, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set the value and expiration of a key
- rxSetex(String, long, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Set the value and expiration of a key
- rxSetHandler() - Method in class io.vertx.reactivex.core.CompositeFuture
-
Deprecated.
- rxSetHandler() - Method in class io.vertx.reactivex.core.Future
-
Deprecated.
- rxSetHandshake(Future<Integer>) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
-
Set an asynchronous result for the handshake, upon completion of the specified
future
, the
WebSocket will either be
accepted when the
future
succeeds with the HTTP status code
rejected when the
future
is succeeds with an HTTP status code different than
rejected when the
future
fails with the HTTP status code
500
The provided future might be completed by the WebSocket itself, e.g calling the
ServerWebSocket.close(io.vertx.core.Handler<io.vertx.core.AsyncResult<java.lang.Void>>)
method
will try to accept the handshake and close the WebSocket afterward.
- rxSetnx(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxSetnx(String, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set the value of a key, only if the key does not exist
- rxSetnx(String, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
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
-
- rxSetrange(String, int, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Overwrite part of a string at key starting at the specified offset
- rxSetrange(String, int, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Overwrite part of a string at key starting at the specified offset
- rxSetTransactionIsolation(TransactionIsolation) - Method in class io.vertx.reactivex.ext.sql.SQLConnection
-
Attempts to change the transaction isolation level for this Connection object to the one given.
- rxSetWithOptions(String, String, SetOptions) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set the string value of a key
- rxSetWithOptions(String, String, SetOptions) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Set the string value of a key
- rxSeveral(int) - Method in class io.vertx.reactivex.cassandra.ResultSet
-
Fetch a specific amount of rows and notify via a handler.
- rxShutdown(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxSinter(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxSinter(List<String>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Intersect multiple sets
- rxSinter(List<String>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Intersect multiple sets
- rxSinterstore(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxSinterstore(String, List<String>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Intersect multiple sets and store the resulting set in a key
- rxSinterstore(String, List<String>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Intersect multiple sets and store the resulting set in a key
- rxSismember(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxSismember(String, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Determine if a given value is a member of a set
- rxSismember(String, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Determine if a given value is a member of a set
- 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
-
- rxSlaveof(String, int) - Method in class io.vertx.reactivex.redis.RedisClient
-
Make the server a slave of another instance
- rxSlaveof(String, int) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Make the server a slave of another instance
- rxSlaveofNoone() - Method in class io.vertx.reactivex.redis.RedisClient
-
Make this server a master
- rxSlaveofNoone() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Make this server a master
- rxSlaves(String) - Method in class io.vertx.reactivex.redis.sentinel.RedisSentinel
-
Show a list of slaves for this master, and their state
- rxSlowlog(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxSlowlogGet(int) - Method in class io.vertx.reactivex.redis.RedisClient
-
Read the Redis slow queries log
- rxSlowlogGet(int) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Read the Redis slow queries log
- rxSlowlogLen() - Method in class io.vertx.reactivex.redis.RedisClient
-
Get the length of the Redis slow queries log
- rxSlowlogLen() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get the length of the Redis slow queries log
- rxSlowlogReset() - Method in class io.vertx.reactivex.redis.RedisClient
-
Reset the Redis slow queries log
- rxSlowlogReset() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Reset the Redis slow queries log
- rxSmembers(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxSmembers(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get all the members in a set
- rxSmembers(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get all the members in a set
- rxSmove(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxSmove(String, String, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Move a member from one set to another
- rxSmove(String, String, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Move a member from one set to another
- rxSort(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxSort(String, SortOptions) - Method in class io.vertx.reactivex.redis.RedisClient
-
Sort the elements in a list, set or sorted set
- rxSort(String, SortOptions) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
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
-
- rxSpop(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Remove and return a random member from a set
- rxSpop(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Remove and return a random member from a set
- rxSpopMany(String, int) - Method in class io.vertx.reactivex.redis.RedisClient
-
Remove and return random members from a set
- rxSpopMany(String, int) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Remove and return random members from a set
- rxSrandmember(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxSrandmember(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get one or multiple random members from a set
- rxSrandmember(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get one or multiple random members from a set
- rxSrandmemberCount(String, int) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get one or multiple random members from a set
- rxSrandmemberCount(String, int) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get one or multiple random members from a set
- rxSrem(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxSrem(String, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Remove one member from a set
- rxSrem(String, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Remove one member from a set
- rxSremMany(String, List<String>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Remove one or more members from a set
- rxSremMany(String, List<String>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Remove one or more members from a set
- rxSscan(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxSscan(String, String, ScanOptions) - Method in class io.vertx.reactivex.redis.RedisClient
-
Incrementally iterate Set elements
- rxSscan(String, String, ScanOptions) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Incrementally iterate Set elements
- rxStart(String, int, String, String) - Method in class io.vertx.reactivex.amqpbridge.AmqpBridge
-
Starts the bridge, establishing the underlying connection.
- rxStart(String, int) - Method in class io.vertx.reactivex.amqpbridge.AmqpBridge
-
Starts the bridge, establishing the underlying connection.
- rxStart() - Method in class io.vertx.reactivex.core.AbstractVerticle
-
Override to return a Completable
that will complete the deployment of this verticle.
- rxStart() - Method in class io.vertx.reactivex.ext.shell.ShellService
-
Start the shell service, this is an asynchronous start.
- rxStart() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
-
Start the rabbitMQ client.
- rxStop() - Method in class io.vertx.reactivex.core.AbstractVerticle
-
Override to return a Completable
that will complete the undeployment of this verticle.
- rxStop() - Method in class io.vertx.reactivex.ext.shell.ShellService
-
Stop the shell service, this is an asynchronous start.
- rxStop() - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
-
Stop the rabbitMQ client.
- rxStrlen(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxStrlen(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get the length of the value stored in a key
- rxStrlen(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
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(Set<String>) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
-
Subscribe to the given list of topics 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(Map<String, Integer>) - Method in class io.vertx.reactivex.mqtt.MqttClient
-
Subscribes to the topic and adds a handler which will be called after the request is sent
- rxSubscribe(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxSubscribe(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Listen for messages published to the given channels
- rxSubscribe(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Listen for messages published to the given channels
- rxSubscribeMany(List<String>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Listen for messages published to the given channels
- rxSubscribeMany(List<String>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Listen for messages published to the given channels
- 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
-
- rxSunion(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxSunion(List<String>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Add multiple sets
- rxSunion(List<String>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Add multiple sets
- rxSunionstore(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxSunionstore(String, List<String>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Add multiple sets and store the resulting set in a key
- rxSunionstore(String, List<String>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Add multiple sets and store the resulting set in a key
- rxSwapdb(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxSwapdb(int, int) - Method in class io.vertx.reactivex.redis.RedisClient
-
Swaps two Redis databases
- rxSwapdb(int, int) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
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
-
- rxSync() - Method in class io.vertx.reactivex.redis.RedisClient
-
Internal command used for replication
- rxSync() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Internal command used for replication
- rxTime() - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxTime() - Method in class io.vertx.reactivex.redis.RedisClient
-
Return the current server time
- rxTime() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return the current server time
- 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.
- rxTouch(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxTouch(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Alters the last access time of a key(s).
- rxTouchMany(List<String>) - Method in class io.vertx.reactivex.redis.RedisClient
-
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.
- rxTransaction(TxnRequest) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxTruncate(String, long) - Method in class io.vertx.reactivex.core.file.FileSystem
-
Truncate the file represented by path
to length len
in bytes, asynchronously.
- rxTtl(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxTtl(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get the time to live for a key
- rxTtl(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get the time to live for a key
- rxType(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxType(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Determine the type stored at key
- rxType(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Determine the type stored at key
- rxUndeploy(String) - Method in class io.vertx.reactivex.core.Vertx
-
Like
#undeploy(String)
but the completionHandler will be notified when the undeployment is complete.
- 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
-
- rxUnlink(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Delete a key asynchronously in another thread.
- rxUnlink(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Delete a key asynchronously in another thread.
- rxUnlinkMany(List<String>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Delete multiple keys asynchronously in another thread.
- rxUnlinkMany(List<String>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Delete multiple keys 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
- rxUnregisterCommand(String) - Method in class io.vertx.reactivex.ext.shell.command.CommandRegistry
-
Unregister a command.
- 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.mqtt.MqttClient
-
Unsubscribe from receiving messages on given topic
- rxUnsubscribe(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxUnsubscribe(List<String>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Stop listening for messages posted to the given channels
- rxUnsubscribe(List<String>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Stop listening for messages posted to the given channels
- rxUnwatch() - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxUnwatch() - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Forget about all watched keys
- rxUpdate(String, JsonObject, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Deprecated.
- rxUpdate(String, JsonObject, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
Deprecated.
- rxUpdate(String) - Method in class io.vertx.reactivex.ext.sql.SQLClient
-
Executes the given SQL statement which may be an INSERT
, UPDATE
, or DELETE
statement.
- rxUpdate(String) - Method in class io.vertx.reactivex.ext.sql.SQLConnection
-
Executes the given SQL statement which may be an INSERT
, UPDATE
, or DELETE
statement.
- 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(AclToken) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Update Acl token
- rxUpdateAclToken(AclToken) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxUpdateCheck(String, CheckStatus) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
Set status of the check to given status.
- rxUpdateCheck(String, CheckStatus) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxUpdateCheckWithNote(String, CheckStatus, String) - 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.ConsulService
-
- 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
- rxUpdateCollection(String, JsonObject, JsonObject) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- 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
- rxUpdateCollectionWithOptions(String, JsonObject, JsonObject, UpdateOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- rxUpdatePreparedQuery(PreparedQueryDefinition) - Method in class io.vertx.reactivex.ext.consul.ConsulClient
-
- rxUpdatePreparedQuery(PreparedQueryDefinition) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxUpdateSettings(Http2Settings) - Method in class io.vertx.reactivex.core.http.HttpConnection
-
Send to the remote endpoint an update of this endpoint settings
The
completionHandler
will be notified when the remote endpoint has acknowledged the settings.
- rxUpdateWithOptions(String, JsonObject, JsonObject, UpdateOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Deprecated.
- rxUpdateWithOptions(String, JsonObject, JsonObject, UpdateOptions) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
Deprecated.
- rxUpdateWithParams(String, JsonArray) - Method in class io.vertx.reactivex.ext.sql.SQLClient
-
Executes the given prepared statement which may be an INSERT
, UPDATE
, or DELETE
statement with the given parameters
- rxUpdateWithParams(String, JsonArray) - Method in class io.vertx.reactivex.ext.sql.SQLConnection
-
Executes the given prepared statement which may be an INSERT
, UPDATE
, or DELETE
statement with the given parameters
- rxUserInfo() - Method in class io.vertx.reactivex.ext.auth.oauth2.AccessToken
-
Load the user info as per OIDC spec.
- rxWait(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxWait(long, long) - Method in class io.vertx.reactivex.redis.RedisClient
-
Wait for the synchronous replication of all the write commands sent in the context of the current connection.
- rxWait(long, long) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
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".
- rxWarnCheck(String) - Method in class io.vertx.reactivex.ext.consul.ConsulService
-
- rxWarnCheckWithNote(String, 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.ConsulService
-
- rxWatch(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxWatch(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Watch the given keys to determine execution of the MULTI/EXEC block
- rxWatchMany(List<String>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Watch the given keys to determine execution of the MULTI/EXEC block
- rxWebSocket(int, String, String) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Connect a WebSocket to the specified port, host and relative request URI
- rxWebSocket(String, String) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Connect a WebSocket to the host and relative request URI and default port
- rxWebSocket(String) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Connect a WebSocket at the relative request URI using the default host and port
- rxWebSocket(WebSocketConnectOptions) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Connect a WebSocket with the specified options.
- rxWebSocketAbs(String, MultiMap, WebsocketVersion, List<String>) - Method in class io.vertx.reactivex.core.http.HttpClient
-
Connect a WebSocket with the specified absolute url, with the specified headers, using
the specified version of WebSockets, and the specified WebSocket sub protocols.
- rxWrite(AmqpMessage) - Method in class io.vertx.reactivex.amqp.AmqpSender
-
- rxWrite(T) - Method in class io.vertx.reactivex.core.eventbus.MessageProducer
-
- rxWrite(Buffer) - Method in class io.vertx.reactivex.core.file.AsyncFile
-
- 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(Buffer) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
-
- rxWrite(String) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
-
- rxWrite(String, String) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
-
- rxWrite(Buffer) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
- rxWrite(String, String) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
- rxWrite(String) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
- rxWrite(Buffer) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
-
- rxWrite(Buffer) - Method in class io.vertx.reactivex.core.http.WebSocket
-
- rxWrite(String) - Method in class io.vertx.reactivex.core.net.NetSocket
-
- rxWrite(String, String) - Method in class io.vertx.reactivex.core.net.NetSocket
-
- rxWrite(Buffer) - Method in class io.vertx.reactivex.core.net.NetSocket
-
Like but with an handler
called when the message has been written
or failed to be written.
- rxWrite(Buffer) - Method in class io.vertx.reactivex.ext.web.handler.sockjs.SockJSSocket
-
- rxWrite(KafkaProducerRecord<K, V>) - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
-
- rxWriteBinaryMessage(Buffer) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
-
- rxWriteBinaryMessage(Buffer) - Method in class io.vertx.reactivex.core.http.WebSocket
-
- 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.ServerWebSocket
-
- rxWriteFinalBinaryFrame(Buffer) - Method in class io.vertx.reactivex.core.http.WebSocket
-
- rxWriteFinalTextFrame(String) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
-
- rxWriteFinalTextFrame(String) - Method in class io.vertx.reactivex.core.http.WebSocket
-
- rxWriteFrame(WebSocketFrame) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
-
- rxWriteFrame(WebSocketFrame) - Method in class io.vertx.reactivex.core.http.WebSocket
-
- rxWriteTextMessage(String) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
-
- rxWriteTextMessage(String) - Method in class io.vertx.reactivex.core.http.WebSocket
-
- rxXack(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxXadd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxXclaim(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxXdel(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxXgroup(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxXinfo(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxXlen(String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxXpending(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxXrange(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxXread(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxXreadgroup(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxXrevrange(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxXsetid(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxXtrim(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxZadd(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxZadd(String, double, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Add one or more members to a sorted set, or update its score if it already exists
- rxZadd(String, double, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Add one or more members to a sorted set, or update its score if it already exists
- rxZaddMany(String, Map<String, Double>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Add one or more members to a sorted set, or update its score if it already exists
- rxZaddMany(String, Map<String, Double>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
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
-
- rxZcard(String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get the number of members in a sorted set
- rxZcard(String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get the number of members in a sorted set
- rxZcount(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxZcount(String, double, double) - Method in class io.vertx.reactivex.redis.RedisClient
-
Count the members in a sorted set with scores within the given values
- rxZcount(String, double, double) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Count the members in a sorted set with scores within the given values
- rxZincrby(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxZincrby(String, double, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Increment the score of a member in a sorted set
- rxZincrby(String, double, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Increment the score of a member in a sorted set
- rxZinterstore(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxZinterstore(String, List<String>, AggregateOptions) - Method in class io.vertx.reactivex.redis.RedisClient
-
Intersect multiple sorted sets and store the resulting sorted set in a new key
- rxZinterstore(String, List<String>, AggregateOptions) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Intersect multiple sorted sets and store the resulting sorted set in a new key
- rxZinterstoreWeighed(String, Map<String, Double>, AggregateOptions) - Method in class io.vertx.reactivex.redis.RedisClient
-
Intersect multiple sorted sets and store the resulting sorted set in a new key using weights for scoring
- rxZinterstoreWeighed(String, Map<String, Double>, AggregateOptions) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Intersect multiple sorted sets and store the resulting sorted set in a new key using weights for scoring
- rxZlexcount(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxZlexcount(String, String, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Count the number of members in a sorted set between a given lexicographical range
- rxZlexcount(String, String, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Count the number of members in a sorted set between a given lexicographical range
- rxZpopmax(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxZpopmin(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxZrange(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxZrange(String, long, long) - Method in class io.vertx.reactivex.redis.RedisClient
-
Return a range of members in a sorted set, by index
- rxZrange(String, long, long) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return a range of members in a sorted set, by index
- rxZrangebylex(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxZrangebylex(String, String, String, LimitOptions) - Method in class io.vertx.reactivex.redis.RedisClient
-
Return a range of members in a sorted set, by lexicographical range
- rxZrangebylex(String, String, String, LimitOptions) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return a range of members in a sorted set, by lexicographical range
- rxZrangebyscore(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxZrangebyscore(String, String, String, RangeLimitOptions) - Method in class io.vertx.reactivex.redis.RedisClient
-
Return a range of members in a sorted set, by score
- rxZrangebyscore(String, String, String, RangeLimitOptions) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return a range of members in a sorted set, by score
- rxZrangeWithOptions(String, long, long, RangeOptions) - Method in class io.vertx.reactivex.redis.RedisClient
-
Return a range of members in a sorted set, by index
- rxZrangeWithOptions(String, long, long, RangeOptions) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return a range of members in a sorted set, by index
- rxZrank(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxZrank(String, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Determine the index of a member in a sorted set
- rxZrank(String, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Determine the index of a member in a sorted set
- rxZrem(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxZrem(String, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Remove one member from a sorted set
- rxZrem(String, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Remove one member from a sorted set
- rxZremMany(String, List<String>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Remove one or more members from a sorted set
- rxZremMany(String, List<String>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Remove one or more members from a sorted set
- rxZremrangebylex(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxZremrangebylex(String, String, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Remove all members in a sorted set between the given lexicographical range
- rxZremrangebylex(String, String, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
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
-
- rxZremrangebyrank(String, long, long) - Method in class io.vertx.reactivex.redis.RedisClient
-
Remove all members in a sorted set within the given indexes
- rxZremrangebyrank(String, long, long) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Remove all members in a sorted set within the given indexes
- rxZremrangebyscore(String, String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxZremrangebyscore(String, String, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Remove all members in a sorted set within the given scores
- rxZremrangebyscore(String, String, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Remove all members in a sorted set within the given scores
- rxZrevrange(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxZrevrange(String, long, long, RangeOptions) - Method in class io.vertx.reactivex.redis.RedisClient
-
Return a range of members in a sorted set, by index, with scores ordered from high to low
- rxZrevrange(String, long, long, RangeOptions) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return a range of members in a sorted set, by index, with scores ordered from high to low
- rxZrevrangebylex(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxZrevrangebylex(String, String, String, LimitOptions) - Method in class io.vertx.reactivex.redis.RedisClient
-
Return a range of members in a sorted set, by score, between the given lexicographical range with scores ordered from high to low
- rxZrevrangebylex(String, String, String, LimitOptions) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return a range of members in a sorted set, by score, between the given lexicographical range with scores ordered from high to low
- rxZrevrangebyscore(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxZrevrangebyscore(String, String, String, RangeLimitOptions) - Method in class io.vertx.reactivex.redis.RedisClient
-
Return a range of members in a sorted set, by score, with scores ordered from high to low
- rxZrevrangebyscore(String, String, String, RangeLimitOptions) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Return a range of members in a sorted set, by score, with scores ordered from high to low
- rxZrevrank(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxZrevrank(String, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Determine the index of a member in a sorted set, with scores ordered from high to low
- rxZrevrank(String, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
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
-
- rxZscan(String, String, ScanOptions) - Method in class io.vertx.reactivex.redis.RedisClient
-
Incrementally iterate sorted sets elements and associated scores
- rxZscan(String, String, ScanOptions) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Incrementally iterate sorted sets elements and associated scores
- rxZscore(String, String) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxZscore(String, String) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get the score associated with the given member in a sorted set
- rxZscore(String, String) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get the score associated with the given member in a sorted set
- rxZunionstore(List<String>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- rxZunionstore(String, List<String>, AggregateOptions) - Method in class io.vertx.reactivex.redis.RedisClient
-
Add multiple sorted sets and store the resulting sorted set in a new key
- rxZunionstore(String, List<String>, AggregateOptions) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Add multiple sorted sets and store the resulting sorted set in a new key
- rxZunionstoreWeighed(String, Map<String, Double>, AggregateOptions) - Method in class io.vertx.reactivex.redis.RedisClient
-
Add multiple sorted sets using weights, and store the resulting sorted set in a new key
- rxZunionstoreWeighed(String, Map<String, Double>, AggregateOptions) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Add multiple sorted sets using weights, and store the resulting sorted set in a new key
- SADD - Static variable in class io.vertx.reactivex.redis.client.Command
-
- sadd(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- sadd(String, String, Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Add a member to a set
- sadd(String, String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Add a member to a set
- saddMany(String, List<String>, Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Add one or more members to a set
- saddMany(String, List<String>, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
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
-
- save(T, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.cassandra.Mapper
-
Asynchronous save method.
- save(String, JsonObject, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Save a document in the specified collection
- save(String, JsonObject, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- SAVE - Static variable in class io.vertx.reactivex.redis.client.Command
-
- save(Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- save(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Synchronously save the dataset to disk
- save(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Synchronously save the dataset to disk
- saveWithOptions(String, JsonObject, WriteOption, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.ext.mongo.MongoClient
-
Save a document in the specified collection with the specified write option
- saveWithOptions(String, JsonObject, WriteOption, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.ext.mongo.MongoService
-
- SC_ACCEPTED - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
202 Accepted
- SC_BAD_GATEWAY - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
502 Bad Gateway
- SC_BAD_REQUEST - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
400 Bad Request
- SC_CLIENT_ERRORS - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
Any 4XX client error
- SC_CONFLICT - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
409 Conflict
- SC_CONTINUE - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
100 Continue
- SC_CREATED - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
201 Created
- SC_EARLY_HINTS - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
103 Early Hints
- SC_EXPECTATION_FAILED - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
417 Expectation Failed
- SC_FAILED_DEPENDENCY - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
424 Failed Dependency (WebDAV, RFC4918)
- SC_FORBIDDEN - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
403 Forbidden
- SC_FOUND - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
302 Found
- SC_GATEWAY_TIMEOUT - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
504 Gateway Timeout
- SC_GONE - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
410 Gone
- SC_HTTP_VERSION_NOT_SUPPORTED - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
505 HTTP Version Not Supported
- SC_INFORMATIONAL_RESPONSE - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
Any 1XX informational response
- SC_INSUFFICIENT_STORAGE - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
507 Insufficient Storage (WebDAV, RFC4918)
- SC_INTERNAL_SERVER_ERROR - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
500 Internal Server Error
- SC_LENGTH_REQUIRED - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
411 Length Required
- SC_LOCKED - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
423 Locked (WebDAV, RFC4918)
- SC_METHOD_NOT_ALLOWED - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
405 Method Not Allowed
- SC_MISDIRECTED_REQUEST - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
421 Misdirected Request
- SC_MOVED_PERMANENTLY - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
301 Moved Permanently
- SC_MULTI_STATUS - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
207 Multi-Status (WebDAV, RFC2518)
- SC_MULTIPLE_CHOICES - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
300 Multiple Choices
- SC_NETWORK_AUTHENTICATION_REQUIRED - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
511 Network Authentication Required (RFC6585)
- SC_NO_CONTENT - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
204 No Content
- SC_NON_AUTHORITATIVE_INFORMATION - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
203 Non-Authoritative Information (since HTTP/1.1)
- SC_NOT_ACCEPTABLE - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
406 Not Acceptable
- SC_NOT_EXTENDED - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
510 Not Extended (RFC2774)
- SC_NOT_FOUND - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
404 Not Found
- SC_NOT_IMPLEMENTED - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
501 Not Implemented
- SC_NOT_MODIFIED - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
304 Not Modified
- SC_OK - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
200 OK
- SC_PARTIAL_CONTENT - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
206 Partial Content
- SC_PAYMENT_REQUIRED - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
402 Payment Required
- SC_PERMANENT_REDIRECT - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
308 Permanent Redirect (RFC7538)
- SC_PRECONDITION_FAILED - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
412 Precondition Failed
- SC_PRECONDITION_REQUIRED - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
428 Precondition Required (RFC6585)
- SC_PROCESSING - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
102 Processing (WebDAV, RFC2518)
- SC_PROXY_AUTHENTICATION_REQUIRED - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
407 Proxy Authentication Required
- SC_REDIRECTION - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
Any 3XX redirection
- SC_REQUEST_ENTITY_TOO_LARGE - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
413 Request Entity Too Large
- SC_REQUEST_HEADER_FIELDS_TOO_LARGE - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
431 Request Header Fields Too Large (RFC6585)
- SC_REQUEST_TIMEOUT - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
408 Request Timeout
- SC_REQUEST_URI_TOO_LONG - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
414 Request-URI Too Long
- SC_REQUESTED_RANGE_NOT_SATISFIABLE - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
416 Requested Range Not Satisfiable
- SC_RESET_CONTENT - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
205 Reset Content
- SC_SEE_OTHER - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
303 See Other (since HTTP/1.1)
- SC_SERVER_ERRORS - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
Any 5XX server error
- SC_SERVICE_UNAVAILABLE - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
503 Service Unavailable
- SC_SUCCESS - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
Any 2XX success
- SC_SWITCHING_PROTOCOLS - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
101 Switching Protocols
- SC_TEMPORARY_REDIRECT - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
307 Temporary Redirect (since HTTP/1.1)
- SC_TOO_MANY_REQUESTS - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
429 Too Many Requests (RFC6585)
- SC_UNAUTHORIZED - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
401 Unauthorized
- SC_UNORDERED_COLLECTION - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
425 Unordered Collection (WebDAV, RFC3648)
- SC_UNPROCESSABLE_ENTITY - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
422 Unprocessable Entity (WebDAV, RFC4918)
- SC_UNSUPPORTED_MEDIA_TYPE - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
415 Unsupported Media Type
- SC_UPGRADE_REQUIRED - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
426 Upgrade Required (RFC2817)
- SC_USE_PROXY - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
305 Use Proxy (since HTTP/1.1)
- SC_VARIANT_ALSO_NEGOTIATES - Static variable in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
506 Variant Also Negotiates (RFC2295)
- SCAN - Static variable in class io.vertx.reactivex.redis.client.Command
-
- scan(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- scan(String, ScanOptions, Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Incrementally iterate the keys space
- scan(String, ScanOptions, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Incrementally iterate the keys space
- SCARD - Static variable in class io.vertx.reactivex.redis.client.Command
-
- scard(String, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- scard(String, Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get the number of members in a set
- scard(String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get the number of members in a set
- scheduler(Context) - Static method in class io.vertx.reactivex.core.RxHelper
-
Create a scheduler for a
Context
, actions are executed on the event loop of this context.
- scheduler(Vertx) - Static method in class io.vertx.reactivex.core.RxHelper
-
Create a scheduler for a
Vertx
object, actions are executed on the event loop.
- scheme() - Method in class io.vertx.reactivex.core.http.HttpServerRequest
-
- SCRIPT - Static variable in class io.vertx.reactivex.redis.client.Command
-
- script(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- Script - Class in io.vertx.reactivex.redis
-
This factory is deprecated use
Redis
instead,
or for a typed API
RedisAPI
.
- Script(Script) - Constructor for class io.vertx.reactivex.redis.Script
-
- Script(Object) - Constructor for class io.vertx.reactivex.redis.Script
-
- scriptDebug(ScriptDebugOptions, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set the debug mode for executed scripts.
- scriptExists(String, Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Check existence of script in the script cache.
- scriptExists(String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Check existence of script in the script cache.
- scriptExistsMany(List<String>, Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Check existence of scripts in the script cache.
- scriptExistsMany(List<String>, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Check existence of scripts in the script cache.
- scriptFlush(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Remove all the scripts from the script cache.
- scriptFlush(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Remove all the scripts from the script cache.
- scriptKill(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Kill the script currently in execution.
- scriptKill(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Kill the script currently in execution.
- scriptLoad(String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Load the specified Lua script into the script cache.
- scriptLoad(String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Load the specified Lua script into the script cache.
- SDIFF - Static variable in class io.vertx.reactivex.redis.client.Command
-
- sdiff(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- sdiff(String, List<String>, Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Subtract multiple sets
- sdiff(String, List<String>, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Subtract multiple sets
- SDIFFSTORE - Static variable in class io.vertx.reactivex.redis.client.Command
-
- sdiffstore(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- sdiffstore(String, String, List<String>, Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Subtract multiple sets and store the resulting set in a key
- sdiffstore(String, String, List<String>, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Subtract multiple sets and store the resulting set in a key
- secretKey() - Method in class io.vertx.reactivex.pgclient.PgConnection
-
- 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, long, Handler<AsyncResult<Void>>) - 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.
- seekToBeginning(TopicPartition, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
-
Seek to the first offset for each of the given partition.
- seekToBeginning(Set<TopicPartition>, Handler<AsyncResult<Void>>) - 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.
- seekToEnd(TopicPartition, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
-
Seek to the last offset for each of the given partition.
- seekToEnd(Set<TopicPartition>, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
-
Seek to the last offset for each of the given partitions.
- SELECT - Static variable in class io.vertx.reactivex.redis.client.Command
-
- select(String, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- select(int, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Change the selected database for the current connection
- select(int, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Change the selected database for the current connection
- SelfSignedCertificate - Class in io.vertx.reactivex.core.net
-
A self-signed certificate helper for testing and development purposes.
- SelfSignedCertificate(SelfSignedCertificate) - Constructor for class io.vertx.reactivex.core.net.SelfSignedCertificate
-
- SelfSignedCertificate(Object) - Constructor for class io.vertx.reactivex.core.net.SelfSignedCertificate
-
- send(AmqpMessage) - Method in class io.vertx.reactivex.amqp.AmqpSender
-
Sends an AMQP message.
- send(Buffer, int, String, Handler<AsyncResult<DatagramSocket>>) - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
-
- send(String, int, String, Handler<AsyncResult<DatagramSocket>>) - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
-
- send(String, String, int, String, Handler<AsyncResult<DatagramSocket>>) - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
-
- send() - Method in class io.vertx.reactivex.core.eventbus.DeliveryContext
-
- send(String, Object) - Method in class io.vertx.reactivex.core.eventbus.EventBus
-
Sends a message.
- send(String, Object, Handler<AsyncResult<Message<T>>>) - Method in class io.vertx.reactivex.core.eventbus.EventBus
-
Deprecated.
- send(String, Object, DeliveryOptions) - Method in class io.vertx.reactivex.core.eventbus.EventBus
-
Like but specifying options
that can be used to configure the delivery.
- send(String, Object, DeliveryOptions, Handler<AsyncResult<Message<T>>>) - Method in class io.vertx.reactivex.core.eventbus.EventBus
-
Deprecated.
- send(T) - Method in class io.vertx.reactivex.core.eventbus.MessageProducer
-
Deprecated.
- send(T, Handler<AsyncResult<Message<R>>>) - Method in class io.vertx.reactivex.core.eventbus.MessageProducer
-
Deprecated.
- send(Map<String, String>, Buffer) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
-
Sends a SEND
frame to the server.
- send(Map<String, String>, Buffer, Handler<Frame>) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
-
Sends a SEND
frame to the server.
- 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, Buffer, Handler<Frame>) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
-
Sends a SEND
frame to the server to the given destination.
- send(Frame) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
-
Sends the given frame to the server.
- send(Frame, Handler<Frame>) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
-
Sends the given frame to the server.
- 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(String, Map<String, String>, Buffer, Handler<Frame>) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
-
Sends a SEND
frame to the server to the given destination.
- send(Handler<AsyncResult<HttpResponse<T>>>) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
-
Send a request, the
handler
will receive the response as an
HttpResponse
.
- send(KafkaProducerRecord<K, V>) - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
-
Asynchronously write a record to a topic
- send(KafkaProducerRecord<K, V>, Handler<AsyncResult<RecordMetadata>>) - Method in class io.vertx.reactivex.kafka.client.producer.KafkaProducer
-
Asynchronously write a record to a topic
- send(Request, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.Redis
-
Send the given command to the redis server or cluster.
- send(Request, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisConnection
-
Send the given command to the redis server or cluster.
- sendBuffer(Buffer, Handler<AsyncResult<HttpResponse<T>>>) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
-
- sender() - Method in class io.vertx.reactivex.core.datagram.DatagramPacket
-
- sender(int, String) - Method in class io.vertx.reactivex.core.datagram.DatagramSocket
-
- 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
-
- sendFile(String) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
- sendFile(String, long) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
- 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, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
- sendFile(String, long, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
- sendFile(String, long, long, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.core.http.HttpServerResponse
-
- 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.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.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, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.core.net.NetSocket
-
- sendFile(String, long, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.core.net.NetSocket
-
- sendFile(String, long, long, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.core.net.NetSocket
-
- sendForm(MultiMap, Handler<AsyncResult<HttpResponse<T>>>) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
-
- 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
-
- sendHead(Handler<HttpVersion>) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
-
- sendJson(Object, Handler<AsyncResult<HttpResponse<T>>>) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
-
- sendJsonObject(JsonObject, Handler<AsyncResult<HttpResponse<T>>>) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
-
- sendMail(MailMessage, Handler<AsyncResult<MailResult>>) - Method in class io.vertx.reactivex.ext.mail.MailClient
-
send a single mail via MailClient
- sendMail(MailMessage, Handler<AsyncResult<MailResult>>) - Method in class io.vertx.reactivex.ext.mail.MailService
-
- sendMultipartForm(MultipartForm, Handler<AsyncResult<HttpResponse<T>>>) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
-
- sendStream(ReadStream<Buffer>, Handler<AsyncResult<HttpResponse<T>>>) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
-
- sendStream(Flowable<Buffer>, Handler<AsyncResult<HttpResponse<T>>>) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
-
- sendStream(Observable<Buffer>, Handler<AsyncResult<HttpResponse<T>>>) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
-
- sendWithAck(AmqpMessage, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.amqp.AmqpSender
-
Sends an AMQP message and waits for an acknowledgement.
- SENTINEL - Static variable in class io.vertx.reactivex.redis.client.Command
-
- sentinels(String, Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.sentinel.RedisSentinel
-
Show a list of sentinel instances for this master, and their state
- server() - Method in class io.vertx.reactivex.ext.shell.ShellService
-
- server() - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
-
- server() - Method in class io.vertx.reactivex.ext.stomp.StompServerConnection
-
- 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
-
- 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
-
- serverWebSocket() - Method in class io.vertx.reactivex.ext.web.handler.graphql.ApolloWSMessage
-
- service() - Method in class io.vertx.reactivex.core.dns.SrvRecord
-
Returns the service's name (i.e.
- 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
-
- 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
-
- 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(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.shell.cli.Completion
-
- session() - Method in class io.vertx.reactivex.ext.shell.command.CommandProcess
-
- Session - Class in io.vertx.reactivex.ext.shell.session
-
A shell session.
- Session(Session) - Constructor for class io.vertx.reactivex.ext.shell.session.Session
-
- Session(Object) - Constructor for class io.vertx.reactivex.ext.shell.session.Session
-
- session() - Method in class io.vertx.reactivex.ext.shell.Shell
-
- 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
-
- sessionState(JsonObject) - Static method in class io.vertx.reactivex.ext.auth.oauth2.KeycloakHelper
-
- SessionStore - Class in io.vertx.reactivex.ext.web.sstore
-
A session store is used to store sessions for an Vert.x-Web web app
NOTE: This class has been automatically generated from the
original
non RX-ified interface using Vert.x codegen.
- 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(String, String) - Method in class io.vertx.reactivex.core.MultiMap
-
Sets a value
under the specified name
.
- set(CharSequence, CharSequence) - Method in class io.vertx.reactivex.core.MultiMap
-
- set(String, Iterable<String>) - Method in class io.vertx.reactivex.core.MultiMap
-
Sets values for the specified name.
- set(CharSequence, Iterable<CharSequence>) - Method in class io.vertx.reactivex.core.MultiMap
-
- SET - Static variable in class io.vertx.reactivex.redis.client.Command
-
- set(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- set(String, String, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set the string value of a key
- set(String, String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Set the string value of a key
- 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.
- setAlgorithm(HashAlgorithm) - Method in class io.vertx.reactivex.ext.auth.mongo.HashStrategy
-
Allows the selection of the hashing algorithm.
- setAll(MultiMap) - Method in class io.vertx.reactivex.core.MultiMap
-
Cleans this instance.
- setAll(Map<String, String>) - Method in class io.vertx.reactivex.core.MultiMap
-
Cleans and set all values of the given instance
- setAllowRootFileSystemAccess(boolean) - Method in class io.vertx.reactivex.ext.web.handler.StaticHandler
-
Enable/Disable access to the root of the filesystem
- setAlwaysAsyncFS(boolean) - Method in class io.vertx.reactivex.ext.web.handler.StaticHandler
-
Set whether async filesystem access should always be used
- setArguments(List<Argument>) - Method in class io.vertx.reactivex.core.cli.CLI
-
Sets the list of arguments.
- setAudience(List<String>) - Method in class io.vertx.reactivex.ext.web.handler.JWTAuthHandler
-
Set the audience list
- setAuthenticationQuery(String) - Method in class io.vertx.reactivex.ext.auth.jdbc.JDBCAuth
-
Set the authentication query to use.
- setAuthProvider(AuthProvider) - Method in class io.vertx.reactivex.ext.auth.User
-
Deprecated.
- setAuthProvider(AuthProvider) - Method in class io.vertx.reactivex.ext.web.handler.SessionHandler
-
Deprecated.
- setAutoCommit(boolean, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.sql.SQLConnection
-
Sets the auto commit flag for this connection.
- setBeforeScanHandler(Handler<Void>) - Method in class io.vertx.reactivex.config.ConfigRetriever
-
Registers a handler called before every scan.
- setBinary(String, Buffer, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set the binary string value of a key - without encoding as utf-8
- setBinary(String, Buffer, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Set the binary string value of a key - without encoding as utf-8
- setBinaryWithOptions(String, Buffer, SetOptions, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set the string value of a key
- setBinaryWithOptions(String, Buffer, SetOptions, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Set the string value of a key
- SETBIT - Static variable in class io.vertx.reactivex.redis.client.Command
-
- setbit(String, String, String, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- setbit(String, long, int, Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Sets or clears the bit at offset in the string value stored at key
- setbit(String, long, int, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Sets or clears the bit at offset in the string value stored at key
- setBody(Buffer) - Method in class io.vertx.reactivex.ext.web.RoutingContext
-
Set the body.
- setBodyHandler(BodyHandler) - Method in class io.vertx.reactivex.ext.web.api.contract.openapi3.OpenAPI3RouterFactory
-
Supply your own BodyHandler if you would like to control body limit, uploads directory and deletion of uploaded files
- setBodyHandler(BodyHandler) - Method in interface io.vertx.reactivex.ext.web.api.contract.RouterFactory
-
Supply your own BodyHandler if you would like to control body limit, uploads directory and deletion of uploaded files
- setBodyLimit(long) - Method in class io.vertx.reactivex.ext.web.handler.BodyHandler
-
Set the maximum body size in bytes, -1
means no limit
- setBuffer(int, Buffer) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Sets the bytes at position pos
in the Buffer to the bytes represented by the Buffer b
.
- setBuffer(int, Buffer, int, int) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Sets the bytes at position pos
in the Buffer to the bytes represented by the Buffer b
on the given offset
and len
.
- setByte(int, byte) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Sets the byte
at position pos
in the Buffer to the value b
.
- setBytes(int, ByteBuffer) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Sets the bytes at position pos
in the Buffer to the bytes represented by the ByteBuffer b
.
- setBytes(int, byte[]) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Sets the bytes at position pos
in the Buffer to the bytes represented by the byte[] b
.
- setBytes(int, byte[], int, int) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Sets the given number of bytes at position pos
in the Buffer to the bytes represented by the byte[] b
.
- 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
- setChanged(boolean) - Method in class io.vertx.reactivex.ext.web.Cookie
-
Deprecated.
- 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)
- setCollectionName(String) - Method in class io.vertx.reactivex.ext.auth.mongo.MongoAuth
-
Set the name of the collection to be used.
- setConfigurationProcessor(Function<JsonObject, JsonObject>) - Method in class io.vertx.reactivex.config.ConfigRetriever
-
- setCookieHttpOnlyFlag(boolean) - Method in class io.vertx.reactivex.ext.web.handler.SessionHandler
-
Sets whether the 'HttpOnly' flag should be set for 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.
- setCookieSecureFlag(boolean) - Method in class io.vertx.reactivex.ext.web.handler.SessionHandler
-
Sets whether the 'secure' flag should be set for the session cookie.
- 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.core.cli.CLI
-
- 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
- setDomain(String) - Method in class io.vertx.reactivex.core.http.Cookie
-
Sets the domain of this cookie
- setDomain(String) - Method in class io.vertx.reactivex.ext.web.Cookie
-
Deprecated.
- setDouble(int, double) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Sets the double
at position pos
in the Buffer to the value d
.
- 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 - Static variable in class io.vertx.reactivex.redis.client.Command
-
- setex(String, String, String, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- setex(String, long, String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set the value and expiration of a key
- setex(String, long, String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
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.
- setExtension(String) - Method in class io.vertx.reactivex.ext.web.templ.freemarker.FreeMarkerTemplateEngine
-
Deprecated.
- setExtension(String) - Method in class io.vertx.reactivex.ext.web.templ.handlebars.HandlebarsTemplateEngine
-
Deprecated.
- setExtension(String) - Method in class io.vertx.reactivex.ext.web.templ.jade.JadeTemplateEngine
-
Deprecated.
- setExtension(String) - Method in class io.vertx.reactivex.ext.web.templ.mvel.MVELTemplateEngine
-
Deprecated.
- setExtension(String) - Method in class io.vertx.reactivex.ext.web.templ.pebble.PebbleTemplateEngine
-
Deprecated.
- setExtension(String) - Method in class io.vertx.reactivex.ext.web.templ.rocker.RockerTemplateEngine
-
Deprecated.
- setExternalSalt(String) - Method in class io.vertx.reactivex.ext.auth.mongo.HashStrategy
-
Set an external salt.
- setExtraOperationContextPayloadMapper(Function<RoutingContext, JsonObject>) - Method in class io.vertx.reactivex.ext.web.api.contract.openapi3.OpenAPI3RouterFactory
-
When set, this function is called while creating the payload of OperationRequest
- setExtraOperationContextPayloadMapper(Function<RoutingContext, JsonObject>) - Method in interface io.vertx.reactivex.ext.web.api.contract.RouterFactory
-
When set, this function is called while creating the payload of OperationRequest
- setFilesReadOnly(boolean) - Method in class io.vertx.reactivex.ext.web.handler.StaticHandler
-
Set whether files are read-only and will never change
- setFloat(int, float) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Sets the float
at position pos
in the Buffer to the value f
.
- 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<AsyncResult<CompositeFuture>>) - Method in class io.vertx.reactivex.core.CompositeFuture
-
Deprecated.
- setHandler(Handler<AsyncResult<T>>) - Method in class io.vertx.reactivex.core.Future
-
Deprecated.
- setHandler(Handler<WatchResult<T>>) - Method in class io.vertx.reactivex.ext.consul.Watch
-
Set the result handler.
- setHandshake(Future<Integer>, Handler<AsyncResult<Integer>>) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
-
Set an asynchronous result for the handshake, upon completion of the specified
future
, the
WebSocket will either be
accepted when the
future
succeeds with the HTTP status code
rejected when the
future
is succeeds with an HTTP status code different than
rejected when the
future
fails with the HTTP status code
500
The provided future might be completed by the WebSocket itself, e.g calling the
ServerWebSocket.close(io.vertx.core.Handler<io.vertx.core.AsyncResult<java.lang.Void>>)
method
will try to accept the handshake and close the WebSocket afterward.
- setHandshake(Future<Integer>) - Method in class io.vertx.reactivex.core.http.ServerWebSocket
-
- setHashAlgorithm(HashAlgorithm) - Method in class io.vertx.reactivex.ext.auth.mongo.MongoAuth
-
The Hash Algorithm which is used by the current instance
- setHashStrategy(HashStrategy) - Method in class io.vertx.reactivex.ext.auth.mongo.MongoAuth
-
The HashStrategy which is used by the current instance
- setHeaderName(String) - Method in class io.vertx.reactivex.ext.web.handler.CSRFHandler
-
Set the header name.
- setHidden(boolean) - Method in class io.vertx.reactivex.core.cli.CLI
-
Sets whether or not the current instance of
CLI
must be hidden.
- setHost(String) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
-
Set the request host.
For HTTP/2 it sets the pseudo header otherwise it sets the header
- setHttp2PushMapping(List<Http2PushMapping>) - Method in class io.vertx.reactivex.ext.web.handler.StaticHandler
-
Set the file mapping for http2push and link preload
- setHttpOnly(boolean) - Method in class io.vertx.reactivex.core.http.Cookie
-
Determines if this cookie is HTTP only.
- setHttpOnly(boolean) - Method in class io.vertx.reactivex.ext.web.Cookie
-
Deprecated.
- setIgnoreExpiration(boolean) - Method in class io.vertx.reactivex.ext.web.handler.JWTAuthHandler
-
Set whether expiration is ignored
- 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
- setInt(int, int) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Sets the int
at position pos
in the Buffer to the value i
.
- setIntLE(int, int) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Sets the int
at position pos
in the Buffer to the value i
in the Little Endian Byte Order.
- setIssuer(String) - Method in class io.vertx.reactivex.ext.web.handler.JWTAuthHandler
-
Set the issuer
- setLazySession(boolean) - Method in class io.vertx.reactivex.ext.web.handler.SessionHandler
-
Use a lazy session creation mechanism.
- setLong(int, long) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Sets the long
at position pos
in the Buffer to the value l
.
- setLongLE(int, long) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Sets the long
at position pos
in the Buffer to the value l
in the Little Endian Byte Order.
- setMaxAge(long) - Method in class io.vertx.reactivex.core.http.Cookie
-
Sets the maximum age of this cookie in seconds.
- setMaxAge(long) - Method in class io.vertx.reactivex.ext.web.Cookie
-
Deprecated.
- 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
- setMaxBufferedMessages(int) - Method in class io.vertx.reactivex.core.eventbus.MessageConsumer
-
Set the number of messages this registration will buffer when this stream is paused.
- setMaxCacheSize(int) - Method in class io.vertx.reactivex.ext.web.handler.StaticHandler
-
Set the max cache size, when caching is enabled
- setMaxCacheSize(int) - Method in class io.vertx.reactivex.ext.web.templ.freemarker.FreeMarkerTemplateEngine
-
Set the max cache size for the engine
- setMaxCacheSize(int) - Method in class io.vertx.reactivex.ext.web.templ.handlebars.HandlebarsTemplateEngine
-
Set the max cache size for the engine
- setMaxCacheSize(int) - Method in class io.vertx.reactivex.ext.web.templ.jade.JadeTemplateEngine
-
Set the max cache size for the engine
- setMaxCacheSize(int) - Method in class io.vertx.reactivex.ext.web.templ.mvel.MVELTemplateEngine
-
Set the max cache size for the engine
- setMaxCacheSize(int) - Method in class io.vertx.reactivex.ext.web.templ.pebble.PebbleTemplateEngine
-
Set the max cache size for the engine
- setMaxCacheSize(int) - Method in class io.vertx.reactivex.ext.web.templ.rocker.RockerTemplateEngine
-
Set the max cache size for the engine
- setMaxRedirects(int) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
-
Set the max number of HTTP redirects this request will follow.
- setMedium(int, int) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Sets the 24bit int
at position pos
in the Buffer to the value i
.
- setMediumLE(int, int) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Sets the 24bit int
at position pos
in the Buffer to the value i
.
- setMergeFormAttributes(boolean) - Method in class io.vertx.reactivex.ext.web.handler.BodyHandler
-
Set whether form attributes will be added to the request parameters
- setMinLength(int) - Method in class io.vertx.reactivex.ext.web.handler.SessionHandler
-
Set expected session id minimum length.
- setMode(TemplateMode) - Method in class io.vertx.reactivex.ext.web.templ.thymeleaf.ThymeleafTemplateEngine
-
Set the mode for the engine
- 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.core.cli.CLI
-
Sets the name of the CLI.
- setName(String) - Method in class io.vertx.reactivex.ext.web.api.RequestParameter
-
Set parameter name
- setNonces(JsonArray) - Method in class io.vertx.reactivex.ext.auth.jdbc.JDBCAuth
-
Provide a application configuration level on hash nonce's as a ordered list of
nonces where each position corresponds to a version.
- setNonces(JsonArray) - Method in class io.vertx.reactivex.ext.auth.jdbc.JDBCHashStrategy
-
Sets a ordered list of nonces where each position corresponds to a version.
- setNotImplementedFailureHandler(Handler<RoutingContext>) - Method in class io.vertx.reactivex.ext.web.api.contract.openapi3.OpenAPI3RouterFactory
-
Deprecated.
- setNotImplementedFailureHandler(Handler<RoutingContext>) - Method in interface io.vertx.reactivex.ext.web.api.contract.RouterFactory
-
Deprecated.
- SETNX - Static variable in class io.vertx.reactivex.redis.client.Command
-
- setnx(String, String, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- setnx(String, String, Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set the value of a key, only if the key does not exist
- setnx(String, String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Set the value of a key, only if the key does not exist
- setOption(MySQLSetOption, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.mysqlclient.MySQLConnection
-
Send a SET_OPTION command to set options for the current connection.
- setOptions(List<Option>) - Method in class io.vertx.reactivex.core.cli.CLI
-
Sets the list of arguments.
- setOptions(SQLOptions) - Method in class io.vertx.reactivex.ext.sql.SQLConnection
-
Sets the desired options to be applied to the current connection when statements are executed.
- setOptions(RouterFactoryOptions) - Method in class io.vertx.reactivex.ext.web.api.contract.openapi3.OpenAPI3RouterFactory
-
Set options of router factory.
- setOptions(RouterFactoryOptions) - Method in interface io.vertx.reactivex.ext.web.api.contract.RouterFactory
-
Set options of router factory.
- setOutput(Handler<Buffer>) - Method in class io.vertx.reactivex.core.parsetools.RecordParser
-
- setPasswordCredentialField(String) - Method in class io.vertx.reactivex.ext.auth.mongo.MongoAuth
-
- setPasswordField(String) - Method in class io.vertx.reactivex.ext.auth.mongo.MongoAuth
-
Set the name of the field to be used for the password Defaults to
MongoAuth
- setPasswordParam(String) - Method in class io.vertx.reactivex.ext.web.handler.FormLoginHandler
-
Set the name of the form param used to submit the password
- setPath(String) - Method in class io.vertx.reactivex.core.http.Cookie
-
Sets the path of this cookie.
- setPath(String) - Method in class io.vertx.reactivex.ext.web.Cookie
-
Deprecated.
- setPeriodic(long, Handler<Long>) - Method in class io.vertx.reactivex.core.Vertx
-
Set a periodic timer to fire every delay
milliseconds, at which point handler
will be called with
the id of the timer.
- setPermissionField(String) - Method in class io.vertx.reactivex.ext.auth.mongo.MongoAuth
-
Set the name of the field to be used for the permissions.
- setPermissionsQuery(String) - Method in class io.vertx.reactivex.ext.auth.jdbc.JDBCAuth
-
Set the permissions query to use.
- 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.
- setPriority(int) - Method in class io.vertx.reactivex.core.cli.CLI
-
Sets the priority of the CLI.
- setPrompt(Function<Session, String>) - Method in class io.vertx.reactivex.ext.shell.Shell
-
Set a new prompt in this session.
- 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.ext.sql.SQLConnection
-
Deprecated.
- SETRANGE - Static variable in class io.vertx.reactivex.redis.client.Command
-
- setrange(String, String, String, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- setrange(String, int, String, Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Overwrite part of a string at key starting at the specified offset
- setrange(String, int, String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Overwrite part of a string at key starting at the specified offset
- setRawMessage(JsonObject) - Method in class io.vertx.reactivex.ext.bridge.BaseBridgeEvent
-
Get 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
-
Get the raw JSON message for the event.
- setRawMethod(String) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
-
Set the value the method to send when the method is used.
- 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.
- setResponseBody(String) - Method in class io.vertx.reactivex.ext.web.handler.CSRFHandler
-
Set the body returned by the handler when the XSRF token is missing or invalid.
- 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
- setRoleField(String) - Method in class io.vertx.reactivex.ext.auth.mongo.MongoAuth
-
Set the name of the field to be used for the roles.
- setRolePrefix(String) - Method in class io.vertx.reactivex.ext.auth.jdbc.JDBCAuth
-
Set the role prefix to distinguish from permissions when checking for isPermitted requests.
- setRolePrefix(String) - Method in class io.vertx.reactivex.ext.auth.shiro.ShiroAuth
-
Set the role prefix to distinguish from permissions when checking for isPermitted requests.
- setRolesQuery(String) - Method in class io.vertx.reactivex.ext.auth.jdbc.JDBCAuth
-
Set the roles query to use.
- setSaltField(String) - Method in class io.vertx.reactivex.ext.auth.mongo.MongoAuth
-
Set the name of the field to be used for the salt.
- setSaltStyle(HashSaltStyle) - Method in class io.vertx.reactivex.ext.auth.mongo.HashStrategy
-
Set the saltstyle as defined by HashSaltStyle
.
- setSameSite(CookieSameSite) - Method in class io.vertx.reactivex.core.http.Cookie
-
Sets the same site of this cookie.
- setSecure(boolean) - Method in class io.vertx.reactivex.core.http.Cookie
-
Sets the security getStatus of this cookie
- setSecure(boolean) - Method in class io.vertx.reactivex.ext.web.Cookie
-
Deprecated.
- setSendVaryHeader(boolean) - Method in class io.vertx.reactivex.ext.web.handler.StaticHandler
-
Set whether vary header should be sent with response.
- setSession(Session) - Method in class io.vertx.reactivex.ext.shell.system.Job
-
Set a session on the job.
- setSession(Session) - Method in class io.vertx.reactivex.ext.shell.system.Process
-
Set the process session
- setSession(Session) - Method in class io.vertx.reactivex.ext.shell.term.Term
-
Associate the term with a session.
- setSession(Session) - Method in class io.vertx.reactivex.ext.web.RoutingContext
-
Set the session.
- 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
- setShort(int, short) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Sets the short
at position pos
in the Buffer to the value s
.
- setShortLE(int, short) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Sets the short
at position pos
in the Buffer to the value s
in the Little Endian Byte Order.
- setSize(int, int) - Method in class io.vertx.reactivex.ext.shell.term.Pty
-
Resize the terminal.
- 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
- 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
This is not implemented for HTTP/1.x.
- setString(int, String) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Sets the bytes at position pos
in the Buffer to the value of str
encoded in UTF-8.
- setString(int, String, String) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Sets the bytes at position pos
in the Buffer to the value of str
encoded in encoding enc
.
- setSummary(String) - Method in class io.vertx.reactivex.core.cli.CLI
-
Sets the summary of the CLI.
- setTimeout(long) - Method in class io.vertx.reactivex.core.http.HttpClientRequest
-
Set's the amount of time after which if the request does not return any data within the timeout period an
TimeoutException
will be passed to the exception handler (if provided) and
the request will be closed.
- 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.
- setTimer(long, Handler<Long>) - Method in class io.vertx.reactivex.core.Vertx
-
Set a one-shot timer to fire after delay
milliseconds, at which point handler
will be called with
the id of the timer.
- settings() - Method in class io.vertx.reactivex.core.http.HttpConnection
-
- setTransactionIsolation(TransactionIsolation, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.sql.SQLConnection
-
Attempts to change the transaction isolation level for this Connection object to the one given.
- setTrustJWT(boolean) - Method in class io.vertx.reactivex.ext.auth.oauth2.AccessToken
-
- setTty(Tty) - Method in class io.vertx.reactivex.ext.shell.system.Job
-
Set a tty on the job.
- setTty(Tty) - Method in class io.vertx.reactivex.ext.shell.system.Process
-
Set the process tty.
- setUnsignedByte(int, short) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Sets the unsigned byte
at position pos
in the Buffer to the value b
.
- setUnsignedInt(int, long) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Sets the unsigned int
at position pos
in the Buffer to the value i
.
- setUnsignedIntLE(int, long) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Sets the unsigned int
at position pos
in the Buffer to the value i
in the Little Endian Byte Order.
- setUnsignedShort(int, int) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Sets the unsigned short
at position pos
in the Buffer to the value s
.
- setUnsignedShortLE(int, int) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Sets the unsigned short
at position pos
in the Buffer to the value s
in the Little Endian Byte Order.
- setupCallback(Route) - Method in class io.vertx.reactivex.ext.web.handler.OAuth2AuthHandler
-
add the callback handler to a given route.
- setUploadsDirectory(String) - Method in class io.vertx.reactivex.ext.web.handler.BodyHandler
-
Set the uploads directory to use
- setUser(User) - Method in class io.vertx.reactivex.ext.web.RoutingContext
-
Set the user.
- setUsernameCredentialField(String) - Method in class io.vertx.reactivex.ext.auth.mongo.MongoAuth
-
- setUsernameField(String) - Method in class io.vertx.reactivex.ext.auth.mongo.MongoAuth
-
Set the name of the field to be used for the username.
- setUsernameParam(String) - Method in class io.vertx.reactivex.ext.web.handler.FormLoginHandler
-
Set the name of the form param used to submit the username
- setValidationFailureHandler(Handler<RoutingContext>) - Method in class io.vertx.reactivex.ext.web.api.contract.openapi3.OpenAPI3RouterFactory
-
Deprecated.
- setValidationFailureHandler(Handler<RoutingContext>) - Method in interface io.vertx.reactivex.ext.web.api.contract.RouterFactory
-
Deprecated.
- setValue(String) - Method in class io.vertx.reactivex.core.http.Cookie
-
Sets the value of this cookie
- setValue(Object) - Method in class io.vertx.reactivex.ext.web.api.RequestParameter
-
Set value
- setValue(String) - Method in class io.vertx.reactivex.ext.web.Cookie
-
Deprecated.
- setWebRoot(String) - Method in class io.vertx.reactivex.ext.web.handler.StaticHandler
-
Set the web root
- setWindowSize(int) - Method in class io.vertx.reactivex.core.http.HttpConnection
-
Update the current connection wide window size to a new size.
- setWithOptions(String, String, SetOptions, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Set the string value of a key
- setWithOptions(String, String, SetOptions, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Set the string value of a key
- 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.eventbus.MessageProducer
-
- setWriteQueueMaxSize(int) - Method in class io.vertx.reactivex.core.file.AsyncFile
-
- 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 class io.vertx.reactivex.core.streams.Pump
-
Set the write queue max size to maxSize
- 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.kafka.client.producer.KafkaProducer
-
- several(int, Handler<AsyncResult<List<Row>>>) - Method in class io.vertx.reactivex.cassandra.ResultSet
-
Fetch a specific amount of rows and notify via a handler.
- 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
-
- sharedData() - Method in class io.vertx.reactivex.core.Vertx
-
Get the shared data object.
- Shell - Class in io.vertx.reactivex.ext.shell
-
An interactive session between a consumer and a shell.
- Shell(Shell) - Constructor for class io.vertx.reactivex.ext.shell.Shell
-
- Shell(Object) - Constructor for class io.vertx.reactivex.ext.shell.Shell
-
- shellHandler(Handler<Shell>) - Method in class io.vertx.reactivex.ext.shell.ShellServer
-
Called when a new shell is created.
- ShellServer - Class in io.vertx.reactivex.ext.shell
-
- ShellServer(ShellServer) - Constructor for class io.vertx.reactivex.ext.shell.ShellServer
-
- ShellServer(Object) - Constructor for class io.vertx.reactivex.ext.shell.ShellServer
-
- ShellService - Class in io.vertx.reactivex.ext.shell
-
The shell service, provides a remotely accessible shell available via Telnet or SSH according to the
ShellServiceOptions
configuration.
The shell service will expose commands using
CommandResolver
on the classpath and
the shared command registry for the Vert.x instance.
- ShellService(ShellService) - Constructor for class io.vertx.reactivex.ext.shell.ShellService
-
- ShellService(Object) - Constructor for class io.vertx.reactivex.ext.shell.ShellService
-
- ShiroAuth - Class in io.vertx.reactivex.ext.auth.shiro
-
Factory interface for creating Apache Shiro based
AuthProvider
instances.
- ShiroAuth(ShiroAuth) - Constructor for class io.vertx.reactivex.ext.auth.shiro.ShiroAuth
-
- ShiroAuth(Object) - Constructor for class io.vertx.reactivex.ext.auth.shiro.ShiroAuth
-
- 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.HttpConnection
-
Initiate a graceful connection shutdown, the connection is taken out of service and closed when all current requests
are processed, otherwise after 30 seconds the connection will be closed.
- shutdown(long) - Method in class io.vertx.reactivex.core.http.HttpConnection
-
- SHUTDOWN - Static variable in class io.vertx.reactivex.redis.client.Command
-
- shutdown(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- shutdownHandler(Handler<Void>) - Method in class io.vertx.reactivex.core.http.HttpConnection
-
Set an handler called when a frame has been sent or received and all connections are closed.
- SignalHandler - Class in io.vertx.reactivex.ext.shell.term
-
NOTE: This class has been automatically generated from the
original
non RX-ified interface using Vert.x codegen.
- SignalHandler(SignalHandler) - Constructor for class io.vertx.reactivex.ext.shell.term.SignalHandler
-
- SignalHandler(Object) - Constructor for class io.vertx.reactivex.ext.shell.term.SignalHandler
-
- SingleHelper - Class in io.vertx.reactivex.core
-
- SingleHelper() - Constructor for class io.vertx.reactivex.core.SingleHelper
-
- SINTER - Static variable in class io.vertx.reactivex.redis.client.Command
-
- sinter(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- sinter(List<String>, Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Intersect multiple sets
- sinter(List<String>, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Intersect multiple sets
- SINTERSTORE - Static variable in class io.vertx.reactivex.redis.client.Command
-
- sinterstore(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- sinterstore(String, List<String>, Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Intersect multiple sets and store the resulting set in a key
- sinterstore(String, List<String>, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Intersect multiple sets and store the resulting set in a key
- SISMEMBER - Static variable in class io.vertx.reactivex.redis.client.Command
-
- sismember(String, String, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- sismember(String, String, Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Determine if a given value is a member of a set
- sismember(String, String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Determine if a given value is a member of a set
- size() - Method in class io.vertx.reactivex.core.CompositeFuture
-
- size() - Method in class io.vertx.reactivex.core.file.FileProps
-
The size of the file, in bytes
- 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.MultiMap
-
Return the number of keys.
- size(Handler<AsyncResult<Integer>>) - 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(Handler<AsyncResult<Integer>>) - 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.redis.client.Response
-
Get this size of this multi response.
- 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
-
- 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.
- slave() - Method in class io.vertx.reactivex.ext.shell.term.Pty
-
- SLAVEOF - Static variable in class io.vertx.reactivex.redis.client.Command
-
- slaveof(String, String, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- slaveof(String, int, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Make the server a slave of another instance
- slaveof(String, int, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Make the server a slave of another instance
- slaveofNoone(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Make this server a master
- slaveofNoone(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Make this server a master
- slaves(String, Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.sentinel.RedisSentinel
-
Show a list of slaves for this master, and their state
- slice() - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Returns a slice of this buffer.
- slice(int, int) - Method in class io.vertx.reactivex.core.buffer.Buffer
-
Returns a slice of this buffer.
- SLOWLOG - Static variable in class io.vertx.reactivex.redis.client.Command
-
- slowlog(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- slowlogGet(int, Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Read the Redis slow queries log
- slowlogGet(int, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Read the Redis slow queries log
- slowlogLen(Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get the length of the Redis slow queries log
- slowlogLen(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get the length of the Redis slow queries log
- slowlogReset(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Reset the Redis slow queries log
- slowlogReset(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Reset the Redis slow queries log
- SMEMBERS - Static variable in class io.vertx.reactivex.redis.client.Command
-
- smembers(String, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- smembers(String, Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get all the members in a set
- smembers(String, Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get all the members in a set
- SMOVE - Static variable in class io.vertx.reactivex.redis.client.Command
-
- smove(String, String, String, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- smove(String, String, String, Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Move a member from one set to another
- smove(String, String, String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
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.sockjs.BridgeEvent
-
Get the SockJSSocket instance corresponding to the event
- SocketAddress - Class in io.vertx.reactivex.core.net
-
The address of a socket, an inet socket address or a domain socket address.
- SocketAddress(SocketAddress) - Constructor for class io.vertx.reactivex.core.net.SocketAddress
-
- SocketAddress(Object) - Constructor for class io.vertx.reactivex.core.net.SocketAddress
-
- 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
-
- SockJSTermHandler - Class in io.vertx.reactivex.ext.shell.term
-
NOTE: This class has been automatically generated from the
original
non RX-ified interface using Vert.x codegen.
- SockJSTermHandler(SockJSTermHandler) - Constructor for class io.vertx.reactivex.ext.shell.term.SockJSTermHandler
-
- SockJSTermHandler(Object) - Constructor for class io.vertx.reactivex.ext.shell.term.SockJSTermHandler
-
- SORT - Static variable in class io.vertx.reactivex.redis.client.Command
-
- sort(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- sort(String, SortOptions, Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Sort the elements in a list, set or sorted set
- sort(String, SortOptions, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
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
-
- specifySchema(String, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.mysqlclient.MySQLConnection
-
Send a INIT_DB command to change the default schema of the connection.
- SPOP - Static variable in class io.vertx.reactivex.redis.client.Command
-
- spop(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- spop(String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Remove and return a random member from a set
- spop(String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Remove and return a random member from a set
- spopMany(String, int, Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Remove and return random members from a set
- spopMany(String, int, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Remove and return random members from a set
- SQLClient - Class in io.vertx.reactivex.ext.sql
-
A common asynchronous client interface for interacting with SQL compliant database
NOTE: This class has been automatically generated from the
original
non RX-ified interface using Vert.x codegen.
- SQLClient(SQLClient) - Constructor for class io.vertx.reactivex.ext.sql.SQLClient
-
- SQLClient(Object) - Constructor for class io.vertx.reactivex.ext.sql.SQLClient
-
- SqlClient - Class in io.vertx.reactivex.sqlclient
-
Defines the 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
-
- SQLClientHelper - Class in io.vertx.reactivex.ext.sql
-
Utilities for generating observables with a
SQLClient
.
- SQLConnection - Class in io.vertx.reactivex.ext.sql
-
Represents a connection to a SQL database
NOTE: This class has been automatically generated from the
original
non RX-ified interface using Vert.x codegen.
- SQLConnection(SQLConnection) - Constructor for class io.vertx.reactivex.ext.sql.SQLConnection
-
- SQLConnection(Object) - Constructor for class io.vertx.reactivex.ext.sql.SQLConnection
-
- SqlConnection - Class in io.vertx.reactivex.sqlclient
-
A connection to database server.
- SqlConnection(SqlConnection) - Constructor for class io.vertx.reactivex.sqlclient.SqlConnection
-
- SqlConnection(Object) - Constructor for class io.vertx.reactivex.sqlclient.SqlConnection
-
- SQLOperations - Interface in io.vertx.reactivex.ext.sql
-
Represents a SQL query interface to a database
NOTE: This class has been automatically generated from the
original
non RX-ified interface using Vert.x codegen.
- SqlResult<T> - Class in io.vertx.reactivex.sqlclient
-
Represents the result of an operation on database.
- SqlResult(SqlResult) - Constructor for class io.vertx.reactivex.sqlclient.SqlResult
-
- SqlResult(Object, TypeArg<T>) - Constructor for class io.vertx.reactivex.sqlclient.SqlResult
-
- SQLRowStream - Class in io.vertx.reactivex.ext.sql
-
A ReadStream of Rows from the underlying RDBMS.
- SQLRowStream(SQLRowStream) - Constructor for class io.vertx.reactivex.ext.sql.SQLRowStream
-
- SQLRowStream(Object) - Constructor for class io.vertx.reactivex.ext.sql.SQLRowStream
-
- SRANDMEMBER - Static variable in class io.vertx.reactivex.redis.client.Command
-
- srandmember(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- srandmember(String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get one or multiple random members from a set
- srandmember(String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get one or multiple random members from a set
- srandmemberCount(String, int, Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get one or multiple random members from a set
- srandmemberCount(String, int, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get one or multiple random members from a set
- SREM - Static variable in class io.vertx.reactivex.redis.client.Command
-
- srem(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- srem(String, String, Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Remove one member from a set
- srem(String, String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Remove one member from a set
- sremMany(String, List<String>, Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Remove one or more members from a set
- sremMany(String, List<String>, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Remove one or more members from a set
- SrvRecord - Class in io.vertx.reactivex.core.dns
-
Represent a Service-Record (SRV) which was resolved for a domain.
- SrvRecord(SrvRecord) - Constructor for class io.vertx.reactivex.core.dns.SrvRecord
-
- SrvRecord(Object) - Constructor for class io.vertx.reactivex.core.dns.SrvRecord
-
- SSCAN - Static variable in class io.vertx.reactivex.redis.client.Command
-
- sscan(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- sscan(String, String, ScanOptions, Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Incrementally iterate Set elements
- sscan(String, String, ScanOptions, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Incrementally iterate Set elements
- ssl(Boolean) - Method in class io.vertx.reactivex.ext.web.client.HttpRequest
-
- 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.WebSocket
-
- sslSession() - Method in class io.vertx.reactivex.core.net.NetSocket
-
- stackTrace() - Method in class io.vertx.reactivex.ext.unit.report.Failure
-
- start(String, int, String, String, Handler<AsyncResult<AmqpBridge>>) - Method in class io.vertx.reactivex.amqpbridge.AmqpBridge
-
Starts the bridge, establishing the underlying connection.
- start(String, int, Handler<AsyncResult<AmqpBridge>>) - Method in class io.vertx.reactivex.amqpbridge.AmqpBridge
-
Starts the bridge, establishing the underlying connection.
- start(Future<Void>) - Method in class io.vertx.reactivex.core.AbstractVerticle
-
- start() - Method in class io.vertx.reactivex.core.streams.Pump
-
Start the Pump.
- start() - Method in class io.vertx.reactivex.ext.consul.Watch
-
Start this Watch
- start() - Method in class io.vertx.reactivex.ext.shell.ShellService
-
Start the shell service, this is an asynchronous start.
- start(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.shell.ShellService
-
Start the shell service, this is an asynchronous start.
- start(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
-
Start the rabbitMQ client.
- 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.ext.shell.system.Job
-
- status() - Method in class io.vertx.reactivex.ext.shell.system.Process
-
- status(int) - Static method in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
Creates a predicate asserting that the status response code is equal to statusCode
.
- status(int, int) - Static method in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicate
-
Creates a predicate asserting that the status response code is in the [min,max[
range.
- statusCode() - Method in class io.vertx.reactivex.core.http.HttpClientResponse
-
- statusCode() - Method in class io.vertx.reactivex.ext.auth.oauth2.OAuth2Response
-
the returned status code from the HTTP layer.
- 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 class io.vertx.reactivex.ext.web.client.HttpResponse
-
- statusUpdateHandler(Handler<ExecStatus>) - Method in class io.vertx.reactivex.ext.shell.system.Job
-
Set an handler called when the job terminates.
- stdinHandler(Handler<String>) - Method in class io.vertx.reactivex.ext.shell.command.CommandProcess
-
- stdinHandler(Handler<String>) - Method in class io.vertx.reactivex.ext.shell.term.Term
-
- stdinHandler(Handler<String>) - Method in class io.vertx.reactivex.ext.shell.term.Tty
-
Set a stream handler on the standard input to read the data.
- stdoutHandler(Handler<String>) - Method in class io.vertx.reactivex.ext.shell.term.Pty
-
Set the standard out handler of the pseudo terminal.
- 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(Future<Void>) - Method in class io.vertx.reactivex.core.AbstractVerticle
-
- stop() - Method in class io.vertx.reactivex.core.streams.Pump
-
Stop the Pump.
- stop() - Method in class io.vertx.reactivex.ext.consul.Watch
-
Stop the watch and release its resources
- stop() - Method in class io.vertx.reactivex.ext.shell.ShellService
-
Stop the shell service, this is an asynchronous stop.
- stop(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.ext.shell.ShellService
-
Stop the shell service, this is an asynchronous start.
- stop(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.rabbitmq.RabbitMQClient
-
Stop the rabbitMQ client.
- 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
.
- stringValue() - Method in class io.vertx.reactivex.core.parsetools.JsonEvent
-
- 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 - Static variable in class io.vertx.reactivex.redis.client.Command
-
- strlen(String, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- strlen(String, Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Get the length of the value stored in a key
- strlen(String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Get the length of the value stored in a key
- 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(String) - Method in class io.vertx.reactivex.amqp.AmqpMessageBuilder
-
- 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, Handler<Frame>) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
-
Subscribes to the given destination.
- subscribe(String, Handler<Frame>, 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(String, Map<String, String>, Handler<Frame>, Handler<Frame>) - Method in class io.vertx.reactivex.ext.stomp.StompClientConnection
-
Subscribes to the given destination.
- subscribe(String) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
-
Subscribe to the given topic 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.
- subscribe(String, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
-
Subscribe to the given topic to get dynamically assigned partitions.
- subscribe(Set<String>, Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.kafka.client.consumer.KafkaConsumer
-
Subscribe to the given list of topics 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, int, Handler<AsyncResult<Integer>>) - Method in class io.vertx.reactivex.mqtt.MqttClient
-
Subscribes to the topic with a specified QoS level
- subscribe(Map<String, Integer>) - Method in class io.vertx.reactivex.mqtt.MqttClient
-
Subscribes to the topics with related QoS levels
- subscribe(Map<String, Integer>, Handler<AsyncResult<Integer>>) - Method in class io.vertx.reactivex.mqtt.MqttClient
-
Subscribes to the topic and adds a handler which will be called after the request is sent
- SUBSCRIBE - Static variable in class io.vertx.reactivex.redis.client.Command
-
- subscribe(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- subscribe(String, Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Listen for messages published to the given channels
- subscribe(String, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Listen for messages published to the given channels
- subscribeAcknowledge(int, List<MqttQoS>) - 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.
- subscribeMany(List<String>, Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Listen for messages published to the given channels
- subscribeMany(List<String>, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Listen for messages published to the given channels
- 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(Handler<AsyncResult<Set<String>>>) - 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
- SUBSTR - Static variable in class io.vertx.reactivex.redis.client.Command
-
- substr(String, String, String, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- subtag() - Method in class io.vertx.reactivex.ext.web.LanguageHeader
-
- subtag(int) - Method in class io.vertx.reactivex.ext.web.LanguageHeader
-
- subtagCount() - Method in class io.vertx.reactivex.ext.web.LanguageHeader
-
- succeeded(int) - Method in class io.vertx.reactivex.core.CompositeFuture
-
Returns true if a wrapped future is succeeded
- succeeded() - Method in class io.vertx.reactivex.core.Future
-
Did it succeed?
- 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.client.predicate.ResponsePredicateResult
-
Whether the result is a success or failure.
- succeededFuture() - Static method in class io.vertx.reactivex.core.Future
-
Create a succeeded future with a null result
- succeededFuture(T) - Static method in class io.vertx.reactivex.core.Future
-
Created a succeeded future with the specified result.
- success() - Static method in class io.vertx.reactivex.ext.web.client.predicate.ResponsePredicateResult
-
- SUNION - Static variable in class io.vertx.reactivex.redis.client.Command
-
- sunion(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- sunion(List<String>, Handler<AsyncResult<JsonArray>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Add multiple sets
- sunion(List<String>, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Add multiple sets
- SUNIONSTORE - Static variable in class io.vertx.reactivex.redis.client.Command
-
- sunionstore(List<String>, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- sunionstore(String, List<String>, Handler<AsyncResult<Long>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Add multiple sets and store the resulting set in a key
- sunionstore(String, List<String>, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Add multiple sets and store the resulting set in a key
- suspend() - Method in class io.vertx.reactivex.ext.shell.system.Job
-
Resume the job.
- suspend() - Method in class io.vertx.reactivex.ext.shell.system.Process
-
Resume the process.
- suspend(Handler<Void>) - Method in class io.vertx.reactivex.ext.shell.system.Process
-
Resume the process.
- suspendHandler(Handler<Void>) - Method in class io.vertx.reactivex.ext.shell.command.CommandProcess
-
Set a suspend handler, this handler is called when the command is suspended, for instance user
press Ctrl-Z
.
- suspendHandler(SignalHandler) - Method in class io.vertx.reactivex.ext.shell.term.Term
-
Set a suspend signal handler on the term.
- SWAPDB - Static variable in class io.vertx.reactivex.redis.client.Command
-
- swapdb(String, String, Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- swapdb(int, int, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Swaps two Redis databases
- swapdb(int, int, Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Swaps two Redis databases
- symlink(String, String, Handler<AsyncResult<Void>>) - 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 - Static variable in class io.vertx.reactivex.redis.client.Command
-
- sync(Handler<AsyncResult<Response>>) - Method in class io.vertx.reactivex.redis.client.RedisAPI
-
- sync(Handler<AsyncResult<Void>>) - Method in class io.vertx.reactivex.redis.RedisClient
-
Internal command used for replication
- sync(Handler<AsyncResult<String>>) - Method in class io.vertx.reactivex.redis.RedisTransaction
-
Internal command used for replication
- SYSTEM_PROPERTY_NAME - Static variable in class io.vertx.reactivex.ext.web.common.WebEnvironment
-