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

A

abort(String, Map<String, String>, Handler<Map<String, Object>>) - Method in StompClientConnection
Aborts a transaction.
abortHandler(Handler<ServerFrame>) - Method in StompServerHandler
Configures the action to execute when a ABORT frame is received.
absoluteURI() - Method in HttpServerRequest
@return
Returns:
the absolute URI corresponding to the the HTTP request
accept(HttpServerRequest) - Method in Router
This method is used to provide a request to the router.
acceptableLocales() - Method in RoutingContext
Returns the locales for the current request.
acceptMoreValues(Map<String, Object>) - Method in CommandLine
Checks whether or not the given option accept more values.
AccessToken - Class in io.vertx.groovy.ext.auth.oauth2
AccessToken extension to the User interface
AccessToken(Object) - Constructor in AccessToken
ack(StompServerConnection, Map<String, Object>) - Method in Destination
Handles a ACK frame.
ack(String, String, Handler<Map<String, Object>>) - Method in StompClientConnection
Sends an acknowledgement for the given frame.
ackHandler(Handler<ServerFrame>) - Method in StompServerHandler
Configures the action to execute when a ACK frame is received.
Acknowledgement - Class in io.vertx.groovy.ext.stomp
Structure passed to acknowledgement handler called when a ACK or NACK frame is received.
Acknowledgement(Object) - Constructor in Acknowledgement
actualPort() - Method in HttpServer
The actual port the server is listening on.
actualPort() - Method in NetServer
The actual port the server is listening on.
actualPort() - Method in StompServer
Gets the port on which the server is listening.
actualPort() - Method in TermServer
The actual port the server is listening on.
add(String, String) - Method in MultiMap
Adds a new value with the specified name and value.
addAll(MultiMap) - Method in MultiMap
Adds all the entries from another MultiMap to this one
addAndGet(long, Handler<AsyncResult<Long>>) - Method in Counter
Add the value to the counter atomically and return the new count
addArgument(Map<String, Object>) - Method in CLI
Adds an argument.
addArguments(List<Map<String, Object>>) - Method in CLI
Adds a set of arguments.
addAuthorities(Set<String>) - Method in AuthHandler
addAuthorities(Set<String>) - Method in AuthHandlerImpl
Add a set of required authorities for this auth handler
addAuthorities(Set<String>) - Method in BasicAuthHandler
Add a set of required authorities for this auth handler
addAuthorities(Set<String>) - Method in JWTAuthHandler
Add a set of required authorities for this auth handler
addAuthorities(Set<String>) - Method in OAuth2AuthHandler
Add a set of required authorities for this auth handler
addAuthorities(Set<String>) - Method in RedirectAuthHandler
Add a set of required authorities for this auth handler
addAuthority(String) - Method in AuthHandler
addAuthority(String) - Method in AuthHandlerImpl
Add a required authority for this auth handler
addAuthority(String) - Method in BasicAuthHandler
Add a required authority for this auth handler
addAuthority(String) - Method in JWTAuthHandler
Add a required authority for this auth handler
addAuthority(String) - Method in OAuth2AuthHandler
Add a required authority for this auth handler
addAuthority(String) - Method in RedirectAuthHandler
Add a required authority for this auth handler
addBodyEndHandler(Handler<Void>) - Method in RoutingContext
Add a handler that will be called just before the response body has been completely written.
addCookie(Cookie) - Method in RoutingContext
Add a cookie.
addHeadersEndHandler(Handler<Void>) - Method in RoutingContext
Add a handler that will be called just before headers are written to the response.
addInterceptor(Handler<SendContext>) - Method in EventBus
Add an interceptor that will be called whenever a message is sent from Vert.x
addOption(Map<String, Object>) - Method in CLI
Adds an option.
addOptions(List<Map<String, Object>>) - Method in CLI
Adds a set of options.
address() - Method in Message
The address the message was sent to @return
address() - Method in MessageConsumer
Returns:
The address the handler was registered with.
address() - Method in MessageProducer
Returns:
The address to which the producer produces messages.
after(Handler<TestContext>) - Method in TestSuite
Set a callback executed after the tests.
afterEach(Handler<TestContext>) - Method in TestSuite
Set a callback executed after each test and before the suite after callback.
all(List<Future>) - Method in CompositeFuture
Like CompositeFuture.all but with a list of futures.
allArguments() - Method in CommandLine
Returns:
the ordered list of arguments.
allowCredentials(boolean) - Method in CorsHandler
Set whether credentials are allowed
allowedHeader(String) - Method in CorsHandler
Add an allowed header
allowedHeaders(Set<String>) - Method in CorsHandler
Add a set of allowed headers
allowedMethod(HttpMethod) - Method in CorsHandler
Add an allowed method
AmqpBridge - Class in io.vertx.groovy.amqpbridge
Vert.x AMQP Bridge.
AmqpBridge(Object) - Constructor in AmqpBridge
any(List<Future>) - Method in CompositeFuture
Like CompositeFuture.any but with a list of futures.
api(HttpMethod, String, Map<String, Object>, Handler<AsyncResult<Map<String, Object>>>) - Method in OAuth2Auth
Call OAuth2 APIs.
append(String, String, Handler<AsyncResult<Long>>) - Method in RedisClient
Append a value to a key
append(String, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Append a value to a key
appendBuffer(Buffer, int, int) - Method in Buffer
Appends the specified Buffer starting at the offset using len to the end of this Buffer.
appendByte(byte) - Method in Buffer
Appends the specified byte to the end of the Buffer.
appendDouble(double) - Method in Buffer
Appends the specified double to the end of the Buffer.
appendFloat(float) - Method in Buffer
Appends the specified float to the end of the Buffer.
appendInt(int) - Method in Buffer
Appends the specified int to the end of the Buffer.
appendIntLE(int) - Method in Buffer
Appends the specified int to the end of the Buffer in the Little Endian Byte Order.
appendLong(long) - Method in Buffer
Appends the specified long to the end of the Buffer.
appendLongLE(long) - Method in Buffer
Appends the specified long to the end of the Buffer in the Little Endian Byte Order.
appendMedium(int) - Method in Buffer
Appends the specified 24bit int to the end of the Buffer.
appendMediumLE(int) - Method in Buffer
Appends the specified 24bit int to the end of the Buffer in the Little Endian Byte Order.
appendShort(short) - Method in Buffer
Appends the specified short to the end of the Buffer.The buffer will expand as necessary to accommodate any bytes written.
appendShortLE(short) - Method in Buffer
Appends the specified short to the end of the Buffer in the Little Endian Byte Order.The buffer will expand as necessary to accommodate any bytes written.
appendString(String) - Method in Buffer
Appends the specified String str to the end of the Buffer with UTF-8 encoding.
appendUnsignedByte(short) - Method in Buffer
Appends the specified unsigned byte to the end of the Buffer.
appendUnsignedInt(long) - Method in Buffer
Appends the specified unsigned int to the end of the Buffer.
appendUnsignedIntLE(long) - Method in Buffer
Appends the specified unsigned int to the end of the Buffer in the Little Endian Byte Order.
appendUnsignedShort(int) - Method in Buffer
Appends the specified unsigned short to the end of the Buffer.The buffer will expand as necessary to accommodate any bytes written.
appendUnsignedShortLE(int) - Method in Buffer
Appends the specified unsigned short to the end of the Buffer in the Little Endian Byte Order.The buffer will expand as necessary to accommodate any bytes written.
args() - Method in CommandProcess
@return
Returns:
the actual string arguments of the command
argsTokens() - Method in CommandProcess
@return
Returns:
the unparsed arguments tokens
asJavaVerticle() - Method in GroovyVerticle
@return the Java io.vertx.core.Verticle adapter for this Groovy Verticle
assertEquals(Object, Object, String) - Method in TestContext
Assert the expected argument is equals to the actual argument.
assertFalse(boolean, String) - Method in TestContext
Assert the specified condition is false.
assertInRange(double, double, double, String) - Method in TestContext
Asserts that the expected double argument is equals to the actual double argument within a positive delta.
assertNotEquals(Object, Object, String) - Method in TestContext
Assert the first argument is not equals to the second argument.
assertNotNull(Object, String) - Method in TestContext
Assert the expected argument is not null.
assertNull(Object, String) - Method in TestContext
Assert the expected argument is null.
assertTrue(boolean, String) - Method in TestContext
Assert the specified condition is true.
Async - Class in io.vertx.groovy.ext.unit
An asynchronous exit point for a test.
Async(Object) - Constructor in Async
async(int) - Method in TestContext
Create and returns a new async object, the returned async controls the completion of the test.
asyncAssertFailure(Handler<Throwable>) - Method in TestContext
Creates and returns a new async handler, the returned handler controls the completion of the test.
asyncAssertSuccess(Handler<T>) - Method in TestContext
Creates and returns a new async handler, the returned handler controls the completion of the test.
AsyncFile - Class in io.vertx.groovy.core.file
Represents a file on the file-system which can be read from, or written to asynchronously.
AsyncFile(Object) - Constructor in AsyncFile
AsyncMap - Class in io.vertx.groovy.core.shareddata
An asynchronous map.
AsyncMap(Object) - Constructor in AsyncMap
AsyncSQLClient - Class in io.vertx.groovy.ext.asyncsql
Represents an asynchronous SQL client
AsyncSQLClient(Object) - Constructor in AsyncSQLClient
auth(String, Handler<AsyncResult<String>>) - Method in RedisClient
Authenticate to the server
auth(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Authenticate to the server
authenticate(Map<String, Object>, Handler<AsyncResult<User>>) - Method in AuthProvider
Authenticate a user.
AuthHandler - Interface in io.vertx.groovy.ext.web.handler
Base interface for auth handlers.
AuthHandlerImpl - Class in io.vertx.groovy.ext.web.handler
AuthHandlerImpl(Object) - Constructor in AuthHandlerImpl
authorizeURL(Map<String, Object>) - Method in OAuth2Auth
Generate a redirect URL to the authN/Z backend.
AuthProvider - Class in io.vertx.groovy.ext.auth.common
User-facing interface for authenticating users.
AuthProvider(AuthProvider) - Constructor in AuthProvider
authProvider(AuthProvider) - Method in StompServerHandler
Configures the to be used to authenticate the user.
authProvider(AuthProvider) - Method in TermServer
Set an auth provider to use, any provider configured in options will override this provider.
authURI(String, String) - Method in OAuth2AuthHandler
Build the authorization URL.
await(long) - Method in Completion
Cause the current thread to wait until this completion completes with a configurable timeout.
awaitSuccess(long) - Method in Completion
Cause the current thread to wait until this completion completes and succeeds with a configurable timeout.

B

backgroundHandler(Handler<Void>) - Method in CommandProcess
Set a background handler, this handler is called when the command is running and put to background.
baseCommands(Vertx) - Method in CommandResolver
@return the base commands of Vert.x Shell.
basicAck(long, boolean, Handler<AsyncResult<Map<String, Object>>>) - Method in RabbitMQClient
Acknowledge one or several received messages.
BasicAuthHandler - Class in io.vertx.groovy.ext.web.handler
An auth handler that provides HTTP Basic Authentication support.
BasicAuthHandler(Object) - Constructor in BasicAuthHandler
basicConsume(String, String, boolean, Handler<AsyncResult<Void>>) - Method in RabbitMQClient
Start a non-nolocal, non-exclusive consumer, with a server-generated consumerTag.
basicGet(String, boolean, Handler<AsyncResult<Map<String, Object>>>) - Method in RabbitMQClient
Retrieve a message from a queue using AMQP.Basic.Get
basicNack(long, boolean, boolean, Handler<AsyncResult<Map<String, Object>>>) - Method in RabbitMQClient
Reject one or several received messages.
basicPublish(String, String, Map<String, Object>, Handler<AsyncResult<Void>>) - Method in RabbitMQClient
Publish a message.
basicQos(int, Handler<AsyncResult<Void>>) - Method in RabbitMQClient
Request specific "quality of service" settings, Limiting the number of unacknowledged messages on a channel (or connection).
batch(List<String>, Handler<AsyncResult<List<Integer>>>) - Method in SQLConnection
Batch simple SQL strings and execute the batch where the async result contains a array of Integers.
batchCallableWithParams(String, List<List<Object>>, List<List<Object>>, Handler<AsyncResult<List<Integer>>>) - Method in SQLConnection
Batch a callable statement with all entries from the args list.
batchWithParams(String, List<List<Object>>, Handler<AsyncResult<List<Integer>>>) - Method in SQLConnection
Batch a prepared statement with all entries from the args list.
before(Handler<TestContext>) - Method in TestSuite
Set a callback executed before the tests.
beforeEach(Handler<TestContext>) - Method in TestSuite
Set a callback executed before each test and after the suite before callback.
beginHandler(Handler<ServerFrame>) - Method in StompServerHandler
Configures the action to execute when a BEGIN frame is received.
beginTime() - Method in TestResult
The time at which the test began in millis.
beginTX(String, Map<String, String>, Handler<Map<String, Object>>) - Method in StompClientConnection
Begins a transaction.
bgrewriteaof(Handler<AsyncResult<String>>) - Method in RedisClient
Asynchronously rewrite the append-only file
bgrewriteaof(Handler<AsyncResult<String>>) - Method in RedisTransaction
Asynchronously rewrite the append-only file
bgsave(Handler<AsyncResult<String>>) - Method in RedisClient
Asynchronously save the dataset to disk
bgsave(Handler<AsyncResult<String>>) - Method in RedisTransaction
Asynchronously save the dataset to disk
binaryData() - Method in WebSocketFrame
@return
Returns:
the data of the frame
binaryFrame(Buffer, boolean) - Method in WebSocketFrame
Create a binary WebSocket frame.
binaryHandlerID() - Method in ServerWebSocket
When a Websocket is created it automatically registers an event handler with the event bus - the ID of that handler is given by this method.
binaryHandlerID() - Method in WebSocket
When a Websocket is created it automatically registers an event handler with the event bus - the ID of that handler is given by this method.
binaryHandlerID() - Method in WebSocketBase
binaryHandlerID() - Method in WebSocketBaseImpl
When a Websocket is created it automatically registers an event handler with the event bus - the ID of that handler is given by this method.
bindings() - Method in ServiceDiscovery
Returns:
the set of service references retrieved by this service discovery.
bitcount(String, Handler<AsyncResult<Long>>) - Method in RedisClient
Count set bits in a string
bitcount(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Count set bits in a string
bitcountRange(String, long, long, Handler<AsyncResult<Long>>) - Method in RedisClient
Count set bits in a string
bitcountRange(String, long, long, Handler<AsyncResult<String>>) - Method in RedisTransaction
Count set bits in a string
bitop(BitOperation, String, List<String>, Handler<AsyncResult<Long>>) - Method in RedisClient
Perform bitwise operations between strings
bitop(BitOperation, String, List<String>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Perform bitwise operations between strings
bitpos(String, int, Handler<AsyncResult<Long>>) - Method in RedisClient
Find first bit set or clear in a string
bitpos(String, int, Handler<AsyncResult<String>>) - Method in RedisTransaction
Find first bit set or clear in a string
bitposFrom(String, int, int, Handler<AsyncResult<Long>>) - Method in RedisClient
Find first bit set or clear in a string
bitposFrom(String, int, int, Handler<AsyncResult<String>>) - Method in RedisTransaction
Find first bit set or clear in a string
bitposRange(String, int, int, int, Handler<AsyncResult<Long>>) - Method in RedisClient
Find first bit set or clear in a string
bitposRange(String, int, int, int, Handler<AsyncResult<String>>) - Method in RedisTransaction
Find first bit set or clear in a string
blockingCreate() - Method in GroovyVerticleFactory
blockingHandler(Handler<RoutingContext>, boolean) - Method in Route
Specify a blocking request handler for the route.
blockMulticastGroup(String, String, String, Handler<AsyncResult<DatagramSocket>>) - Method in DatagramSocket
Block the given address for the given multicast address on the given network interface and notifies the once the operation completes.
blpop(String, int, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Remove and get the first element in a list, or block until one is available
blpop(String, int, Handler<AsyncResult<String>>) - Method in RedisTransaction
Remove and get the first element in a list, or block until one is available
blpopMany(List<String>, int, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Remove and get the first element in any of the lists, or block until one is available
blpopMany(List<String>, int, Handler<AsyncResult<String>>) - Method in RedisTransaction
Remove and get the first element in any of the lists, or block until one is available
body() - Method in Message
The body of the message.
bodyEndHandler(Handler<Void>) - Method in HttpServerResponse
Provide a handler that will be called just before the last part of the body is written to the wire and the response is ended.
BodyHandler - Class in io.vertx.groovy.ext.web.handler
A handler which gathers the entire request body and sets it on the .
BodyHandler(Object) - Constructor in BodyHandler
bodyHandler(Handler<Buffer>) - Method in HttpClientResponse
Convenience method for receiving the entire request body in one piece.
bodyHandler(Handler<Buffer>) - Method in HttpServerRequest
Convenience method for receiving the entire request body in one piece.
bodyStream() - Method in MessageConsumer
Returns:
a read stream for the body of the message stream.
bridge(Vertx, Map<String, Object>) - Method in Destination
bridge(Map<String, Object>, Handler<BridgeEvent>) - Method in SockJSHandler
Like SockJSHandler.bridge but specifying a handler that will receive bridge events.
bridge(Map<String, Object>) - Method in StompServerHandler
Configures the STOMP server to act as a bridge with the Vert.x event bus.
BridgeEvent - Class in io.vertx.groovy.ext.web.handler.sockjs
Represents an event that occurs on the event bus bridge.
BridgeEvent(Object) - Constructor in BridgeEvent
brpop(String, int, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Remove and get the last element in a list, or block until one is available
brpop(String, int, Handler<AsyncResult<String>>) - Method in RedisTransaction
Remove and get the last element in a list, or block until one is available
brpoplpush(String, String, int, Handler<AsyncResult<String>>) - Method in RedisClient
Pop a value from a list, push it to another list and return it; or block until one is available
brpoplpush(String, String, int, Handler<AsyncResult<String>>) - Method in RedisTransaction
Pop a value from a list, push it to another list and return it; or block until one is available
brpopMany(List<String>, int, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Remove and get the last element in any of the lists, or block until one is available
brpopMany(List<String>, int, Handler<AsyncResult<String>>) - Method in RedisTransaction
Remove and get the last element in any of the lists, or block until one is available
Buffer - Class in io.vertx.groovy.core.buffer
Most data is shuffled around inside Vert.x using buffers.
Buffer(Object) - Constructor in Buffer
build(Vertx) - Method in CommandBuilder
Build the command
bytesWritten() - Method in HttpServerResponse
Returns:
the total number of bytes written for the body of the response.

C

cached() - Method in ServiceReference
Gets the service object if already retrieved.
call(String, Handler<AsyncResult<Map<String, Object>>>) - Method in SQLConnection
Calls the given SQL PROCEDURE which returns the result from the procedure.
callWithParams(String, List<Object>, List<Object>, Handler<AsyncResult<Map<String, Object>>>) - Method in SQLConnection
Calls the given SQL PROCEDURE which returns the result from the procedure.
cancel() - Method in TimeoutStream
Cancels the timeout.
cancelTimer(long) - Method in Vertx
Cancels the timer with the specified id.
caseInsensitiveMultiMap() - Method in MultiMap
Create a multi-map implementation with case insensitive keys, for instance it can be used to hold some HTTP headers.
cause(int) - Method in CompositeFuture
Returns a cause of a wrapped future
cause() - Method in Future
A Throwable describing failure.
charSet() - Method in FileUpload
@return
Returns:
the charset of the upload
charset() - Method in HttpServerFileUpload
@return
Returns:
the charset for the upload
chmod(String, String, Handler<AsyncResult<Void>>) - Method in FileSystem
Change the permissions on the file represented by path to perms, asynchronously.
chmodBlocking(String, String) - Method in FileSystem
chmodRecursive(String, String, String, Handler<AsyncResult<Void>>) - Method in FileSystem
Change the permissions on the file represented by path to perms, asynchronously.
chmodRecursiveBlocking(String, String, String) - Method in FileSystem
Blocking version of FileSystem.chmodRecursive
chown(String, String, String, Handler<AsyncResult<Void>>) - Method in FileSystem
Change the ownership on the file represented by path to user and {code group}, asynchronously.
chownBlocking(String, String, String) - Method in FileSystem
Blocking version of
CircuitBreaker - Class in io.vertx.groovy.circuitbreaker
An implementation of the circuit breaker pattern for Vert.x
CircuitBreaker(Object) - Constructor in CircuitBreaker
clear(Handler<AsyncResult<Void>>) - Method in AsyncMap
Clear all entries in the map
clear() - Method in LocalMap
Clear all entries in the map
clear() - Method in MultiMap
Removes all
clear() - Method in Router
Remove all the routes from this router
clear(Handler<AsyncResult<Boolean>>) - Method in SessionStore
Remove all sessions from the store
clearCache() - Method in User
The User object will cache any roles or permissions that it knows it has to avoid hitting the underlying auth provider each time.
clearUser() - Method in RoutingContext
Clear the current user object in the context.
CLI - Class in io.vertx.groovy.core.cli
Interface defining a command-line interface (in other words a command such as 'run', 'ls'...).
CLI(Object) - Constructor in CLI
cli() - Method in Command
@return
Returns:
the command line interface, can be null
cli() - Method in CommandLine
Returns:
the model of this command line object.
clientGetname(Handler<AsyncResult<String>>) - Method in RedisClient
Get the current connection name
clientGetname(Handler<AsyncResult<String>>) - Method in RedisTransaction
Get the current connection name
clientKill(Map<String, Object>, Handler<AsyncResult<Long>>) - Method in RedisClient
Kill the connection of a client
clientKill(Map<String, Object>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Kill the connection of a client
clientList(Handler<AsyncResult<String>>) - Method in RedisClient
Get the list of client connections
clientList(Handler<AsyncResult<String>>) - Method in RedisTransaction
Get the list of client connections
clientPause(long, Handler<AsyncResult<String>>) - Method in RedisClient
Stop processing commands from clients for some time
clientPause(long, Handler<AsyncResult<String>>) - Method in RedisTransaction
Stop processing commands from clients for some time
clientSetname(String, Handler<AsyncResult<String>>) - Method in RedisClient
Set the current connection name
clientSetname(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Set the current connection name
CliToken - Class in io.vertx.groovy.ext.shell.cli
A parsed token in the command line interface.
CliToken(Object) - Constructor in CliToken
close(Handler<AsyncResult<Void>>) - Method in AmqpBridge
Shuts the bridge down, closing the underlying connection.
close(Handler<AsyncResult<Void>>) - Method in AsyncFile
Close the file.
close(Handler<AsyncResult<Void>>) - Method in AsyncSQLClient
Close the client and release all resources.
close() - Method in CircuitBreaker
Closes the circuit breaker.
close() - Method in DatagramSocket
Closes the DatagramSocket.
close() - Method in GroovyVerticleFactory
close() - Method in HttpClient
Close the client.
close() - Method in HttpConnection
Close the connection and all the currently active streams.
close(Handler<AsyncResult<Void>>) - Method in HttpServer
Like HttpServer.close but supplying a handler that will be called when the server is actually closed (or has failed).
close() - Method in HttpServerResponse
Close the underlying TCP connection corresponding to the request.
close() - Method in JDBCClient
Close the client
close() - Method in JobController
Close the shell session and terminate all the underlying jobs.
close() - Method in LocalMap
Close and release the map
close() - Method in MailClient
close() - Method in MailService
close() - Method in MessageProducer
Closes the producer, this method should be called when the message producer is not used anymore.
close() - Method in MongoClient
Close the client and release its resources
close() - Method in NetClient
Close the client.
close(Handler<AsyncResult<Void>>) - Method in NetServer
Like NetServer.close but supplying a handler that will be notified when close is complete.
close() - Method in NetSocket
Close the NetSocket
close(Handler<AsyncResult<Void>>) - Method in RedisClient
Close the client - when it is fully closed the handler will be called.
close(Handler<AsyncResult<Void>>) - Method in RedisTransaction
Close the client - when it is fully closed the handler will be called.
close() - Method in ServerWebSocket
Close the WebSocket.
close() - Method in ServiceDiscovery
Closes the service discovery
close(Handler<Void>) - Method in ServiceExporter
Close the exporter
close() - Method in SessionStore
Close the store
close() - Method in Shell
Close the shell.
close(Handler<AsyncResult<Void>>) - Method in ShellServer
Close the shell server, this is an asynchronous close.
close() - Method in SockJSSocket
Close it
close() - Method in SQLConnection
Closes the connection.
close() - Method in StompClient
Closes the client.
close() - Method in StompClientConnection
Closes the connection without sending the DISCONNECT frame.
close() - Method in StompServer
Closes the server.
close() - Method in StompServerConnection
Closes the connection with the client.
close() - Method in TcpEventBusBridge
Close the current socket.
close() - Method in Term
Close the connection to terminal.
close(Handler<AsyncResult<Void>>) - Method in TermServer
Like TermServer.close but supplying a handler that will be notified when close is complete.
close(Handler<AsyncResult<Void>>) - Method in Vertx
Like Vertx.close but the completionHandler will be called when the close is complete
close() - Method in WebSocket
Close the WebSocket.
close() - Method in WebSocketBase
close() - Method in WebSocketBaseImpl
Close the WebSocket.
close() - Method in WorkerExecutor
Close the executor.
closed() - Method in HttpServerResponse
Returns:
has the underlying TCP connection corresponding to the request already been closed?
closeHandler(Handler<Void>) - Method in CircuitBreaker
Sets a invoked when the circuit breaker state switches to close.
closeHandler(Handler<Void>) - Method in HttpConnection
Set a close handler.
closeHandler(Handler<Void>) - Method in HttpServerResponse
Set a close handler for the response.
closeHandler(Handler<Void>) - Method in NetSocket
Set a handler that will be called when the NetSocket is closed
closeHandler(Handler<Void>) - Method in ServerWebSocket
closeHandler(Handler<StompClientConnection>) - Method in StompClientConnection
Sets a handler notified when the STOMP connection is closed.
closeHandler(Handler<StompServerConnection>) - Method in StompServerHandler
Configures the action to execute when a connection with the client is closed.
closeHandler(Handler<Void>) - Method in Term
Set a handler that will be called when the terminal is closed.
closeHandler(Handler<Void>) - Method in WebSocket
closeHandler(Handler<Void>) - Method in WebSocketBase
closeHandler(Handler<Void>) - Method in WebSocketBaseImpl
Set a close handler.
clusterAddslots(List<Long>, Handler<AsyncResult<Void>>) - Method in RedisClient
Assign new hash slots to receiving node.
clusterAddslots(List<String>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Assign new hash slots to receiving node.
clusterCountFailureReports(String, Handler<AsyncResult<Long>>) - Method in RedisClient
Return the number of failure reports active for a given node.
clusterCountFailureReports(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Return the number of failure reports active for a given node.
clusterCountkeysinslot(long, Handler<AsyncResult<Long>>) - Method in RedisClient
Return the number of local keys in the specified hash slot.
clusterCountkeysinslot(long, Handler<AsyncResult<String>>) - Method in RedisTransaction
Return the number of local keys in the specified hash slot.
clusterDelslots(long, Handler<AsyncResult<Void>>) - Method in RedisClient
Set hash slots as unbound in receiving node.
clusterDelslots(long, Handler<AsyncResult<String>>) - Method in RedisTransaction
Set hash slots as unbound in receiving node.
clusterDelslotsMany(List<Long>, Handler<AsyncResult<Void>>) - Method in RedisClient
Set hash slots as unbound in receiving node.
clusterDelslotsMany(List<String>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Set hash slots as unbound in receiving node.
ClusteredSessionStore - Class in io.vertx.groovy.ext.web.sstore
A session store which stores sessions in a distributed map so they are available across the cluster.
ClusteredSessionStore(Object) - Constructor in ClusteredSessionStore
clusteredVertx(Map<String, Object>, Handler<AsyncResult<Vertx>>) - Method in Vertx
Creates a clustered instance using the specified options.
clusterFailover(Handler<AsyncResult<Void>>) - Method in RedisClient
Forces a slave to perform a manual failover of its master.
clusterFailover(Handler<AsyncResult<String>>) - Method in RedisTransaction
Forces a slave to perform a manual failover of its master.
clusterFailOverWithOptions(FailoverOptions, Handler<AsyncResult<Void>>) - Method in RedisClient
Forces a slave to perform a manual failover of its master.
clusterFailOverWithOptions(FailoverOptions, Handler<AsyncResult<String>>) - Method in RedisTransaction
Forces a slave to perform a manual failover of its master.
clusterForget(String, Handler<AsyncResult<Void>>) - Method in RedisClient
Remove a node from the nodes table.
clusterForget(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Remove a node from the nodes table.
clusterGetkeysinslot(long, long, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Return local key names in the specified hash slot.
clusterGetkeysinslot(long, long, Handler<AsyncResult<String>>) - Method in RedisTransaction
Return local key names in the specified hash slot.
clusterInfo(Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Provides info about Redis Cluster node state.
clusterInfo(Handler<AsyncResult<String>>) - Method in RedisTransaction
Provides info about Redis Cluster node state.
clusterKeyslot(String, Handler<AsyncResult<Long>>) - Method in RedisClient
Returns the hash slot of the specified key.
clusterKeyslot(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Returns the hash slot of the specified key.
clusterMeet(String, long, Handler<AsyncResult<Void>>) - Method in RedisClient
Force a node cluster to handshake with another node.
clusterMeet(String, long, Handler<AsyncResult<String>>) - Method in RedisTransaction
Force a node cluster to handshake with another node.
clusterNodes(Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Get Cluster config for the node.
clusterNodes(Handler<AsyncResult<String>>) - Method in RedisTransaction
Get Cluster config for the node.
clusterReplicate(String, Handler<AsyncResult<Void>>) - Method in RedisClient
Reconfigure a node as a slave of the specified master node.
clusterReplicate(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Reconfigure a node as a slave of the specified master node.
clusterReset(Handler<AsyncResult<Void>>) - Method in RedisClient
Reset a Redis Cluster node.
clusterReset(Handler<AsyncResult<String>>) - Method in RedisTransaction
Reset a Redis Cluster node.
clusterResetWithOptions(ResetOptions, Handler<AsyncResult<Void>>) - Method in RedisClient
Reset a Redis Cluster node.
clusterResetWithOptions(ResetOptions, Handler<AsyncResult<String>>) - Method in RedisTransaction
Reset a Redis Cluster node.
clusterSaveconfig(Handler<AsyncResult<Void>>) - Method in RedisClient
Forces the node to save cluster state on disk.
clusterSaveconfig(Handler<AsyncResult<String>>) - Method in RedisTransaction
Forces the node to save cluster state on disk.
clusterSetConfigEpoch(long, Handler<AsyncResult<Void>>) - Method in RedisClient
Set the configuration epoch in a new node.
clusterSetConfigEpoch(long, Handler<AsyncResult<String>>) - Method in RedisTransaction
Set the configuration epoch in a new node.
clusterSetslot(long, SlotCmd, Handler<AsyncResult<Void>>) - Method in RedisClient
Bind an hash slot to a specific node.
clusterSetslot(long, SlotCmd, Handler<AsyncResult<String>>) - Method in RedisTransaction
Bind an hash slot to a specific node.
clusterSetslotWithNode(long, SlotCmd, String, Handler<AsyncResult<Void>>) - Method in RedisClient
Bind an hash slot to a specific node.
clusterSetslotWithNode(long, SlotCmd, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Bind an hash slot to a specific node.
clusterSlaves(String, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
List slave nodes of the specified master node.
clusterSlaves(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
List slave nodes of the specified master node.
clusterSlots(Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Get array of Cluster slot to node mappings
clusterSlots(Handler<AsyncResult<String>>) - Method in RedisTransaction
Get array of Cluster slot to node mappings
Command - Class in io.vertx.groovy.ext.shell.command
A Vert.x Shell command, it can be created from any language using the CommandBuilder.command or from a Java class using Command.create
Command(Object) - Constructor in Command
command(CLI) - Method in CommandBuilder
Create a new commmand with its CLI descriptor.
command(Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Get array of Redis command details
command(Handler<AsyncResult<String>>) - Method in RedisTransaction
Get array of Redis command details
CommandBuilder - Class in io.vertx.groovy.ext.shell.command
A build for Vert.x Shell command.
CommandBuilder(Object) - Constructor in CommandBuilder
commandCount(Handler<AsyncResult<Long>>) - Method in RedisClient
Get total number of Redis commands
commandCount(Handler<AsyncResult<String>>) - Method in RedisTransaction
Get total number of Redis commands
commandGetkeys(Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Extract keys given a full Redis command
commandGetkeys(Handler<AsyncResult<String>>) - Method in RedisTransaction
Extract keys given a full Redis command
commandInfo(List<String>, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Get array of specific Redis command details
commandInfo(List<String>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Get array of specific Redis command details
CommandLine - Class in io.vertx.groovy.core.cli
The parser transforms a CLI (a model) into an CommandLine.
CommandLine(Object) - Constructor in CommandLine
commandLine() - Method in CommandProcess
@return
Returns:
the command line object or null
CommandProcess - Class in io.vertx.groovy.ext.shell.command
The command process provides interaction with the process of the command provided by Vert.x Shell.
CommandProcess(Object) - Constructor in CommandProcess
CommandRegistry - Class in io.vertx.groovy.ext.shell.command
A registry that contains the commands known by a shell.
CommandRegistry(Object) - Constructor in CommandRegistry
CommandResolver - Class in io.vertx.groovy.ext.shell.command
A resolver for commands, so the shell can discover commands.
CommandResolver(Object) - Constructor in CommandResolver
commands() - Method in CommandResolver
@return
Returns:
the current commands
commit(Handler<AsyncResult<Void>>) - Method in SQLConnection
Commits all changes made since the previous commit/rollback.
commit(String, Map<String, String>, Handler<Map<String, Object>>) - Method in StompClientConnection
Commits a transaction.
commitHandler(Handler<ServerFrame>) - Method in StompServerHandler
Configures the action to execute when a COMMIT frame is received.
compareAndSet(long, long, Handler<AsyncResult<Boolean>>) - Method in Counter
Set the counter to the specified value only if the current value is the expectec value.
complete() - Method in Async
Signals the asynchronous operation is done, this method must be called with a count greater than 0, otherwise it throw an IllegalStateException to signal the error.
complete(Completion) - Method in Command
Perform command completion, when the command is done completing it should call or )} method to signal completion is done.
complete(String, boolean) - Method in Completion
End the completion with a value that will be inserted to complete the line.
complete() - Method in Future
Set a null result.
completer() - Method in Future
@return
Returns:
an handler completing this future
Completion - Class in io.vertx.groovy.ext.unit
A completion object that emits completion notifications either succeeded or failed.
Completion(Object) - Constructor in Completion
completionHandler(Handler<Completion>) - Method in CommandBuilder
Set the command completion handler, the completion handler when the user asks for contextual command line completion, usually hitting the tab key.
completionHandler(Handler<AsyncResult<Void>>) - Method in MessageConsumer
Optional method which can be called to indicate when the registration has been propagated across the cluster.
compose(Function<T, Future<U>>) - Method in Future
Compose this future with a mapper function.
CompositeFuture - Class in io.vertx.groovy.core
The composite future wraps a list of futures, it is useful when several futures needs to be coordinated.
CompositeFuture(Object) - Constructor in CompositeFuture
computeHash(String, User) - Method in HashStrategy
Compute the hashed password given the unhashed password and the user
config() - Method in Context
If the context is associated with a Verticle deployment, this returns the configuration that was specified when the verticle was deployed.
configGet(String, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Get the value of a configuration parameter
configGet(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Get the value of a configuration parameter
configResetstat(Handler<AsyncResult<String>>) - Method in RedisClient
Reset the stats returned by INFO
configResetstat(Handler<AsyncResult<String>>) - Method in RedisTransaction
Reset the stats returned by INFO
configRewrite(Handler<AsyncResult<String>>) - Method in RedisClient
Rewrite the configuration file with the in memory configuration
configRewrite(Handler<AsyncResult<String>>) - Method in RedisTransaction
Rewrite the configuration file with the in memory configuration
configSet(String, String, Handler<AsyncResult<String>>) - Method in RedisClient
Set a configuration parameter to the given value
configSet(String, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Set a configuration parameter to the given value
configureHeartbeat(long, long, Handler<StompServerConnection>) - Method in StompServerConnection
Configures the heartbeat.
connect(int, String, Handler<AsyncResult<NetSocket>>) - Method in NetClient
Open a connection to a server at the specific port and host.
connect(String) - Method in Router
Add a route that matches a HTTP CONNECT request and the specified path
connect(Handler<AsyncResult<StompClientConnection>>) - Method in StompClient
Connects to the server using the host and port configured in the client's options.
connectHandler(Handler<NetSocket>) - Method in NetServer
Supply a connect handler for this server.
connectHandler(Handler<ServerFrame>) - Method in StompServerHandler
Configures the action to execute when a CONNECT frame is received.
connection() - Method in HttpClientRequest
@return
Returns:
the HttpConnection associated with this request
connection() - Method in HttpServerRequest
@return
Returns:
the HttpConnection associated with this request
connection() - Method in ServerFrame
@return
Returns:
the connection
connectionDroppedHandler(Handler<StompClientConnection>) - Method in StompClientConnection
Sets a handler notified when the server does not respond to a ping request in time.
connectionHandler(Handler<HttpConnection>) - Method in HttpClientRequest
Set a connection handler called when an HTTP connection has been established.
connectionHandler(Handler<HttpConnection>) - Method in HttpServer
Set a connection handler for the server.
connectStream() - Method in NetServer
Return the connect stream for this server.
connectWithRegex(String) - Method in Router
Add a route that matches a HTTP CONNECT request and the specified path regex
consumer(String, Handler<Message<T>>) - Method in EventBus
Create a consumer and register it against the specified address.
consumes(String) - Method in Route
Add a content type consumed by this route.
contains(String) - Method in MultiMap
Checks to see if there is a value with the specified name
contentTransferEncoding() - Method in FileUpload
Returns:
the content transfer encoding of the upload - this describes how the upload was encoded in the form submission.
contentTransferEncoding() - Method in HttpServerFileUpload
@return
Returns:
the contentTransferEncoding for the upload
contentType() - Method in FileUpload
@return
Returns:
the content type (MIME type) of the upload
contentType() - Method in HttpServerFileUpload
@return
Returns:
the content type for the upload
Context - Class in io.vertx.groovy.core
The execution context of a io.vertx.groovy.core.Handler execution.
Context(Object) - Constructor in Context
continuationFrame(Buffer, boolean) - Method in WebSocketFrame
Create a continuation frame
continueHandler(Handler<Void>) - Method in 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.groovy.ext.web
Represents an HTTP Cookie.
Cookie(Object) - Constructor in Cookie
cookieCount() - Method in RoutingContext
Returns:
the number of cookies.
CookieHandler - Class in io.vertx.groovy.ext.web.handler
A handler which decodes cookies from the request, makes them available in the and writes them back in the response.
CookieHandler(Object) - Constructor in CookieHandler
cookies() - Method in HttpClientResponse
@return
Returns:
the Set-Cookie headers (including trailers)
cookies() - Method in RoutingContext
Returns:
a set of all the cookies.
copy() - Method in Buffer
Returns a copy of the entire Buffer.
copy(String, String, Handler<AsyncResult<Void>>) - Method in FileSystem
Copy a file from the path from to path to, asynchronously.
copyBlocking(String, String) - Method in FileSystem
Blocking version of FileSystem.copy
copyRecursive(String, String, boolean, Handler<AsyncResult<Void>>) - Method in FileSystem
Copy a file from the path from to path to, asynchronously.
copyRecursiveBlocking(String, String, boolean) - Method in FileSystem
Blocking version of FileSystem.copyRecursive
CorsHandler - Class in io.vertx.groovy.ext.web.handler
A handler which implements server side http://www.w3.org/TR/cors/[CORS] support for Vert.x-Web.
CorsHandler(Object) - Constructor in CorsHandler
count() - Method in Async
@return
Returns:
the current count
count(String, Map<String, Object>, Handler<AsyncResult<Long>>) - Method in MongoClient
Count matching documents in a collection.
countDown() - Method in Async
Count down the async.
Counter - Class in io.vertx.groovy.core.shareddata
An asynchronous counter that can be used to across the cluster to maintain a consistent count.
Counter(Object) - Constructor in Counter
country() - Method in Locale
Returns the country as reported by the HTTP client.
create(Vertx, Map<String, Object>) - Method in AmqpBridge
Creates a Bridge with the given options.
create(AuthProvider, String) - Method in BasicAuthHandler
Create a basic auth handler, specifying realm
create(String) - Method in BodyHandler
Create a body handler and use the given upload directory.
create(String, Vertx) - Method in CircuitBreaker
Creates a new instance of CircuitBreaker, with default options.
create(String) - Method in CLI
Creates an instance of CLI using the default implementation.
create(Vertx, long) - Method in ClusteredSessionStore
Create a session store.
create(CLI) - Method in CommandLine
Creates a command line object from the CLI.
create(Vertx) - Method in CommandRegistry
Create a new registry.
create() - Method in CookieHandler
Create a cookie handler
create(String) - Method in CorsHandler
Create a CORS handler
create(String) - Method in CSRFHandler
Instantiate a new CSRFHandlerImpl with a secret
create(Vertx, String) - Method in DestinationFactory
Creates a destination for the given address.
create(String) - Method in ErrorHandler
Create an error handler
create(Vertx, Handler<TestSuiteReport>) - Method in EventBusCollector
create(long) - Method in FaviconHandler
Create a handler with the specified max cache time
create(AuthProvider, String, String, String, String) - Method in FormLoginHandler
Create a handler
create() - Method in HandlebarsTemplateEngine
Create a template engine using defaults
create() - Method in JadeTemplateEngine
Create a template engine using defaults
create(JDBCClient) - Method in JDBCAuth
Create a JDBC auth provider implementation
create(Vertx, Map<String, Object>) - Method in JWTAuth
Create a JWT auth provider
create(JWTAuth, String) - Method in JWTAuthHandler
Create a JWT auth handler
create(String, String, String) - Method in Locale
create(Vertx, String, long) - Method in LocalSessionStore
Create a session store
create(boolean, LoggerFormat) - Method in LoggerHandler
Create a handler with he specified format
create(Vertx) - Method in MetricsService
Creates a metric service for a given Vertx instance.
create(MongoClient, Map<String, Object>) - Method in MongoAuth
Creates an instance of MongoAuth by using the given and configuration object.
create() - Method in MVELTemplateEngine
Create a template engine using defaults
create(Vertx, OAuth2FlowType) - Method in OAuth2Auth
Create a OAuth2 auth provider
create(OAuth2Auth, String) - Method in OAuth2AuthHandler
Create a OAuth2 auth handler
create(String) - Method in Pty
Create a new pseudo terminal.
create(Vertx, Map<String, Object>) - Method in RabbitMQClient
create(AuthProvider, String, String) - Method in RedirectAuthHandler
Create a handler
create(Vertx, Map<String, Object>) - Method in RedisClient
create() - Method in ResponseTimeHandler
Create a handler
create(Vertx) - Method in ServiceDiscovery
Creates a new instance of ServiceDiscovery using the default configuration.
create() - Method in Session
Create a new empty session.
create(SessionStore) - Method in SessionHandler
Create a session handler
create(Vertx) - Method in ShellServer
Create a new shell server with specific options.
create(Vertx, Map<String, Object>) - Method in ShellService
Create a new shell service.
create(Vertx, Map<String, Object>) - Method in ShiroAuth
Create a Shiro auth provider
create(Vertx, Map<String, Object>) - Method in SockJSHandler
Create a SockJS handler
create(Vertx, String) - Method in SockJSTermHandler
create(String) - Method in StaticHandler
Create a handler, specifying web-root
create(Vertx, Map<String, Object>) - Method in StompClient
Creates a StompClient using the default implementation.
create(Vertx) - Method in StompServer
Creates a StompServer based on the default Stomp Server implementation, and use the default options.
create(Vertx) - Method in StompServerHandler
Creates an instance of StompServerHandler using the default (compliant) implementation.
create(Vertx, Map<String, Object>, Map<String, Object>) - Method in TcpEventBusBridge
create(TemplateEngine, String, String) - Method in TemplateHandler
Create a handler
create(String, Handler<TestContext>) - Method in TestCase
Create a test case.
create(String) - Method in TestSuite
Create and return a new test suite.
create() - Method in ThymeleafTemplateEngine
Create a template engine using defaults
create(long, int) - Method in TimeoutHandler
Create a handler
create(AuthProvider) - Method in UserSessionHandler
Create a new handler
create(String, Handler<RoutingContext>) - Method in VirtualHostHandler
Create a handler
createBlank(String) - Method in CliToken
Create a new blank token.
createCollection(String, Handler<AsyncResult<Void>>) - Method in MongoClient
Create a new collection
createConsumer(String) - Method in AmqpBridge
Creates a consumer on the given AMQP address.
createDatagramSocket() - Method in Vertx
Create a datagram socket using default options
createDnsClient(int, String) - Method in Vertx
Create a DNS client to connect to a DNS server at the specified host and port
createErrorFrame(String, Map<String, String>, String) - Method in Frames
createEventBusProxy(Vertx, String) - Method in MailService
create a proxy of MailService that delegates to the mail service running somewhere else via the event bus
createFile(String, String, Handler<AsyncResult<Void>>) - Method in FileSystem
Creates an empty file with the specified path and permissions perms, asynchronously.
createFileBlocking(String, String) - Method in FileSystem
Blocking version of FileSystem.createFile
createHttpClient() - Method in Vertx
Create a HTTP/HTTPS client using default options
createHttpServer() - Method in Vertx
Create an HTTP/HTTPS server using default options
createHttpTermServer(Vertx, Router, Map<String, Object>) - Method in TermServer
Create a term server for the HTTP protocol, using an existing router.
createJob(Process, String) - Method in JobController
Create a job wrapping a process.
createJob(String) - Method in Shell
createKeycloak(Vertx, OAuth2FlowType, Map<String, Object>) - Method in OAuth2Auth
Create a OAuth2 auth provider
createNetClient() - Method in Vertx
Create a TCP/SSL client using default options
createNetServer() - Method in Vertx
Create a TCP/SSL server using default options
createNonShared(Vertx, Map<String, Object>) - Method in JDBCClient
Create a JDBC client which maintains its own data source.
createNonShared(Vertx, Map<String, Object>) - Method in MailClient
createNonShared(Vertx, Map<String, Object>) - Method in MongoClient
Create a Mongo client which maintains its own data source.
createNonShared(Vertx, Map<String, Object>) - Method in MySQLClient
Create a MySQL client which maintains its own pool.
createNonShared(Vertx, Map<String, Object>) - Method in PostgreSQLClient
Create a PostgreSQL client which maintains its own pool.
createProcess(List<CliToken>) - Method in Command
Create a new process with the passed arguments.
createProducer(String) - Method in AmqpBridge
Creates a producer to the given AMQP address.
createReceiptFrame(String, Map<String, String>) - Method in Frames
createRecord(String, String, String, Map<String, Object>) - Method in EventBusService
Sugar method to creates a record for this type.
createRecord(String, String) - Method in HttpEndpoint
Same as HttpEndpoint.createRecord but without metadata, using the port 80 and using "/" as root.
createRecord(String, Map<String, Object>, Map<String, Object>) - Method in JDBCDataSource
createRecord(String, String) - Method in MessageSource
Same as MessageSource.createRecord without additional metadata, and no type for the payload.
createRunnerForTestWithParameters(TestWithParameters) - Method in VertxUnitRunnerWithParametersFactory
createSession(long) - Method in SessionStore
Create a new session
createShared(Vertx, Map<String, Object>) - Method in JDBCClient
Like JDBCClient.createShared but with the default data source name
createShared(Vertx, Map<String, Object>) - Method in MailClient
createShared(Vertx, Map<String, Object>) - Method in MongoClient
Like MongoClient.createShared but with the default data source name
createShared(Vertx, Map<String, Object>) - Method in MySQLClient
Like MySQLClient.createShared but with the default pool name
createShared(Vertx, Map<String, Object>) - Method in PostgreSQLClient
Like PostgreSQLClient.createShared but with the default pool name
createSharedWorkerExecutor(String, int, long) - Method in Vertx
Create a named worker executor, the executor should be closed when it's not needed anymore to release resources.
createShell() - Method in ShellServer
Create a new shell, the returned shell should be closed explicitely.
createSSHTermServer(Vertx, Map<String, Object>) - Method in TermServer
Create a term server for the SSH protocol.
createTelnetTermServer(Vertx, Map<String, Object>) - Method in TermServer
Create a term server for the Telnet protocol.
createText(String) - Method in CliToken
Create a text token.
createVerticle(String, ClassLoader) - Method in GroovyVerticleFactory
creationTime() - Method in FileProps
The date the file was created @return
CSRFHandler - Class in io.vertx.groovy.ext.web.handler
This handler adds a CSRF token to requests which mutate state.
CSRFHandler(Object) - Constructor in CSRFHandler
currentContext() - Method in Vertx
Gets the current context
currentRoute() - Method in RoutingContext
Returns:
the current route this context is being routed through.
customFrameHandler(Handler<HttpFrame>) - Method in HttpClientResponse
Set an custom frame handler.
customFrameHandler(Handler<HttpFrame>) - Method in HttpServerRequest
Set a custom frame handler.

D

data() - Method in DatagramPacket
Returns the data of the DatagramPacket
DatagramPacket - Class in io.vertx.groovy.core.datagram
A received datagram packet (UDP) which contains the data and information about the sender of the data itself.
DatagramPacket(Object) - Constructor in DatagramPacket
DatagramSocket - Class in io.vertx.groovy.core.datagram
A datagram socket can be used to send DatagramPacket's to remote datagram servers and receive DatagramPackets .
DatagramSocket(Object) - Constructor in DatagramSocket
dbsize(Handler<AsyncResult<Long>>) - Method in RedisClient
Return the number of keys in the selected database
dbsize(Handler<AsyncResult<String>>) - Method in RedisTransaction
Return the number of keys in the selected database
debugObject(String, Handler<AsyncResult<String>>) - Method in RedisClient
Get debugging information about a key
debugObject(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Get debugging information about a key
debugSegfault(Handler<AsyncResult<String>>) - Method in RedisClient
Make the server crash
debugSegfault(Handler<AsyncResult<String>>) - Method in RedisTransaction
Make the server crash
decr(String, Handler<AsyncResult<Long>>) - Method in RedisClient
Decrement the integer value of a key by one
decr(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Decrement the integer value of a key by one
decrby(String, long, Handler<AsyncResult<Long>>) - Method in RedisClient
Decrement the integer value of a key by the given number
decrby(String, long, Handler<AsyncResult<String>>) - Method in RedisTransaction
Decrement the integer value of a key by the given number
decrementAndGet(Handler<AsyncResult<Long>>) - Method in Counter
Decrement the counter atomically and return the new count
del(String, Handler<AsyncResult<Long>>) - Method in RedisClient
Delete a key
del(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Delete a key
delete(String, Handler<AsyncResult<Void>>) - Method in FileSystem
Deletes the file represented by the specified path, asynchronously.
delete(String, Handler<HttpClientResponse>) - Method in HttpClient
Create an HTTP DELETE request to send to the server at the default host and port, specifying a response handler to receive the response
delete(String) - Method in Router
Add a route that matches a HTTP DELETE request and the specified path
delete(String, Handler<AsyncResult<Boolean>>) - Method in SessionStore
Delete the session with the specified ID
deleteAbs(String, Handler<HttpClientResponse>) - Method in HttpClient
Create an HTTP DELETE request to send to the server using an absolute URI, specifying a response handler to receive the response
deleteBlocking(String) - Method in FileSystem
Blocking version of FileSystem.delete
deleteRecursive(String, boolean, Handler<AsyncResult<Void>>) - Method in FileSystem
Deletes the file represented by the specified path, asynchronously.
deleteRecursiveBlocking(String, boolean) - Method in FileSystem
Blocking version of FileSystem.deleteRecursive
deleteWithRegex(String) - Method in Router
Add a route that matches a HTTP DELETE request and the specified path regex
delimitedMode(Buffer) - Method in RecordParser
Flip the parser into delimited mode, and where the delimiter can be represented by the delimiter delim.
deliver(int) - Method in SignalHandler
deliveryOptions(Map<String, Object>) - Method in MessageProducer
Update the delivery options of this producer.
delMany(List<String>, Handler<AsyncResult<Long>>) - Method in RedisClient
Delete many keys
delMany(List<String>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Delete many keys
deploymentID() - Method in Context
If the context is associated with a Verticle deployment, this returns the deployment ID of that deployment.
deploymentIDs() - Method in Vertx
Return a Set of deployment IDs for the currently deployed deploymentIDs.
deployVerticle(String, Map<String, Object>, Handler<AsyncResult<String>>) - Method in Vertx
Represents a STOMP destination.
Destination(Object) - Constructor in Destination
DestinationFactory - Class in io.vertx.groovy.ext.stomp
Interface implemented to customize the destination creation.
DestinationFactory(Object) - Constructor in DestinationFactory
destinationFactory(DestinationFactory) - Method in StompServerHandler
Configures the DestinationFactory used to create Destination objects.
destroy() - Method in Session
Destroy the session
disable() - Method in Route
Disable this route.
discard(Handler<AsyncResult<String>>) - Method in RedisTransaction
Discard all commands issued after MULTI
disconnect(Map<String, Object>, Handler<Map<String, Object>>) - Method in StompClientConnection
Disconnects the client.
disconnectHandler(Handler<ServerFrame>) - Method in StompServerHandler
Configures the action to execute when a DISCONNECT frame is received.
dispatch(StompServerConnection, Map<String, Object>) - Method in Destination
Dispatches the given frame.
distinct(String, String, String, Handler<AsyncResult<List<Object>>>) - Method in MongoClient
Gets the distinct values of the specified field name.
distinctBatch(String, String, String, Handler<AsyncResult<Map<String, Object>>>) - Method in MongoClient
Gets the distinct values of the specified field name.
DnsClient - Class in io.vertx.groovy.core.dns
Provides a way to asynchronously lookup information from DNS servers.
DnsClient(Object) - Constructor in DnsClient
doInvokeTestMethod(FrameworkMethod, Object, TestContext) - Method in VertxUnitRunner
doValidateTestMethod(FrameworkMethod) - Method in VertxUnitRunner
drainHandler(Handler<Void>) - Method in AsyncFile
drainHandler(Handler<Void>) - Method in HttpClientRequest
drainHandler(Handler<Void>) - Method in HttpServerResponse
drainHandler(Handler<Void>) - Method in MessageProducer
drainHandler(Handler<Void>) - Method in NetSocket
drainHandler(Handler<Void>) - Method in PacketWritestream
drainHandler(Handler<Void>) - Method in ServerWebSocket
drainHandler(Handler<Void>) - Method in SockJSSocket
drainHandler(Handler<Void>) - Method in WebSocket
drainHandler(Handler<Void>) - Method in WebSocketBase
drainHandler(Handler<Void>) - Method in WebSocketBaseImpl
drainHandler(Handler<Void>) - Method in WriteStream
drainHandler(Handler<Void>) - Method in WriteStreamImpl
Set a drain handler on the stream.
dropCollection(String, Handler<AsyncResult<Void>>) - Method in MongoClient
Drop a collection
dump(String, Handler<AsyncResult<String>>) - Method in RedisClient
Return a serialized version of the value stored at the specified key.
dump(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Return a serialized version of the value stored at the specified key.
durationTime() - Method in TestResult
How long the test lasted in millis.

E

echo(String, Handler<AsyncResult<String>>) - Method in RedisClient
Echo the given string
echo(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Echo the given string
echo(String) - Method in Term
Echo some text in the terminal, escaped if necessary.
enable() - Method in Route
Enable this route.
encode() - Method in Cookie
Encode the cookie to a string.
end() - Method in AsyncFile
Close the file, see AsyncFile.close.
end(int) - Method in CommandProcess
End the process.
end() - Method in HttpClientRequest
Ends the request.
end() - Method in HttpServerResponse
Ends the response.
end() - Method in MessageProducer
Closes the producer, calls MessageProducer.close
end() - Method in NetSocket
end(Buffer) - Method in PacketWritestream
Same as WriteStream.end but writes some data to the stream before ending.
end() - Method in ServerWebSocket
end() - Method in SockJSSocket
end() - Method in WebSocket
end() - Method in WebSocketBase
end() - Method in WebSocketBaseImpl
end(T) - Method in WriteStream
end(T) - Method in WriteStreamImpl
Same as WriteStream.end but writes some data to the stream before ending.
ended() - Method in HttpServerResponse
Returns:
has the response already ended?
endHandler(Handler<Void>) - Method in AsyncFile
endHandler(Handler<Void>) - Method in CommandProcess
Set an end handler, this handler is called when the command is ended, for instance the command is running and the shell closes.
endHandler(Handler<Void>) - Method in DatagramSocket
endHandler(Handler<Void>) - Method in HttpClientRequest
endHandler(Handler<Void>) - Method in HttpClientResponse
endHandler(Handler<Void>) - Method in HttpServerFileUpload
endHandler(Handler<Void>) - Method in HttpServerRequest
endHandler(Handler<Void>) - Method in HttpServerRequestStream
endHandler(Handler<Void>) - Method in MessageConsumer
endHandler(Handler<Void>) - Method in NetSocket
endHandler(Handler<Void>) - Method in NetSocketStream
endHandler(Handler<Void>) - Method in ReadStream
endHandler(Handler<Void>) - Method in ReadStreamImpl
Set an end handler.
endHandler(Handler<Void>) - Method in ServerWebSocket
endHandler(Handler<Void>) - Method in ServerWebSocketStream
endHandler(Handler<Void>) - Method in SockJSSocket
endHandler(Handler<TestResult>) - Method in TestCaseReport
Set a callback for completion, the specified handler is invoked when the test exec has completed.
endHandler(Handler<Void>) - Method in TestSuiteReport
endHandler(Handler<Void>) - Method in TimeoutStream
endHandler(Handler<Void>) - Method in WebSocket
endHandler(Handler<Void>) - Method in WebSocketBase
endHandler(Handler<Void>) - Method in WebSocketBaseImpl
endHandler(Handler<Void>) - Method in WebSocketStream
errorFrameHandler(Handler<Map<String, Object>>) - Method in StompClient
A general error frame handler.
ErrorHandler - Class in io.vertx.groovy.ext.web.handler
A pretty error handler for rendering error pages.
ErrorHandler(Object) - Constructor in ErrorHandler
errorHandler(Handler<Map<String, Object>>) - Method in StompClientConnection
Sets a handler notified when an ERROR frame is received by the client.
eval(String, List<String>, List<String>, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Execute a Lua script server side.
eval(String, List<String>, List<String>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Execute a Lua script server side.
evalsha(String, List<String>, List<String>, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Execute a Lua script server side.
evalsha(String, List<String>, List<String>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Execute a Lua script server side.
EventBus - Class in io.vertx.groovy.core.eventbus
A Vert.x event-bus is a light-weight distributed messaging system which allows different parts of your application, or different applications and services to communicate with each in a loosely coupled way.
EventBus(Object) - Constructor in EventBus
eventBus() - Method in Vertx
Get the event bus object.
EventBusCollector - Class in io.vertx.groovy.ext.unit.collect
The event bus collector listen to events on the Vert.x event bus and translate them into reports.
EventBusCollector(Object) - Constructor in EventBusCollector
EventBusService - Class in io.vertx.groovy.servicediscovery.types
for event bus services (service proxies).
EventBusService(Object) - Constructor in EventBusService
exceptionHandler(Handler<Throwable>) - Method in AsyncFile
exceptionHandler(Handler<Throwable>) - Method in Context
Set an exception handler called when the context runs an action throwing an uncaught throwable.
exceptionHandler(Handler<Throwable>) - Method in DatagramSocket
exceptionHandler(Handler<Throwable>) - Method in HttpClientRequest
exceptionHandler(Handler<Throwable>) - Method in HttpClientResponse
exceptionHandler(Handler<Throwable>) - Method in HttpConnection
Set an handler called when a connection error happens
exceptionHandler(Handler<Throwable>) - Method in HttpServerFileUpload
exceptionHandler(Handler<Throwable>) - Method in HttpServerRequest
exceptionHandler(Handler<Throwable>) - Method in HttpServerRequestStream
exceptionHandler(Handler<Throwable>) - Method in HttpServerResponse
exceptionHandler(Handler<Throwable>) - Method in MessageConsumer
exceptionHandler(Handler<Throwable>) - Method in MessageProducer
exceptionHandler(Handler<Throwable>) - Method in NetSocket
exceptionHandler(Handler<Throwable>) - Method in NetSocketStream
exceptionHandler(Handler<Throwable>) - Method in PacketWritestream
exceptionHandler(Handler<Throwable>) - Method in ReadStream
exceptionHandler(Handler<Throwable>) - Method in ReadStreamImpl
Set an exception handler on the read stream.
exceptionHandler(Handler<Throwable>) - Method in Router
Specify a handler for any unhandled exceptions on this router.
exceptionHandler(Handler<Throwable>) - Method in ServerWebSocket
exceptionHandler(Handler<Throwable>) - Method in ServerWebSocketStream
exceptionHandler(Handler<Throwable>) - Method in SockJSSocket
exceptionHandler(Handler<Throwable>) - Method in StreamBase
exceptionHandler(Handler<Throwable>) - Method in StreamBaseImpl
Set an exception handler.
exceptionHandler() - Method in TestContext
@return
Returns:
an exception handler that will fail this context
exceptionHandler(Handler<Throwable>) - Method in TestSuiteReport
Set an exception handler, the exception handler reports the test suite errors, it can be called mulitple times before the test ends.
exceptionHandler(Handler<Throwable>) - Method in TimeoutStream
exceptionHandler(Handler<Throwable>) - Method in Vertx
Set a default exception handler for Context, set on at creation.
exceptionHandler(Handler<Throwable>) - Method in WebSocket
exceptionHandler(Handler<Throwable>) - Method in WebSocketBase
exceptionHandler(Handler<Throwable>) - Method in WebSocketBaseImpl
exceptionHandler(Handler<Throwable>) - Method in WebSocketStream
exceptionHandler(Handler<Throwable>) - Method in WriteStream
exceptionHandler(Handler<Throwable>) - Method in WriteStreamImpl
Set an exception handler on the write stream.
exchangeBind(String, String, String, Handler<AsyncResult<Void>>) - Method in RabbitMQClient
Bind an exchange to an exchange.
exchangeDeclare(String, String, boolean, boolean, Handler<AsyncResult<Void>>) - Method in RabbitMQClient
Declare an exchange.
exchangeDelete(String, Handler<AsyncResult<Void>>) - Method in RabbitMQClient
Delete an exchange, without regard for whether it is in use or not.
exchangeUnbind(String, String, String, Handler<AsyncResult<Void>>) - Method in RabbitMQClient
Unbind an exchange from an exchange.
exec(Handler<AsyncResult<List<Object>>>) - Method in RedisTransaction
Execute all commands issued after MULTI
execute(Handler<Future<T>>) - Method in CircuitBreaker
Same as CircuitBreaker.executeWithFallback but using the circuit breaker default fallback.
execute(String, Handler<AsyncResult<Void>>) - Method in SQLConnection
Executes the given SQL statement
executeAndReport(Future<T>, Handler<Future<T>>) - Method in CircuitBreaker
Same as CircuitBreaker.executeAndReportWithFallback but using the circuit breaker default fallback.
executeAndReportWithFallback(Future<T>, Handler<Future<T>>, Function<Throwable, T>) - Method in CircuitBreaker
Executes the given operation with the circuit breaker control.
executeBlocking(Handler<Future<T>>, Handler<AsyncResult<T>>) - Method in Context
Invoke Context.executeBlocking with order = true.
executeBlocking(Handler<Future<T>>, Handler<AsyncResult<T>>) - Method in Vertx
Like Vertx.executeBlocking called with ordered = true.
executeBlocking(Handler<Future<T>>, Handler<AsyncResult<T>>) - Method in WorkerExecutor
Like WorkerExecutor.executeBlocking called with ordered = true.
executeWithFallback(Handler<Future<T>>, Function<Throwable, T>) - Method in CircuitBreaker
Executes the given operation with the circuit breaker control.
exists(String, Handler<AsyncResult<Boolean>>) - Method in FileSystem
Determines whether the file as specified by the path path exists, asynchronously.
exists(String, Handler<AsyncResult<Long>>) - Method in RedisClient
Determine if a key exists
exists(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Determine if a key exists
existsBlocking(String) - Method in FileSystem
Blocking version of FileSystem.exists
exitCode() - Method in Process
@return
Returns:
the process exit code when the status is otherwise null
expire(String, int, Handler<AsyncResult<Long>>) - Method in RedisClient
Set a key's time to live in seconds
expire(String, int, Handler<AsyncResult<String>>) - Method in RedisTransaction
Set a key's time to live in seconds
expireat(String, long, Handler<AsyncResult<Long>>) - Method in RedisClient
Set the expiration for a key as a UNIX timestamp
expireat(String, long, Handler<AsyncResult<String>>) - Method in RedisTransaction
Set the expiration for a key as a UNIX timestamp
expired() - Method in AccessToken
Check if the access token is expired or not.
exposedHeader(String) - Method in CorsHandler
Add an exposed header
exposedHeaders(Set<String>) - Method in CorsHandler
Add a set of exposed headers

F

fail(String) - Method in Future
Set the failure.
fail(int, String) - Method in Message
Signal to the sender that processing of this message failed.
fail(Throwable) - Method in RoutingContext
Fail the context with the specified throwable.
fail(Throwable) - Method in TestContext
Throw a failure with the specified failure cause.
failed(int) - Method in CompositeFuture
Returns true if a wrapped future is failed
failed() - Method in Future
Did it fail?
failed() - Method in RoutingContext
Returns:
true if the context is being routed to failure handlers.
failed() - Method in TestResult
Did it fail?
failedFuture(String) - Method in Future
Create a failed future with the specified failure message.
Failure - Class in io.vertx.groovy.ext.unit.report
A failure provides the details of a failure that happened during the execution of a test case.
Failure(Object) - Constructor in Failure
failure(Throwable) - Method in InternalHelper
failure() - Method in RoutingContext
If the context is being routed to failure handlers after a failure has been triggered by calling RoutingContext.fail then this will return that throwable.
failure() - Method in TestResult
An exception describing failure, null if the test succeeded.
failureCount() - Method in CircuitBreaker
Returns:
the current number of failures.
failureHandler(Handler<RoutingContext>) - Method in Route
Specify a failure handler for the route.
fallback(Function<Throwable, T>) - Method in CircuitBreaker
Sets a default invoked when the bridge is open to handle the "request", or on failure if FaviconHandler - Class in io.vertx.groovy.ext.web.handler
A handler that serves favicons.
FaviconHandler(Object) - Constructor in FaviconHandler
fileName() - Method in FileUpload
@return
Returns:
the file name of the upload as provided in the form submission
filename() - Method in HttpServerFileUpload
Returns:
the filename which was used when upload the file.
FileProps - Class in io.vertx.groovy.core.file
Represents properties of a file on the file system.
FileProps(Object) - Constructor in FileProps
FileSystem - Class in io.vertx.groovy.core.file
Contains a broad set of operations for manipulating files on the file system.
FileSystem(Object) - Constructor in FileSystem
fileSystem() - Method in Vertx
Get the filesystem object.
FileSystemProps - Class in io.vertx.groovy.core.file
Represents properties of the file system.
FileSystemProps(Object) - Constructor in FileSystemProps
FileUpload - Class in io.vertx.groovy.ext.web
Represents a file-upload from an HTTP multipart form submission.
FileUpload(Object) - Constructor in FileUpload
fileUploads() - Method in RoutingContext
Returns:
a set of fileuploads (if any) for the request.
find(String, Map<String, Object>, Handler<AsyncResult<List<Map<String, Object>>>>) - Method in MongoClient
Find matching documents in the specified collection
findBatch(String, Map<String, Object>, Handler<AsyncResult<Map<String, Object>>>) - Method in MongoClient
Find matching documents in the specified collection.
findBatchWithOptions(String, Map<String, Object>, Map<String, Object>, Handler<AsyncResult<Map<String, Object>>>) - Method in MongoClient
Find matching documents in the specified collection, specifying options.
findOne(String, Map<String, Object>, Map<String, Object>, Handler<AsyncResult<Map<String, Object>>>) - Method in MongoClient
Find a single matching document in the specified collection
findWithOptions(String, Map<String, Object>, Map<String, Object>, Handler<AsyncResult<List<Map<String, Object>>>>) - Method in MongoClient
Find matching documents in the specified collection, specifying options
fixedSizeMode(int) - Method in RecordParser
Flip the parser into fixed size mode, where the record size is specified by size in bytes.
flags() - Method in HttpFrame
@return
Returns:
the 8-bit flags specific to the frame
flush(Handler<AsyncResult<Void>>) - Method in AsyncFile
Same as AsyncFile.flush but the handler will be called when the flush is complete or if an error occurs
flushall(Handler<AsyncResult<String>>) - Method in RedisClient
Remove all keys from all databases
flushall(Handler<AsyncResult<String>>) - Method in RedisTransaction
Remove all keys from all databases
flushdb(Handler<AsyncResult<String>>) - Method in RedisClient
Remove all keys from the current database
flushdb(Handler<AsyncResult<String>>) - Method in RedisTransaction
Remove all keys from the current database
foregroundHandler(Handler<Void>) - Method in CommandProcess
Set a foreground handler, this handler is called when the command is running and put to foreground.
foregroundJob() - Method in JobController
@return
Returns:
the current foreground job
formAttributes() - Method in HttpServerRequest
Returns a map of all form attributes in the request.
FormLoginHandler - Class in io.vertx.groovy.ext.web.handler
Handler that handles login from a form on a custom login page.
FormLoginHandler(Object) - Constructor in FormLoginHandler
frame() - Method in ServerFrame
@return the received frame
frameHandler(Handler<WebSocketFrame>) - Method in ServerWebSocket
frameHandler(Handler<WebSocketFrame>) - Method in WebSocket
frameHandler(Handler<WebSocketFrame>) - Method in WebSocketBase
frameHandler(Handler<WebSocketFrame>) - Method in WebSocketBaseImpl
Set a frame handler on the connection.
Frames - Class in io.vertx.groovy.ext.stomp
Utility methods to build common frames() - Method in Acknowledgement
Returns:
the list of frames that have been acknowledged / not-acknowledged.
Frames(Object) - Constructor in Frames
fsProps(String, Handler<AsyncResult<FileSystemProps>>) - Method in FileSystem
Returns properties of the file-system being used by the specified path, asynchronously.
fsPropsBlocking(String) - Method in FileSystem
Blocking version of FileSystem.fsProps
Future - Class in io.vertx.groovy.core
Represents the result of an action that may, or may not, have occurred yet.
Future(Object) - Constructor in Future

G

generateToken(Map<String, Object>, Map<String, Object>) - Method in JWTAuth
Generate a new JWT token.
geoadd(String, double, double, String, Handler<AsyncResult<Long>>) - Method in 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 RedisTransaction
Add one or more geospatial items in the geospatial index represented using a sorted set.
geoaddMany(String, List<Map<String, Object>>, Handler<AsyncResult<Long>>) - Method in RedisClient
Add one or more geospatial items in the geospatial index represented using a sorted set.
geoaddMany(String, List<Map<String, Object>>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Add one or more geospatial items in the geospatial index represented using a sorted set.
geodist(String, String, String, Handler<AsyncResult<String>>) - Method in 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 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 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 RedisTransaction
Return the distance between two members in the geospatial index represented by the sorted set.
geohash(String, String, Handler<AsyncResult<List<Object>>>) - Method in 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 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<List<Object>>>) - Method in 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 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(String, String, Handler<AsyncResult<List<Object>>>) - Method in 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 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<List<Object>>>) - Method in 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 RedisTransaction
Return the positions (longitude,latitude) of all the specified members of the geospatial index represented by the sorted set at key.
georadius(String, double, double, double, GeoUnit, Handler<AsyncResult<List<Object>>>) - Method in 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 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).
georadiusbymember(String, String, double, GeoUnit, Handler<AsyncResult<List<Object>>>) - Method in 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 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.
georadiusbymemberWithOptions(String, String, double, GeoUnit, Map<String, Object>, Handler<AsyncResult<List<Object>>>) - Method in 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, Map<String, Object>, Handler<AsyncResult<String>>) - Method in 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.
georadiusWithOptions(String, double, double, double, GeoUnit, Map<String, Object>, Handler<AsyncResult<List<Object>>>) - Method in 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, Map<String, Object>, Handler<AsyncResult<String>>) - Method in 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(K, Handler<AsyncResult<V>>) - Method in AsyncMap
Get a value from the map, asynchronously.
get(String) - Method in Context
Get some data from the context.
get(Handler<AsyncResult<Long>>) - Method in Counter
Get the current value of the counter
get(String, Handler<HttpClientResponse>) - Method in HttpClient
Create an HTTP GET request to send to the server at the default host and port, specifying a response handler to receive the response
get(K) - Method in LocalMap
Get a value from the map
get(String) - Method in MultiMap
Returns the value of with the specified name.
get(String, Handler<AsyncResult<String>>) - Method in RedisClient
Get the value of a key
get(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Get the value of a key
get(String) - Method in Router
Add a route that matches a HTTP GET request and the specified path
get(String) - Method in RoutingContext
Get some data from the context.
get() - Method in ServiceReference
Gets the object to access the service.
get(String) - Method in Session
Get some data from the session
get(String, Handler<AsyncResult<Session>>) - Method in SessionStore
Get the session with the specified ID
get(String) - Method in TestContext
Get some data from the context.
getAbs(String, Handler<HttpClientResponse>) - Method in HttpClient
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 RoutingContext
If the route specifies produces matches, e.g. produces `text/html` and `text/plain`, and the `accept` header matches one or more of these then this returns the most acceptable match.
getAll(String) - Method in MultiMap
Returns the values with the specified name
getAndAdd(long, Handler<AsyncResult<Long>>) - Method in Counter
Add the value to the counter atomically and return the value before the add
getAndIncrement(Handler<AsyncResult<Long>>) - Method in Counter
Increment the counter atomically and return the value before the increment.
getArgument(int) - Method in CLI
Gets an getArguments() - Method in CLI
Gets the list of defined arguments.
getArgumentValue(int) - Method in CommandLine
Gets the value of an argument with the given index.
getBaseName(Measured) - Method in MetricsService
@param measured the measure object
getBinary(String, Handler<AsyncResult<Buffer>>) - Method in RedisClient
Get the value of a key - without decoding as utf-8
getBinary(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Get the value of a key - without decoding as utf-8
getbit(String, long, Handler<AsyncResult<Long>>) - Method in RedisClient
Returns the bit value at offset in the string value stored at key
getbit(String, long, Handler<AsyncResult<String>>) - Method in RedisTransaction
Returns the bit value at offset in the string value stored at key
getBody() - Method in RoutingContext
Returns:
Get the entire HTTP request body as a .
getBodyAsJson() - Method in RoutingContext
Returns:
Get the entire HTTP request body as a .
getBodyAsJsonArray() - Method in RoutingContext
Returns:
Get the entire HTTP request body as a .
getBodyAsString(String) - Method in RoutingContext
Get the entire HTTP request body as a string, assuming the specified encoding.
getBuffer(int, int) - Method in Buffer
Returns a copy of a sub-sequence the Buffer as a Buffer starting at position start and ending at position end - 1
getByte(int) - Method in Buffer
Returns the byte at position pos in the Buffer.
getClient(ServiceDiscovery, Map<String, Object>, Handler<AsyncResult<HttpClient>>) - Method in HttpEndpoint
Convenient method that looks for a HTTP endpoint and provides the configured .
getClusterWideMap(String, Handler<AsyncResult<AsyncMap<K, V>>>) - Method in SharedData
Get the cluster wide map with the specified name.
getCollectionName() - Method in MongoAuth
The name of the collection used to store User objects inside.
getCollections(Handler<AsyncResult<List<String>>>) - Method in MongoClient
Get a list of all collections in the database.
getCommand(String) - Method in CommandResolver
Returns a single command by its name.
getConnection(Handler<AsyncResult<SQLConnection>>) - Method in AsyncSQLClient
Returns a connection that can be used to perform SQL operations on.
getConnection(Handler<AsyncResult<SQLConnection>>) - Method in JDBCClient
Returns a connection that can be used to perform SQL operations on.
getConsumer(ServiceDiscovery, Map<String, Object>, Handler<AsyncResult<MessageConsumer<T>>>) - Method in MessageSource
Convenient method that looks for a message source and provides the configured .
getCookie(String) - Method in RoutingContext
Get the cookie with the specified name.
getCounter(String, Handler<AsyncResult<Counter>>) - Method in SharedData
Get a cluster wide counter.
getDelegate() - Method in AccessToken
getDelegate() - Method in Acknowledgement
getDelegate() - Method in AmqpBridge
getDelegate() - Method in Async
getDelegate() - Method in AsyncFile
getDelegate() - Method in AsyncMap
getDelegate() - Method in AsyncSQLClient
getDelegate() - Method in AuthHandler
getDelegate() - Method in AuthHandlerImpl
getDelegate() - Method in AuthProvider
getDelegate() - Method in BasicAuthHandler
getDelegate() - Method in BodyHandler
getDelegate() - Method in BridgeEvent
getDelegate() - Method in Buffer
getDelegate() - Method in CircuitBreaker
getDelegate() - Method in CLI
getDelegate() - Method in CliToken
getDelegate() - Method in ClusteredSessionStore
getDelegate() - Method in Command
getDelegate() - Method in CommandBuilder
getDelegate() - Method in CommandLine
getDelegate() - Method in CommandProcess
getDelegate() - Method in CommandRegistry
getDelegate() - Method in CommandResolver
getDelegate() - Method in Completion
getDelegate() - Method in CompositeFuture
getDelegate() - Method in Context
getDelegate() - Method in Cookie
getDelegate() - Method in CookieHandler
getDelegate() - Method in CorsHandler
getDelegate() - Method in Counter
getDelegate() - Method in CSRFHandler
getDelegate() - Method in DatagramPacket
getDelegate() - Method in DatagramSocket
getDelegate() - Method in Destination
getDelegate() - Method in DestinationFactory
getDelegate() - Method in DnsClient
getDelegate() - Method in ErrorHandler
getDelegate() - Method in EventBus
getDelegate() - Method in EventBusCollector
getDelegate() - Method in EventBusService
getDelegate() - Method in Failure
getDelegate() - Method in FaviconHandler
getDelegate() - Method in FileProps
getDelegate() - Method in FileSystem
getDelegate() - Method in FileSystemProps
getDelegate() - Method in FileUpload
getDelegate() - Method in FormLoginHandler
getDelegate() - Method in Frames
getDelegate() - Method in Future
getDelegate() - Method in HandlebarsTemplateEngine
getDelegate() - Method in HashStrategy
getDelegate() - Method in HttpClient
getDelegate() - Method in HttpClientRequest
getDelegate() - Method in HttpClientResponse
getDelegate() - Method in HttpConnection
getDelegate() - Method in HttpEndpoint
getDelegate() - Method in HttpFrame
getDelegate() - Method in HttpServer
getDelegate() - Method in HttpServerFileUpload
getDelegate() - Method in HttpServerRequest
getDelegate() - Method in HttpServerRequestStream
getDelegate() - Method in HttpServerResponse
getDelegate() - Method in JadeTemplateEngine
getDelegate() - Method in JDBCAuth
getDelegate() - Method in JDBCClient
getDelegate() - Method in JDBCDataSource
getDelegate() - Method in Job
getDelegate() - Method in JobController
getDelegate() - Method in JWTAuth
getDelegate() - Method in JWTAuthHandler
getDelegate() - Method in Locale
getDelegate() - Method in LocalMap
getDelegate() - Method in LocalSessionStore
getDelegate() - Method in Lock
getDelegate() - Method in LoggerHandler
getDelegate() - Method in MailClient
getDelegate() - Method in MailService
getDelegate() - Method in Measured
getDelegate() - Method in MeasuredImpl
getDelegate() - Method in Message
getDelegate() - Method in MessageConsumer
getDelegate() - Method in MessageProducer
getDelegate() - Method in MessageSource
getDelegate() - Method in MetricsService
getDelegate() - Method in MongoAuth
getDelegate() - Method in MongoClient
getDelegate() - Method in MultiMap
getDelegate() - Method in MVELTemplateEngine
getDelegate() - Method in MxRecord
getDelegate() - Method in MySQLClient
getDelegate() - Method in NetClient
getDelegate() - Method in NetServer
getDelegate() - Method in NetSocket
getDelegate() - Method in NetSocketStream
getDelegate() - Method in OAuth2Auth
getDelegate() - Method in OAuth2AuthHandler
getDelegate() - Method in PacketWritestream
getDelegate() - Method in PostgreSQLClient
getDelegate() - Method in Process
getDelegate() - Method in Pty
getDelegate() - Method in Pump
getDelegate() - Method in RabbitMQClient
getDelegate() - Method in ReadStream
getDelegate() - Method in ReadStreamImpl
getDelegate() - Method in RecordParser
getDelegate() - Method in RedirectAuthHandler
getDelegate() - Method in RedisClient
getDelegate() - Method in RedisTransaction
getDelegate() - Method in ResponseTimeHandler
getDelegate() - Method in Route
getDelegate() - Method in Router
getDelegate() - Method in RoutingContext
getDelegate() - Method in SendContext
getDelegate() - Method in ServerFrame
getDelegate() - Method in ServerWebSocket
getDelegate() - Method in ServerWebSocketStream
getDelegate() - Method in ServiceDiscovery
getDelegate() - Method in ServiceDiscoveryBridge
getDelegate() - Method in ServiceExporter
getDelegate() - Method in ServiceImporter
getDelegate() - Method in ServicePublisher
getDelegate() - Method in ServiceReference
getDelegate() - Method in Session
getDelegate() - Method in SessionHandler
getDelegate() - Method in SessionStore
getDelegate() - Method in SharedData
getDelegate() - Method in Shell
getDelegate() - Method in ShellServer
getDelegate() - Method in ShellService
getDelegate() - Method in ShiroAuth
getDelegate() - Method in SignalHandler
getDelegate() - Method in SocketAddress
getDelegate() - Method in SockJSHandler
getDelegate() - Method in SockJSSocket
getDelegate() - Method in SockJSTermHandler
getDelegate() - Method in SQLConnection
getDelegate() - Method in SrvRecord
getDelegate() - Method in StaticHandler
getDelegate() - Method in StompClient
getDelegate() - Method in StompClientConnection
getDelegate() - Method in StompServer
getDelegate() - Method in StompServerConnection
getDelegate() - Method in StompServerHandler
getDelegate() - Method in StreamBase
getDelegate() - Method in StreamBaseImpl
getDelegate() - Method in TcpEventBusBridge
getDelegate() - Method in TemplateEngine
getDelegate() - Method in TemplateHandler
getDelegate() - Method in Term
getDelegate() - Method in TermServer
getDelegate() - Method in TestCase
getDelegate() - Method in TestCaseReport
getDelegate() - Method in TestCompletion
getDelegate() - Method in TestContext
getDelegate() - Method in TestResult
getDelegate() - Method in TestSuite
getDelegate() - Method in TestSuiteReport
getDelegate() - Method in ThymeleafTemplateEngine
getDelegate() - Method in TimeoutHandler
getDelegate() - Method in TimeoutStream
getDelegate() - Method in Tty
getDelegate() - Method in User
getDelegate() - Method in UserSessionHandler
getDelegate() - Method in Vertx
getDelegate() - Method in VirtualHostHandler
getDelegate() - Method in WebSocket
getDelegate() - Method in WebSocketBase
getDelegate() - Method in WebSocketBaseImpl
getDelegate() - Method in WebSocketFrame
getDelegate() - Method in WebSocketStream
getDelegate() - Method in WorkerExecutor
getDelegate() - Method in WriteStream
getDelegate() - Method in WriteStreamImpl
getDescription() - Method in CLI
Returns:
the CLI description.
getDestination(String) - Method in StompServerHandler
Gets the destination with the given name.
getDestinations() - Method in StompServerHandler
Returns:
the list of destination managed by the STOMP server.
getDomain() - Method in Cookie
@return
Returns:
the domain for the cookie
getDouble(int) - Method in Buffer
Returns the double at position pos in the Buffer.
getFloat(int) - Method in Buffer
Returns the float at position pos in the Buffer.
getFormAttribute(String) - Method in HttpServerRequest
Return the first form attribute value with the specified name
getHashStrategy() - Method in MongoAuth
The HashStrategy which is used by the current instance
getHeader(String) - Method in HttpClientResponse
Return the first header value with the specified name
getHeader(String) - Method in HttpServerRequest
Return the first header value with the specified name
getHost() - Method in HttpClientRequest
Returns:
the request host.
getInstanceCount() - Method in Context
@return
Returns:
the number of instances of the verticle that were deployed in the deployment (if any) related to this context
getInt(int) - Method in Buffer
Returns the int at position pos in the Buffer.
getIntLE(int) - Method in Buffer
Gets a 32-bit integer at the specified absolute index in this buffer with Little Endian Byte Order.
getJDBCClient(ServiceDiscovery, Map<String, Object>, Map<String, Object>, Handler<AsyncResult<JDBCClient>>) - Method in JDBCDataSource
Convenient method that looks for a JDBC datasource source and provides the configured JDBCClient.
getJob(int) - Method in JobController
Returns an active job in this session by its .
getLocalMap(String) - Method in SharedData
Return a LocalMap with the specific name.
getLock(String, Handler<AsyncResult<Lock>>) - Method in SharedData
Get a cluster wide lock with the specified name.
getLockWithTimeout(String, long, Handler<AsyncResult<Lock>>) - Method in SharedData
Like SharedData.getLock but specifying a timeout.
getLong(int) - Method in Buffer
Returns the long at position pos in the Buffer.
getLongLE(int) - Method in Buffer
Gets a 64-bit long integer at the specified absolute index in this buffer in Little Endian Byte Order.
getMaxBufferedMessages() - Method in MessageConsumer
@return
Returns:
the maximum number of messages that can be buffered when this stream is paused
getMedium(int) - Method in Buffer
Gets a 24-bit medium integer at the specified absolute index in this buffer.
getMediumLE(int) - Method in Buffer
Gets a 24-bit medium integer at the specified absolute index in this buffer in the Little Endian Byte Order.
getMetricsSnapshot(String) - Method in MetricsService
Will return the metrics that begins with the baseName, null if no metrics is available.
getName() - Method in CLI
Returns:
the CLI name.
getName() - Method in Cookie
@return
Returns:
the name of this cookie
getNow(String, Handler<HttpClientResponse>) - Method in HttpClient
Sends an HTTP GET request to the server at the default host and port, specifying a response handler to receive the response
getOption(String) - Method in CLI
Gets an getOptions() - Method in CLI
Gets the list of options.
getOptionValue(String) - Method in CommandLine
Gets the value of an option with the matching name (can be the long name, short name or arg name).
getOrCreateContext() - Method in Vertx
Gets the current context, or creates one if there isn't one
getOrCreateDestination(String) - Method in StompServerHandler
Gets a Destination object if existing, or create a new one.
getParam(String) - Method in HttpServerRequest
Return the first param value with the specified name
getPasswordCredentialField() - Method in MongoAuth
Get the name of the field to be used as property for the password of credentials in the method AuthProvider.authenticate.
getPasswordField() - Method in MongoAuth
Get the name of the field to be used for the password Defaults to MongoAuth
getPath() - Method in Cookie
@return the path for this cookie
getPath() - Method in Route
@return
Returns:
the path prefix (if any) for this route
getPermissionField() - Method in MongoAuth
Get the name of the field to be used for the permissions.
getProxy(ServiceDiscovery, String, Handler<AsyncResult<T>>) - Method in EventBusService
Lookup for a service record and if found, retrieve it and return the service object (used to consume the service).
getrange(String, long, long, Handler<AsyncResult<String>>) - Method in RedisClient
Get a substring of the string stored at a key
getrange(String, long, long, Handler<AsyncResult<String>>) - Method in RedisTransaction
Get a substring of the string stored at a key
getRawMessage() - Method in BridgeEvent
Get the raw JSON message for the event.
getRawMethod() - Method in HttpClientRequest
@return
Returns:
the raw value of the method this request sends
getRawValueForArgument(Map<String, Object>) - Method in CommandLine
Gets the raw value of the given argument.
getRawValueForOption(Map<String, Object>) - Method in CommandLine
Gets the raw value of the given option.
getRawValues(Map<String, Object>) - Method in CommandLine
Gets the raw values of the given option.
getRawValuesForArgument(Map<String, Object>) - Method in CommandLine
Gets the raw values of the given argument.
getRawValuesForOption(Map<String, Object>) - Method in CommandLine
Gets the raw values of the given option.
getRecord(Function<Map<String, Object>, Boolean>, boolean, Handler<AsyncResult<Map<String, Object>>>) - Method in ServiceDiscovery
Lookups for a single record.
getRecords(Function<Map<String, Object>, Boolean>, boolean, Handler<AsyncResult<List<Map<String, Object>>>>) - Method in ServiceDiscovery
Lookups for a set of records.
getReference(Map<String, Object>) - Method in ServiceDiscovery
Gets a service reference from the given record.
getReferenceWithConfiguration(Map<String, Object>, Map<String, Object>) - Method in ServiceDiscovery
Gets a service reference from the given record, the reference is configured with the given json object.
getRoleField() - Method in MongoAuth
Get the name of the field to be used for the roles.
getRoutes() - Method in Router
@return
Returns:
a list of all the routes on this router
getSalt(User) - Method in HashStrategy
Retrieve the salt.
getSaltField() - Method in MongoAuth
Get the name of the field to be used for the salt.
getSaltStyle() - Method in HashStrategy
Get the defined io.vertx.groovy.ext.auth.mongo.HashSaltStyle of the current instance
getSession() - Method in Process
@return
Returns:
the process session
getset(String, String, Handler<AsyncResult<String>>) - Method in RedisClient
Set the string value of a key and return its old value
getset(String, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Set the string value of a key and return its old value
getShared(Vertx) - Method in CommandRegistry
Get the shared registry for the Vert.x instance.
getShort(int) - Method in Buffer
Returns the short at position pos in the Buffer.
getShortLE(int) - Method in Buffer
Gets a 16-bit short integer at the specified absolute index in this buffer in Little Endian Byte Order.
getStatusCode() - Method in HttpServerResponse
Returns:
the HTTP status code of the response.
getStatusMessage() - Method in HttpServerResponse
Returns:
the HTTP status message of the response.
getStoredPwd(User) - Method in HashStrategy
Retrieve the password from the user, or as clear text or as hashed version, depending on the definition
getString(int, int) - Method in 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
getSubscriptions(StompServerConnection) - Method in Destination
Gets all subscription ids for the given destination hold by the given client
getSummary() - Method in CLI
Returns:
the CLI summary.
getToken(Map<String, Object>, Handler<AsyncResult<AccessToken>>) - Method in OAuth2Auth
Returns the Access Token object.
getTrailer(String) - Method in HttpClientResponse
Return the first trailer value with the specified name
getTransactionIsolation(Handler<AsyncResult<TransactionIsolation>>) - Method in SQLConnection
Attempts to return the transaction isolation level for this Connection object to the one given.
getTty() - Method in Process
@return
Returns:
the process tty
getUnsignedByte(int) - Method in Buffer
Returns the unsigned byte at position pos in the Buffer, as a short.
getUnsignedInt(int) - Method in Buffer
Returns the unsigned int at position pos in the Buffer, as a long.
getUnsignedIntLE(int) - Method in Buffer
Returns the unsigned int at position pos in the Buffer, as a long in Little Endian Byte Order.
getUnsignedMedium(int) - Method in Buffer
Gets an unsigned 24-bit medium integer at the specified absolute index in this buffer.
getUnsignedMediumLE(int) - Method in 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 Buffer
Returns the unsigned short at position pos in the Buffer, as an int.
getUnsignedShortLE(int) - Method in Buffer
Gets an unsigned 16-bit short integer at the specified absolute index in this buffer in Little Endian Byte Order.
getUsernameCredentialField() - Method in MongoAuth
Get the name of the field to be used as property for the username in the method AuthProvider.authenticate.
getUsernameField() - Method in MongoAuth
Get the name of the field to be used for the username.
getValue() - Method in Cookie
@return
Returns:
the value of this cookie
getWindowSize() - Method in HttpConnection
@return
Returns:
the current connection window size or -1 for HTTP/1.x
getWithRegex(String) - Method in Router
Add a route that matches a HTTP GET request and the specified path regex
goAway(long, int, Buffer) - Method in HttpConnection
Send a go away frame to the remote endpoint of the connection.
goAwayHandler(Handler<Map<String, Object>>) - Method in HttpConnection
Set an handler called when a frame is received.
GroovyVerticle - Class in io.vertx.lang.groovy
The base class for Groovy verticles.
GroovyVerticleFactory - Class in io.vertx.lang.groovy
Placeholder

H

halfOpenHandler(Handler<Void>) - Method in CircuitBreaker
Sets a invoked when the circuit breaker state switches to half-open.
handle(RoutingContext) - Method in AuthHandler
handle(RoutingContext) - Method in AuthHandlerImpl
handle(RoutingContext) - Method in BasicAuthHandler
handle(RoutingContext) - Method in BodyHandler
handle(RoutingContext) - Method in CookieHandler
handle(RoutingContext) - Method in CorsHandler
handle(RoutingContext) - Method in CSRFHandler
handle(RoutingContext) - Method in ErrorHandler
handle(RoutingContext) - Method in FaviconHandler
handle(RoutingContext) - Method in FormLoginHandler
handle(RoutingContext) - Method in JWTAuthHandler
handle(RoutingContext) - Method in LoggerHandler
handle(RoutingContext) - Method in OAuth2AuthHandler
handle(Buffer) - Method in RecordParser
This method is called to provide the parser with data.
handle(RoutingContext) - Method in RedirectAuthHandler
handle(RoutingContext) - Method in ResponseTimeHandler
handle(RoutingContext) - Method in SessionHandler
handle(RoutingContext) - Method in SockJSHandler
handle(SockJSSocket) - Method in SockJSTermHandler
handle(RoutingContext) - Method in StaticHandler
handle(ServerFrame) - Method in StompServerHandler
handle(RoutingContext) - Method in TemplateHandler
handle(RoutingContext) - Method in TimeoutHandler
handle(RoutingContext) - Method in UserSessionHandler
handle(RoutingContext) - Method in VirtualHostHandler
HandlebarsTemplateEngine - Class in io.vertx.groovy.ext.web.templ
A template engine that uses the Handlebars library.
HandlebarsTemplateEngine(Object) - Constructor in HandlebarsTemplateEngine
handleContext(RoutingContext) - Method in Router
Used to route a context to the router.
handleFailure(RoutingContext) - Method in Router
Used to route a failure to the router.
handler(Handler<Buffer>) - Method in AsyncFile
handler(Handler<AsyncResult<T>>) - Method in Completion
Completion handler to receive a completion signal when this completions completes.
handler(Handler<DatagramPacket>) - Method in DatagramSocket
handler(Handler<HttpClientResponse>) - Method in HttpClientRequest
handler(Handler<Buffer>) - Method in HttpClientResponse
handler(Handler<Buffer>) - Method in HttpServerFileUpload
handler(Handler<Buffer>) - Method in HttpServerRequest
handler(Handler<HttpServerRequest>) - Method in HttpServerRequestStream
handler(Handler<Message<T>>) - Method in MessageConsumer
handler(Handler<Buffer>) - Method in NetSocket
handler(Handler<NetSocket>) - Method in NetSocketStream
handler(Handler<T>) - Method in ReadStream
handler(Handler<T>) - Method in ReadStreamImpl
Set a data handler.
handler(Handler<RoutingContext>) - Method in Route
Specify a request handler for the route.
handler(Handler<Buffer>) - Method in ServerWebSocket
handler(Handler<ServerWebSocket>) - Method in ServerWebSocketStream
handler(Handler<Buffer>) - Method in SockJSSocket
handler(StompServerHandler) - Method in StompServer
Configures the StompServerHandler.
handler() - Method in StompServerConnection
@return
Returns:
the STOMP server handler dealing with this connection
handler(Handler<TestCaseReport>) - Method in TestSuiteReport
handler(Handler<Long>) - Method in TimeoutStream
handler(Handler<Buffer>) - Method in WebSocket
handler(Handler<Buffer>) - Method in WebSocketBase
handler(Handler<Buffer>) - Method in WebSocketBaseImpl
handler(Handler<WebSocket>) - Method in WebSocketStream
handleReceipt(Map<String, Object>, StompServerConnection) - Method in Frames
HashStrategy - Class in io.vertx.groovy.ext.auth.mongo
Determines how the hashing is computed in the implementation You can implement this to provide a different hashing strategy to the default.
HashStrategy(Object) - Constructor in HashStrategy
hasJWTToken() - Method in OAuth2Auth
Returns true if this provider supports JWT tokens as the access_token.
hasPermission(String, Handler<AsyncResult<Boolean>>) - Method in User
Does the user have the specified permission?
hdel(String, String, Handler<AsyncResult<Long>>) - Method in RedisClient
Delete one or more hash fields
hdel(String, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Delete one or more hash fields
hdelMany(String, List<String>, Handler<AsyncResult<Long>>) - Method in RedisClient
Delete one or more hash fields
hdelMany(String, List<String>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Delete one or more hash fields
head(String, Handler<HttpClientResponse>) - Method in HttpClient
Create an HTTP HEAD request to send to the server at the default host and port, specifying a response handler to receive the response
head(String) - Method in Router
Add a route that matches a HTTP HEAD request and the specified path
headAbs(String, Handler<HttpClientResponse>) - Method in HttpClient
Create an HTTP HEAD request to send to the server using an absolute URI, specifying a response handler to receive the response
headers() - Method in HttpClientRequest
@return
Returns:
The HTTP headers
headers() - Method in HttpClientResponse
@return
Returns:
the headers
headers() - Method in HttpServerRequest
Returns:
the headers in the request.
headers() - Method in HttpServerResponse
@return
Returns:
The HTTP headers
headers() - Method in Message
Multi-map of message headers.
headers() - Method in ServerWebSocket
@return
Returns:
the headers in the WebSocket handshake
headers() - Method in SockJSSocket
Return the headers corresponding to the last request for this socket or the websocket handshake Any cookie headers will be removed for security reasons @return
headersEndHandler(Handler<Void>) - Method in HttpServerResponse
Provide a handler that will be called just before the headers are written to the wire.
headNow(String, Handler<HttpClientResponse>) - Method in HttpClient
Sends an HTTP HEAD request to the server at the default host and port, specifying a response handler to receive the response
headWithRegex(String) - Method in Router
Add a route that matches a HTTP HEAD request and the specified path regex
headWritten() - Method in HttpServerResponse
Returns:
have the headers for the response already been written?
height() - Method in Tty
@return
Returns:
the current height, i.e the number of columns or if unknown
hexists(String, String, Handler<AsyncResult<Long>>) - Method in RedisClient
Determine if a hash field exists
hexists(String, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Determine if a hash field exists
hget(String, String, Handler<AsyncResult<String>>) - Method in RedisClient
Get the value of a hash field
hget(String, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Get the value of a hash field
hgetall(String, Handler<AsyncResult<Map<String, Object>>>) - Method in RedisClient
Get all the fields and values in a hash
hgetall(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Get all the fields and values in a hash
hincrby(String, String, long, Handler<AsyncResult<Long>>) - Method in RedisClient
Increment the integer value of a hash field by the given number
hincrby(String, String, long, Handler<AsyncResult<String>>) - Method in RedisTransaction
Increment the integer value of a hash field by the given number
hincrbyfloat(String, String, double, Handler<AsyncResult<String>>) - Method in RedisClient
Increment the float value of a hash field by the given amount
hincrbyfloat(String, String, double, Handler<AsyncResult<String>>) - Method in RedisTransaction
Increment the float value of a hash field by the given amount
hkeys(String, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Get all the fields in a hash
hkeys(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Get all the fields in a hash
hlen(String, Handler<AsyncResult<Long>>) - Method in RedisClient
Get the number of fields in a hash
hlen(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Get the number of fields in a hash
hmget(String, List<String>, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Get the values of all the given hash fields
hmget(String, List<String>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Get the values of all the given hash fields
hmset(String, Map<String, Object>, Handler<AsyncResult<String>>) - Method in RedisClient
Set multiple hash fields to multiple values
hmset(String, Map<String, Object>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Set multiple hash fields to multiple values
host() - Method in HttpServerRequest
Returns:
the request host.
host() - Method in SocketAddress
hscan(String, String, Map<String, Object>, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Incrementally iterate hash fields and associated values
hscan(String, String, Map<String, Object>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Incrementally iterate hash fields and associated values
hset(String, String, String, Handler<AsyncResult<Long>>) - Method in RedisClient
Set the string value of a hash field
hset(String, String, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Set the string value of a hash field
hsetnx(String, String, String, Handler<AsyncResult<Long>>) - Method in RedisClient
Set the value of a hash field, only if the field does not exist
hsetnx(String, String, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Set the value of a hash field, only if the field does not exist
HttpClient - Class in io.vertx.groovy.core.http
An asynchronous HTTP client.
HttpClient(Object) - Constructor in HttpClient
HttpClientRequest - Class in io.vertx.groovy.core.http
Represents a client-side HTTP request.
HttpClientRequest(Object) - Constructor in HttpClientRequest
HttpClientResponse - Class in io.vertx.groovy.core.http
Represents a client-side HTTP response.
HttpClientResponse(Object) - Constructor in HttpClientResponse
HttpConnection - Class in io.vertx.groovy.core.http
Represents an HTTP connection.
HttpConnection(Object) - Constructor in HttpConnection
HttpEndpoint - Class in io.vertx.groovy.servicediscovery.types
for HTTP endpoint (REST api).
HttpEndpoint(Object) - Constructor in HttpEndpoint
HttpFrame - Class in io.vertx.groovy.core.http
An HTTP/2 frame.
HttpFrame(Object) - Constructor in HttpFrame
HttpServer - Class in io.vertx.groovy.core.http
An HTTP and WebSockets server.
HttpServer(Object) - Constructor in HttpServer
HttpServerFileUpload - Class in io.vertx.groovy.core.http
Represents an file upload from an HTML FORM.
HttpServerFileUpload(Object) - Constructor in HttpServerFileUpload
HttpServerRequest - Class in io.vertx.groovy.core.http
Represents a server-side HTTP request.
HttpServerRequest(Object) - Constructor in HttpServerRequest
HttpServerRequestStream - Class in io.vertx.groovy.core.http
A ReadStream of HttpServerRequest, used for notifying http request to a HttpServer.
HttpServerRequestStream(Object) - Constructor in HttpServerRequestStream
HttpServerResponse - Class in io.vertx.groovy.core.http
Represents a server-side HTTP response.
HttpServerResponse(Object) - Constructor in HttpServerResponse
hvals(String, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Get all the values in a hash
hvals(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Get all the values in a hash

I

id() - Method in Job
@return
Returns:
the job id
id() - Method in Session
Returns:
The unique ID of the session.
incr(String, Handler<AsyncResult<Long>>) - Method in RedisClient
Increment the integer value of a key by one
incr(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Increment the integer value of a key by one
incrby(String, long, Handler<AsyncResult<Long>>) - Method in RedisClient
Increment the integer value of a key by the given amount
incrby(String, long, Handler<AsyncResult<String>>) - Method in RedisTransaction
Increment the integer value of a key by the given amount
incrbyfloat(String, double, Handler<AsyncResult<String>>) - Method in RedisClient
Increment the float value of a key by the given amount
incrbyfloat(String, double, Handler<AsyncResult<String>>) - Method in RedisTransaction
Increment the float value of a key by the given amount
incrementAndGet(Handler<AsyncResult<Long>>) - Method in Counter
Increment the counter atomically and return the new count
info(Handler<AsyncResult<Map<String, Object>>>) - Method in RedisClient
Get information and statistics about the server
info(Handler<AsyncResult<String>>) - Method in RedisTransaction
Get information and statistics about the server
infoSection(String, Handler<AsyncResult<Map<String, Object>>>) - Method in RedisClient
Get information and statistics about the server
infoSection(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Get information and statistics about the server
init(Vertx) - Method in GroovyVerticleFactory
insert(String, Map<String, Object>, Handler<AsyncResult<String>>) - Method in MongoClient
Insert a document in the specified collection
insertUser(String, String, List<String>, List<String>, Handler<AsyncResult<String>>) - Method in MongoAuth
Insert a new user into mongo in the convenient way
insertWithOptions(String, Map<String, Object>, WriteOption, Handler<AsyncResult<String>>) - Method in MongoClient
Insert a document in the specified collection with the specified write option
installTestApplications(Router, Vertx) - Method in SockJSHandler
Install SockJS test applications on a router - used when running the SockJS test suite
InternalHelper - Class in io.vertx.lang.groovy
@author Julien Viet
interrupt() - Method in Job
Attempt to interrupt the job.
interrupt(Handler<Void>) - Method in Process
Attempt to interrupt the process.
interruptHandler(Handler<Void>) - Method in CommandProcess
Set an interrupt handler, this handler is called when the command is interrupted, for instance user press Ctrl-C.
interruptHandler(SignalHandler) - Method in Term
Set an interrupt signal handler on the term.
isArgumentAssigned(Map<String, Object>) - Method in CommandLine
Checks whether or not the given argument has been assigned in the command line.
isAskingForHelp() - Method in CommandLine
Checks whether or not the user has passed a "help" option and is asking for help.
isAuthorised(String, Handler<AsyncResult<Boolean>>) - Method in User
Is the user authorised to
isBinary() - Method in WebSocketFrame
@return
Returns:
true if it's a binary frame
isBlank() - Method in CliToken
@return
Returns:
true when it's a blank token
isChanged() - Method in Cookie
Has the cookie been changed?
isChunked() - Method in HttpClientRequest
Returns:
Is the request chunked?
isChunked() - Method in HttpServerResponse
Returns:
is the response chunked?
isClustered() - Method in Vertx
Is this Vert.x instance clustered?
isComplete(int) - Method in CompositeFuture
Returns true if a wrapped future is completed
isComplete() - Method in Future
Has the future completed?
isCompleted() - Method in Completion
@return
Returns:
true if this completion is completed
isConnected() - Method in RabbitMQClient
Check if a connection is open
isContinuation() - Method in WebSocketFrame
@return
Returns:
true if it's a continuation frame
isDestroyed() - Method in Session
Returns:
has the session been destroyed?
isDirectory() - Method in FileProps
Is the file a directory?
isEmpty() - Method in LocalMap
@return
Returns:
true if there are zero entries in the map
isEmpty() - Method in MultiMap
Return true if empty @return
isEnded() - Method in HttpServerRequest
Has the request ended?
isError() - Method in Failure
@return
Returns:
true if the failure is an error failure otherwise it is an assertion failure
isEventLoopContext() - Method in Context
Is the current context an event loop context?
isExpectMultipart() - Method in HttpServerRequest
Returns:
true if we are expecting a multi-part body for this request.
isFailed() - Method in Completion
@return
Returns:
true if the this completion is completed and failed
isFinal() - Method in WebSocketFrame
Returns:
true if this is the final frame.
isFlagEnabled(String) - Method in CommandLine
Gets the value of an option marked as a flag.
isForeground() - Method in CommandProcess
@return
Returns:
true if the command is running in foreground
isHidden() - Method in CLI
Checks whether or not the current CLI instance is hidden.
isListening() - Method in StompServer
Checks whether or not the server is listening.
isMetricsEnabled() - Method in DatagramSocket
Whether the metrics are enabled for this measured object
isMetricsEnabled() - Method in EventBus
Whether the metrics are enabled for this measured object
isMetricsEnabled() - Method in HttpClient
Whether the metrics are enabled for this measured object
isMetricsEnabled() - Method in HttpServer
Whether the metrics are enabled for this measured object
isMetricsEnabled() - Method in Measured
isMetricsEnabled() - Method in MeasuredImpl
Whether the metrics are enabled for this measured object
isMetricsEnabled() - Method in NetClient
Whether the metrics are enabled for this measured object
isMetricsEnabled() - Method in NetServer
Whether the metrics are enabled for this measured object
isMetricsEnabled() - Method in Vertx
Whether the metrics are enabled for this measured object
isMetricsEnabled() - Method in WorkerExecutor
Whether the metrics are enabled for this measured object
isMultiThreadedWorkerContext() - Method in Context
Is the current context a multi-threaded worker context?
isOnEventLoopThread() - Method in Context
Is the current thread an event thread?
isOnVertxThread() - Method in Context
Is the current thread a Vert.x thread?
isOnWorkerThread() - Method in Context
Is the current thread a worker thread?
isOpenChannel() - Method in RabbitMQClient
Check if a channel is open
isOptionAssigned(Map<String, Object>) - Method in CommandLine
Checks whether or not the given option has been assigned in the command line.
isOther() - Method in FileProps
Is the file some other type?
isRegistered() - Method in MessageConsumer
@return
Returns:
true if the current consumer is registered
isRegularFile() - Method in FileProps
Is the file a regular file?
isSeenInCommandLine(Map<String, Object>) - Method in CommandLine
Checks whether or not the given option has been seen in the user command line.
isSizeAvailable() - Method in HttpServerFileUpload
Returns:
true if the size of the upload can be retrieved via HttpServerFileUpload.size.
isSSL() - Method in HttpServerRequest
@return
Returns:
true if this NetSocket is encrypted via SSL/TLS
isSsl() - Method in NetSocket
Returns:
true if this NetSocket is encrypted via SSL/TLS.
isSucceeded() - Method in Completion
@return
Returns:
true if the this completion is completed succeeded
isSymbolicLink() - Method in FileProps
Is the file a symbolic link?
isText() - Method in CliToken
@return
Returns:
true when it's a text token
isText() - Method in WebSocketFrame
@return
Returns:
true if it's a text frame
isValid() - Method in CommandLine
Checks whether or not the command line is valid, i.e. all constraints from arguments and options have been satisfied.
isWorkerContext() - Method in Context
Is the current context a worker context?

J

JadeTemplateEngine - Class in io.vertx.groovy.ext.web.templ
A template engine that uses Jade.
JadeTemplateEngine(Object) - Constructor in JadeTemplateEngine
JDBCAuth - Class in io.vertx.groovy.ext.auth.jdbc
Factory interface for creating AuthProvider instances that use the Vert.x JDBC client
JDBCAuth(Object) - Constructor in JDBCAuth
JDBCClient - Class in io.vertx.groovy.ext.jdbc
An asynchronous client interface for interacting with a JDBC compliant database
JDBCClient(Object) - Constructor in JDBCClient
JDBCDataSource - Class in io.vertx.groovy.servicediscovery.types
JDBCDataSource(Object) - Constructor in JDBCDataSource
Job - Class in io.vertx.groovy.ext.shell.system
A job executed in a JobController, grouping one or several process.
Job(Object) - Constructor in Job
JobController - Class in io.vertx.groovy.ext.shell.system
The job controller.
JobController(Object) - Constructor in JobController
jobController() - Method in Shell
@return
Returns:
the shell's job controller
jobs() - Method in JobController
@return
Returns:
the active jobs
JWTAuth - Class in io.vertx.groovy.ext.auth.jwt
Factory interface for creating JWT based AuthProvider instances.
JWTAuth(Object) - Constructor in JWTAuth
JWTAuthHandler - Class in io.vertx.groovy.ext.web.handler
An auth handler that provides JWT Authentication support.
JWTAuthHandler(Object) - Constructor in JWTAuthHandler

K

keys(String, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Find all keys matching the given pattern
keys(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Find all keys matching the given pattern

L

language() - Method in Locale
Returns the language as reported by the HTTP client.
last() - Method in Route
Specify this is the last route for the router.
lastAccessed() - Method in Session
@return
Returns:
the time the session was last accessed
lastAccessedTime() - Method in Term
@return
Returns:
the last time this term received input
lastAccessTime() - Method in FileProps
The date the file was last accessed @return
lastModifiedTime() - Method in FileProps
The date the file was last modified @return
lastsave(Handler<AsyncResult<Long>>) - Method in RedisClient
Get the UNIX time stamp of the last successful save to disk
lastsave(Handler<AsyncResult<String>>) - Method in RedisTransaction
Get the UNIX time stamp of the last successful save to disk
lastStopped() - Method in Job
@return
Returns:
when the job was last stopped
length() - Method in Buffer
Returns the length of the buffer, measured in bytes.
lindex(String, int, Handler<AsyncResult<String>>) - Method in RedisClient
Get an element from a list by its index
lindex(String, int, Handler<AsyncResult<String>>) - Method in RedisTransaction
Get an element from a list by its index
line() - Method in Job
@return
Returns:
the execution line of the job, i.e the shell command line that launched this job
lineTokens() - Method in Completion
@return
Returns:
the current line being completed as preparsed tokens
link(String, String, Handler<AsyncResult<Void>>) - Method in FileSystem
Create a hard link on the file system from link to existing, asynchronously.
linkBlocking(String, String) - Method in FileSystem
Blocking version of FileSystem.link
linsert(String, InsertOptions, String, String, Handler<AsyncResult<Long>>) - Method in RedisClient
Insert an element before or after another element in a list
linsert(String, InsertOptions, String, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Insert an element before or after another element in a list
listen(int, String, Handler<AsyncResult<DatagramSocket>>) - Method in DatagramSocket
Start listening on the given port and host.
listen(Handler<AsyncResult<HttpServer>>) - Method in HttpServer
Like HttpServer.listen but supplying a handler that will be called when the server is actually listening (or has failed).
listen(int, Handler<AsyncResult<NetServer>>) - Method in NetServer
Like NetServer.listen but providing a handler that will be notified when the server is listening, or fails.
listen(Handler<AsyncResult<Void>>) - Method in ShellServer
Start the shell service, this is an asynchronous start.
listen(int, String, Handler<AsyncResult<StompServer>>) - Method in StompServer
Connects the STOMP server to the given port / interface.
listen(int, Handler<AsyncResult<TcpEventBusBridge>>) - Method in TcpEventBusBridge
Listen on specific port
listen(Handler<AsyncResult<TermServer>>) - Method in TermServer
Bind the term server, the TermServer.termHandler must be set before.
listenMulticastGroup(String, String, String, Handler<AsyncResult<DatagramSocket>>) - Method in DatagramSocket
Joins a multicast group and listens for packets send to it on the given network interface.
llen(String, Handler<AsyncResult<Long>>) - Method in RedisClient
Get the length of a list
llen(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Get the length of a list
localAddress() - Method in DatagramSocket
Return the SocketAddress to which this DatagramSocket is bound.
localAddress() - Method in HttpServerRequest
@return
Returns:
the local (server side) address of the server that handles the request
localAddress() - Method in NetSocket
@return
Returns:
the local address for this socket
localAddress() - Method in ServerWebSocket
@return
Returns:
the local address for this socket
localAddress() - Method in SockJSSocket
Return the local address for this socket @return
localAddress() - Method in WebSocket
@return
Returns:
the local address for this socket
localAddress() - Method in WebSocketBase
localAddress() - Method in WebSocketBaseImpl
@return
Returns:
the local address for this socket
localConsumer(String, Handler<Message<T>>) - Method in EventBus
Like EventBus.consumer but the address won't be propagated across the cluster.
Locale - Class in io.vertx.groovy.ext.web
Locale(Object) - Constructor in Locale
LocalMap - Class in io.vertx.groovy.core.shareddata
Local maps can be used to share data safely in a single Vert.x instance.
LocalMap(Object) - Constructor in LocalMap
LocalSessionStore - Class in io.vertx.groovy.ext.web.sstore
A session store which is only available on a single node.
LocalSessionStore(Object) - Constructor in LocalSessionStore
Lock - Class in io.vertx.groovy.core.shareddata
An asynchronous exclusive lock which can be obtained from any node in the cluster.
Lock(Object) - Constructor in Lock
LoggerHandler - Class in io.vertx.groovy.ext.web.handler
A handler which logs request information to the Vert.x logger.
LoggerHandler(Object) - Constructor in LoggerHandler
logout(Handler<AsyncResult<Void>>) - Method in AccessToken
Revoke refresh token and calls the logout endpoint.
lookup4(String, Handler<AsyncResult<String>>) - Method in DnsClient
Try to lookup the A (ipv4) record for the given name.
lookup6(String, Handler<AsyncResult<String>>) - Method in DnsClient
Try to lookup the AAAA (ipv6) record for the given name.
lookup(String, Handler<AsyncResult<String>>) - Method in DnsClient
Try to lookup the A (ipv4) or AAAA (ipv6) record for the given name.
lpop(String, Handler<AsyncResult<String>>) - Method in RedisClient
Remove and get the first element in a list
lpop(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Remove and get the first element in a list
lprops(String, Handler<AsyncResult<FileProps>>) - Method in FileSystem
Obtain properties for the link represented by path, asynchronously.
lpropsBlocking(String) - Method in FileSystem
Blocking version of FileSystem.lprops
lpush(String, String, Handler<AsyncResult<Long>>) - Method in RedisClient
Prepend one value to a list
lpush(String, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Prepend one value to a list
lpushMany(String, List<String>, Handler<AsyncResult<Long>>) - Method in RedisClient
Prepend one or multiple values to a list
lpushMany(String, List<String>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Prepend one or multiple values to a list
lpushx(String, String, Handler<AsyncResult<Long>>) - Method in RedisClient
Prepend a value to a list, only if the list exists
lpushx(String, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Prepend a value to a list, only if the list exists
lrange(String, long, long, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Get a range of elements from a list
lrange(String, long, long, Handler<AsyncResult<String>>) - Method in RedisTransaction
Get a range of elements from a list
lrem(String, long, String, Handler<AsyncResult<Long>>) - Method in RedisClient
Remove elements from a list
lrem(String, long, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Remove elements from a list
lset(String, long, String, Handler<AsyncResult<String>>) - Method in RedisClient
Set the value of an element in a list by its index
lset(String, long, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Set the value of an element in a list by its index
ltrim(String, long, long, Handler<AsyncResult<String>>) - Method in RedisClient
Trim a list to the specified range
ltrim(String, long, long, Handler<AsyncResult<String>>) - Method in RedisTransaction
Trim a list to the specified range

M

MailClient - Class in io.vertx.groovy.ext.mail
MailClient(Object) - Constructor in MailClient
MailService - Class in io.vertx.groovy.ext.mail
@author Tim Fox
MailService(Object) - Constructor in MailService
map(V) - Method in Future
Map the result of a future to a specific value.
matches(String) - Method in Destination
Checks whether or not the given address matches with the current destination.
maxAgeSeconds(int) - Method in CorsHandler
Set how long the browser should cache the information
Measured - Interface in io.vertx.groovy.core.metrics
MeasuredImpl - Class in io.vertx.groovy.core.metrics
MeasuredImpl(Object) - Constructor in MeasuredImpl
Message - Class in io.vertx.groovy.core.eventbus
Represents a message that is received from the event bus in a handler.
message() - Method in Failure
@return
Returns:
the error message
Message(Object) - Constructor in Message
message() - Method in SendContext
@return
Returns:
The message being sent
MessageConsumer - Class in io.vertx.groovy.core.eventbus
An event bus consumer object representing a stream of message to an EventBus address that can be read from.
MessageConsumer(Object) - Constructor in MessageConsumer
messageCount(String, Handler<AsyncResult<Map<String, Object>>>) - Method in RabbitMQClient
Returns the number of messages in a queue ready to be delivered.
MessageProducer - Class in io.vertx.groovy.core.eventbus
Represents a stream of message that can be written to.
MessageProducer(Object) - Constructor in MessageProducer
MessageSource - Class in io.vertx.groovy.servicediscovery.types
Service type for data producer.
MessageSource(Object) - Constructor in MessageSource
method() - Method in HttpClientRequest
The HTTP method for the request.
method() - Method in HttpServerRequest
Returns:
the HTTP method for the request.
method(HttpMethod) - Method in Route
Add an HTTP method for this route.
metricsNames() - Method in MetricsService
@return
Returns:
the known metrics names by this service
MetricsService - Class in io.vertx.groovy.ext.dropwizard
The metrics service mainly allows to return a snapshot of measured objects.
MetricsService(Object) - Constructor in MetricsService
mget(String, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Get the value of the given key
mget(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Get the value of the given key
mgetMany(List<String>, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Get the values of all the given keys
mgetMany(List<String>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Get the values of all the given keys
migrate(String, int, String, int, long, Map<String, Object>, Handler<AsyncResult<String>>) - Method in RedisClient
Atomically transfer a key from a Redis instance to another one.
migrate(String, int, String, int, long, Map<String, Object>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Atomically transfer a key from a Redis instance to another one.
mkdir(String, String, Handler<AsyncResult<Void>>) - Method in FileSystem
Create the directory represented by path, asynchronously.
mkdirBlocking(String, String) - Method in FileSystem
Blocking version of FileSystem.mkdir
mkdirs(String, String, Handler<AsyncResult<Void>>) - Method in FileSystem
Create the directory represented by path and any non existent parents, asynchronously.
mkdirsBlocking(String, String) - Method in FileSystem
Blocking version of FileSystem.mkdirs
MongoAuth - Class in io.vertx.groovy.ext.auth.mongo
An extension of AuthProvider which is using as store
MongoAuth(Object) - Constructor in MongoAuth
MongoClient - Class in io.vertx.groovy.ext.mongo
A Vert.x service used to interact with MongoDB server instances.
MongoClient(Object) - Constructor in MongoClient
monitor(Handler<AsyncResult<Void>>) - Method in RedisClient
Listen for all requests received by the server in real time
monitor(Handler<AsyncResult<String>>) - Method in RedisTransaction
Listen for all requests received by the server in real time
mountPoint() - Method in RoutingContext
Returns:
the mount point for this router.
mountSubRouter(String, Router) - Method in Router
Mount a sub router on this router
move(String, String, Handler<AsyncResult<Void>>) - Method in FileSystem
Move a file from the path from to path to, asynchronously.
move(String, int, Handler<AsyncResult<Long>>) - Method in RedisClient
Move a key to another database
move(String, int, Handler<AsyncResult<String>>) - Method in RedisTransaction
Move a key to another database
moveBlocking(String, String) - Method in FileSystem
Blocking version of FileSystem.move
mset(Map<String, Object>, Handler<AsyncResult<String>>) - Method in RedisClient
Set multiple keys to multiple values
mset(Map<String, Object>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Set multiple keys to multiple values
msetnx(Map<String, Object>, Handler<AsyncResult<Long>>) - Method in RedisClient
Set multiple keys to multiple values, only if none of the keys exist
msetnx(Map<String, Object>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Set multiple keys to multiple values, only if none of the keys exist
multi(Handler<AsyncResult<String>>) - Method in RedisTransaction
Mark the start of a RedisTransaction block
MultiMap - Class in io.vertx.groovy.core
This class represents a MultiMap of String keys to a List of String values.
MultiMap(Object) - Constructor in MultiMap
MVELTemplateEngine - Class in io.vertx.groovy.ext.web.templ
A template engine that uses the Handlebars library.
MVELTemplateEngine(Object) - Constructor in MVELTemplateEngine
MxRecord - Class in io.vertx.groovy.core.dns
Represent a Mail-Exchange-Record (MX) which was resolved for a domain.
MxRecord(Object) - Constructor in MxRecord
MySQLClient - Class in io.vertx.groovy.ext.asyncsql
Represents an asynchronous MySQL client
MySQLClient(Object) - Constructor in MySQLClient

N

nack(StompServerConnection, Map<String, Object>) - Method in Destination
Handles a NACK frame.
nack(String, String, Handler<Map<String, Object>>) - Method in StompClientConnection
Sends a non-acknowledgement for the given frame.
nackHandler(Handler<ServerFrame>) - Method in StompServerHandler
Configures the action to execute when a NACK frame is received.
name() - Method in CircuitBreaker
Returns:
the name of the circuit breaker.
name() - Method in Command
@return
Returns:
the command name
name() - Method in FileUpload
@return
Returns:
the name of the upload as provided in the form submission
name() - Method in HttpServerFileUpload
@return
Returns:
the name of the attribute
name() - Method in MxRecord
The name of the MX record @return
name() - Method in SrvRecord
Returns the name for the server being queried.
name() - Method in TestCaseReport
@return
Returns:
the test case name
name() - Method in TestResult
The test description, may be null if none was provided.
name() - Method in TestSuiteReport
@return
Returns:
the test suite name
names() - Method in MultiMap
Gets a immutable java.util.Set of all names
NetClient - Class in io.vertx.groovy.core.net
A TCP client.
NetClient(Object) - Constructor in NetClient
NetServer - Class in io.vertx.groovy.core.net
Represents a TCP server
NetServer(Object) - Constructor in NetServer
NetSocket - Class in io.vertx.groovy.core.net
Represents a socket-like interface to a TCP connection on either the client or the server side.
netSocket() - Method in HttpClientResponse
Get a net socket for the underlying connection of this request.
netSocket() - Method in HttpServerRequest
Get a net socket for the underlying connection of this request.
NetSocket(Object) - Constructor in NetSocket
NetSocketStream - Class in io.vertx.groovy.core.net
A ReadStream of NetSocket, used for notifying socket connections to a NetServer.
NetSocketStream(Object) - Constructor in NetSocketStream
newDelimited(Buffer, Handler<Buffer>) - Method in RecordParser
Create a new RecordParser instance, initially in delimited mode, and where the delimiter can be represented by the Buffer delim.
newFixed(int, Handler<Buffer>) - Method in RecordParser
Create a new RecordParser instance, initially in fixed size mode, and where the record size is specified by the size parameter.
next() - Method in RoutingContext
Tell the router to route this context to the next matching route (if any).
next() - Method in SendContext
Call the next interceptor
normalisedPath() - Method in RoutingContext
Return the normalised path for the request.
numberOfSubscriptions() - Method in Destination
Gets the number of subscriptions attached to the current Destination.
numberPumped() - Method in Pump
Return the total number of items pumped by this pump.

O

OAuth2Auth - Class in io.vertx.groovy.ext.auth.oauth2
Factory interface for creating OAuth2 based AuthProvider instances.
OAuth2Auth(Object) - Constructor in OAuth2Auth
OAuth2AuthHandler - Class in io.vertx.groovy.ext.web.handler
An auth handler that provides OAuth2 Authentication support.
OAuth2AuthHandler(Object) - Constructor in OAuth2AuthHandler
object(String, ObjectCmd, Handler<AsyncResult<Void>>) - Method in RedisClient
Inspect the internals of Redis objects
object(String, ObjectCmd, Handler<AsyncResult<String>>) - Method in RedisTransaction
Inspect the internals of Redis objects
onAck(StompServerConnection, Map<String, Object>, List<Map<String, Object>>) - Method in StompServerHandler
Method called by single message (client-individual policy) or a set of message (client policy) are acknowledged.
onAckHandler(Handler<Acknowledgement>) - Method in StompServerHandler
Configures the action to execute when messages are acknowledged.
onAuthenticationRequest(StompServer, String, String, Handler<AsyncResult<Boolean>>) - Method in StompServerHandler
Called when the client connects to a server requiring authentication.
onClose(StompServerConnection) - Method in StompServerHandler
Called when the connection is closed.
onNack(StompServerConnection, Map<String, Object>, List<Map<String, Object>>) - Method in StompServerHandler
Method called by single message (client-individual policy) or a set of message (client policy) are not acknowledged.
onNackHandler(Handler<Acknowledgement>) - Method in StompServerHandler
Configures the action to execute when messages are not acknowledged.
onPublish(Map<String, Object>) - Method in ServiceExporter
Notify a new record has been published, the record's registration can be used to uniquely identify the record
onServerActivity() - Method in StompServerConnection
Notifies the connection about server activity (the server has sent a frame).
onUnpublish(String) - Method in ServiceExporter
Notify an existing record has been removed
onUpdate(Map<String, Object>) - Method in ServiceExporter
Notify an existing record has been updated, the record's registration can be used to uniquely identify the record
open() - Method in CircuitBreaker
Explicitly opens the circuit.
open(String, Map<String, Object>, Handler<AsyncResult<AsyncFile>>) - Method in FileSystem
Open the file represented by path, asynchronously.
openBlocking(String, Map<String, Object>) - Method in FileSystem
Blocking version of FileSystem.open
openHandler(Handler<Void>) - Method in CircuitBreaker
Sets a invoked when the circuit breaker state switches to open.
options(String, Handler<HttpClientResponse>) - Method in HttpClient
Create an HTTP OPTIONS request to send to the server at the default host and port, specifying a response handler to receive the response
options(String) - Method in Router
Add a route that matches a HTTP OPTIONS request and the specified path
options() - Method in StompClient
@return the client's options.
options() - Method in StompServer
@return the server options
optionsAbs(String, Handler<HttpClientResponse>) - Method in HttpClient
Create an HTTP OPTIONS request to send to the server using an absolute URI, specifying a response handler to receive the response
optionsNow(String, Handler<HttpClientResponse>) - Method in HttpClient
Sends an HTTP OPTIONS request to the server at the default host and port, specifying a response handler to receive the response
optionsWithRegex(String) - Method in Router
Add a route that matches a HTTP OPTIONS request and the specified path regex
order(int) - Method in Route
Specify the order for this route.
owner() - Method in Context
@return
Returns:
The Vertx instance that created the context

P

PacketWritestream - Class in io.vertx.groovy.core.datagram
A WriteStream for sending packets to a SocketAddress.
PacketWritestream(Object) - Constructor in PacketWritestream
params() - Method in HttpServerRequest
@return
Returns:
the query parameters in the request
parse(List<String>, boolean) - Method in CLI
Parses the user command line interface and create a new CommandLine containing extracting values.
patch(String) - Method in Router
Add a route that matches a HTTP PATCH request and the specified path
patchWithRegex(String) - Method in Router
Add a route that matches a HTTP PATCH request and the specified path regex
path() - Method in HttpClientRequest
Returns:
The path part of the uri.
path() - Method in HttpServerRequest
Returns:
The path part of the uri.
path(String) - Method in Route
Set the path prefix for this route.
path() - Method in ServerWebSocket
Returns:
the WebSocket handshake path.
pathParam(String) - Method in RoutingContext
Gets the value of a single path parameter
pathParams() - Method in RoutingContext
Returns a map of named parameters as defined in path declaration with their actual values
pathRegex(String) - Method in Route
Set the path prefix as a regular expression.
pause() - Method in AsyncFile
pause() - Method in DatagramSocket
pause() - Method in HttpClientRequest
pause() - Method in HttpClientResponse
pause() - Method in HttpServerFileUpload
pause() - Method in HttpServerRequest
pause() - Method in HttpServerRequestStream
pause() - Method in MessageConsumer
pause() - Method in NetSocket
pause() - Method in NetSocketStream
pause() - Method in ReadStream
pause() - Method in ReadStreamImpl
Pause the ReadSupport.
pause() - Method in ServerWebSocket
pause() - Method in ServerWebSocketStream
pause() - Method in SockJSSocket
pause() - Method in TestSuiteReport
pause() - Method in TimeoutStream
pause() - Method in WebSocket
pause() - Method in WebSocketBase
pause() - Method in WebSocketBaseImpl
pause() - Method in WebSocketStream
payload() - Method in HttpFrame
@return
Returns:
the frame payload
periodicStream(long) - Method in Vertx
Returns a periodic timer as a read stream.
persist(String, Handler<AsyncResult<Long>>) - Method in RedisClient
Remove the expiration from a key
persist(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Remove the expiration from a key
pexpire(String, long, Handler<AsyncResult<Long>>) - Method in RedisClient
Set a key's time to live in milliseconds
pexpire(String, long, Handler<AsyncResult<String>>) - Method in RedisTransaction
Set a key's time to live in milliseconds
pexpireat(String, long, Handler<AsyncResult<Long>>) - Method in RedisClient
Set the expiration for a key as a UNIX timestamp specified in milliseconds
pexpireat(String, long, Handler<AsyncResult<String>>) - Method in RedisTransaction
Set the expiration for a key as a UNIX timestamp specified in milliseconds
pfadd(String, String, Handler<AsyncResult<Long>>) - Method in RedisClient
Adds the specified element to the specified HyperLogLog.
pfadd(String, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Adds the specified element to the specified HyperLogLog.
pfaddMany(String, List<String>, Handler<AsyncResult<Long>>) - Method in RedisClient
Adds the specified elements to the specified HyperLogLog.
pfaddMany(String, List<String>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Adds the specified elements to the specified HyperLogLog.
pfcount(String, Handler<AsyncResult<Long>>) - Method in RedisClient
Return the approximated cardinality of the set observed by the HyperLogLog at key.
pfcount(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Return the approximated cardinality of the set observed by the HyperLogLog at key.
pfcountMany(List<String>, Handler<AsyncResult<Long>>) - Method in RedisClient
Return the approximated cardinality of the set(s) observed by the HyperLogLog at key(s).
pfcountMany(List<String>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Return the approximated cardinality of the set(s) observed by the HyperLogLog at key(s).
pfmerge(String, List<String>, Handler<AsyncResult<String>>) - Method in RedisClient
Merge N different HyperLogLogs into a single one.
pfmerge(String, List<String>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Merge N different HyperLogLogs into a single one.
ping() - Method in Frames
ping(Buffer, Handler<AsyncResult<Buffer>>) - Method in HttpConnection
Send a frame to the remote endpoint.
ping(Handler<AsyncResult<String>>) - Method in RedisClient
Ping the server
ping(Handler<AsyncResult<String>>) - Method in RedisTransaction
Ping the server
ping() - Method in StompServerConnection
Sends a `PING` frame to the client.
pingHandler(Handler<Buffer>) - Method in HttpConnection
Set an handler notified when a frame is received from the remote endpoint.
pingHandler(Handler<StompClientConnection>) - Method in StompClientConnection
Sets a handler that let customize the behavior when a ping needs to be sent to the server.
pingHandler(Handler<StompServerConnection>) - Method in StompServerHandler
Allows customizing the action to do when the server needs to send a `PING` to the client.
port() - Method in SocketAddress
port() - Method in SrvRecord
Returns the port the service is running on.
post(String, Handler<HttpClientResponse>) - Method in HttpClient
Create an HTTP POST request to send to the server at the default host and port, specifying a response handler to receive the response
post(String) - Method in Router
Add a route that matches a HTTP POST request and the specified path
postAbs(String, Handler<HttpClientResponse>) - Method in HttpClient
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.groovy.ext.asyncsql
Represents an PostgreSQL client
PostgreSQLClient(Object) - Constructor in PostgreSQLClient
postWithRegex(String) - Method in Router
Add a route that matches a HTTP POST request and the specified path regex
preferredLocale() - Method in RoutingContext
Helper to return the user preferred locale.
prefix() - Method in GroovyVerticleFactory
principal() - Method in User
Get the underlying principal for the User.
priority() - Method in MxRecord
The priority of the MX record.
priority() - Method in SrvRecord
Returns the priority for this service record.
Process - Class in io.vertx.groovy.ext.shell.system
A process managed by the shell.
process() - Method in Job
@return
Returns:
the first process in the job
Process(Object) - Constructor in Process
processArgs() - Method in Context
The process args @return
processHandler(Handler<CommandProcess>) - Method in CommandBuilder
Set the command process handler, the process handler is called when the command is executed.
produces(String) - Method in Route
Add a content type produced by this route.
props(String, Handler<AsyncResult<FileProps>>) - Method in FileSystem
Obtain properties for the file represented by path, asynchronously.
propsBlocking(String) - Method in FileSystem
Blocking version of FileSystem.props
protocol() - Method in SrvRecord
Returns the protocol for the service being queried (i.e.
psetex(String, long, String, Handler<AsyncResult<Void>>) - Method in RedisClient
Set the value and expiration in milliseconds of a key
psetex(String, long, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Set the value and expiration in milliseconds of a key
psubscribe(String, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Listen for messages published to channels matching the given pattern
psubscribe(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Listen for messages published to channels matching the given pattern
psubscribeMany(List<String>, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Listen for messages published to channels matching the given patterns
psubscribeMany(List<String>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Listen for messages published to channels matching the given patterns
pttl(String, Handler<AsyncResult<Long>>) - Method in RedisClient
Get the time to live for a key in milliseconds
pttl(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Get the time to live for a key in milliseconds
Pty - Class in io.vertx.groovy.ext.shell.term
A pseudo terminal used for controlling a Tty.
Pty(Object) - Constructor in Pty
publish(String, Object, Map<String, Object>) - Method in EventBus
Like EventBus.publish but specifying options that can be used to configure the delivery.
publish(String, String, Handler<AsyncResult<Long>>) - Method in RedisClient
Post a message to a channel
publish(String, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Post a message to a channel
publish(Map<String, Object>, Handler<AsyncResult<Map<String, Object>>>) - Method in ServiceDiscovery
Publishes a record.
publish(Map<String, Object>, Handler<AsyncResult<Map<String, Object>>>) - Method in ServicePublisher
Publishes a record.
publisher(String, Map<String, Object>) - Method in EventBus
Like EventBus.publisher but specifying delivery options that will be used for configuring the delivery of the message.
pubsubChannels(String, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Lists the currently active channels - only those matching the pattern
pubsubChannels(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Lists the currently active channels - only those matching the pattern
pubsubNumpat(Handler<AsyncResult<Long>>) - Method in RedisClient
Returns the number of subscriptions to patterns (that are performed using the PSUBSCRIBE command)
pubsubNumpat(Handler<AsyncResult<String>>) - Method in RedisTransaction
Returns the number of subscriptions to patterns (that are performed using the PSUBSCRIBE command)
pubsubNumsub(List<String>, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Returns the number of subscribers (not counting clients subscribed to patterns) for the specified channels
pubsubNumsub(List<String>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Returns the number of subscribers (not counting clients subscribed to patterns) for the specified channels
Pump - Class in io.vertx.groovy.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(Object) - Constructor in Pump
punsubscribe(List<String>, Handler<AsyncResult<Void>>) - Method in RedisClient
Stop listening for messages posted to channels matching the given patterns
punsubscribe(List<String>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Stop listening for messages posted to channels matching the given patterns
push(HttpMethod, String, String, MultiMap, Handler<AsyncResult<HttpServerResponse>>) - Method in HttpServerResponse
Push a response to the client.
pushHandler(Handler<HttpClientRequest>) - Method in HttpClientRequest
Set a push handler for this request.
put(K, V, long, Handler<AsyncResult<Void>>) - Method in AsyncMap
Like AsyncMap.put but specifying a timeout.
put(String, Object) - Method in Context
Put some data in the context.
put(String, Handler<HttpClientResponse>) - Method in HttpClient
Create an HTTP PUT request to send to the server at the default host and port, specifying a response handler to receive the response
put(K, V) - Method in LocalMap
Put an entry in the map
put(String) - Method in Router
Add a route that matches a HTTP PUT request and the specified path
put(String, Object) - Method in RoutingContext
Put some arbitrary data in the context.
put(String, Object) - Method in Session
Put some data in a session
put(Session, Handler<AsyncResult<Boolean>>) - Method in SessionStore
Add a session with the specified ID
put(String, Object) - Method in TestContext
Put some data in the context.
putAbs(String, Handler<HttpClientResponse>) - Method in HttpClient
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 HttpClientRequest
Put an HTTP header
putHeader(String, String) - Method in HttpServerResponse
Put an HTTP header
putIfAbsent(K, V, long, Handler<AsyncResult<V>>) - Method in AsyncMap
Link AsyncMap.putIfAbsent but specifying a timeout.
putIfAbsent(K, V) - Method in LocalMap
Put the entry only if there is no existing entry for that key
putTrailer(String, String) - Method in HttpServerResponse
Put an HTTP trailer
putWithRegex(String) - Method in Router
Add a route that matches a HTTP PUT request and the specified path regex

Q

query() - Method in HttpClientRequest
Returns:
the query part of the uri.
query() - Method in HttpServerRequest
Returns:
the query part of the uri.
query() - Method in ServerWebSocket
Returns:
the WebSocket handshake query string.
query(String, Handler<AsyncResult<Map<String, Object>>>) - Method in SQLConnection
Executes the given SQL SELECT statement which returns the results of the query.
queryWithParams(String, List<Object>, Handler<AsyncResult<Map<String, Object>>>) - Method in SQLConnection
Executes the given SQL SELECT prepared statement which returns the results of the query.
queue(Vertx, String) - Method in Destination
queueBind(String, String, String, Handler<AsyncResult<Void>>) - Method in RabbitMQClient
Bind a queue to an exchange
queueDeclare(String, boolean, boolean, boolean, Handler<AsyncResult<Map<String, Object>>>) - Method in RabbitMQClient
Declare a queue
queueDeclareAuto(Handler<AsyncResult<Map<String, Object>>>) - Method in RabbitMQClient
Actively declare a server-named exclusive, autodelete, non-durable queue.
queueDelete(String, Handler<AsyncResult<Map<String, Object>>>) - Method in RabbitMQClient
Delete a queue, without regard for whether it is in use or has messages on it
queueDeleteIf(String, boolean, boolean, Handler<AsyncResult<Map<String, Object>>>) - Method in RabbitMQClient
Delete a queue

R

RabbitMQClient - Class in io.vertx.groovy.rabbitmq
RabbitMQClient(Object) - Constructor in RabbitMQClient
randomkey(Handler<AsyncResult<String>>) - Method in RedisClient
Return a random key from the keyspace
randomkey(Handler<AsyncResult<String>>) - Method in RedisTransaction
Return a random key from the keyspace
raw() - Method in CliToken
@return
Returns:
the raw token value, that may contain unescaped chars, for instance
rawLine() - Method in Completion
@return
Returns:
the current line being completed in raw format, i.e without any char escape performed
rawMessage() - Method in BridgeEvent
Use BridgeEvent.getRawMessage instead, will be removed in 3.3 @return
rawMethod() - Method in HttpServerRequest
@return
Returns:
the HTTP method as sent by the client
read(Buffer, int, long, int, Handler<AsyncResult<Buffer>>) - Method in AsyncFile
Reads length bytes of data from the file at position position in the file, asynchronously.
readDir(String, String, Handler<AsyncResult<List<String>>>) - Method in FileSystem
Read the contents of the directory specified by path, asynchronously.
readDirBlocking(String, String) - Method in FileSystem
Blocking version of FileSystem.readDir
readFile(String, Handler<AsyncResult<Buffer>>) - Method in FileSystem
Reads the entire file as represented by the path path as a , asynchronously.
readFileBlocking(String) - Method in FileSystem
Blocking version of FileSystem.readFile
readline(String, Handler<String>, Handler<Completion>) - Method in Term
Prompt the user a line of text, providing a completion handler to handle user's completion.
ReadStream - Interface in io.vertx.groovy.core.streams
Represents a stream of items that can be read from.
ReadStreamImpl - Class in io.vertx.groovy.core.streams
ReadStreamImpl(Object) - Constructor in ReadStreamImpl
readSymlink(String, Handler<AsyncResult<String>>) - Method in FileSystem
Returns the path representing the file that the symbolic link specified by link points to, asynchronously.
readSymlinkBlocking(String) - Method in FileSystem
Blocking version of FileSystem.readSymlink
receivedFrameHandler(Handler<Map<String, Object>>) - Method in StompClient
Configures a received handler that gets notified when a STOMP frame is received by the client.
receivedFrameHandler(Handler<Map<String, Object>>) - Method in StompClientConnection
Configures a received handler that get notified when a STOMP frame is received by the client.
receivedFrameHandler(Handler<ServerFrame>) - Method in StompServerHandler
Configures a handler that get notified when a STOMP frame is received by the server.
record() - Method in ServiceReference
@return the service record.
RecordParser - Class in io.vertx.groovy.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(Object) - Constructor in RecordParser
RedirectAuthHandler - Class in io.vertx.groovy.ext.web.handler
An auth handler that's used to handle auth by redirecting user to a custom login page.
RedirectAuthHandler(Object) - Constructor in RedirectAuthHandler
RedisClient - Class in io.vertx.groovy.redis
RedisClient(Object) - Constructor in RedisClient
RedisTransaction - Class in io.vertx.groovy.redis
This Interface represents a TX
RedisTransaction(Object) - Constructor in RedisTransaction
refresh(Handler<AsyncResult<Void>>) - Method in AccessToken
Refresh the access token
register(String) - Method in EventBusCollector
Register the collector as a consumer of the event bus with the specified address.
registerCommand(Command, Handler<AsyncResult<Command>>) - Method in CommandRegistry
Register a command
registerCommandResolver(CommandResolver) - Method in ShellServer
Register a command resolver for this server.
registerCommands(List<Command>, Handler<AsyncResult<List<Command>>>) - Method in CommandRegistry
Register a list of commands.
registerServiceExporter(ServiceExporter, Map<String, Object>) - Method in ServiceDiscovery
Registers a discovery bridge.
registerServiceImporter(ServiceImporter, Map<String, Object>) - Method in ServiceDiscovery
Registers a discovery service importer.
registerTermServer(TermServer) - Method in ShellServer
Register a term server to this shell server, the term server lifecycle methods are managed by this shell server.
reject() - Method in ServerWebSocket
Reject the WebSocket.
release() - Method in Lock
Release the lock.
release(ServiceReference) - Method in ServiceDiscovery
Releases the service reference.
release() - Method in ServiceReference
Releases the reference.
releaseServiceObject(ServiceDiscovery, Object) - Method in ServiceDiscovery
Release the service object retrieved using get methods from the service type interface.
remoteAddress() - Method in HttpServerRequest
@return
Returns:
the remote (client side) address of the request
remoteAddress() - Method in NetSocket
@return
Returns:
the remote address for this socket
remoteAddress() - Method in ServerWebSocket
@return
Returns:
the remote address for this socket
remoteAddress() - Method in SockJSSocket
Return the remote address for this socket @return
remoteAddress() - Method in WebSocket
@return
Returns:
the remote address for this socket
remoteAddress() - Method in WebSocketBase
remoteAddress() - Method in WebSocketBaseImpl
@return
Returns:
the remote address for this socket
remoteSettings() - Method in HttpConnection
@return the current remote endpoint settings for this connection - this is not implemented for HTTP/1.x
remoteSettingsHandler(Handler<Map<String, Object>>) - Method in HttpConnection
Set an handler that is called when remote endpoint remove(K, Handler<AsyncResult<V>>) - Method in AsyncMap
Remove a value from the map, asynchronously.
remove(String) - Method in Context
Remove some data from the context.
remove(K) - Method in LocalMap
Remove an entry from the map
remove(String, Map<String, Object>, Handler<AsyncResult<Void>>) - Method in MongoClient
Remove matching documents from a collection
remove(String) - Method in MultiMap
Removes the value with the given name
remove() - Method in Route
Remove this route from the router
remove(String) - Method in Session
Remove some data from the session
remove(String) - Method in TestContext
Remove some data from the context.
removeArgument(int) - Method in CLI
Removes an argument identified by its index.
removeBodyEndHandler(int) - Method in RoutingContext
Remove a body end handler
removeCookie(String) - Method in RoutingContext
Remove a cookie.
removeDocument(String, Map<String, Object>, Handler<AsyncResult<Map<String, Object>>>) - Method in MongoClient
Remove a single matching document from a collection and return the handler with MongoClientDeleteResult result
removeDocuments(String, Map<String, Object>, Handler<AsyncResult<Map<String, Object>>>) - Method in MongoClient
Remove matching documents from a collection and return the handler with MongoClientDeleteResult result
removeDocumentsWithOptions(String, Map<String, Object>, WriteOption, Handler<AsyncResult<Map<String, Object>>>) - Method in MongoClient
Remove matching documents from a collection with the specified write option and return the handler with MongoClientDeleteResult result
removeDocumentWithOptions(String, Map<String, Object>, WriteOption, Handler<AsyncResult<Map<String, Object>>>) - Method in MongoClient
Remove a single matching document from a collection with the specified write option and return the handler with MongoClientDeleteResult result
removeHeadersEndHandler(int) - Method in RoutingContext
Remove a headers end handler
removeIfPresent(K, V, Handler<AsyncResult<Boolean>>) - Method in AsyncMap
Remove a value from the map, only if entry already exists with same value.
removeIfPresent(K, V) - Method in LocalMap
Remove the entry only if there is an entry with the specified key and value
removeInterceptor(Handler<SendContext>) - Method in EventBus
Remove an interceptor
removeOne(String, Map<String, Object>, Handler<AsyncResult<Void>>) - Method in MongoClient
Remove a single matching document from a collection
removeOneWithOptions(String, Map<String, Object>, WriteOption, Handler<AsyncResult<Void>>) - Method in MongoClient
Remove a single matching document from a collection with the specified write option
removeOption(String) - Method in CLI
Removes an option identified by its name.
removeWithOptions(String, Map<String, Object>, WriteOption, Handler<AsyncResult<Void>>) - Method in MongoClient
Remove matching documents from a collection with the specified write option
rename(String, String, Handler<AsyncResult<String>>) - Method in RedisClient
Rename a key
rename(String, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Rename a key
renamenx(String, String, Handler<AsyncResult<Long>>) - Method in RedisClient
Rename a key, only if the new key does not exist
renamenx(String, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Rename a key, only if the new key does not exist
render(RoutingContext, String, Handler<AsyncResult<Buffer>>) - Method in TemplateEngine
Render
replace(K, V, Handler<AsyncResult<V>>) - Method in AsyncMap
Replace the entry only if it is currently mapped to some value
replace(K, V) - Method in LocalMap
Replace the entry only if there is an existing entry with the key
replace(String, Map<String, Object>, Map<String, Object>, Handler<AsyncResult<Void>>) - Method in MongoClient
Replace matching documents in the specified collection
replaceDocuments(String, Map<String, Object>, Map<String, Object>, Handler<AsyncResult<Map<String, Object>>>) - Method in MongoClient
Replace matching documents in the specified collection and return the handler with MongoClientUpdateResult result
replaceDocumentsWithOptions(String, Map<String, Object>, Map<String, Object>, Map<String, Object>, Handler<AsyncResult<Map<String, Object>>>) - Method in MongoClient
Replace matching documents in the specified collection, specifying options and return the handler with MongoClientUpdateResult result
replaceIfPresent(K, V, V, Handler<AsyncResult<Boolean>>) - Method in AsyncMap
Replace the entry only if it is currently mapped to a specific value
replaceIfPresent(K, V, V) - Method in LocalMap
Replace the entry only if there is an existing entry with the specified key and value
replaceWithOptions(String, Map<String, Object>, Map<String, Object>, Map<String, Object>, Handler<AsyncResult<Void>>) - Method in MongoClient
Replace matching documents in the specified collection, specifying options
reply(Object, Map<String, Object>, Handler<AsyncResult<Message<R>>>) - Method in Message
The same as reply(R message, DeliveryOptions) but you can specify handler for the reply - i.e.
replyAddress() - Method in Message
The reply address.
request(HttpMethod, String, Handler<HttpClientResponse>) - Method in HttpClient
Create an HTTP request to send to the server at the default host and port, specifying a response handler to receive the response
request() - Method in RoutingContext
@return
Returns:
the HTTP request object
requestAbs(HttpMethod, String, Handler<HttpClientResponse>) - Method in HttpClient
Create an HTTP request to send to the server using an absolute URI, specifying a response handler to receive the response
requestHandler(Handler<HttpServerRequest>) - Method in HttpServer
Set the request handler for the server to requestHandler.
requestStream() - Method in HttpServer
Return the request stream for the server.
reroute(HttpMethod, String) - Method in RoutingContext
Restarts the current router with a new method and path.
reset() - Method in CircuitBreaker
Resets the circuit breaker state (number of failure set to 0 and state set to closed).
reset(long) - Method in HttpClientRequest
Reset this stream with the error code.
reset(long) - Method in HttpServerResponse
Reset this HTTP/2 stream with the error code.
resizehandler(Handler<Void>) - Method in CommandProcess
resizehandler(Handler<Void>) - Method in Term
resizehandler(Handler<Void>) - Method in Tty
Set a resize handler, the handler is called when the tty size changes.
resolve(Future<T>) - Method in Completion
Completes the future upon completion, otherwise fails it.
resolveA(String, Handler<AsyncResult<List<String>>>) - Method in DnsClient
Try to resolve all A (ipv4) records for the given name.
resolveAAAA(String, Handler<AsyncResult<List<String>>>) - Method in DnsClient
Try to resolve all AAAA (ipv6) records for the given name.
resolveCNAME(String, Handler<AsyncResult<List<String>>>) - Method in DnsClient
Try to resolve the CNAME record for the given name.
resolveMX(String, Handler<AsyncResult<List<MxRecord>>>) - Method in DnsClient
Try to resolve the MX records for the given name.
resolveNS(String, Handler<AsyncResult<List<String>>>) - Method in DnsClient
Try to resolve the NS records for the given name.
resolvePTR(String, Handler<AsyncResult<String>>) - Method in DnsClient
Try to resolve the PTR record for the given name.
resolveSRV(String, Handler<AsyncResult<List<SrvRecord>>>) - Method in DnsClient
Try to resolve the SRV records for the given name.
resolveTXT(String, Handler<AsyncResult<List<String>>>) - Method in DnsClient
Try to resolve the TXT records for the given name.
response() - Method in HttpServerRequest
Returns:
the response.
response() - Method in RoutingContext
@return
Returns:
the HTTP response object
ResponseTimeHandler - Class in io.vertx.groovy.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(Object) - Constructor in ResponseTimeHandler
restore(String, long, String, Handler<AsyncResult<String>>) - Method in RedisClient
Create a key using the provided serialized value, previously obtained using DUMP.
restore(String, long, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Create a key using the provided serialized value, previously obtained using DUMP.
result(int) - Method in CompositeFuture
Returns the result of a wrapped future
result() - Method in Future
The result of the operation.
result(V) - Method in InternalHelper
resume() - Method in AsyncFile
resume() - Method in DatagramSocket
resume() - Method in HttpClientRequest
resume() - Method in HttpClientResponse
resume() - Method in HttpServerFileUpload
resume() - Method in HttpServerRequest
resume() - Method in HttpServerRequestStream
resume(boolean) - Method in Job
Resume the job.
resume() - Method in MessageConsumer
resume() - Method in NetSocket
resume() - Method in NetSocketStream
resume(boolean, Handler<Void>) - Method in Process
Suspend the process.
resume() - Method in ReadStream
resume() - Method in ReadStreamImpl
Resume reading.
resume() - Method in ServerWebSocket
resume() - Method in ServerWebSocketStream
resume() - Method in SockJSSocket
resume() - Method in TestSuiteReport
resume() - Method in TimeoutStream
resume() - Method in WebSocket
resume() - Method in WebSocketBase
resume() - Method in WebSocketBaseImpl
resume() - Method in WebSocketStream
resumeHandler(Handler<Void>) - Method in 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.
retryTimeout() - Method in SessionStore
The retry timeout value in milli seconds used by the session handler when it retrieves a value from the store.
reverseLookup(String, Handler<AsyncResult<String>>) - Method in DnsClient
Try to do a reverse lookup of an IP address.
revoke(String, Handler<AsyncResult<Void>>) - Method in AccessToken
Revoke access or refresh token
role(Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Return the role of the instance in the context of replication
role(Handler<AsyncResult<String>>) - Method in RedisTransaction
Return the role of the instance in the context of replication
rollback(Handler<AsyncResult<Void>>) - Method in SQLConnection
Rolls back all changes made since the previous commit/rollback.
Route - Class in io.vertx.groovy.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(Object) - Constructor in Route
route(String) - Method in Router
Add a route that matches the specified path
Router - Class in io.vertx.groovy.ext.web
A router receives request from an HttpServer and routes it to the first matching Route that it contains.
Router(Object) - Constructor in Router
routeWithRegex(String) - Method in Router
Add a route that matches the specified path regex
RoutingContext - Class in io.vertx.groovy.ext.web
Represents the context for the handling of a request in Vert.x-Web.
RoutingContext(Object) - Constructor in RoutingContext
rpop(String, Handler<AsyncResult<String>>) - Method in RedisClient
Remove and get the last element in a list
rpop(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Remove and get the last element in a list
rpoplpush(String, String, Handler<AsyncResult<String>>) - Method in RedisClient
Remove the last element in a list, append it to another list and return it
rpoplpush(String, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Remove the last element in a list, append it to another list and return it
rpush(String, String, Handler<AsyncResult<Long>>) - Method in RedisClient
Append one or multiple values to a list
rpush(String, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Append one or multiple values to a list
rpushMany(String, List<String>, Handler<AsyncResult<Long>>) - Method in RedisClient
Append one or multiple values to a list
rpushMany(String, List<String>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Append one or multiple values to a list
rpushx(String, String, Handler<AsyncResult<Long>>) - Method in RedisClient
Append a value to a list, only if the list exists
rpushx(String, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Append a value to a list, only if the list exists
run() - Method in Job
Run the job, before running the job a must be set.
run(boolean, Handler<Void>) - Method in Process
Run the process.
run(Vertx, Map<String, Object>) - Method in TestSuite
Run the testsuite with the specified options and the specified vertx instance.
runCommand(String, Map<String, Object>, Handler<AsyncResult<Map<String, Object>>>) - Method in MongoClient
Run an arbitrary MongoDB command.
runOnContext(Handler<Void>) - Method in Context
Run the specified action asynchronously on the same context, some time after the current execution has completed.
runOnContext(Handler<Void>) - Method in 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.

S

sadd(String, String, Handler<AsyncResult<Long>>) - Method in RedisClient
Add a member to a set
sadd(String, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Add a member to a set
saddMany(String, List<String>, Handler<AsyncResult<Long>>) - Method in RedisClient
Add one or more members to a set
saddMany(String, List<String>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Add one or more members to a set
safeCreate(D, Class<T>) - Method in InternalHelper
save(String, Map<String, Object>, Handler<AsyncResult<String>>) - Method in MongoClient
Save a document in the specified collection
save(Handler<AsyncResult<String>>) - Method in RedisClient
Synchronously save the dataset to disk
save(Handler<AsyncResult<String>>) - Method in RedisTransaction
Synchronously save the dataset to disk
saveWithOptions(String, Map<String, Object>, WriteOption, Handler<AsyncResult<String>>) - Method in MongoClient
Save a document in the specified collection with the specified write option
scan(String, Map<String, Object>, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Incrementally iterate the keys space
scan(String, Map<String, Object>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Incrementally iterate the keys space
scard(String, Handler<AsyncResult<Long>>) - Method in RedisClient
Get the number of members in a set
scard(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Get the number of members in a set
scheme() - Method in HttpServerRequest
@return
Returns:
the scheme of the request
scriptExists(String, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Check existence of script in the script cache.
scriptExists(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Check existence of script in the script cache.
scriptExistsMany(List<String>, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Check existence of scripts in the script cache.
scriptExistsMany(List<String>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Check existence of scripts in the script cache.
scriptFlush(Handler<AsyncResult<String>>) - Method in RedisClient
Remove all the scripts from the script cache.
scriptFlush(Handler<AsyncResult<String>>) - Method in RedisTransaction
Remove all the scripts from the script cache.
scriptKill(Handler<AsyncResult<String>>) - Method in RedisClient
Kill the script currently in execution.
scriptKill(Handler<AsyncResult<String>>) - Method in RedisTransaction
Kill the script currently in execution.
scriptLoad(String, Handler<AsyncResult<String>>) - Method in RedisClient
Load the specified Lua script into the script cache.
scriptLoad(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Load the specified Lua script into the script cache.
ScriptVerticle - Class in io.vertx.lang.groovy
A Vert.x native verticle wrapping a Groovy script, the script will be executed when the Verticle starts.
ScriptVerticle(Script) - Constructor in ScriptVerticle
sdiff(String, List<String>, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Subtract multiple sets
sdiff(String, List<String>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Subtract multiple sets
sdiffstore(String, String, List<String>, Handler<AsyncResult<Long>>) - Method in RedisClient
Subtract multiple sets and store the resulting set in a key
sdiffstore(String, String, List<String>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Subtract multiple sets and store the resulting set in a key
select(int, Handler<AsyncResult<String>>) - Method in RedisClient
Change the selected database for the current connection
select(int, Handler<AsyncResult<String>>) - Method in RedisTransaction
Change the selected database for the current connection
send(String, String, int, String, Handler<AsyncResult<DatagramSocket>>) - Method in DatagramSocket
Write the given java.lang.String to the SocketAddress using the given encoding.
send(String, Object, Map<String, Object>, Handler<AsyncResult<Message<T>>>) - Method in EventBus
Like EventBus.send but specifying a replyHandler that will be called if the recipient subsequently replies to the message.
send(T, Handler<AsyncResult<Message<R>>>) - Method in MessageProducer
send() - Method in SendContext
@return true if the message is being sent (point to point) or False if the message is being published
send(String, Map<String, String>, Buffer, Handler<Map<String, Object>>) - Method in StompClientConnection
Sends a SEND frame to the server to the given destination.
SendContext - Class in io.vertx.groovy.core.eventbus
Encapsulates a message being sent from Vert.x.
SendContext(Object) - Constructor in SendContext
sender() - Method in DatagramPacket
Returns the SocketAddress of the sender that sent this DatagramPacket.
sender(int, String) - Method in DatagramSocket
Returns a PacketWritestream able to send to the SocketAddress.
sender(String, Map<String, Object>) - Method in EventBus
Like EventBus.sender but specifying delivery options that will be used for configuring the delivery of the message.
sendFile(String, long, long, Handler<AsyncResult<Void>>) - Method in HttpServerResponse
Like HttpServerResponse.sendFile but providing a handler which will be notified once the file has been completely written to the wire.
sendFile(String, long, long, Handler<AsyncResult<Void>>) - Method in NetSocket
Same as NetSocket.sendFile but also takes a handler that will be called when the send has completed or a failure has occurred
sendHandler(Handler<ServerFrame>) - Method in StompServerHandler
Configures the action to execute when a SEND frame is received.
sendHead(Handler<HttpVersion>) - Method in HttpClientRequest
Like HttpClientRequest.sendHead but with an handler after headers have been sent.
sendMail(Map<String, Object>, Handler<AsyncResult<Map<String, Object>>>) - Method in MailClient
sendMail(Map<String, Object>, Handler<AsyncResult<Map<String, Object>>>) - Method in MailService
server() - Method in ShellService
@return
Returns:
the shell server
server() - Method in StompClientConnection
Returns:
the server name.
server() - Method in StompServerConnection
Returns:
the STOMP server serving this connection.
ServerFrame - Class in io.vertx.groovy.ext.stomp
Structure passed to server handler when receiving a frame.
ServerFrame(Object) - Constructor in ServerFrame
ServerWebSocket - Class in io.vertx.groovy.core.http
Represents a server side WebSocket.
ServerWebSocket(Object) - Constructor in ServerWebSocket
ServerWebSocketStream - Class in io.vertx.groovy.core.http
A ReadStream of ServerWebSocket, used for notifying web socket connections to a HttpServer.
ServerWebSocketStream(Object) - Constructor in ServerWebSocketStream
service() - Method in SrvRecord
Returns the service's name (i.e.
ServiceDiscovery - Class in io.vertx.groovy.servicediscovery
Service Discovery main entry point.
ServiceDiscovery(Object) - Constructor in ServiceDiscovery
ServiceDiscoveryBridge - Class in io.vertx.groovy.servicediscovery.spi
Service Discovery bridge allows integrate other discovery technologies with the Vert.x service discovery.
ServiceDiscoveryBridge(Object) - Constructor in ServiceDiscoveryBridge
ServiceExporter - Class in io.vertx.groovy.servicediscovery.spi
The service exporter allows integrate other discovery technologies with the Vert.x service discovery.
ServiceExporter(Object) - Constructor in ServiceExporter
ServiceImporter - Class in io.vertx.groovy.servicediscovery.spi
The service importer allows integrate other discovery technologies with the Vert.x service discovery.
ServiceImporter(Object) - Constructor in ServiceImporter
ServicePublisher - Class in io.vertx.groovy.servicediscovery.spi
The publisher is used by the importer to publish or unpublish records.
ServicePublisher(Object) - Constructor in ServicePublisher
ServiceReference - Class in io.vertx.groovy.servicediscovery
Once a consumer has chosen a service, it builds a ServiceReference managing the binding with the chosen service provider.
ServiceReference(Object) - Constructor in ServiceReference
Session - Class in io.vertx.groovy.ext.shell.session
A shell session.
session() - Method in CommandProcess
@return
Returns:
the shell session
session() - Method in Completion
Returns:
the shell current session, useful for accessing data like the current path for file completion, etc...
session() - Method in RoutingContext
Get the session.
Session(Object) - Constructor in Session
session() - Method in Shell
@return
Returns:
the current shell session
session() - Method in StompClientConnection
Returns:
the session id.
session() - Method in StompServerConnection
@return
Returns:
the STOMP session id computed when the client has established the connection to the server
SessionHandler - Class in io.vertx.groovy.ext.web.handler
A handler that maintains a Session for each browser session.
SessionHandler(Object) - Constructor in SessionHandler
SessionStore - Class in io.vertx.groovy.ext.web.sstore
A session store is used to store sessions for an Vert.x-Web web app
SessionStore(Object) - Constructor in SessionStore
set(String, String) - Method in MultiMap
Sets a value under the specified name.
set(String, String, Handler<AsyncResult<Void>>) - Method in RedisClient
Set the string value of a key
set(String, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Set the string value of a key
setAcceptableContentType(String) - Method in RoutingContext
Set the acceptable content type.
setAccessed() - Method in Session
Mark the session as being accessed.
setAll(MultiMap) - Method in MultiMap
Cleans this instance.
setAllowRootFileSystemAccess(boolean) - Method in StaticHandler
Enable/Disable access to the root of the filesystem
setAlwaysAsyncFS(boolean) - Method in StaticHandler
Set whether async filesystem access should always be used
setArguments(List<Map<String, Object>>) - Method in CLI
Sets the list of arguments.
setAudience(List<String>) - Method in JWTAuthHandler
Set the audience list
setAuthenticationQuery(String) - Method in JDBCAuth
Set the authentication query to use.
setAuthProvider(AuthProvider) - Method in User
Set the auth provider for the User.
setAutoCommit(boolean, Handler<AsyncResult<Void>>) - Method in SQLConnection
Sets the auto commit flag for this connection.
setBinary(String, Buffer, Handler<AsyncResult<Void>>) - Method in RedisClient
Set the binary string value of a key - without encoding as utf-8
setBinary(String, Buffer, Handler<AsyncResult<String>>) - Method in RedisTransaction
Set the binary string value of a key - without encoding as utf-8
setBinaryWithOptions(String, Buffer, Map<String, Object>, Handler<AsyncResult<Void>>) - Method in RedisClient
Set the string value of a key
setBinaryWithOptions(String, Buffer, Map<String, Object>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Set the string value of a key
setbit(String, long, int, Handler<AsyncResult<Long>>) - Method in RedisClient
Sets or clears the bit at offset in the string value stored at key
setbit(String, long, int, Handler<AsyncResult<String>>) - Method in RedisTransaction
Sets or clears the bit at offset in the string value stored at key
setBody(Buffer) - Method in RoutingContext
Set the body.
setBodyLimit(long) - Method in BodyHandler
Set the maximum body size -1 means unlimited
setBuffer(int, Buffer, int, int) - Method in 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 Buffer
Sets the byte at position pos in the Buffer to the value b.
setCacheEntryTimeout(long) - Method in StaticHandler
Set the server cache entry timeout when caching is enabled
setCachingEnabled(boolean) - Method in StaticHandler
Set whether cache header handling is enabled
setChanged(boolean) - Method in Cookie
Set the cookie as being changed.
setChunked(boolean) - Method in HttpClientRequest
If chunked is true then the request will be set into HTTP chunked mode
setChunked(boolean) - Method in 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.
setCollectionName(String) - Method in MongoAuth
Set the name of the collection to be used.
setCookieHttpOnlyFlag(boolean) - Method in SessionHandler
Sets whether the 'HttpOnly' flag should be set for the session cookie.
setCookieName(String) - Method in CSRFHandler
Set the cookie name.
setCookieSecureFlag(boolean) - Method in SessionHandler
Sets whether the 'secure' flag should be set for the session cookie.
setDeleteUploadedFilesOnEnd(boolean) - Method in BodyHandler
Set whether uploaded files should be removed after handling the request
setDescription(String) - Method in CLI
setDirectLoggedInOKURL(String) - Method in 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 StaticHandler
Set whether directory listing is enabled
setDirectoryTemplate(String) - Method in StaticHandler
Set the directory template to be used when directory listing
setDomain(String) - Method in Cookie
Sets the domain of this cookie
setDouble(int, double) - Method in Buffer
Sets the double at position pos in the Buffer to the value d.
setEnableFSTuning(boolean) - Method in StaticHandler
Set whether async/sync filesystem tuning should enabled
setEnableRangeSupport(boolean) - Method in StaticHandler
Set whether range requests (resumable downloads; media streaming) should be enabled.
setex(String, long, String, Handler<AsyncResult<String>>) - Method in RedisClient
Set the value and expiration of a key
setex(String, long, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Set the value and expiration of a key
setExpectMultipart(boolean) - Method in HttpServerRequest
Call this with true if you are expecting a multi-part body to be submitted in the request.
setExtension(String) - Method in HandlebarsTemplateEngine
Set the extension for the engine
setExtension(String) - Method in JadeTemplateEngine
Set the extension for the engine
setExtension(String) - Method in MVELTemplateEngine
Set the extension for the engine
setExternalSalt(String) - Method in HashStrategy
Set an external salt.
setFilesReadOnly(boolean) - Method in StaticHandler
Set whether files are read-only and will never change
setFloat(int, float) - Method in Buffer
Sets the float at position pos in the Buffer to the value f.
setHandler(Handler<AsyncResult<CompositeFuture>>) - Method in CompositeFuture
setHandler(Handler<AsyncResult<T>>) - Method in Future
Set a handler for the result.
setHashStrategy(HashStrategy) - Method in MongoAuth
The HashStrategy which is used by the current instance
setHeaderName(String) - Method in CSRFHandler
Set the header name.
setHidden(boolean) - Method in CLI
Sets whether or not the current instance of CLI must be hidden.
setHost(String) - Method in HttpClientRequest
Set the request host.
setHttpOnly(boolean) - Method in Cookie
Determines if this cookie is HTTP only.
setIgnoreExpiration(boolean) - Method in JWTAuthHandler
Set whether expiration is ignored
setIncludeHidden(boolean) - Method in StaticHandler
Set whether hidden files should be served
setIndexPage(String) - Method in StaticHandler
Set the index page
setInt(int, int) - Method in Buffer
Sets the int at position pos in the Buffer to the value i.
setIntLE(int, int) - Method in Buffer
Sets the int at position pos in the Buffer to the value i in the Little Endian Byte Order.
setIssuer(String) - Method in JWTAuthHandler
Set the issuer
setLong(int, long) - Method in Buffer
Sets the long at position pos in the Buffer to the value l.
setLongLE(int, long) - Method in Buffer
Sets the long at position pos in the Buffer to the value l in the Little Endian Byte Order.
setMaxAge(long) - Method in Cookie
Sets the maximum age of this cookie in seconds.
setMaxAgeSeconds(long) - Method in StaticHandler
Set value for max age in caching headers
setMaxAvgServeTimeNs(long) - Method in StaticHandler
Set the max serve time in ns, above which serves are considered slow
setMaxBufferedMessages(int) - Method in MessageConsumer
Set the number of messages this registration will buffer when this stream is paused.
setMaxCacheSize(int) - Method in HandlebarsTemplateEngine
Set the max cache size for the engine
setMaxCacheSize(int) - Method in JadeTemplateEngine
Set the max cache size for the engine
setMaxCacheSize(int) - Method in MVELTemplateEngine
Set the max cache size for the engine
setMaxCacheSize(int) - Method in StaticHandler
Set the max cache size, when caching is enabled
setMedium(int, int) - Method in Buffer
Sets the 24bit int at position pos in the Buffer to the value i.
setMediumLE(int, int) - Method in Buffer
Sets the 24bit int at position pos in the Buffer to the value i. in the Little Endian Byte Order
setMergeFormAttributes(boolean) - Method in BodyHandler
Set whether form attributes will be added to the request parameters
setMode(TemplateMode) - Method in ThymeleafTemplateEngine
Set the mode for the engine
setNagHttps(boolean) - Method in CSRFHandler
Should the handler give warning messages if this handler is used in other than https protocols?
setNagHttps(boolean) - Method in SessionHandler
Set whether a nagging log warning should be written if the session handler is accessed over HTTP, not HTTPS
setName(String) - Method in CLI
Sets the name of the CLI.
setnx(String, String, Handler<AsyncResult<Long>>) - Method in RedisClient
Set the value of a key, only if the key does not exist
setnx(String, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Set the value of a key, only if the key does not exist
setOptions(List<Map<String, Object>>) - Method in CLI
Sets the list of arguments.
setOutput(Handler<Buffer>) - Method in RecordParser
setPasswordCredentialField(String) - Method in MongoAuth
Set the name of the field to be used as property for the password of credentials in the method AuthProvider.authenticate.
setPasswordField(String) - Method in MongoAuth
Set the name of the field to be used for the password Defaults to MongoAuth
setPasswordParam(String) - Method in FormLoginHandler
Set the name of the form param used to submit the password
setPath(String) - Method in Cookie
Sets the path of this cookie.
setPeriodic(long, Handler<Long>) - Method in 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 MongoAuth
Set the name of the field to be used for the permissions.
setPermissionsQuery(String) - Method in JDBCAuth
Set the permissions query to use.
setQueryTimeout(int) - Method in SQLConnection
Sets a connection wide query timeout.
setrange(String, int, String, Handler<AsyncResult<Long>>) - Method in RedisClient
Overwrite part of a string at key starting at the specified offset
setrange(String, int, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Overwrite part of a string at key starting at the specified offset
setRawMessage(Map<String, Object>) - Method in BridgeEvent
Get the raw JSON message for the event.
setRawMethod(String) - Method in HttpClientRequest
Set the value the method to send when the method is used.
setReadBufferSize(int) - Method in AsyncFile
Sets the buffer size that will be used to read the data from the file.
setReadPos(long) - Method in AsyncFile
Sets the position from which data will be read from when using the file as a ReadStream.
setReturnURLParam(String) - Method in FormLoginHandler
Set the name of the session attrioute used to specify the return url
setRoleField(String) - Method in MongoAuth
Set the name of the field to be used for the roles.
setRolePrefix(String) - Method in JDBCAuth
Set the role prefix to distinguish from permissions when checking for isPermitted requests.
setRolePrefix(String) - Method in ShiroAuth
Set the role prefix to distinguish from permissions when checking for isPermitted requests.
setRolesQuery(String) - Method in JDBCAuth
Set the roles query to use.
setSaltField(String) - Method in MongoAuth
Set the name of the field to be used for the salt.
setSaltStyle(HashSaltStyle) - Method in HashStrategy
Set the saltstyle as defined by io.vertx.groovy.ext.auth.mongo.HashSaltStyle.
setSecure(boolean) - Method in Cookie
Sets the security getStatus of this cookie
setSession(Session) - Method in Job
Set a session on the job.
setSession(Session) - Method in Process
Set the process session
setSession(Session) - Method in RoutingContext
Set the session.
setSession(Session) - Method in Term
Associate the term with a session.
setSessionCookieName(String) - Method in SessionHandler
Set the session cookie name
setSessionTimeout(long) - Method in SessionHandler
Set the session timeout
setShort(int, short) - Method in Buffer
Sets the short at position pos in the Buffer to the value s.
setShortLE(int, short) - Method in 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 Pty
Resize the terminal.
setStatusCode(int) - Method in HttpServerResponse
Set the status code.
setStatusMessage(String) - Method in HttpServerResponse
Set the status message
setString(int, String, String) - Method in Buffer
Sets the bytes at position pos in the Buffer to the value of str encoded in encoding enc.
setSummary(String) - Method in CLI
Sets the summary of the CLI.
setTimeout(long) - Method in CSRFHandler
Set the timeout for tokens generated by the handler, by default it uses the default from the session handler.
setTimeout(long) - Method in HttpClientRequest
Set's the amount of time after which if the request does not return any data within the timeout period an java.util.concurrent.TimeoutException will be passed to the exception handler (if provided) and the request will be closed.
setTimer(long, Handler<Long>) - Method in 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 HttpConnection
@return the latest server settings acknowledged by the remote endpoint - this is not implemented for HTTP/1.x
setTransactionIsolation(TransactionIsolation, Handler<AsyncResult<Void>>) - Method in SQLConnection
Attempts to change the transaction isolation level for this Connection object to the one given.
setTty(Tty) - Method in Job
Set a tty on the job.
setTty(Tty) - Method in Process
Set the process tty.
setUnsignedByte(int, short) - Method in Buffer
Sets the unsigned byte at position pos in the Buffer to the value b.
setUnsignedInt(int, long) - Method in Buffer
Sets the unsigned int at position pos in the Buffer to the value i.
setUnsignedIntLE(int, long) - Method in 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 Buffer
Sets the unsigned short at position pos in the Buffer to the value s.
setUnsignedShortLE(int, int) - Method in 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 OAuth2AuthHandler
add the callback handler to a given route.
setUploadsDirectory(String) - Method in BodyHandler
Set the uploads directory to use
setUser(User) - Method in RoutingContext
Set the user.
setUsernameCredentialField(String) - Method in MongoAuth
Set the name of the field to be used as property for the username in the method AuthProvider.authenticate.
setUsernameField(String) - Method in MongoAuth
Set the name of the field to be used for the username.
setUsernameParam(String) - Method in FormLoginHandler
Set the name of the form param used to submit the username
setValue(String) - Method in Cookie
Sets the value of this cookie
setWebRoot(String) - Method in StaticHandler
Set the web root
setWindowSize(int) - Method in HttpConnection
Update the current connection wide window size to a new size.
setWithOptions(String, String, Map<String, Object>, Handler<AsyncResult<String>>) - Method in RedisClient
Set the string value of a key
setWithOptions(String, String, Map<String, Object>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Set the string value of a key
setWritePos(long) - Method in AsyncFile
Sets the position from which data will be written when using the file as a WriteStream.
setWriteQueueMaxSize(int) - Method in AsyncFile
setWriteQueueMaxSize(int) - Method in HttpClientRequest
setWriteQueueMaxSize(int) - Method in HttpServerResponse
setWriteQueueMaxSize(int) - Method in MessageProducer
setWriteQueueMaxSize(int) - Method in NetSocket
setWriteQueueMaxSize(int) - Method in PacketWritestream
setWriteQueueMaxSize(int) - Method in Pump
Set the write queue max size to maxSize
setWriteQueueMaxSize(int) - Method in ServerWebSocket
setWriteQueueMaxSize(int) - Method in SockJSSocket
setWriteQueueMaxSize(int) - Method in WebSocket
setWriteQueueMaxSize(int) - Method in WebSocketBase
setWriteQueueMaxSize(int) - Method in WebSocketBaseImpl
setWriteQueueMaxSize(int) - Method in WriteStream
setWriteQueueMaxSize(int) - Method in WriteStreamImpl
Set the maximum size of the write queue to maxSize.
SharedData - Class in io.vertx.groovy.core.shareddata
Shared data allows you to share data safely between different parts of your application in a safe way.
SharedData(Object) - Constructor in SharedData
sharedData() - Method in Vertx
Get the shared data object.
Shell - Class in io.vertx.groovy.ext.shell
An interactive session between a consumer and a shell.
Shell(Object) - Constructor in Shell
ShellServer - Class in io.vertx.groovy.ext.shell
The shell server.
ShellServer(Object) - Constructor in ShellServer
ShellService - Class in io.vertx.groovy.ext.shell
The shell service, provides a remotely accessible shell available via Telnet or SSH according to the ShellService(Object) - Constructor in ShellService
ShiroAuth - Class in io.vertx.groovy.ext.auth.shiro
Factory interface for creating Apache Shiro based AuthProvider instances.
ShiroAuth(Object) - Constructor in ShiroAuth
shutdown(long) - Method in HttpConnection
Initiate a connection shutdown, a go away frame is sent and the connection is closed when all current streams will be closed or the timeout is fired.
shutdownHandler(Handler<Void>) - Method in HttpConnection
Set an handler called when a frame has been sent or received and all connections are closed.
SignalHandler - Class in io.vertx.groovy.ext.shell.term
@author Julien Viet
SignalHandler(Object) - Constructor in SignalHandler
sinter(List<String>, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Intersect multiple sets
sinter(List<String>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Intersect multiple sets
sinterstore(String, List<String>, Handler<AsyncResult<Long>>) - Method in RedisClient
Intersect multiple sets and store the resulting set in a key
sinterstore(String, List<String>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Intersect multiple sets and store the resulting set in a key
sismember(String, String, Handler<AsyncResult<Long>>) - Method in RedisClient
Determine if a given value is a member of a set
sismember(String, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Determine if a given value is a member of a set
size(Handler<AsyncResult<Integer>>) - Method in AsyncMap
Provide the number of entries in the map
size() - Method in CompositeFuture
@return
Returns:
the number of wrapped future
size() - Method in FileProps
The size of the file, in bytes @return
size() - Method in FileUpload
@return
Returns:
the size of the upload, in bytes
size() - Method in HttpServerFileUpload
The size of the upload may not be available until it is all read.
size() - Method in LocalMap
Get the size of the map
size() - Method in MultiMap
Return the number of keys.
size(Handler<AsyncResult<Integer>>) - Method in SessionStore
Get the number of sessions in the store
slave() - Method in Pty
@return
Returns:
the pseudo terminal slave
slaveof(String, int, Handler<AsyncResult<String>>) - Method in RedisClient
Make the server a slave of another instance
slaveof(String, int, Handler<AsyncResult<String>>) - Method in RedisTransaction
Make the server a slave of another instance
slaveofNoone(Handler<AsyncResult<String>>) - Method in RedisClient
Make this server a master
slaveofNoone(Handler<AsyncResult<String>>) - Method in RedisTransaction
Make this server a master
slice(int, int) - Method in Buffer
Returns a slice of this buffer.
slowlogGet(int, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Read the Redis slow queries log
slowlogGet(int, Handler<AsyncResult<String>>) - Method in RedisTransaction
Read the Redis slow queries log
slowlogLen(Handler<AsyncResult<Long>>) - Method in RedisClient
Get the length of the Redis slow queries log
slowlogLen(Handler<AsyncResult<String>>) - Method in RedisTransaction
Get the length of the Redis slow queries log
slowlogReset(Handler<AsyncResult<Void>>) - Method in RedisClient
Reset the Redis slow queries log
slowlogReset(Handler<AsyncResult<String>>) - Method in RedisTransaction
Reset the Redis slow queries log
smembers(String, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Get all the members in a set
smembers(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Get all the members in a set
smove(String, String, String, Handler<AsyncResult<Long>>) - Method in RedisClient
Move a member from one set to another
smove(String, String, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Move a member from one set to another
socket() - Method in BridgeEvent
Get the SockJSSocket instance corresponding to the event
SocketAddress - Class in io.vertx.groovy.core.net
The address of a socket
SocketAddress(Object) - Constructor in SocketAddress
socketHandler(Handler<SockJSSocket>) - Method in SockJSHandler
Set a SockJS socket handler.
SockJSHandler - Class in io.vertx.groovy.ext.web.handler.sockjs
A handler that allows you to handle SockJS connections from clients.
SockJSHandler(Object) - Constructor in SockJSHandler
SockJSSocket - Class in io.vertx.groovy.ext.web.handler.sockjs
You interact with SockJS clients through instances of SockJS socket.
SockJSSocket(Object) - Constructor in SockJSSocket
SockJSTermHandler - Class in io.vertx.groovy.ext.shell.term
@author Julien Viet
SockJSTermHandler(Object) - Constructor in SockJSTermHandler
sort(String, Map<String, Object>, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Sort the elements in a list, set or sorted set
sort(String, Map<String, Object>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Sort the elements in a list, set or sorted set
spop(String, Handler<AsyncResult<String>>) - Method in RedisClient
Remove and return a random member from a set
spop(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Remove and return a random member from a set
spopMany(String, int, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Remove and return random members from a set
spopMany(String, int, Handler<AsyncResult<String>>) - Method in RedisTransaction
Remove and return random members from a set
SQLConnection - Class in io.vertx.groovy.ext.sql
Represents a connection to a SQL database
SQLConnection(Object) - Constructor in SQLConnection
srandmember(String, Handler<AsyncResult<String>>) - Method in RedisClient
Get one or multiple random members from a set
srandmember(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Get one or multiple random members from a set
srandmemberCount(String, int, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Get one or multiple random members from a set
srandmemberCount(String, int, Handler<AsyncResult<String>>) - Method in RedisTransaction
Get one or multiple random members from a set
srem(String, String, Handler<AsyncResult<Long>>) - Method in RedisClient
Remove one member from a set
srem(String, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Remove one member from a set
sremMany(String, List<String>, Handler<AsyncResult<Long>>) - Method in RedisClient
Remove one or more members from a set
sremMany(String, List<String>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Remove one or more members from a set
SrvRecord - Class in io.vertx.groovy.core.dns
Represent a Service-Record (SRV) which was resolved for a domain.
SrvRecord(Object) - Constructor in SrvRecord
sscan(String, String, Map<String, Object>, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Incrementally iterate Set elements
sscan(String, String, Map<String, Object>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Incrementally iterate Set elements
stackTrace() - Method in Failure
@return
Returns:
the stack trace
start(String, int, Handler<AsyncResult<AmqpBridge>>) - Method in AmqpBridge
Starts the bridge, establishing the underlying connection.
start(Future<Void>) - Method in GroovyVerticle
Start the verticle instance.
start() - Method in Pump
Start the Pump.
start(Handler<AsyncResult<Void>>) - Method in RabbitMQClient
Start the rabbitMQ client.
start(Future<Void>) - Method in ScriptVerticle
Start the verticle instance.
start(Vertx, ServicePublisher, Map<String, Object>, Future<Void>) - Method in ServiceDiscoveryBridge
Starts the bridge.
start(Vertx, ServicePublisher, Map<String, Object>, Future<Void>) - Method in ServiceImporter
Starts the bridge.
start(Handler<AsyncResult<Void>>) - Method in ShellService
Start the shell service, this is an asynchronous start.
state() - Method in CircuitBreaker
Returns:
the current state.
StaticHandler - Class in io.vertx.groovy.ext.web.handler
A handler for serving static resources from the file system or classpath.
StaticHandler(Object) - Constructor in StaticHandler
status() - Method in Job
@return
Returns:
the job exec status
status() - Method in Process
@return
Returns:
the current process status
statusCode() - Method in HttpClientResponse
@return
Returns:
the status code of the response
statusCode() - Method in RoutingContext
If the context is being routed to failure handlers after a failure has been triggered by calling RoutingContext.fail then this will return that status code.
statusMessage() - Method in HttpClientResponse
@return
Returns:
the status message of the response
statusUpdateHandler(Handler<ExecStatus>) - Method in Job
Set an handler called when the job terminates.
stdinHandler(Handler<String>) - Method in CommandProcess
stdinHandler(Handler<String>) - Method in Term
stdinHandler(Handler<String>) - Method in Tty
Set a stream handler on the standard input to read the data.
stdoutHandler(Handler<String>) - Method in Pty
Set the standard out handler of the pseudo terminal.
StompClient - Class in io.vertx.groovy.ext.stomp
Defines a STOMP client.
StompClient(Object) - Constructor in StompClient
StompClientConnection - Class in io.vertx.groovy.ext.stomp
Once a connection to the STOMP server has been made, client receives a StompClientConnection, that let send and receive STOMP frames.
StompClientConnection(Object) - Constructor in StompClientConnection
stompHandler() - Method in StompServer
Returns:
the StompServerHandler used by this server.
stompHandler(Handler<ServerFrame>) - Method in StompServerHandler
Configures the action to execute when a STOMP frame is received.
StompServer - Class in io.vertx.groovy.ext.stomp
Defines a STOMP server.
StompServer(Object) - Constructor in StompServer
StompServerConnection - Class in io.vertx.groovy.ext.stomp
Class representing a connection between a STOMP client a the server.
StompServerConnection(Object) - Constructor in StompServerConnection
StompServerHandler - Class in io.vertx.groovy.ext.stomp
STOMP server handler implements the behavior of the STOMP server when a specific event occurs.
StompServerHandler(Object) - Constructor in StompServerHandler
stop(Future<Void>) - Method in GroovyVerticle
Stop the verticle instance.
stop() - Method in Pump
Stop the Pump.
stop(Handler<AsyncResult<Void>>) - Method in RabbitMQClient
Stop the rabbitMQ client.
stop(Future<Void>) - Method in ScriptVerticle
Stop the verticle instance.
stop(Vertx, ServicePublisher, Future<Void>) - Method in ServiceDiscoveryBridge
Stops the bridge.
stop(Vertx, ServicePublisher, Future<Void>) - Method in ServiceImporter
Stops the bridge.
stop(Handler<AsyncResult<Void>>) - Method in ShellService
Stop the shell service, this is an asynchronous start.
StreamBase - Interface in io.vertx.groovy.core.streams
Base interface for a stream.
StreamBaseImpl - Class in io.vertx.groovy.core.streams
StreamBaseImpl(Object) - Constructor in StreamBaseImpl
streamId() - Method in HttpClientRequest
@return
Returns:
the id of the stream of this response, when it is not yet determined, i.e the request has not been yet sent or it is not supported HTTP/1.x
streamId() - Method in HttpServerResponse
@return
Returns:
the id of the stream of this response, for HTTP/1.x
streamToFileSystem(String) - Method in HttpServerFileUpload
Stream the content of this upload to the given file on storage.
strlen(String, Handler<AsyncResult<Long>>) - Method in RedisClient
Get the length of the value stored in a key
strlen(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Get the length of the value stored in a key
subscribe(StompServerConnection, Map<String, Object>) - Method in Destination
Handles a subscription request to the current Destination.
subscribe(String, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Listen for messages published to the given channels
subscribe(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Listen for messages published to the given channels
subscribe(String, Map<String, String>, Handler<Map<String, Object>>, Handler<Map<String, Object>>) - Method in StompClientConnection
Subscribes to the given destination.
subscribeHandler(Handler<ServerFrame>) - Method in StompServerHandler
Configures the action to execute when a SUBSCRIBE frame is received.
subscribeMany(List<String>, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Listen for messages published to the given channels
subscribeMany(List<String>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Listen for messages published to the given channels
subscription() - Method in Acknowledgement
@return the subscription frame
succeeded(int) - Method in CompositeFuture
Returns true if a wrapped future is succeeded
succeeded() - Method in Future
Did it succeed?
succeeded() - Method in TestResult
Did it succeed?
succeededFuture(T) - Method in Future
Created a succeeded future with the specified result.
sunion(List<String>, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Add multiple sets
sunion(List<String>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Add multiple sets
sunionstore(String, List<String>, Handler<AsyncResult<Long>>) - Method in RedisClient
Add multiple sets and store the resulting set in a key
sunionstore(String, List<String>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Add multiple sets and store the resulting set in a key
suspend() - Method in Job
Resume the job.
suspend(Handler<Void>) - Method in Process
Resume the process.
suspendHandler(Handler<Void>) - Method in CommandProcess
Set a suspend handler, this handler is called when the command is suspended, for instance user press Ctrl-Z.
suspendHandler(SignalHandler) - Method in Term
Set a suspend signal handler on the term.
symlink(String, String, Handler<AsyncResult<Void>>) - Method in FileSystem
Create a symbolic link on the file system from link to existing, asynchronously.
symlinkBlocking(String, String) - Method in FileSystem
Blocking version of FileSystem.link
sync(Handler<AsyncResult<Void>>) - Method in RedisClient
Internal command used for replication
sync(Handler<AsyncResult<String>>) - Method in RedisTransaction
Internal command used for replication

T

target() - Method in SrvRecord
Returns the name of the host for the service.
TcpEventBusBridge - Class in io.vertx.ext.groovy.eventbus.bridge.tcp
TCP EventBus bridge for Vert.x
TcpEventBusBridge(Object) - Constructor in TcpEventBusBridge
TemplateEngine - Class in io.vertx.groovy.ext.web.templ
A template engine uses a specific template and the data in a routing context to render a resource into a buffer.
TemplateEngine(Object) - Constructor in TemplateEngine
TemplateHandler - Class in io.vertx.groovy.ext.web.handler
A handler which renders responses using a template engine and where the template name is selected from the URI path.
TemplateHandler(Object) - Constructor in TemplateHandler
Term - Class in io.vertx.groovy.ext.shell.term
The terminal.
Term(Object) - Constructor in Term
termHandler(Handler<Term>) - Method in SockJSTermHandler
termHandler(Handler<Term>) - Method in TermServer
Set the term handler that will receive incoming client connections.
terminate() - Method in Job
Terminate the job.
terminate(Handler<Void>) - Method in Process
Terminate the process.
terminatedHandler(Handler<Integer>) - Method in Process
Set an handler for being notified when the process terminates.
TermServer - Class in io.vertx.groovy.ext.shell.term
A server for terminal based applications.
TermServer(Object) - Constructor in TermServer
test(String, int, Handler<TestContext>) - Method in TestSuite
Add a new test case to the suite.
TestCase - Class in io.vertx.groovy.ext.unit
A test case object can be used to create a single test.
TestCase(Object) - Constructor in TestCase
TestCaseReport - Class in io.vertx.groovy.ext.unit.report
Report the execution of a test case.
TestCaseReport(Object) - Constructor in TestCaseReport
TestCompletion - Class in io.vertx.groovy.ext.unit
This object provides callback-ability for the end of a test suite, the completion succeeds when all tests pass otherwise it fails.
TestCompletion(Object) - Constructor in TestCompletion
TestContext - Class in io.vertx.groovy.ext.unit
The test context is used for performing test assertions and manage the completion of the test.
TestContext(Object) - Constructor in TestContext
TestResult - Class in io.vertx.groovy.ext.unit.report
The result of a test.
TestResult(Object) - Constructor in TestResult
TestSuite - Class in io.vertx.groovy.ext.unit
A named suite of test cases that are executed altogether.
TestSuite(Object) - Constructor in TestSuite
TestSuiteReport - Class in io.vertx.groovy.ext.unit.report
The test suite reports is basically a stream of events reporting the test suite execution.
TestSuiteReport(Object) - Constructor in TestSuiteReport
textData() - Method in WebSocketFrame
Returns:
the content of this frame as a UTF-8 string and returns the converted string.
textFrame(String, boolean) - Method in WebSocketFrame
Create a text WebSocket frame.
textHandlerID() - Method in ServerWebSocket
When a Websocket is created it automatically registers an event handler with the eventbus, the ID of that handler is given by textHandlerID.
textHandlerID() - Method in WebSocket
When a Websocket is created it automatically registers an event handler with the eventbus, the ID of that handler is given by textHandlerID.
textHandlerID() - Method in WebSocketBase
textHandlerID() - Method in WebSocketBaseImpl
When a Websocket is created it automatically registers an event handler with the eventbus, the ID of that handler is given by textHandlerID.
ThymeleafTemplateEngine - Class in io.vertx.groovy.ext.web.templ
A template engine that uses the Thymeleaf library.
ThymeleafTemplateEngine(Object) - Constructor in ThymeleafTemplateEngine
time(Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Return the current server time
time(Handler<AsyncResult<String>>) - Method in RedisTransaction
Return the current server time
timeout() - Method in Session
Returns:
the amount of time in ms, after which the session will expire, if not accessed.
TimeoutHandler - Class in io.vertx.groovy.ext.web.handler
Handler that will timeout requests if the response has not been written after a certain time.
TimeoutHandler(Object) - Constructor in TimeoutHandler
TimeoutStream - Class in io.vertx.groovy.core
A timeout stream is triggered by a timer, the io.vertx.groovy.core.Handler will be call when the timer is fired, it can be once or several times depending on the nature of the timer related to this stream.
TimeoutStream(Object) - Constructor in TimeoutStream
timerStream(long) - Method in Vertx
Returns a one-shot timer as a read stream.
toBackground() - Method in Job
Send the job to background.
toBackground(Handler<Void>) - Method in Process
Set the process in background.
toForeground() - Method in Job
Send the job to foreground.
toForeground(Handler<Void>) - Method in Process
Set the process in foreground.
toJsonArray() - Method in Buffer
Returns a Json array representation of the Buffer @return
toJsonObject() - Method in Buffer
Returns a Json object representation of the Buffer @return
toJsonObject(Map<String, Object>) - Method in InternalHelper
tokenize(String) - Method in CliToken
Tokenize the string argument and return a list of tokens.
topic(Vertx, String) - Method in Destination
toString(String) - Method in Buffer
Returns a String representation of the Buffer with the encoding specified by enc
totalSpace() - Method in FileSystemProps
@return
Returns:
The total space on the file system, in bytes
trace(String) - Method in Router
Add a route that matches a HTTP TRACE request and the specified path
traceWithRegex(String) - Method in Router
Add a route that matches a HTTP TRACE request and the specified path regex
trailers() - Method in HttpClientResponse
@return
Returns:
the trailers
trailers() - Method in HttpServerResponse
@return
Returns:
The HTTP trailers
transaction() - Method in RedisClient
Return a RedisTransaction instance
truncate(String, long, Handler<AsyncResult<Void>>) - Method in FileSystem
Truncate the file represented by path to length len in bytes, asynchronously.
truncateBlocking(String, long) - Method in FileSystem
Blocking version of FileSystem.truncate
ttl(String, Handler<AsyncResult<Long>>) - Method in RedisClient
Get the time to live for a key
ttl(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Get the time to live for a key
Tty - Class in io.vertx.groovy.ext.shell.term
Provide interactions with the Shell TTY.
Tty(Object) - Constructor in Tty
type() - Method in BridgeEvent
@return
Returns:
the type of the event
type() - Method in HttpFrame
@return
Returns:
the 8-bit type of the frame
type(String, Handler<AsyncResult<String>>) - Method in RedisClient
Determine the type stored at key
type(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Determine the type stored at key
type() - Method in Tty
Returns:
the declared tty type, for instance , , etc... it can be null when the tty does not have declared its type.

U

unallocatedSpace() - Method in FileSystemProps
@return
Returns:
The total un-allocated space on the file system, in bytes
undeploy(String, Handler<AsyncResult<Void>>) - Method in Vertx
Like #undeploy(String) but the completionHandler will be notified when the undeployment is complete.
unlink(String, Handler<AsyncResult<Void>>) - Method in FileSystem
Unlinks the link on the file system represented by the path link, asynchronously.
unlinkBlocking(String) - Method in FileSystem
Blocking version of FileSystem.unlink
unlistenMulticastGroup(String, String, String, Handler<AsyncResult<DatagramSocket>>) - Method in DatagramSocket
Leaves a multicast group and stops listening for packets send to it on the given network interface.
unpublish(String, Handler<AsyncResult<Void>>) - Method in ServiceDiscovery
Un-publishes a record.
unpublish(String, Handler<AsyncResult<Void>>) - Method in ServicePublisher
Un-publishes a record.
unregister(Handler<AsyncResult<Void>>) - Method in MessageConsumer
Unregisters the handler which created this registration
unregisterCommand(String, Handler<AsyncResult<Void>>) - Method in CommandRegistry
Unregister a command.
unsubscribe(StompServerConnection, Map<String, Object>) - Method in Destination
Handles a un-subscription request to the current Destination.
unsubscribe(List<String>, Handler<AsyncResult<Void>>) - Method in RedisClient
Stop listening for messages posted to the given channels
unsubscribe(List<String>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Stop listening for messages posted to the given channels
unsubscribe(String, Map<String, String>, Handler<Map<String, Object>>) - Method in StompClientConnection
Un-subscribes from the given destination.
unsubscribeConnection(StompServerConnection) - Method in Destination
Removes all subscriptions of the given connection
unsubscribeHandler(Handler<ServerFrame>) - Method in StompServerHandler
Configures the action to execute when a UNSUBSCRIBE frame is received.
unwatch(Handler<AsyncResult<String>>) - Method in RedisTransaction
Forget about all watched keys
unwrapObject(Object) - Method in InternalHelper
update(String, Map<String, Object>, Map<String, Object>, Handler<AsyncResult<Void>>) - Method in MongoClient
Update matching documents in the specified collection
update(Map<String, Object>, Handler<AsyncResult<Map<String, Object>>>) - Method in ServiceDiscovery
Updates the given record.
update(String, Handler<AsyncResult<Map<String, Object>>>) - Method in SQLConnection
Executes the given SQL statement which may be an INSERT, UPDATE, or DELETE statement.
updateCollection(String, Map<String, Object>, Map<String, Object>, Handler<AsyncResult<Map<String, Object>>>) - Method in MongoClient
Update matching documents in the specified collection and return the handler with MongoClientUpdateResult result
updateCollectionWithOptions(String, Map<String, Object>, Map<String, Object>, Map<String, Object>, Handler<AsyncResult<Map<String, Object>>>) - Method in MongoClient
Update matching documents in the specified collection, specifying options and return the handler with MongoClientUpdateResult result
updateSettings(Map<String, Object>, Handler<AsyncResult<Void>>) - Method in 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.

updateWithOptions(String, Map<String, Object>, Map<String, Object>, Map<String, Object>, Handler<AsyncResult<Void>>) - Method in MongoClient
Update matching documents in the specified collection, specifying options
updateWithParams(String, List<Object>, Handler<AsyncResult<Map<String, Object>>>) - Method in SQLConnection
Executes the given prepared statement which may be an INSERT, UPDATE, or DELETE statement with the given parameters
upgrade() - Method in HttpServerRequest
Upgrade the connection to a WebSocket connection.
upgradeToSsl(Handler<Void>) - Method in NetSocket
Upgrade channel to use SSL/TLS.
uploadedFileName() - Method in FileUpload
Returns:
the actual temporary file name on the server where the file was uploaded to.
uploadHandler(Handler<HttpServerFileUpload>) - Method in HttpServerRequest
Set an upload handler.
uri() - Method in HttpClientRequest
Returns:
The URI of the request.
uri() - Method in HttpServerRequest
Returns:
the URI of the request.
uri() - Method in ServerWebSocket
uri() - Method in SockJSSocket
Return the URI corresponding to the last request for this socket or the websocket handshake @return
usableSpace() - Method in FileSystemProps
@return
Returns:
The total usable space on the file system, in bytes
useNormalisedPath(boolean) - Method in Route
If true then the normalised request path will be used when routing (e.g. removing duplicate /) Default is true
User - Class in io.vertx.groovy.ext.auth.common
Represents an authenticate User and contains operations to authorise the user, using a role/permission based model.
user() - Method in RoutingContext
Get the authenticated user (if any).
User(User) - Constructor in User
UserSessionHandler - Class in io.vertx.groovy.ext.web.handler
This handler should be used if you want to store the User object in the Session so it's available between different requests, without you having re-authenticate each time.
UserSessionHandler(Object) - Constructor in UserSessionHandler

V

value() - Method in CliToken
@return
Returns:
the token value
variant() - Method in Locale
Returns the variant as reported by the HTTP client.
version() - Method in HttpClientResponse
@return
Returns:
the version of the response
version() - Method in HttpServerRequest
@return
Returns:
the HTTP version of the request
version() - Method in StompClientConnection
Returns:
the STOMP protocol version negotiated with the server.
Vertx - Class in io.vertx.groovy.core
The entry point into the Vert.x Core API.
vertx() - Method in CommandProcess
@return
Returns:
the current Vert.x instance
vertx() - Method in Completion
@return
Returns:
the current Vert.x instance
vertx() - Method in RoutingContext
@return
Returns:
the Vert.x instance associated to the initiating Router for this context
vertx() - Method in StompClient
Returns:
the vert.x instance used by the client.
vertx() - Method in StompServer
Returns:
the instance of vert.x used by the server.
Vertx(Object) - Constructor in Vertx
VertxUnitRunner - Class in io.vertx.groovy.ext.unit.junit
A JUnit runner for Groovy JUnit tests.
VertxUnitRunner(Class<?>) - Constructor in VertxUnitRunner
VertxUnitRunnerWithParameters - Class in io.vertx.groovy.ext.unit.junit
@author Julien Viet
VertxUnitRunnerWithParameters(TestWithParameters) - Constructor in VertxUnitRunnerWithParameters
VertxUnitRunnerWithParametersFactory - Class in io.vertx.groovy.ext.unit.junit
A org.junit.runners.parameterized.ParametersRunnerFactory for a VertxUnitRunner for enabling Vert.x Unit parameterized tests in Groovy.
VirtualHostHandler - Class in io.vertx.groovy.ext.web.handler
Handler that will filter requests based on the request Host name.
VirtualHostHandler(Object) - Constructor in VirtualHostHandler

W

wait(long, long, Handler<AsyncResult<String>>) - Method in RedisClient
Wait for the synchronous replication of all the write commands sent in the context of the current connection.
wait(long, long, Handler<AsyncResult<String>>) - Method in RedisTransaction
Wait for the synchronous replication of all the write commands sent in the context of the current connection.
watch(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Watch the given keys to determine execution of the MULTI/EXEC block
watchMany(List<String>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Watch the given keys to determine execution of the MULTI/EXEC block
webSession() - Method in SockJSSocket
@return
Returns:
the Vert.x-Web session corresponding to this socket
WebSocket - Class in io.vertx.groovy.core.http
Represents a client-side WebSocket.
websocket(String, MultiMap, WebsocketVersion, String, Handler<WebSocket>, Handler<Throwable>) - Method in HttpClient
Connect a WebSocket at the relative request URI using the default host and port, the specified headers, the specified version of WebSockets and the specified sub protocols
WebSocket(Object) - Constructor in WebSocket
WebSocketBase - Interface in io.vertx.groovy.core.http
Base WebSocket implementation.
WebSocketBaseImpl - Class in io.vertx.groovy.core.http
WebSocketBaseImpl(Object) - Constructor in WebSocketBaseImpl
WebSocketFrame - Class in io.vertx.groovy.core.http
A WebSocket frame that represents either text or binary data.
WebSocketFrame(Object) - Constructor in WebSocketFrame
websocketHandler(Handler<ServerWebSocket>) - Method in HttpServer
Set the websocket handler for the server to wsHandler.
webSocketHandler() - Method in StompServer
Gets the able to manage web socket connections.
WebSocketStream - Class in io.vertx.groovy.core.http
A stream for HttpClient WebSocket connection.
websocketStream(String, MultiMap, WebsocketVersion, String) - Method in HttpClient
Create a WebSocket stream at the relative request URI using the default host and port, the specified headers, the specified version of WebSockets and the specified sub protocols
websocketStream() - Method in HttpServer
Return the websocket stream for the server.
WebSocketStream(Object) - Constructor in WebSocketStream
webUser() - Method in SockJSSocket
@return
Returns:
the Vert.x-Web user corresponding to this socket
weight() - Method in SrvRecord
Returns the weight of this service record.
width() - Method in Tty
@return
Returns:
the current width, i.e the number of rows or if unknown
WorkerExecutor - Class in io.vertx.groovy.core
An executor for executing blocking code in Vert.x .
WorkerExecutor(Object) - Constructor in WorkerExecutor
wrapObject(Object) - Method in InternalHelper
write(Buffer, long, Handler<AsyncResult<Void>>) - Method in AsyncFile
Write a Buffer to the file at position position in the file, asynchronously.
write(String) - Method in CommandProcess
Write some text to the standard output.
write(String, String) - Method in HttpClientRequest
Write a java.lang.String to the request body, encoded using the encoding enc.
write(String) - Method in HttpServerResponse
Write a java.lang.String to the response body, encoded in UTF-8.
write(T) - Method in MessageProducer
write(String, String) - Method in NetSocket
Write a java.lang.String to the connection, encoded using the encoding enc.
write(Buffer) - Method in PacketWritestream
write(String) - Method in Pty
Write data to the slave standard input of the pseudo terminal.
write(Buffer) - Method in ServerWebSocket
write(Buffer) - Method in SockJSSocket
write(Buffer) - Method in StompServerConnection
Writes the given buffer to the socket.
write(String) - Method in Term
write(String) - Method in Tty
Write data to the standard output.
write(Buffer) - Method in WebSocket
write(Buffer) - Method in WebSocketBase
write(Buffer) - Method in WebSocketBaseImpl
write(T) - Method in WriteStream
write(T) - Method in WriteStreamImpl
Write some data to the stream.
writeBinaryMessage(Buffer) - Method in ServerWebSocket
writeBinaryMessage(Buffer) - Method in WebSocket
writeBinaryMessage(Buffer) - Method in WebSocketBase
writeBinaryMessage(Buffer) - Method in WebSocketBaseImpl
Writes a (potentially large) piece of binary data to the connection.
writeContinue() - Method in HttpServerResponse
Used to write an interim 100 Continue response to signify that the client should send the rest of the request.
writeCustomFrame(HttpFrame) - Method in HttpClientRequest
writeCustomFrame(HttpFrame) - Method in HttpServerResponse
writeFile(String, Buffer, Handler<AsyncResult<Void>>) - Method in FileSystem
Creates the file, and writes the specified Buffer data to the file represented by the path path, asynchronously.
writeFileBlocking(String, Buffer) - Method in FileSystem
Blocking version of FileSystem.writeFile
writeFinalBinaryFrame(Buffer) - Method in ServerWebSocket
writeFinalBinaryFrame(Buffer) - Method in WebSocket
writeFinalBinaryFrame(Buffer) - Method in WebSocketBase
writeFinalBinaryFrame(Buffer) - Method in WebSocketBaseImpl
Write a final WebSocket binary frame to the connection
writeFinalTextFrame(String) - Method in ServerWebSocket
writeFinalTextFrame(String) - Method in WebSocket
writeFinalTextFrame(String) - Method in WebSocketBase
writeFinalTextFrame(String) - Method in WebSocketBaseImpl
Write a final WebSocket text frame to the connection
writeFrame(WebSocketFrame) - Method in ServerWebSocket
writeFrame(WebSocketFrame) - Method in WebSocket
writeFrame(WebSocketFrame) - Method in WebSocketBase
writeFrame(WebSocketFrame) - Method in WebSocketBaseImpl
Write a WebSocket frame to the connection
writeHandlerID() - Method in NetSocket
When a NetSocket is created it automatically registers an event handler with the event bus, the ID of that handler is given by writeHandlerID.
writeHandlerID() - Method in SockJSSocket
When a SockJSSocket is created it automatically registers an event handler with the event bus, the ID of that handler is given by writeHandlerID.
writeQueueFull() - Method in AsyncFile
This will return true if there are more bytes in the write queue than the value set using AsyncFile.setWriteQueueMaxSize
writeQueueFull() - Method in HttpClientRequest
This will return true if there are more bytes in the write queue than the value set using HttpClientRequest.setWriteQueueMaxSize
writeQueueFull() - Method in HttpServerResponse
This will return true if there are more bytes in the write queue than the value set using HttpServerResponse.setWriteQueueMaxSize
writeQueueFull() - Method in MessageProducer
This will return true if there are more bytes in the write queue than the value set using MessageProducer.setWriteQueueMaxSize
writeQueueFull() - Method in NetSocket
This will return true if there are more bytes in the write queue than the value set using NetSocket.setWriteQueueMaxSize
writeQueueFull() - Method in PacketWritestream
This will return true if there are more bytes in the write queue than the value set using PacketWritestream.setWriteQueueMaxSize
writeQueueFull() - Method in ServerWebSocket
This will return true if there are more bytes in the write queue than the value set using ServerWebSocket.setWriteQueueMaxSize
writeQueueFull() - Method in SockJSSocket
writeQueueFull() - Method in WebSocket
This will return true if there are more bytes in the write queue than the value set using WebSocket.setWriteQueueMaxSize
writeQueueFull() - Method in WebSocketBase
writeQueueFull() - Method in WebSocketBaseImpl
This will return true if there are more bytes in the write queue than the value set using WebSocketBase.setWriteQueueMaxSize
writeQueueFull() - Method in WriteStream
writeQueueFull() - Method in WriteStreamImpl
This will return true if there are more bytes in the write queue than the value set using WriteStream.setWriteQueueMaxSize
WriteStream - Interface in io.vertx.groovy.core.streams
Represents a stream of data that can be written to.
WriteStreamImpl - Class in io.vertx.groovy.core.streams
WriteStreamImpl(Object) - Constructor in WriteStreamImpl
writingFrameHandler(Handler<Map<String, Object>>) - Method in StompClient
Configures a writing handler that gets notified when a STOMP frame is written on the wire.
writingFrameHandler(Handler<Map<String, Object>>) - Method in StompClientConnection
Configures a handler notified when a frame is going to be written on the wire.
writingFrameHandler(Handler<ServerFrame>) - Method in StompServer
Configures the handler that is invoked every time a frame is going to be written to the "wire".

X

Y

Z

zadd(String, double, String, Handler<AsyncResult<Long>>) - Method in RedisClient
Add one or more members to a sorted set, or update its score if it already exists
zadd(String, double, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Add one or more members to a sorted set, or update its score if it already exists
zaddMany(String, Map<String, Double>, Handler<AsyncResult<Long>>) - Method in RedisClient
Add one or more members to a sorted set, or update its score if it already exists
zaddMany(String, Map<String, Double>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Add one or more members to a sorted set, or update its score if it already exists
zcard(String, Handler<AsyncResult<Long>>) - Method in RedisClient
Get the number of members in a sorted set
zcard(String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Get the number of members in a sorted set
zcount(String, double, double, Handler<AsyncResult<Long>>) - Method in RedisClient
Count the members in a sorted set with scores within the given values
zcount(String, double, double, Handler<AsyncResult<String>>) - Method in RedisTransaction
Count the members in a sorted set with scores within the given values
zincrby(String, double, String, Handler<AsyncResult<String>>) - Method in RedisClient
Increment the score of a member in a sorted set
zincrby(String, double, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Increment the score of a member in a sorted set
zinterstore(String, List<String>, AggregateOptions, Handler<AsyncResult<Long>>) - Method in RedisClient
Intersect multiple sorted sets and store the resulting sorted set in a new key
zinterstore(String, List<String>, AggregateOptions, Handler<AsyncResult<String>>) - Method in RedisTransaction
Intersect multiple sorted sets and store the resulting sorted set in a new key
zinterstoreWeighed(String, Map<String, Double>, AggregateOptions, Handler<AsyncResult<Long>>) - Method in RedisClient
Intersect multiple sorted sets and store the resulting sorted set in a new key using weights for scoring
zinterstoreWeighed(String, Map<String, Double>, AggregateOptions, Handler<AsyncResult<String>>) - Method in RedisTransaction
Intersect multiple sorted sets and store the resulting sorted set in a new key using weights for scoring
zlexcount(String, String, String, Handler<AsyncResult<Long>>) - Method in RedisClient
Count the number of members in a sorted set between a given lexicographical range
zlexcount(String, String, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Count the number of members in a sorted set between a given lexicographical range
zrange(String, long, long, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Return a range of members in a sorted set, by index
zrange(String, long, long, Handler<AsyncResult<String>>) - Method in RedisTransaction
Return a range of members in a sorted set, by index
zrangebylex(String, String, String, Map<String, Object>, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Return a range of members in a sorted set, by lexicographical range
zrangebylex(String, String, String, Map<String, Object>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Return a range of members in a sorted set, by lexicographical range
zrangebyscore(String, String, String, Map<String, Object>, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Return a range of members in a sorted set, by score
zrangebyscore(String, String, String, Map<String, Object>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Return a range of members in a sorted set, by score
zrangeWithOptions(String, long, long, RangeOptions, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Return a range of members in a sorted set, by index
zrangeWithOptions(String, long, long, RangeOptions, Handler<AsyncResult<String>>) - Method in RedisTransaction
Return a range of members in a sorted set, by index
zrank(String, String, Handler<AsyncResult<Long>>) - Method in RedisClient
Determine the index of a member in a sorted set
zrank(String, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Determine the index of a member in a sorted set
zrem(String, String, Handler<AsyncResult<Long>>) - Method in RedisClient
Remove one member from a sorted set
zrem(String, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Remove one member from a sorted set
zremMany(String, List<String>, Handler<AsyncResult<Long>>) - Method in RedisClient
Remove one or more members from a sorted set
zremMany(String, List<String>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Remove one or more members from a sorted set
zremrangebylex(String, String, String, Handler<AsyncResult<Long>>) - Method in RedisClient
Remove all members in a sorted set between the given lexicographical range
zremrangebylex(String, String, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Remove all members in a sorted set between the given lexicographical range
zremrangebyrank(String, long, long, Handler<AsyncResult<Long>>) - Method in RedisClient
Remove all members in a sorted set within the given indexes
zremrangebyrank(String, long, long, Handler<AsyncResult<String>>) - Method in RedisTransaction
Remove all members in a sorted set within the given indexes
zremrangebyscore(String, String, String, Handler<AsyncResult<Long>>) - Method in RedisClient
Remove all members in a sorted set within the given scores
zremrangebyscore(String, String, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Remove all members in a sorted set within the given scores
zrevrange(String, long, long, RangeOptions, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Return a range of members in a sorted set, by index, with scores ordered from high to low
zrevrange(String, long, long, RangeOptions, Handler<AsyncResult<String>>) - Method in RedisTransaction
Return a range of members in a sorted set, by index, with scores ordered from high to low
zrevrangebylex(String, String, String, Map<String, Object>, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Return a range of members in a sorted set, by score, between the given lexicographical range with scores ordered from high to low
zrevrangebylex(String, String, String, Map<String, Object>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Return a range of members in a sorted set, by score, between the given lexicographical range with scores ordered from high to low
zrevrangebyscore(String, String, String, Map<String, Object>, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Return a range of members in a sorted set, by score, with scores ordered from high to low
zrevrangebyscore(String, String, String, Map<String, Object>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Return a range of members in a sorted set, by score, with scores ordered from high to low
zrevrank(String, String, Handler<AsyncResult<Long>>) - Method in RedisClient
Determine the index of a member in a sorted set, with scores ordered from high to low
zrevrank(String, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Determine the index of a member in a sorted set, with scores ordered from high to low
zscan(String, String, Map<String, Object>, Handler<AsyncResult<List<Object>>>) - Method in RedisClient
Incrementally iterate sorted sets elements and associated scores
zscan(String, String, Map<String, Object>, Handler<AsyncResult<String>>) - Method in RedisTransaction
Incrementally iterate sorted sets elements and associated scores
zscore(String, String, Handler<AsyncResult<String>>) - Method in RedisClient
Get the score associated with the given member in a sorted set
zscore(String, String, Handler<AsyncResult<String>>) - Method in RedisTransaction
Get the score associated with the given member in a sorted set
zunionstore(String, List<String>, AggregateOptions, Handler<AsyncResult<Long>>) - Method in RedisClient
Add multiple sorted sets and store the resulting sorted set in a new key
zunionstore(String, List<String>, AggregateOptions, Handler<AsyncResult<String>>) - Method in RedisTransaction
Add multiple sorted sets and store the resulting sorted set in a new key
zunionstoreWeighed(String, Map<String, Double>, AggregateOptions, Handler<AsyncResult<Long>>) - Method in RedisClient
Add multiple sorted sets using weights, and store the resulting sorted set in a new key
zunionstoreWeighed(String, Map<String, Double>, AggregateOptions, Handler<AsyncResult<String>>) - Method in RedisTransaction
Add multiple sorted sets using weights, and store the resulting sorted set in a new key

_

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