Modifier and Type | Method and Description |
---|---|
AmqpConnection |
AmqpConnection.close(Handler<AsyncResult<Void>> done)
Closes the AMQP connection, i.e.
|
void |
AmqpSender.close(Handler<AsyncResult<Void>> handler)
Closes the sender.
|
void |
AmqpReceiver.close(Handler<AsyncResult<Void>> handler)
Closes the receiver.
|
void |
AmqpClient.close(Handler<AsyncResult<Void>> closeHandler)
Closes the client.
|
AmqpClient |
AmqpClient.connect(Handler<AsyncResult<AmqpConnection>> connectionHandler)
Connects to the AMQP broker or router.
|
AmqpConnection |
AmqpConnection.createAnonymousSender(Handler<AsyncResult<AmqpSender>> completionHandler)
Creates an anonymous sender.
|
AmqpConnection |
AmqpConnection.createDynamicReceiver(Handler<AsyncResult<AmqpReceiver>> completionHandler)
Creates a dynamic receiver.
|
AmqpConnection |
AmqpConnection.createReceiver(String address,
AmqpReceiverOptions receiverOptions,
Handler<AsyncResult<AmqpReceiver>> completionHandler)
Creates a receiver used to consumer messages from the given address.
|
AmqpClient |
AmqpClient.createReceiver(String address,
AmqpReceiverOptions receiverOptions,
Handler<AsyncResult<AmqpReceiver>> completionHandler)
Creates a receiver used to consumer messages from the given address.
|
AmqpConnection |
AmqpConnection.createReceiver(String address,
Handler<AsyncResult<AmqpReceiver>> completionHandler)
Creates a receiver used to consume messages from the given address.
|
AmqpClient |
AmqpClient.createReceiver(String address,
Handler<AsyncResult<AmqpReceiver>> completionHandler)
Creates a receiver used to consume messages from the given address.
|
AmqpConnection |
AmqpConnection.createSender(String address,
AmqpSenderOptions options,
Handler<AsyncResult<AmqpSender>> completionHandler)
Creates a sender used to send messages to the given address.
|
AmqpClient |
AmqpClient.createSender(String address,
AmqpSenderOptions options,
Handler<AsyncResult<AmqpSender>> completionHandler)
Creates a sender used to send messages to the given address.
|
AmqpConnection |
AmqpConnection.createSender(String address,
Handler<AsyncResult<AmqpSender>> completionHandler)
Creates a sender used to send messages to the given address.
|
AmqpClient |
AmqpClient.createSender(String address,
Handler<AsyncResult<AmqpSender>> completionHandler)
Creates a sender used to send messages to the given address.
|
AmqpReceiver |
AmqpReceiver.endHandler(Handler<Void> endHandler) |
AmqpConnection |
AmqpConnection.exceptionHandler(Handler<Throwable> handler)
Registers a handler called on disconnection.
|
AmqpSender |
AmqpSender.exceptionHandler(Handler<Throwable> handler) |
AmqpReceiver |
AmqpReceiver.exceptionHandler(Handler<Throwable> handler) |
AmqpReceiver |
AmqpReceiver.handler(Handler<AmqpMessage> handler) |
AmqpSender |
AmqpSender.sendWithAck(AmqpMessage message,
Handler<AsyncResult<Void>> acknowledgementHandler)
Sends an AMQP message and waits for an acknowledgement.
|
Modifier and Type | Method and Description |
---|---|
CamelBridge |
CamelBridge.start(Handler<AsyncResult<Void>> completed)
Starts the bridge.
|
CamelBridge |
CamelBridge.stop(Handler<AsyncResult<Void>> completed)
Stops the bridge.
|
Modifier and Type | Method and Description |
---|---|
ResultSet |
ResultSet.all(Handler<AsyncResult<List<com.datastax.oss.driver.api.core.cql.Row>>> handler)
The method should not be used concurrently with others like
ResultSet.fetchNextPage() or #one(Handler) . |
CassandraClient |
CassandraClient.close(Handler<AsyncResult<Void>> closeHandler)
Closes this client.
|
CassandraRowStream |
CassandraRowStream.endHandler(Handler<Void> handler) |
CassandraRowStream |
CassandraRowStream.exceptionHandler(Handler<Throwable> handler) |
<R> CassandraClient |
CassandraClient.execute(com.datastax.oss.driver.api.core.cql.Statement statement,
java.util.stream.Collector<com.datastax.oss.driver.api.core.cql.Row,?,R> collector,
Handler<AsyncResult<R>> resultHandler)
Execute a statement and produce a result by applying a collector to result set rows.
|
CassandraClient |
CassandraClient.execute(com.datastax.oss.driver.api.core.cql.Statement statement,
Handler<AsyncResult<ResultSet>> resultHandler)
Execute the statement and provide a handler for consuming results.
|
<R> CassandraClient |
CassandraClient.execute(String query,
java.util.stream.Collector<com.datastax.oss.driver.api.core.cql.Row,?,R> collector,
Handler<AsyncResult<R>> resultHandler)
Execute a query and produce a result by applying a collector to result set rows.
|
CassandraClient |
CassandraClient.execute(String query,
Handler<AsyncResult<ResultSet>> resultHandler)
Execute the query and provide a handler for consuming results.
|
CassandraClient |
CassandraClient.executeWithFullFetch(com.datastax.oss.driver.api.core.cql.Statement statement,
Handler<AsyncResult<List<com.datastax.oss.driver.api.core.cql.Row>>> resultHandler)
Execute the query and provide a handler for consuming results.
|
CassandraClient |
CassandraClient.executeWithFullFetch(String query,
Handler<AsyncResult<List<com.datastax.oss.driver.api.core.cql.Row>>> resultHandler)
Execute the query and provide a handler for consuming results.
|
void |
ResultSet.fetchNextPage(Handler<AsyncResult<ResultSet>> handler)
Like
ResultSet.fetchNextPage() but with a direct callback. |
CassandraRowStream |
CassandraRowStream.handler(Handler<com.datastax.oss.driver.api.core.cql.Row> handler) |
void |
CassandraClient.metadata(Handler<AsyncResult<com.datastax.oss.driver.api.core.metadata.Metadata>> handler)
Get
Metadata for the session. |
default void |
CassandraRowStream.pipeTo(WriteStream<com.datastax.oss.driver.api.core.cql.Row> dst,
Handler<AsyncResult<Void>> handler) |
CassandraClient |
CassandraClient.prepare(com.datastax.oss.driver.api.core.cql.SimpleStatement statement,
Handler<AsyncResult<com.datastax.oss.driver.api.core.cql.PreparedStatement>> resultHandler)
Prepares the provided a
SimpleStatement . |
CassandraClient |
CassandraClient.prepare(String query,
Handler<AsyncResult<com.datastax.oss.driver.api.core.cql.PreparedStatement>> resultHandler)
Prepares the provided query string.
|
CassandraClient |
CassandraClient.queryStream(com.datastax.oss.driver.api.core.cql.Statement statement,
Handler<AsyncResult<CassandraRowStream>> rowStreamHandler)
Executes the given SQL statement which returns the results of the query as a read stream.
|
CassandraClient |
CassandraClient.queryStream(String sql,
Handler<AsyncResult<CassandraRowStream>> rowStreamHandler)
Executes the given SQL
SELECT statement which returns the results of the query as a read stream. |
Modifier and Type | Interface and Description |
---|---|
interface |
HystrixMetricHandler
A Vert.x web handler to expose the circuit breaker to the Hystrix dasbboard.
|
Modifier and Type | Method and Description |
---|---|
CircuitBreaker |
CircuitBreaker.closeHandler(Handler<Void> handler)
Sets a
Handler invoked when the circuit breaker state switches to close. |
<T> Future<T> |
CircuitBreaker.execute(Handler<Promise<T>> command)
Same as
CircuitBreaker.executeWithFallback(Handler, Function) but using the circuit breaker default fallback. |
default <T> void |
CircuitBreaker.execute(Handler<Promise<T>> command,
Handler<AsyncResult<T>> handler)
Same as
CircuitBreaker.executeWithFallback(Handler, Function) but using the circuit breaker default fallback. |
default <T> void |
CircuitBreaker.execute(Handler<Promise<T>> command,
Handler<AsyncResult<T>> handler)
Same as
CircuitBreaker.executeWithFallback(Handler, Function) but using the circuit breaker default fallback. |
<T> CircuitBreaker |
CircuitBreaker.executeAndReport(Promise<T> resultPromise,
Handler<Promise<T>> command)
Same as
CircuitBreaker.executeAndReportWithFallback(Promise, Handler, Function) but using the circuit breaker default
fallback. |
<T> CircuitBreaker |
CircuitBreaker.executeAndReportWithFallback(Promise<T> resultPromise,
Handler<Promise<T>> command,
java.util.function.Function<Throwable,T> fallback)
Executes the given operation with the circuit breaker control.
|
<T> Future<T> |
CircuitBreaker.executeWithFallback(Handler<Promise<T>> command,
java.util.function.Function<Throwable,T> fallback)
Executes the given operation with the circuit breaker control.
|
default <T> void |
CircuitBreaker.executeWithFallback(Handler<Promise<T>> command,
java.util.function.Function<Throwable,T> fallback,
Handler<AsyncResult<T>> handler)
Same as
CircuitBreaker.executeWithFallback(Handler, Function) but using a callback. |
default <T> void |
CircuitBreaker.executeWithFallback(Handler<Promise<T>> command,
java.util.function.Function<Throwable,T> fallback,
Handler<AsyncResult<T>> handler)
Same as
CircuitBreaker.executeWithFallback(Handler, Function) but using a callback. |
CircuitBreaker |
CircuitBreaker.halfOpenHandler(Handler<Void> handler)
Sets a
Handler invoked when the circuit breaker state switches to half-open. |
CircuitBreaker |
CircuitBreaker.openHandler(Handler<Void> handler)
Sets a
Handler invoked when the circuit breaker state switches to open. |
Modifier and Type | Method and Description |
---|---|
void |
ConfigRetriever.getConfig(Handler<AsyncResult<JsonObject>> completionHandler)
Reads the configuration from the different
ConfigStore
and computes the final configuration. |
void |
ConfigRetriever.listen(Handler<ConfigChange> listener)
Registers a listener receiving configuration changes.
|
ConfigRetriever |
ConfigRetriever.setBeforeScanHandler(Handler<Void> handler)
Registers a handler called before every scan.
|
Modifier and Type | Method and Description |
---|---|
default void |
ConfigStore.close(Handler<Void> completionHandler)
Deprecated.
implement
ConfigStore.close() instead |
default void |
ConfigStore.get(Handler<AsyncResult<Buffer>> completionHandler)
Deprecated.
implement
ConfigStore.get() instead |
default void |
ConfigProcessor.process(Vertx vertx,
JsonObject configuration,
Buffer input,
Handler<AsyncResult<JsonObject>> handler)
Deprecated.
implement
ConfigProcessor.process(Vertx, JsonObject, Buffer) instead |
Modifier and Type | Method and Description |
---|---|
void |
FileSet.buildConfiguration(List<File> files,
Handler<AsyncResult<JsonObject>> handler)
Iterates over the given set of files, and for each matching file, computes the resulting configuration.
|
Modifier and Type | Method and Description |
---|---|
void |
SlimVaultClient.createToken(TokenRequest tokenRequest,
Handler<AsyncResult<Auth>> resultHandler)
Creates a new token.
|
void |
SlimVaultClient.delete(String path,
Handler<AsyncResult<Void>> resultHandler)
Deletes a secret from `path`.
|
void |
SlimVaultClient.list(String path,
Handler<AsyncResult<List<String>>> resultHandler)
Lists secrets from path (children).
|
void |
SlimVaultClient.loginWithAppRole(String roleId,
String secretId,
Handler<AsyncResult<Auth>> resultHandler)
Logs in against the `AppRole` backend.
|
void |
SlimVaultClient.loginWithCert(Handler<AsyncResult<Auth>> resultHandler)
Logs in against the `Cert` backend.
|
void |
SlimVaultClient.loginWithUserCredentials(String username,
String password,
Handler<AsyncResult<Auth>> resultHandler)
Logs in against the `userpass` backend.
|
void |
SlimVaultClient.lookupSelf(Handler<AsyncResult<Lookup>> resultHandler)
Looks up for the current token metadata.
|
void |
SlimVaultClient.read(String path,
Handler<AsyncResult<Secret>> responseHandler)
Reads a secret from `path`.
|
void |
SlimVaultClient.renewSelf(long leaseDurationInSecond,
Handler<AsyncResult<Auth>> resultHandler)
Renews the current token.
|
void |
SlimVaultClient.write(String path,
JsonObject secrets,
Handler<AsyncResult<Secret>> resultHandler)
Write a secret to `path`.
|
Modifier and Type | Interface and Description |
---|---|
interface |
Promise<T>
Represents the writable side of an action that may, or may not, have occurred yet.
|
Modifier and Type | Method and Description |
---|---|
Handler<Throwable> |
Context.exceptionHandler() |
Handler<Throwable> |
Vertx.exceptionHandler() |
Modifier and Type | Method and Description |
---|---|
default Future<T> |
Future.andThen(Handler<AsyncResult<T>> handler)
Invokes the given
handler upon completion. |
void |
Vertx.close(Handler<AsyncResult<Void>> completionHandler)
Like
Vertx.close() but the completionHandler will be called when the close is complete |
void |
WorkerExecutor.close(Handler<AsyncResult<Void>> handler)
Close the executor.
|
static void |
Vertx.clusteredVertx(VertxOptions options,
Handler<AsyncResult<Vertx>> resultHandler)
Creates a clustered instance using the specified options.
|
void |
Vertx.deployVerticle(Class<? extends Verticle> verticleClass,
DeploymentOptions options,
Handler<AsyncResult<String>> completionHandler)
Like
Vertx.deployVerticle(Verticle, DeploymentOptions, Handler) but Verticle instance is created by
invoking the default constructor of verticleClass . |
void |
Vertx.deployVerticle(String name,
DeploymentOptions options,
Handler<AsyncResult<String>> completionHandler)
Like
Vertx.deployVerticle(String, Handler) but DeploymentOptions are provided to configure the
deployment. |
default void |
Vertx.deployVerticle(String name,
Handler<AsyncResult<String>> completionHandler)
Like
Vertx.deployVerticle(String) but the completionHandler will be notified when the deployment is complete. |
void |
Vertx.deployVerticle(java.util.function.Supplier<Verticle> verticleSupplier,
DeploymentOptions options,
Handler<AsyncResult<String>> completionHandler)
Like
Vertx.deployVerticle(Verticle, DeploymentOptions, Handler) but Verticle instance is created by
invoking the verticleSupplier . |
void |
Vertx.deployVerticle(Verticle verticle,
DeploymentOptions options,
Handler<AsyncResult<String>> completionHandler)
Like
Vertx.deployVerticle(Verticle, Handler) but DeploymentOptions are provided to configure the
deployment. |
void |
Vertx.deployVerticle(Verticle verticle,
Handler<AsyncResult<String>> completionHandler)
Like
Vertx.deployVerticle(Verticle) but the completionHandler will be notified when the deployment is complete. |
TimeoutStream |
TimeoutStream.endHandler(Handler<Void> endHandler) |
Context |
Context.exceptionHandler(Handler<Throwable> handler)
Set an exception handler called when the context runs an action throwing an uncaught throwable.
When this handler is called,
Vertx.currentContext() will return this context. |
TimeoutStream |
TimeoutStream.exceptionHandler(Handler<Throwable> handler) |
Vertx |
Vertx.exceptionHandler(Handler<Throwable> handler)
Set a default exception handler for
Context , set on Context.exceptionHandler(Handler) at creation. |
default <T> Future<T> |
Context.executeBlocking(Handler<Promise<T>> blockingCodeHandler)
Same as
Context.executeBlocking(Handler, Handler) but with an handler called when the operation completes |
default <T> Future<T> |
Vertx.executeBlocking(Handler<Promise<T>> blockingCodeHandler)
Same as
Vertx.executeBlocking(Handler, Handler) but with an handler called when the operation completes |
default <T> Future<T> |
WorkerExecutor.executeBlocking(Handler<Promise<T>> blockingCodeHandler)
Like
WorkerExecutor.executeBlocking(Handler, boolean, Handler) called with ordered = true. |
<T> Future<T> |
Context.executeBlocking(Handler<Promise<T>> blockingCodeHandler,
boolean ordered)
Same as
Context.executeBlocking(Handler, boolean, Handler) but with an handler called when the operation completes |
default <T> Future<T> |
Vertx.executeBlocking(Handler<Promise<T>> blockingCodeHandler,
boolean ordered)
Same as
Vertx.executeBlocking(Handler, boolean, Handler) but with an handler called when the operation completes |
<T> Future<T> |
WorkerExecutor.executeBlocking(Handler<Promise<T>> blockingCodeHandler,
boolean ordered)
Same as
WorkerExecutor.executeBlocking(Handler, boolean, Handler) but with an handler called when the operation completes |
<T> void |
Context.executeBlocking(Handler<Promise<T>> blockingCodeHandler,
boolean ordered,
Handler<AsyncResult<T>> resultHandler)
Safely execute some blocking code.
|
<T> void |
Context.executeBlocking(Handler<Promise<T>> blockingCodeHandler,
boolean ordered,
Handler<AsyncResult<T>> resultHandler)
Safely execute some blocking code.
|
default <T> void |
Vertx.executeBlocking(Handler<Promise<T>> blockingCodeHandler,
boolean ordered,
Handler<AsyncResult<T>> resultHandler)
Safely execute some blocking code.
|
default <T> void |
Vertx.executeBlocking(Handler<Promise<T>> blockingCodeHandler,
boolean ordered,
Handler<AsyncResult<T>> resultHandler)
Safely execute some blocking code.
|
<T> void |
WorkerExecutor.executeBlocking(Handler<Promise<T>> blockingCodeHandler,
boolean ordered,
Handler<AsyncResult<T>> resultHandler)
Safely execute some blocking code.
|
<T> void |
WorkerExecutor.executeBlocking(Handler<Promise<T>> blockingCodeHandler,
boolean ordered,
Handler<AsyncResult<T>> resultHandler)
Safely execute some blocking code.
|
default <T> void |
Context.executeBlocking(Handler<Promise<T>> blockingCodeHandler,
Handler<AsyncResult<T>> resultHandler)
Invoke
Context.executeBlocking(Handler, boolean, Handler) with order = true. |
default <T> void |
Context.executeBlocking(Handler<Promise<T>> blockingCodeHandler,
Handler<AsyncResult<T>> resultHandler)
Invoke
Context.executeBlocking(Handler, boolean, Handler) with order = true. |
default <T> void |
Vertx.executeBlocking(Handler<Promise<T>> blockingCodeHandler,
Handler<AsyncResult<T>> resultHandler)
Like
Vertx.executeBlocking(Handler, boolean, Handler) called with ordered = true. |
default <T> void |
Vertx.executeBlocking(Handler<Promise<T>> blockingCodeHandler,
Handler<AsyncResult<T>> resultHandler)
Like
Vertx.executeBlocking(Handler, boolean, Handler) called with ordered = true. |
default <T> void |
WorkerExecutor.executeBlocking(Handler<Promise<T>> blockingCodeHandler,
Handler<AsyncResult<T>> resultHandler)
Like
WorkerExecutor.executeBlocking(Handler, boolean, Handler) called with ordered = true. |
default <T> void |
WorkerExecutor.executeBlocking(Handler<Promise<T>> blockingCodeHandler,
Handler<AsyncResult<T>> resultHandler)
Like
WorkerExecutor.executeBlocking(Handler, boolean, Handler) called with ordered = true. |
static <T> Future<T> |
Future.future(Handler<Promise<T>> handler)
Create a future that hasn't completed yet and that is passed to the
handler before it is returned. |
TimeoutStream |
TimeoutStream.handler(Handler<Long> handler) |
CompositeFuture |
CompositeFuture.onComplete(Handler<AsyncResult<CompositeFuture>> handler) |
Future<T> |
Future.onComplete(Handler<AsyncResult<T>> handler)
Add a handler to be notified of the result.
|
default Future<T> |
Future.onFailure(Handler<Throwable> handler)
Add a handler to be notified of the failed result.
|
default CompositeFuture |
CompositeFuture.onFailure(Handler<Throwable> handler) |
default CompositeFuture |
CompositeFuture.onSuccess(Handler<CompositeFuture> handler) |
default Future<T> |
Future.onSuccess(Handler<T> handler)
Add a handler to be notified of the succeeded result.
|
void |
Context.runOnContext(Handler<Void> action)
Run the specified action asynchronously on the same context, some time after the current execution has completed.
|
void |
Vertx.runOnContext(Handler<Void> action)
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.
|
default long |
Vertx.setPeriodic(long delay,
Handler<Long> handler)
Set a periodic timer to fire every
delay milliseconds, at which point handler will be called with
the id of the timer. |
long |
Vertx.setPeriodic(long initialDelay,
long delay,
Handler<Long> handler)
Set a periodic timer to fire every
delay milliseconds with initial delay, at which point handler will be called with
the id of the timer. |
long |
Vertx.setTimer(long delay,
Handler<Long> handler)
Set a one-shot timer to fire after
delay milliseconds, at which point handler will be called with
the id of the timer. |
void |
Vertx.undeploy(String deploymentID,
Handler<AsyncResult<Void>> completionHandler)
Like
Vertx.undeploy(String) but the completionHandler will be notified when the undeployment is complete. |
Modifier and Type | Method and Description |
---|---|
DatagramSocket |
DatagramSocket.blockMulticastGroup(String multicastAddress,
String sourceToBlock,
Handler<AsyncResult<Void>> handler)
Block the given address for the given multicast address and notifies the
Handler once
the operation completes. |
DatagramSocket |
DatagramSocket.blockMulticastGroup(String multicastAddress,
String networkInterface,
String sourceToBlock,
Handler<AsyncResult<Void>> handler)
Block the given address for the given multicast address on the given network interface and notifies
the
Handler once the operation completes. |
void |
DatagramSocket.close(Handler<AsyncResult<Void>> handler)
Closes the
DatagramSocket implementation asynchronous
and notifies the handler once done. |
DatagramSocket |
DatagramSocket.endHandler(Handler<Void> endHandler) |
DatagramSocket |
DatagramSocket.exceptionHandler(Handler<Throwable> handler) |
DatagramSocket |
DatagramSocket.handler(Handler<DatagramPacket> handler) |
DatagramSocket |
DatagramSocket.listen(int port,
String host,
Handler<AsyncResult<DatagramSocket>> handler)
Start listening on the given port and host.
|
DatagramSocket |
DatagramSocket.listenMulticastGroup(String multicastAddress,
Handler<AsyncResult<Void>> handler)
Joins a multicast group and listens for packets send to it.
|
DatagramSocket |
DatagramSocket.listenMulticastGroup(String multicastAddress,
String networkInterface,
String source,
Handler<AsyncResult<Void>> handler)
Joins a multicast group and listens for packets send to it on the given network interface.
|
DatagramSocket |
DatagramSocket.send(Buffer packet,
int port,
String host,
Handler<AsyncResult<Void>> handler)
Write the given
Buffer to the SocketAddress . |
DatagramSocket |
DatagramSocket.send(String str,
int port,
String host,
Handler<AsyncResult<Void>> handler)
Write the given
String to the SocketAddress using UTF8 encoding. |
DatagramSocket |
DatagramSocket.send(String str,
String enc,
int port,
String host,
Handler<AsyncResult<Void>> handler)
Write the given
String to the SocketAddress using the given encoding. |
DatagramSocket |
DatagramSocket.unlistenMulticastGroup(String multicastAddress,
Handler<AsyncResult<Void>> handler)
Leaves a multicast group and stops listening for packets send to it.
|
DatagramSocket |
DatagramSocket.unlistenMulticastGroup(String multicastAddress,
String networkInterface,
String source,
Handler<AsyncResult<Void>> handler)
Leaves a multicast group and stops listening for packets send to it on the given network interface.
|
Modifier and Type | Method and Description |
---|---|
DnsClient |
DnsClient.lookup(String name,
Handler<AsyncResult<String>> handler)
Try to lookup the A (ipv4) or AAAA (ipv6) record for the given name.
|
DnsClient |
DnsClient.lookup4(String name,
Handler<AsyncResult<String>> handler)
Try to lookup the A (ipv4) record for the given name.
|
DnsClient |
DnsClient.lookup6(String name,
Handler<AsyncResult<String>> handler)
Try to lookup the AAAA (ipv6) record for the given name.
|
DnsClient |
DnsClient.resolveA(String name,
Handler<AsyncResult<List<String>>> handler)
Try to resolve all A (ipv4) records for the given name.
|
DnsClient |
DnsClient.resolveAAAA(String name,
Handler<AsyncResult<List<String>>> handler)
Try to resolve all AAAA (ipv6) records for the given name.
|
DnsClient |
DnsClient.resolveCNAME(String name,
Handler<AsyncResult<List<String>>> handler)
Try to resolve the CNAME record for the given name.
|
DnsClient |
DnsClient.resolveMX(String name,
Handler<AsyncResult<List<MxRecord>>> handler)
Try to resolve the MX records for the given name.
|
DnsClient |
DnsClient.resolveNS(String name,
Handler<AsyncResult<List<String>>> handler)
Try to resolve the NS records for the given name.
|
DnsClient |
DnsClient.resolvePTR(String name,
Handler<AsyncResult<String>> handler)
Try to resolve the PTR record for the given name.
|
DnsClient |
DnsClient.resolveSRV(String name,
Handler<AsyncResult<List<SrvRecord>>> handler)
Try to resolve the SRV records for the given name.
|
DnsClient |
DnsClient.resolveTXT(String name,
Handler<AsyncResult<List<String>>> handler)
Try to resolve the TXT records for the given name.
|
DnsClient |
DnsClient.reverseLookup(String ipaddress,
Handler<AsyncResult<String>> handler)
Try to do a reverse lookup of an IP address.
|
Modifier and Type | Method and Description |
---|---|
<T> EventBus |
EventBus.addInboundInterceptor(Handler<DeliveryContext<T>> interceptor)
Add an interceptor that will be called whenever a message is received by Vert.x
|
<T> EventBus |
EventBus.addOutboundInterceptor(Handler<DeliveryContext<T>> interceptor)
Add an interceptor that will be called whenever a message is sent from Vert.x
|
void |
MessageProducer.close(Handler<AsyncResult<Void>> handler)
Same as
MessageProducer.close() but with an handler called when the operation completes |
void |
MessageConsumer.completionHandler(Handler<AsyncResult<Void>> completionHandler)
Optional method which can be called to indicate when the registration has been propagated across the cluster.
|
<T> MessageConsumer<T> |
EventBus.consumer(String address,
Handler<Message<T>> handler)
Create a consumer and register it against the specified address.
|
MessageConsumer<T> |
MessageConsumer.endHandler(Handler<Void> endHandler) |
MessageConsumer<T> |
MessageConsumer.exceptionHandler(Handler<Throwable> handler) |
MessageConsumer<T> |
MessageConsumer.handler(Handler<Message<T>> handler) |
<T> MessageConsumer<T> |
EventBus.localConsumer(String address,
Handler<Message<T>> handler)
Like
EventBus.consumer(String, Handler) but the address won't be propagated across the cluster. |
<T> EventBus |
EventBus.removeInboundInterceptor(Handler<DeliveryContext<T>> interceptor)
Remove an interceptor that was added by
EventBus.addInboundInterceptor(Handler) |
<T> EventBus |
EventBus.removeOutboundInterceptor(Handler<DeliveryContext<T>> interceptor)
Remove an interceptor that was added by
EventBus.addOutboundInterceptor(Handler) |
default <R> void |
Message.replyAndRequest(Object message,
DeliveryOptions options,
Handler<AsyncResult<Message<R>>> replyHandler)
Like
Message.replyAndRequest(Object, Handler) but specifying options that can be used
to configure the delivery. |
default <R> void |
Message.replyAndRequest(Object message,
Handler<AsyncResult<Message<R>>> replyHandler)
Reply to this message, specifying a
replyHandler for the reply - i.e. |
default <T> EventBus |
EventBus.request(String address,
Object message,
DeliveryOptions options,
Handler<AsyncResult<Message<T>>> replyHandler)
Like
EventBus.request(String, Object, Handler) but specifying options that can be used to configure the delivery. |
default <T> EventBus |
EventBus.request(String address,
Object message,
Handler<AsyncResult<Message<T>>> replyHandler)
Sends a message and specify a
replyHandler that will be called if the recipient
subsequently replies to the message. |
void |
MessageConsumer.unregister(Handler<AsyncResult<Void>> completionHandler)
Unregisters the handler which created this registration
|
void |
MessageProducer.write(T body,
Handler<AsyncResult<Void>> handler)
Write a message to the event-bus, either sending or publishing.
|
Modifier and Type | Method and Description |
---|---|
FileSystem |
FileSystem.chmod(String path,
String perms,
Handler<AsyncResult<Void>> handler)
Change the permissions on the file represented by
path to perms , asynchronously. |
FileSystem |
FileSystem.chmodRecursive(String path,
String perms,
String dirPerms,
Handler<AsyncResult<Void>> handler)
Change the permissions on the file represented by
path to perms , asynchronously. |
FileSystem |
FileSystem.chown(String path,
String user,
String group,
Handler<AsyncResult<Void>> handler)
Change the ownership on the file represented by
path to user and {code group}, asynchronously. |
void |
AsyncFile.close(Handler<AsyncResult<Void>> handler)
Close the file.
|
FileSystem |
FileSystem.copy(String from,
String to,
CopyOptions options,
Handler<AsyncResult<Void>> handler)
Copy a file from the path
from to path to , asynchronously. |
FileSystem |
FileSystem.copy(String from,
String to,
Handler<AsyncResult<Void>> handler)
Copy a file from the path
from to path to , asynchronously. |
FileSystem |
FileSystem.copyRecursive(String from,
String to,
boolean recursive,
Handler<AsyncResult<Void>> handler)
Copy a file from the path
from to path to , asynchronously. |
FileSystem |
FileSystem.createFile(String path,
Handler<AsyncResult<Void>> handler)
Creates an empty file with the specified
path , asynchronously. |
FileSystem |
FileSystem.createFile(String path,
String perms,
Handler<AsyncResult<Void>> handler)
Creates an empty file with the specified
path and permissions perms , asynchronously. |
FileSystem |
FileSystem.createTempDirectory(String prefix,
Handler<AsyncResult<String>> handler)
Creates a new directory in the default temporary-file directory, using the given
prefix to generate its name, asynchronously.
|
FileSystem |
FileSystem.createTempDirectory(String prefix,
String perms,
Handler<AsyncResult<String>> handler)
Creates a new directory in the default temporary-file directory, using the given
prefix to generate its name, asynchronously.
|
FileSystem |
FileSystem.createTempDirectory(String dir,
String prefix,
String perms,
Handler<AsyncResult<String>> handler)
Creates a new directory in the directory provided by the path
path , using the given
prefix to generate its name, asynchronously. |
FileSystem |
FileSystem.createTempFile(String prefix,
String suffix,
Handler<AsyncResult<String>> handler)
Creates a new file in the default temporary-file directory, using the given
prefix and suffix to generate its name, asynchronously.
|
FileSystem |
FileSystem.createTempFile(String prefix,
String suffix,
String perms,
Handler<AsyncResult<String>> handler)
Creates a new file in the directory provided by the path
dir , using the given
prefix and suffix to generate its name, asynchronously. |
FileSystem |
FileSystem.createTempFile(String dir,
String prefix,
String suffix,
String perms,
Handler<AsyncResult<String>> handler)
Creates a new file in the directory provided by the path
dir , using the given
prefix and suffix to generate its name, asynchronously. |
FileSystem |
FileSystem.delete(String path,
Handler<AsyncResult<Void>> handler)
Deletes the file represented by the specified
path , asynchronously. |
FileSystem |
FileSystem.deleteRecursive(String path,
boolean recursive,
Handler<AsyncResult<Void>> handler)
Deletes the file represented by the specified
path , asynchronously. |
AsyncFile |
AsyncFile.drainHandler(Handler<Void> handler) |
AsyncFile |
AsyncFile.endHandler(Handler<Void> endHandler) |
AsyncFile |
AsyncFile.exceptionHandler(Handler<Throwable> handler) |
FileSystem |
FileSystem.exists(String path,
Handler<AsyncResult<Boolean>> handler)
Determines whether the file as specified by the path
path exists, asynchronously. |
AsyncFile |
AsyncFile.flush(Handler<AsyncResult<Void>> handler)
Same as
AsyncFile.flush() but the handler will be called when the flush is complete or if an error occurs |
FileSystem |
FileSystem.fsProps(String path,
Handler<AsyncResult<FileSystemProps>> handler)
Returns properties of the file-system being used by the specified
path , asynchronously. |
AsyncFile |
AsyncFile.handler(Handler<Buffer> handler) |
void |
AsyncFileLock.isValid(Handler<AsyncResult<Boolean>> handler)
Like
AsyncFileLock.isValid() but the handler will be called when the operation completes or if an error occurs. |
FileSystem |
FileSystem.link(String link,
String existing,
Handler<AsyncResult<Void>> handler)
Create a hard link on the file system from
link to existing , asynchronously. |
void |
AsyncFile.lock(Handler<AsyncResult<AsyncFileLock>> handler)
Like
AsyncFile.lock() but the handler will be called when the operation is complete or if an error occurs. |
void |
AsyncFile.lock(long position,
long size,
boolean shared,
Handler<AsyncResult<AsyncFileLock>> handler)
Like
AsyncFile.lock(long, long, boolean) but the handler will be called when the operation is complete or if an error occurs. |
FileSystem |
FileSystem.lprops(String path,
Handler<AsyncResult<FileProps>> handler)
Obtain properties for the link represented by
path , asynchronously. |
FileSystem |
FileSystem.mkdir(String path,
Handler<AsyncResult<Void>> handler)
Create the directory represented by
path , asynchronously. |
FileSystem |
FileSystem.mkdir(String path,
String perms,
Handler<AsyncResult<Void>> handler)
Create the directory represented by
path , asynchronously. |
FileSystem |
FileSystem.mkdirs(String path,
Handler<AsyncResult<Void>> handler)
Create the directory represented by
path and any non existent parents, asynchronously. |
FileSystem |
FileSystem.mkdirs(String path,
String perms,
Handler<AsyncResult<Void>> handler)
Create the directory represented by
path and any non existent parents, asynchronously. |
FileSystem |
FileSystem.move(String from,
String to,
CopyOptions options,
Handler<AsyncResult<Void>> handler)
Move a file from the path
from to path to , asynchronously. |
FileSystem |
FileSystem.move(String from,
String to,
Handler<AsyncResult<Void>> handler)
Move a file from the path
from to path to , asynchronously. |
FileSystem |
FileSystem.open(String path,
OpenOptions options,
Handler<AsyncResult<AsyncFile>> handler)
Open the file represented by
path , asynchronously. |
FileSystem |
FileSystem.props(String path,
Handler<AsyncResult<FileProps>> handler)
Obtain properties for the file represented by
path , asynchronously. |
AsyncFile |
AsyncFile.read(Buffer buffer,
int offset,
long position,
int length,
Handler<AsyncResult<Buffer>> handler)
Reads
length bytes of data from the file at position position in the file, asynchronously. |
FileSystem |
FileSystem.readDir(String path,
Handler<AsyncResult<List<String>>> handler)
Read the contents of the directory specified by
path , asynchronously. |
FileSystem |
FileSystem.readDir(String path,
String filter,
Handler<AsyncResult<List<String>>> handler)
Read the contents of the directory specified by
path , asynchronously. |
FileSystem |
FileSystem.readFile(String path,
Handler<AsyncResult<Buffer>> handler)
Reads the entire file as represented by the path
path as a Buffer , asynchronously. |
FileSystem |
FileSystem.readSymlink(String link,
Handler<AsyncResult<String>> handler)
Returns the path representing the file that the symbolic link specified by
link points to, asynchronously. |
void |
AsyncFileLock.release(Handler<AsyncResult<Void>> handler)
Like
AsyncFileLock.release() but the handler will be called when the operation completes or if an error occurs. |
default void |
AsyncFile.size(Handler<AsyncResult<Long>> handler)
Like
AsyncFile.size() but the handler will be called when the operation is complete or if an error occurs. |
FileSystem |
FileSystem.symlink(String link,
String existing,
Handler<AsyncResult<Void>> handler)
Create a symbolic link on the file system from
link to existing , asynchronously. |
FileSystem |
FileSystem.truncate(String path,
long len,
Handler<AsyncResult<Void>> handler)
Truncate the file represented by
path to length len in bytes, asynchronously. |
FileSystem |
FileSystem.unlink(String link,
Handler<AsyncResult<Void>> handler)
Unlinks the link on the file system represented by the path
link , asynchronously. |
void |
AsyncFile.write(Buffer buffer,
long position,
Handler<AsyncResult<Void>> handler)
Write a
Buffer to the file at position position in the file, asynchronously. |
FileSystem |
FileSystem.writeFile(String path,
Buffer data,
Handler<AsyncResult<Void>> handler)
Creates the file, and writes the specified
Buffer data to the file represented by the path path ,
asynchronously. |
Modifier and Type | Field and Description |
---|---|
static Handler<HttpServerRequest> |
HttpServerRequest.DEFAULT_INVALID_REQUEST_HANDLER
The default invalid request handler, it uses the
HttpServerRequest.decoderResult() cause and the request information
to determine the status code of the response to be sent. |
Modifier and Type | Method and Description |
---|---|
Handler<HttpServerRequest> |
HttpServer.requestHandler() |
Handler<ServerWebSocket> |
HttpServer.webSocketHandler() |
Modifier and Type | Method and Description |
---|---|
WebSocketBase |
WebSocketBase.binaryMessageHandler(Handler<Buffer> handler)
Set a binary message handler on the connection.
|
default HttpClientResponse |
HttpClientResponse.body(Handler<AsyncResult<Buffer>> handler)
Same as
HttpClientResponse.body() but with an handler called when the operation completes |
default HttpServerRequest |
HttpServerRequest.body(Handler<AsyncResult<Buffer>> handler)
Same as
HttpServerRequest.body() but with an handler called when the operation completes |
HttpServerResponse |
HttpServerResponse.bodyEndHandler(Handler<Void> handler)
Provides a handler that will be called after the last part of the body is written to the wire.
|
default HttpClientResponse |
HttpClientResponse.bodyHandler(Handler<Buffer> bodyHandler)
Convenience method for receiving the entire request body in one piece.
|
default HttpServerRequest |
HttpServerRequest.bodyHandler(Handler<Buffer> bodyHandler)
Convenience method for receiving the entire request body in one piece.
|
void |
HttpServer.close(Handler<AsyncResult<Void>> completionHandler)
Like
HttpServer.close() but supplying a handler that will be called when the server is actually closed (or has failed). |
default void |
HttpConnection.close(Handler<AsyncResult<Void>> handler)
Close the connection and all the currently active streams.
|
void |
HttpClient.close(Handler<AsyncResult<Void>> handler)
Close the client.
|
void |
WebSocketBase.close(Handler<AsyncResult<Void>> handler)
Same as
WebSocketBase.close() but with an handler called when the operation completes |
void |
WebSocketBase.close(short statusCode,
Handler<AsyncResult<Void>> handler)
Same as
WebSocketBase.close(short) but with an handler called when the operation completes |
void |
WebSocketBase.close(short statusCode,
String reason,
Handler<AsyncResult<Void>> handler)
Same as
WebSocketBase.close(short, String) but with an handler called when the operation completes |
HttpServerResponse |
HttpServerResponse.closeHandler(Handler<Void> handler)
Set a close handler for the response, this is called when the underlying connection is closed and the response
was still using the connection.
|
ServerWebSocket |
ServerWebSocket.closeHandler(Handler<Void> handler) |
WebSocket |
WebSocket.closeHandler(Handler<Void> handler) |
HttpConnection |
HttpConnection.closeHandler(Handler<Void> handler)
Set a close handler.
|
WebSocketBase |
WebSocketBase.closeHandler(Handler<Void> handler)
Set a close handler.
|
void |
HttpClientRequest.connect(Handler<AsyncResult<HttpClientResponse>> handler)
Create an HTTP tunnel to the server.
|
HttpServer |
HttpServer.connectionHandler(Handler<HttpConnection> handler)
Set a connection handler for the server.
|
HttpClient |
HttpClient.connectionHandler(Handler<HttpConnection> handler)
Set a connection handler for the client.
|
HttpClientRequest |
HttpClientRequest.continueHandler(Handler<Void> handler)
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. |
HttpClientResponse |
HttpClientResponse.customFrameHandler(Handler<HttpFrame> handler)
Set an custom frame handler.
|
HttpServerRequest |
HttpServerRequest.customFrameHandler(Handler<HttpFrame> handler)
Set a custom frame handler.
|
HttpServerResponse |
HttpServerResponse.drainHandler(Handler<Void> handler) |
ServerWebSocket |
ServerWebSocket.drainHandler(Handler<Void> handler) |
HttpClientRequest |
HttpClientRequest.drainHandler(Handler<Void> handler) |
WebSocket |
WebSocket.drainHandler(Handler<Void> handler) |
WebSocketBase |
WebSocketBase.drainHandler(Handler<Void> handler) |
void |
HttpServerResponse.end(Buffer chunk,
Handler<AsyncResult<Void>> handler)
Same as
HttpServerResponse.end(Buffer) but with an handler called when the operation completes |
void |
HttpClientRequest.end(Buffer chunk,
Handler<AsyncResult<Void>> handler)
Same as
HttpClientRequest.end(String) but with an handler called when the operation completes |
default void |
HttpClientResponse.end(Handler<AsyncResult<Void>> handler)
Same as
HttpClientResponse.end() but with an handler called when the operation completes |
void |
HttpClientRequest.end(Handler<AsyncResult<Void>> handler)
Same as
HttpClientRequest.end() but with an handler called when the operation completes |
default void |
HttpServerRequest.end(Handler<AsyncResult<Void>> handler)
Same as
HttpServerRequest.end() but with an handler called when the operation completes |
void |
WebSocketBase.end(Handler<AsyncResult<Void>> handler)
Same as
WriteStream.end() but with an handler called when the operation completes |
void |
HttpServerResponse.end(String chunk,
Handler<AsyncResult<Void>> handler)
Same as
HttpServerResponse.end(String) but with an handler called when the operation completes |
void |
HttpClientRequest.end(String chunk,
Handler<AsyncResult<Void>> handler)
Same as
HttpClientRequest.end(String) but with an handler called when the operation completes |
void |
HttpServerResponse.end(String chunk,
String enc,
Handler<AsyncResult<Void>> handler)
Same as
HttpServerResponse.end(String, String) but with an handler called when the operation completes |
void |
HttpClientRequest.end(String chunk,
String enc,
Handler<AsyncResult<Void>> handler)
Same as
HttpClientRequest.end(String,String) but with an handler called when the operation completes |
HttpClientResponse |
HttpClientResponse.endHandler(Handler<Void> endHandler) |
HttpServerResponse |
HttpServerResponse.endHandler(Handler<Void> handler)
Set an end handler for the response.
|
ServerWebSocket |
ServerWebSocket.endHandler(Handler<Void> endHandler) |
WebSocket |
WebSocket.endHandler(Handler<Void> endHandler) |
HttpServerFileUpload |
HttpServerFileUpload.endHandler(Handler<Void> endHandler) |
HttpServerRequest |
HttpServerRequest.endHandler(Handler<Void> endHandler) |
WebSocketBase |
WebSocketBase.endHandler(Handler<Void> endHandler) |
HttpClientResponse |
HttpClientResponse.exceptionHandler(Handler<Throwable> handler) |
HttpServerResponse |
HttpServerResponse.exceptionHandler(Handler<Throwable> handler) |
ServerWebSocket |
ServerWebSocket.exceptionHandler(Handler<Throwable> handler) |
HttpServer |
HttpServer.exceptionHandler(Handler<Throwable> handler)
Set an exception handler called for socket errors happening before the HTTP connection
is established, e.g during the TLS handshake.
|
HttpClientRequest |
HttpClientRequest.exceptionHandler(Handler<Throwable> handler) |
WebSocket |
WebSocket.exceptionHandler(Handler<Throwable> handler) |
HttpConnection |
HttpConnection.exceptionHandler(Handler<Throwable> handler)
Set an handler called when a connection error happens
|
HttpServerFileUpload |
HttpServerFileUpload.exceptionHandler(Handler<Throwable> handler) |
HttpServerRequest |
HttpServerRequest.exceptionHandler(Handler<Throwable> handler) |
WebSocketBase |
WebSocketBase.exceptionHandler(Handler<Throwable> handler) |
ServerWebSocket |
ServerWebSocket.frameHandler(Handler<WebSocketFrame> handler) |
WebSocket |
WebSocket.frameHandler(Handler<WebSocketFrame> handler) |
WebSocketBase |
WebSocketBase.frameHandler(Handler<WebSocketFrame> handler)
Set a frame handler on the connection.
|
HttpConnection |
HttpConnection.goAwayHandler(Handler<GoAway> handler)
Set an handler called when a GOAWAY frame is received.
|
HttpClientResponse |
HttpClientResponse.handler(Handler<Buffer> handler) |
ServerWebSocket |
ServerWebSocket.handler(Handler<Buffer> handler) |
WebSocket |
WebSocket.handler(Handler<Buffer> handler) |
HttpServerFileUpload |
HttpServerFileUpload.handler(Handler<Buffer> handler) |
HttpServerRequest |
HttpServerRequest.handler(Handler<Buffer> handler) |
WebSocketBase |
WebSocketBase.handler(Handler<Buffer> handler) |
HttpServerResponse |
HttpServerResponse.headersEndHandler(Handler<Void> handler)
Provide a handler that will be called just before the headers are written to the wire.
|
HttpServer |
HttpServer.invalidRequestHandler(Handler<HttpServerRequest> handler)
Set a
handler for handling invalid requests. |
default HttpServer |
HttpServer.listen(Handler<AsyncResult<HttpServer>> listenHandler)
Like
HttpServer.listen() but supplying a handler that will be called when the server is actually listening (or has failed). |
default HttpServer |
HttpServer.listen(int port,
Handler<AsyncResult<HttpServer>> listenHandler)
Like
HttpServer.listen(int) but supplying a handler that will be called when the server is actually listening (or has failed). |
default HttpServer |
HttpServer.listen(int port,
String host,
Handler<AsyncResult<HttpServer>> listenHandler)
Like
HttpServer.listen(int, String) but supplying a handler that will be called when the server is actually
listening (or has failed). |
default HttpServer |
HttpServer.listen(SocketAddress address,
Handler<AsyncResult<HttpServer>> listenHandler)
Tell the server to start listening on the given address supplying
a handler that will be called when the server is actually
listening (or has failed).
|
HttpConnection |
HttpConnection.ping(Buffer data,
Handler<AsyncResult<Buffer>> pongHandler)
Send a PING frame to the remote endpoint.
|
HttpConnection |
HttpConnection.pingHandler(Handler<Buffer> handler)
Set an handler notified when a PING frame is received from the remote endpoint.
|
WebSocketBase |
WebSocketBase.pongHandler(Handler<Buffer> handler)
Set a pong frame handler on the connection.
|
default HttpServerResponse |
HttpServerResponse.push(HttpMethod method,
String path,
Handler<AsyncResult<HttpServerResponse>> handler)
Like
HttpServerResponse.push(HttpMethod, String, String, MultiMap, Handler) with the host copied from the current request. |
default HttpServerResponse |
HttpServerResponse.push(HttpMethod method,
String path,
MultiMap headers,
Handler<AsyncResult<HttpServerResponse>> handler)
Like
HttpServerResponse.push(HttpMethod, String, String, MultiMap, Handler) with the host copied from the current request. |
default HttpServerResponse |
HttpServerResponse.push(HttpMethod method,
String host,
String path,
Handler<AsyncResult<HttpServerResponse>> handler)
Like
HttpServerResponse.push(HttpMethod, String, String, MultiMap, Handler) with no headers. |
default HttpServerResponse |
HttpServerResponse.push(HttpMethod method,
String host,
String path,
MultiMap headers,
Handler<AsyncResult<HttpServerResponse>> handler)
Push a response to the client.
The
handler will be notified with a success when the push can be sent and with
a failure when the client has disabled push or reset the push before it has been sent.
The handler may be queued if the client has reduced the maximum number of streams the server can push
concurrently.
Push can be sent only for peer initiated streams and if the response is not ended. |
HttpClientRequest |
HttpClientRequest.pushHandler(Handler<HttpClientRequest> handler)
Set a push handler for this request.
The handler is called when the client receives a push promise from the server.
|
HttpConnection |
HttpConnection.remoteSettingsHandler(Handler<Http2Settings> handler)
Set an handler that is called when remote endpoint
Http2Settings are updated. |
void |
HttpClient.request(HttpMethod method,
int port,
String host,
String requestURI,
Handler<AsyncResult<HttpClientRequest>> handler)
Create an HTTP request to send to the server at the
host and port . |
void |
HttpClient.request(HttpMethod method,
String requestURI,
Handler<AsyncResult<HttpClientRequest>> handler)
Create an HTTP request to send to the server at the default host and port.
|
void |
HttpClient.request(HttpMethod method,
String host,
String requestURI,
Handler<AsyncResult<HttpClientRequest>> handler)
Create an HTTP request to send to the server at the
host and default port. |
void |
HttpClient.request(RequestOptions options,
Handler<AsyncResult<HttpClientRequest>> handler)
Create an HTTP request to send to the server.
|
HttpServer |
HttpServer.requestHandler(Handler<HttpServerRequest> handler)
Set the request handler for the server to
requestHandler . |
HttpClientRequest |
HttpClientRequest.response(Handler<AsyncResult<HttpClientResponse>> handler)
Set a callback for the associated
HttpClientResponse . |
default void |
HttpClientRequest.send(Buffer body,
Handler<AsyncResult<HttpClientResponse>> handler)
Send the request with a buffer
body . |
default void |
HttpServerResponse.send(Buffer body,
Handler<AsyncResult<Void>> handler)
Send the request with a buffer
body . |
default void |
HttpClientRequest.send(Handler<AsyncResult<HttpClientResponse>> handler)
Send the request with an empty body.
|
default void |
HttpServerResponse.send(Handler<AsyncResult<Void>> handler)
Send the request with an empty body.
|
default void |
HttpClientRequest.send(ReadStream<Buffer> body,
Handler<AsyncResult<HttpClientResponse>> handler)
Send the request with a stream
body . |
default void |
HttpServerResponse.send(ReadStream<Buffer> body,
Handler<AsyncResult<Void>> handler)
Send the request with a stream
body . |
default void |
HttpClientRequest.send(String body,
Handler<AsyncResult<HttpClientResponse>> handler)
Send the request with a string
body . |
default void |
HttpServerResponse.send(String body,
Handler<AsyncResult<Void>> handler)
Send the request with a string
body . |
default HttpServerResponse |
HttpServerResponse.sendFile(String filename,
Handler<AsyncResult<Void>> resultHandler)
Like
HttpServerResponse.sendFile(String) but providing a handler which will be notified once the file has been completely
written to the wire. |
default HttpServerResponse |
HttpServerResponse.sendFile(String filename,
long offset,
Handler<AsyncResult<Void>> resultHandler)
Like
HttpServerResponse.sendFile(String, long) but providing a handler which will be notified once the file has been completely
written to the wire. |
HttpServerResponse |
HttpServerResponse.sendFile(String filename,
long offset,
long length,
Handler<AsyncResult<Void>> resultHandler)
Like
HttpServerResponse.sendFile(String, long, long) but providing a handler which will be notified once the file has been
completely written to the wire. |
HttpClientRequest |
HttpClientRequest.sendHead(Handler<AsyncResult<Void>> completionHandler)
Like
HttpClientRequest.sendHead() but with an handler after headers have been sent. |
void |
ServerWebSocket.setHandshake(Future<Integer> future,
Handler<AsyncResult<Integer>> handler)
Set an asynchronous result for the handshake, upon completion of the specified
future , the
WebSocket will either be
accepted when the future succeeds with the HTTP 101 status code
rejected when the future is succeeds with an HTTP status code different than 101
rejected when the future fails with the HTTP status code 500
The provided future might be completed by the WebSocket itself, e.g calling the ServerWebSocket.close() method
will try to accept the handshake and close the WebSocket afterward. |
default void |
HttpConnection.shutdown(Handler<AsyncResult<Void>> handler)
Initiate a graceful connection shutdown, the connection is taken out of service and closed when all current requests
are processed, otherwise after 30 seconds the connection will be closed.
|
void |
HttpConnection.shutdown(long timeout,
Handler<AsyncResult<Void>> handler)
Like
HttpConnection.shutdown(Handler) but with a specific timeout in milliseconds. |
HttpConnection |
HttpConnection.shutdownHandler(Handler<Void> handler)
Set an handler called when a GOAWAY frame has been sent or received and all connections are closed.
|
HttpClientResponse |
HttpClientResponse.streamPriorityHandler(Handler<StreamPriority> handler)
Set an handler for stream priority changes.
|
HttpServerRequest |
HttpServerRequest.streamPriorityHandler(Handler<StreamPriority> handler)
Set an handler for stream priority changes
|
void |
HttpServerFileUpload.streamToFileSystem(String filename,
Handler<AsyncResult<Void>> handler)
Stream the content of this upload to the given file on storage.
|
WebSocketBase |
WebSocketBase.textMessageHandler(Handler<String> handler)
Set a text message handler on the connection.
|
default void |
HttpServerRequest.toNetSocket(Handler<AsyncResult<NetSocket>> handler)
Establish a TCP tunnel with the client.
|
default void |
HttpServerRequest.toWebSocket(Handler<AsyncResult<ServerWebSocket>> handler)
Upgrade the connection of the current request to a WebSocket.
|
HttpConnection |
HttpConnection.updateSettings(Http2Settings settings,
Handler<AsyncResult<Void>> completionHandler)
Send to the remote endpoint an update of this endpoint settings
The
completionHandler will be notified when the remote endpoint has acknowledged the settings. |
HttpServerRequest |
HttpServerRequest.uploadHandler(Handler<HttpServerFileUpload> uploadHandler)
Set an upload handler.
|
void |
HttpClient.webSocket(int port,
String host,
String requestURI,
Handler<AsyncResult<WebSocket>> handler)
Connect a WebSocket to the specified port, host and relative request URI
|
void |
HttpClient.webSocket(String requestURI,
Handler<AsyncResult<WebSocket>> handler)
Connect a WebSocket at the relative request URI using the default host and port
|
void |
HttpClient.webSocket(String host,
String requestURI,
Handler<AsyncResult<WebSocket>> handler)
Connect a WebSocket to the host and relative request URI and default port
|
void |
HttpClient.webSocket(WebSocketConnectOptions options,
Handler<AsyncResult<WebSocket>> handler)
Connect a WebSocket with the specified options.
|
void |
HttpClient.webSocketAbs(String url,
MultiMap headers,
WebsocketVersion version,
List<String> subProtocols,
Handler<AsyncResult<WebSocket>> handler)
Connect a WebSocket with the specified absolute url, with the specified headers, using
the specified version of WebSockets, and the specified WebSocket sub protocols.
|
HttpServer |
HttpServer.webSocketHandler(Handler<ServerWebSocket> handler)
Set the WebSocket handler for the server to
wsHandler . |
void |
HttpServerResponse.write(String chunk,
Handler<AsyncResult<Void>> handler)
Same as
HttpServerResponse.write(String) but with an handler called when the operation completes |
void |
HttpClientRequest.write(String chunk,
Handler<AsyncResult<Void>> handler)
Same as
HttpClientRequest.write(String) but with an handler called when the operation completes |
void |
HttpServerResponse.write(String chunk,
String enc,
Handler<AsyncResult<Void>> handler)
Same as
HttpServerResponse.write(String, String) but with an handler called when the operation completes |
void |
HttpClientRequest.write(String chunk,
String enc,
Handler<AsyncResult<Void>> handler)
Same as
HttpClientRequest.write(String,String) but with an handler called when the operation completes |
ServerWebSocket |
ServerWebSocket.writeBinaryMessage(Buffer data,
Handler<AsyncResult<Void>> handler) |
WebSocket |
WebSocket.writeBinaryMessage(Buffer data,
Handler<AsyncResult<Void>> handler) |
WebSocketBase |
WebSocketBase.writeBinaryMessage(Buffer data,
Handler<AsyncResult<Void>> handler)
Same as
WebSocketBase.writeBinaryMessage(Buffer) but with an handler called when the operation completes |
ServerWebSocket |
ServerWebSocket.writeFinalBinaryFrame(Buffer data,
Handler<AsyncResult<Void>> handler) |
WebSocket |
WebSocket.writeFinalBinaryFrame(Buffer data,
Handler<AsyncResult<Void>> handler) |
WebSocketBase |
WebSocketBase.writeFinalBinaryFrame(Buffer data,
Handler<AsyncResult<Void>> handler)
Same as
WebSocketBase.writeFinalBinaryFrame(Buffer, Handler) but with an handler called when the operation completes |
ServerWebSocket |
ServerWebSocket.writeFinalTextFrame(String text,
Handler<AsyncResult<Void>> handler) |
WebSocket |
WebSocket.writeFinalTextFrame(String text,
Handler<AsyncResult<Void>> handler) |
WebSocketBase |
WebSocketBase.writeFinalTextFrame(String text,
Handler<AsyncResult<Void>> handler)
Same as
WebSocketBase.writeFinalTextFrame(String, Handler) but with an handler called when the operation completes |
ServerWebSocket |
ServerWebSocket.writeFrame(WebSocketFrame frame,
Handler<AsyncResult<Void>> handler) |
WebSocket |
WebSocket.writeFrame(WebSocketFrame frame,
Handler<AsyncResult<Void>> handler) |
WebSocketBase |
WebSocketBase.writeFrame(WebSocketFrame frame,
Handler<AsyncResult<Void>> handler)
Same as
WebSocketBase.writeFrame(WebSocketFrame) but with an handler called when the operation completes |
WebSocketBase |
WebSocketBase.writePing(Buffer data,
Handler<AsyncResult<Void>> handler)
Writes a ping frame to the connection.
|
WebSocketBase |
WebSocketBase.writePong(Buffer data,
Handler<AsyncResult<Void>> handler)
Writes a pong frame to the connection.
|
ServerWebSocket |
ServerWebSocket.writeTextMessage(String text,
Handler<AsyncResult<Void>> handler) |
WebSocket |
WebSocket.writeTextMessage(String text,
Handler<AsyncResult<Void>> handler) |
WebSocketBase |
WebSocketBase.writeTextMessage(String text,
Handler<AsyncResult<Void>> handler)
Same as
WebSocketBase.writeTextMessage(String) but with an handler called when the operation completes |
Modifier and Type | Method and Description |
---|---|
Handler<NetSocket> |
NetServer.connectHandler() |
Modifier and Type | Method and Description |
---|---|
void |
NetClient.close(Handler<AsyncResult<Void>> handler)
Close the client.
|
void |
NetSocket.close(Handler<AsyncResult<Void>> handler)
Close the NetSocket and notify the
handler when the operation completes. |
void |
NetServer.close(Handler<AsyncResult<Void>> completionHandler)
Like
NetServer.close() but supplying a handler that will be notified when close is complete. |
NetSocket |
NetSocket.closeHandler(Handler<Void> handler)
Set a handler that will be called when the NetSocket is closed
|
NetClient |
NetClient.connect(int port,
String host,
Handler<AsyncResult<NetSocket>> connectHandler)
Open a connection to a server at the specific
port and host . |
NetClient |
NetClient.connect(int port,
String host,
String serverName,
Handler<AsyncResult<NetSocket>> connectHandler)
Open a connection to a server at the specific
port and host . |
NetClient |
NetClient.connect(SocketAddress remoteAddress,
Handler<AsyncResult<NetSocket>> connectHandler)
Open a connection to a server at the specific
remoteAddress . |
NetClient |
NetClient.connect(SocketAddress remoteAddress,
String serverName,
Handler<AsyncResult<NetSocket>> connectHandler)
Open a connection to a server at the specific
remoteAddress . |
NetServer |
NetServer.connectHandler(Handler<NetSocket> handler)
Supply a connect handler for this server.
|
NetSocket |
NetSocket.drainHandler(Handler<Void> handler) |
void |
NetSocket.end(Handler<AsyncResult<Void>> handler)
Calls
NetSocket.end() . |
NetSocket |
NetSocket.endHandler(Handler<Void> endHandler)
Set an end handler.
|
NetSocket |
NetSocket.exceptionHandler(Handler<Throwable> handler) |
NetServer |
NetServer.exceptionHandler(Handler<Throwable> handler)
Set an exception handler called for socket errors happening before the connection
is passed to the
NetServer.connectHandler(io.vertx.core.Handler<io.vertx.core.net.NetSocket>) , e.g during the TLS handshake. |
NetSocket |
NetSocket.handler(Handler<Buffer> handler) |
default NetServer |
NetServer.listen(Handler<AsyncResult<NetServer>> listenHandler)
Like
NetServer.listen() but providing a handler that will be notified when the server is listening, or fails. |
default NetServer |
NetServer.listen(int port,
Handler<AsyncResult<NetServer>> listenHandler)
Like
NetServer.listen(int) but providing a handler that will be notified when the server is listening, or fails. |
default NetServer |
NetServer.listen(int port,
String host,
Handler<AsyncResult<NetServer>> listenHandler)
Like
NetServer.listen(int, String) but providing a handler that will be notified when the server is listening, or fails. |
default NetServer |
NetServer.listen(SocketAddress localAddress,
Handler<AsyncResult<NetServer>> listenHandler)
Like
NetServer.listen(SocketAddress) but providing a handler that will be notified when the server is listening, or fails. |
default NetSocket |
NetSocket.sendFile(String filename,
Handler<AsyncResult<Void>> resultHandler)
Same as
NetSocket.sendFile(String) but also takes a handler that will be called when the send has completed or
a failure has occurred |
default NetSocket |
NetSocket.sendFile(String filename,
long offset,
Handler<AsyncResult<Void>> resultHandler)
Same as
NetSocket.sendFile(String, long) but also takes a handler that will be called when the send has completed or
a failure has occurred |
NetSocket |
NetSocket.sendFile(String filename,
long offset,
long length,
Handler<AsyncResult<Void>> resultHandler)
Same as
NetSocket.sendFile(String, long, long) but also takes a handler that will be called when the send has completed or
a failure has occurred |
NetSocket |
NetSocket.upgradeToSsl(Handler<AsyncResult<Void>> handler)
Upgrade channel to use SSL/TLS.
|
NetSocket |
NetSocket.upgradeToSsl(String serverName,
Handler<AsyncResult<Void>> handler)
Upgrade channel to use SSL/TLS.
|
void |
NetSocket.write(Buffer message,
Handler<AsyncResult<Void>> handler)
Like
WriteStream.write(Object) but with an handler called when the message has been written
or failed to be written. |
void |
NetSocket.write(String str,
Handler<AsyncResult<Void>> handler)
Same as
NetSocket.write(String) but with an handler called when the operation completes |
void |
NetSocket.write(String str,
String enc,
Handler<AsyncResult<Void>> handler)
Same as
NetSocket.write(String, String) but with an handler called when the operation completes |
Modifier and Type | Interface and Description |
---|---|
interface |
JsonParser
A parser class which allows to incrementally parse json elements and emit json parse events instead of parsing a json
element fully.
|
interface |
RecordParser
A helper class which allows you to easily parse protocols which are delimited by a sequence of bytes, or fixed
size records.
|
Modifier and Type | Method and Description |
---|---|
RecordParser |
RecordParser.endHandler(Handler<Void> endHandler) |
JsonParser |
JsonParser.endHandler(Handler<Void> endHandler) |
RecordParser |
RecordParser.exceptionHandler(Handler<Throwable> handler) |
JsonParser |
JsonParser.exceptionHandler(Handler<Throwable> handler) |
RecordParser |
RecordParser.handler(Handler<Buffer> handler) |
JsonParser |
JsonParser.handler(Handler<JsonEvent> handler) |
static RecordParser |
RecordParser.newDelimited(Buffer delim,
Handler<Buffer> output)
Like
RecordParser.newDelimited(Buffer) but set the output that will receive whole records
which have been parsed. |
static RecordParser |
RecordParser.newDelimited(String delim,
Handler<Buffer> output)
Like
RecordParser.newDelimited(String) but set the output that will receive whole records
which have been parsed. |
static RecordParser |
RecordParser.newFixed(int size,
Handler<Buffer> output)
Like
RecordParser.newFixed(int) but set the output that will receive whole records
which have been parsed. |
void |
RecordParser.setOutput(Handler<Buffer> output) |
Modifier and Type | Method and Description |
---|---|
default void |
Counter.addAndGet(long value,
Handler<AsyncResult<Long>> resultHandler)
Add the value to the counter atomically and return the new count
|
default void |
AsyncMap.clear(Handler<AsyncResult<Void>> resultHandler)
Clear all entries in the map
|
default void |
Counter.compareAndSet(long expected,
long value,
Handler<AsyncResult<Boolean>> resultHandler)
Set the counter to the specified value only if the current value is the expectec value.
|
default void |
Counter.decrementAndGet(Handler<AsyncResult<Long>> resultHandler)
Decrement the counter atomically and return the new count
|
default void |
AsyncMap.entries(Handler<AsyncResult<Map<K,V>>> resultHandler)
Get the entries of the map, asynchronously.
|
default void |
Counter.get(Handler<AsyncResult<Long>> resultHandler)
Get the current value of the counter
|
default void |
AsyncMap.get(K k,
Handler<AsyncResult<V>> resultHandler)
Get a value from the map, asynchronously.
|
default void |
Counter.getAndAdd(long value,
Handler<AsyncResult<Long>> resultHandler)
Add the value to the counter atomically and return the value before the add
|
default void |
Counter.getAndIncrement(Handler<AsyncResult<Long>> resultHandler)
Increment the counter atomically and return the value before the increment.
|
<K,V> void |
SharedData.getAsyncMap(String name,
Handler<AsyncResult<AsyncMap<K,V>>> resultHandler)
Get the
AsyncMap with the specified name. |
<K,V> void |
SharedData.getClusterWideMap(String name,
Handler<AsyncResult<AsyncMap<K,V>>> resultHandler)
Get the cluster wide map with the specified name.
|
void |
SharedData.getCounter(String name,
Handler<AsyncResult<Counter>> resultHandler)
Get an asynchronous counter.
|
<K,V> void |
SharedData.getLocalAsyncMap(String name,
Handler<AsyncResult<AsyncMap<K,V>>> resultHandler)
Get the
AsyncMap with the specified name. |
void |
SharedData.getLocalCounter(String name,
Handler<AsyncResult<Counter>> resultHandler)
Get an asynchronous local counter.
|
void |
SharedData.getLocalLock(String name,
Handler<AsyncResult<Lock>> resultHandler)
Get an asynchronous local lock with the specified name.
|
void |
SharedData.getLocalLockWithTimeout(String name,
long timeout,
Handler<AsyncResult<Lock>> resultHandler)
Like
SharedData.getLocalLock(String, Handler) but specifying a timeout. |
void |
SharedData.getLock(String name,
Handler<AsyncResult<Lock>> resultHandler)
Get an asynchronous lock with the specified name.
|
void |
SharedData.getLockWithTimeout(String name,
long timeout,
Handler<AsyncResult<Lock>> resultHandler)
Like
SharedData.getLock(String, Handler) but specifying a timeout. |
default void |
Counter.incrementAndGet(Handler<AsyncResult<Long>> resultHandler)
Increment the counter atomically and return the new count
|
default void |
AsyncMap.keys(Handler<AsyncResult<Set<K>>> resultHandler)
Get the keys of the map, asynchronously.
|
default void |
AsyncMap.put(K k,
V v,
Handler<AsyncResult<Void>> completionHandler)
Put a value in the map, asynchronously.
|
default void |
AsyncMap.put(K k,
V v,
long ttl,
Handler<AsyncResult<Void>> completionHandler)
Like
AsyncMap.put(K, V, io.vertx.core.Handler<io.vertx.core.AsyncResult<java.lang.Void>>) but specifying a time to live for the entry. |
default void |
AsyncMap.putIfAbsent(K k,
V v,
Handler<AsyncResult<V>> completionHandler)
Put the entry only if there is no entry with the key already present.
|
default void |
AsyncMap.putIfAbsent(K k,
V v,
long ttl,
Handler<AsyncResult<V>> completionHandler)
Link
AsyncMap.putIfAbsent(K, V, io.vertx.core.Handler<io.vertx.core.AsyncResult<V>>) but specifying a time to live for the entry. |
default void |
AsyncMap.remove(K k,
Handler<AsyncResult<V>> resultHandler)
Remove a value from the map, asynchronously.
|
default void |
AsyncMap.removeIfPresent(K k,
V v,
Handler<AsyncResult<Boolean>> resultHandler)
Remove a value from the map, only if entry already exists with same value.
|
default void |
AsyncMap.replace(K k,
V v,
Handler<AsyncResult<V>> resultHandler)
Replace the entry only if it is currently mapped to some value
|
default void |
AsyncMap.replace(K k,
V v,
long ttl,
Handler<AsyncResult<V>> resultHandler)
Replace the entry only if it is currently mapped to some value
|
default void |
AsyncMap.replaceIfPresent(K k,
V oldValue,
V newValue,
Handler<AsyncResult<Boolean>> resultHandler)
Replace the entry only if it is currently mapped to a specific value
|
default void |
AsyncMap.replaceIfPresent(K k,
V oldValue,
V newValue,
long ttl,
Handler<AsyncResult<Boolean>> resultHandler)
Replace the entry only if it is currently mapped to a specific value
|
default void |
AsyncMap.size(Handler<AsyncResult<Integer>> resultHandler)
Provide the number of entries in the map
|
default void |
AsyncMap.values(Handler<AsyncResult<List<V>>> resultHandler)
Get the values of the map, asynchronously.
|
Modifier and Type | Method and Description |
---|---|
void |
ResolverProvider.close(Handler<Void> doneHandler) |
Modifier and Type | Method and Description |
---|---|
WriteStream<T> |
WriteStream.drainHandler(Handler<Void> handler)
Set a drain handler on the stream.
|
void |
WriteStream.end(Handler<AsyncResult<Void>> handler)
Same as
WriteStream.end() but with an handler called when the operation completes |
default void |
WriteStream.end(T data,
Handler<AsyncResult<Void>> handler)
Same as
#end(T) but with an handler called when the operation completes |
ReadStream<T> |
ReadStream.endHandler(Handler<Void> endHandler)
Set an end handler.
|
ReadStream<T> |
ReadStream.exceptionHandler(Handler<Throwable> handler)
Set an exception handler on the read stream.
|
StreamBase |
StreamBase.exceptionHandler(Handler<Throwable> handler)
Set an exception handler.
|
WriteStream<T> |
WriteStream.exceptionHandler(Handler<Throwable> handler)
Set an exception handler on the write stream.
|
ReadStream<T> |
ReadStream.handler(Handler<T> handler)
Set a data handler.
|
default void |
ReadStream.pipeTo(WriteStream<T> dst,
Handler<AsyncResult<Void>> handler)
Pipe this
ReadStream to the WriteStream . |
void |
Pipe.to(WriteStream<T> dst,
Handler<AsyncResult<Void>> completionHandler)
Start to pipe the elements to the destination
WriteStream . |
void |
WriteStream.write(T data,
Handler<AsyncResult<Void>> handler)
Same as
#write(T) but with an handler called when the operation completes |
Modifier and Type | Method and Description |
---|---|
DB2Connection |
DB2Connection.closeHandler(Handler<Void> handler) |
static void |
DB2Connection.connect(Vertx vertx,
DB2ConnectOptions connectOptions,
Handler<AsyncResult<DB2Connection>> handler)
Create a connection to DB2 server with the given
connectOptions . |
static void |
DB2Connection.connect(Vertx vertx,
String connectionUri,
Handler<AsyncResult<DB2Connection>> handler)
Like
DB2Connection.connect(Vertx, DB2ConnectOptions, Handler) with options build
from connectionUri . |
DB2Pool |
DB2Pool.connectHandler(Handler<SqlConnection> handler) |
DB2Connection |
DB2Connection.debug(Handler<AsyncResult<Void>> handler)
Send a DEBUG command to dump debug information to the server's stdout.
|
DB2Connection |
DB2Connection.exceptionHandler(Handler<Throwable> handler) |
DB2Connection |
DB2Connection.ping(Handler<AsyncResult<Void>> handler)
Send a PING command to check if the server is alive.
|
DB2Connection |
DB2Connection.prepare(String sql,
Handler<AsyncResult<PreparedStatement>> handler) |
Modifier and Type | Method and Description |
---|---|
User |
User.isAuthorized(Authorization authority,
Handler<AsyncResult<Boolean>> resultHandler)
Deprecated.
|
default User |
User.isAuthorized(String authority,
Handler<AsyncResult<Boolean>> resultHandler)
Deprecated.
Use typed alternative
User.isAuthorized(Authorization, Handler) |
Modifier and Type | Method and Description |
---|---|
default void |
AuthenticationProvider.authenticate(Credentials credentials,
Handler<AsyncResult<User>> resultHandler)
Authenticate a user.
|
void |
AuthenticationProvider.authenticate(JsonObject credentials,
Handler<AsyncResult<User>> resultHandler)
Deprecated.
For type safety this method should be avoided and
AuthenticationProvider.authenticate(Credentials, Handler) should be
used instead. |
Modifier and Type | Method and Description |
---|---|
void |
AuthorizationProvider.getAuthorizations(User user,
Handler<AsyncResult<Void>> handler)
Updates the user with the set of authorizations.
|
Modifier and Type | Method and Description |
---|---|
JDBCUserUtil |
JDBCUserUtil.createHashedUser(String username,
String hash,
Handler<AsyncResult<Void>> resultHandler)
Deprecated.
Insert a user into a database.
|
JDBCUserUtil |
JDBCUserUtil.createRolePermission(String role,
String permission,
Handler<AsyncResult<Void>> resultHandler)
Deprecated.
Insert a role permission into a database.
|
JDBCUserUtil |
JDBCUserUtil.createUser(String username,
String password,
Handler<AsyncResult<Void>> resultHandler)
Deprecated.
Insert a user into a database.
|
JDBCUserUtil |
JDBCUserUtil.createUserRole(String username,
String role,
Handler<AsyncResult<Void>> resultHandler)
Deprecated.
Insert a user role into a database.
|
Modifier and Type | Method and Description |
---|---|
default MongoUserUtil |
MongoUserUtil.createHashedUser(String username,
String hash,
Handler<AsyncResult<String>> resultHandler)
Insert a user into a database.
|
default MongoUserUtil |
MongoUserUtil.createUser(String username,
String password,
Handler<AsyncResult<String>> resultHandler)
Insert a user into a database.
|
default MongoUserUtil |
MongoUserUtil.createUserRolesAndPermissions(String username,
List<String> roles,
List<String> permissions,
Handler<AsyncResult<String>> resultHandler)
Insert a user role into a database.
|
default void |
MongoAuth.insertUser(String username,
String password,
List<String> roles,
List<String> permissions,
Handler<AsyncResult<String>> resultHandler)
Deprecated.
Please use
MongoUserUtil instead.
Insert a new user into mongo in the convenient way |
Modifier and Type | Method and Description |
---|---|
default OAuth2Auth |
OAuth2Auth.jWKSet(Handler<AsyncResult<Void>> handler)
Retrieve the public server JSON Web Key (JWK) required to verify the authenticity
of issued ID and access tokens.
|
OAuth2Auth |
OAuth2Auth.missingKeyHandler(Handler<String> handler)
Handled to be called when a key (mentioned on a JWT) is missing from the current config.
|
default OAuth2Auth |
OAuth2Auth.refresh(User user,
Handler<AsyncResult<User>> handler)
Refresh the current User (access token).
|
default OAuth2Auth |
OAuth2Auth.revoke(User user,
Handler<AsyncResult<Void>> handler)
Revoke an obtained access token.
|
default OAuth2Auth |
OAuth2Auth.revoke(User user,
String tokenType,
Handler<AsyncResult<Void>> handler)
Revoke an obtained access or refresh token.
|
default OAuth2Auth |
OAuth2Auth.userInfo(User user,
Handler<AsyncResult<JsonObject>> handler)
Retrieve profile information and other attributes for a logged-in end-user.
|
Modifier and Type | Method and Description |
---|---|
static void |
SalesforceAuth.discover(Vertx vertx,
OAuth2Options config,
Handler<AsyncResult<OAuth2Auth>> handler)
Create a OAuth2Auth provider for OpenID Connect Discovery.
|
static void |
IBMCloudAuth.discover(Vertx vertx,
OAuth2Options config,
Handler<AsyncResult<OAuth2Auth>> handler)
Create a OAuth2Auth provider for OpenID Connect Discovery.
|
static void |
GoogleAuth.discover(Vertx vertx,
OAuth2Options config,
Handler<AsyncResult<OAuth2Auth>> handler)
Create a OAuth2Auth provider for OpenID Connect Discovery.
|
static void |
AzureADAuth.discover(Vertx vertx,
OAuth2Options config,
Handler<AsyncResult<OAuth2Auth>> handler)
Create a OAuth2Auth provider for OpenID Connect Discovery.
|
static void |
OpenIDConnectAuth.discover(Vertx vertx,
OAuth2Options config,
Handler<AsyncResult<OAuth2Auth>> handler)
Create a OAuth2Auth provider for OpenID Connect Discovery.
|
static void |
KeycloakAuth.discover(Vertx vertx,
OAuth2Options config,
Handler<AsyncResult<OAuth2Auth>> handler)
Create a OAuth2Auth provider for OpenID Connect Discovery.
|
static void |
AmazonCognitoAuth.discover(Vertx vertx,
OAuth2Options config,
Handler<AsyncResult<OAuth2Auth>> handler)
Create a OAuth2Auth provider for OpenID Connect Discovery.
|
Modifier and Type | Method and Description |
---|---|
default SqlUserUtil |
SqlUserUtil.createHashedUser(String username,
String hash,
Handler<AsyncResult<Void>> resultHandler)
Insert a user into a database.
|
default SqlUserUtil |
SqlUserUtil.createRolePermission(String role,
String permission,
Handler<AsyncResult<Void>> resultHandler)
Insert a role permission into a database.
|
default SqlUserUtil |
SqlUserUtil.createUser(String username,
String password,
Handler<AsyncResult<Void>> resultHandler)
Insert a user into a database.
|
default SqlUserUtil |
SqlUserUtil.createUserRole(String username,
String role,
Handler<AsyncResult<Void>> resultHandler)
Insert a user role into a database.
|
Modifier and Type | Method and Description |
---|---|
default WebAuthn |
WebAuthn.createCredentialsOptions(JsonObject user,
Handler<AsyncResult<JsonObject>> handler)
Gets a challenge and any other parameters for the
navigator.credentials.create() call. |
default MetaDataService |
MetaDataService.fetchTOC(Handler<AsyncResult<Boolean>> handler)
Fetches the FIDO2 MDS3 TOC and process the entries to the metadata store.
|
default MetaDataService |
MetaDataService.fetchTOC(String url,
Handler<AsyncResult<Boolean>> handler)
Fetches the FIDO2 TOC for the given URL and process the entries to the metadata store.
|
default WebAuthn |
WebAuthn.getCredentialsOptions(String name,
Handler<AsyncResult<JsonObject>> handler)
Creates an assertion challenge and any other parameters for the
navigator.credentials.get() call. |
Modifier and Type | Interface and Description |
---|---|
interface |
BaseBridgeEvent
Represents an event that occurs on the event bus bridge.
|
Modifier and Type | Interface and Description |
---|---|
interface |
ClusterHealthCheck
A helper to create Vert.x cluster
HealthChecks procedures. |
Modifier and Type | Method and Description |
---|---|
ConsulClient |
ConsulClient.agentInfo(Handler<AsyncResult<JsonObject>> resultHandler)
Returns the configuration and member information of the local agent
|
ConsulClient |
ConsulClient.catalogDatacenters(Handler<AsyncResult<List<String>>> resultHandler)
Return all the datacenters that are known by the Consul server
|
ConsulClient |
ConsulClient.catalogNodes(Handler<AsyncResult<NodeList>> resultHandler)
Returns the nodes registered in a datacenter
|
ConsulClient |
ConsulClient.catalogNodeServices(String node,
Handler<AsyncResult<ServiceList>> resultHandler)
Returns the node's registered services
|
ConsulClient |
ConsulClient.catalogNodeServicesWithOptions(String node,
BlockingQueryOptions options,
Handler<AsyncResult<ServiceList>> resultHandler)
Returns the node's registered services
This is blocking query unlike
ConsulClient.catalogNodeServices(String, Handler) |
ConsulClient |
ConsulClient.catalogNodesWithOptions(NodeQueryOptions options,
Handler<AsyncResult<NodeList>> resultHandler)
Returns the nodes registered in a datacenter
|
ConsulClient |
ConsulClient.catalogServiceNodes(String service,
Handler<AsyncResult<ServiceList>> resultHandler)
Returns the nodes providing a service
|
ConsulClient |
ConsulClient.catalogServiceNodesWithOptions(String service,
ServiceQueryOptions options,
Handler<AsyncResult<ServiceList>> resultHandler)
Returns the nodes providing a service
|
ConsulClient |
ConsulClient.catalogServices(Handler<AsyncResult<ServiceList>> resultHandler)
Returns the services registered in a datacenter
|
ConsulClient |
ConsulClient.catalogServicesWithOptions(BlockingQueryOptions options,
Handler<AsyncResult<ServiceList>> resultHandler)
Returns the services registered in a datacenter
This is blocking query unlike
ConsulClient.catalogServices(Handler) |
ConsulClient |
ConsulClient.cloneAclToken(String id,
Handler<AsyncResult<String>> idHandler)
Clone Acl token
|
ConsulClient |
ConsulClient.coordinateDatacenters(Handler<AsyncResult<List<DcCoordinates>>> resultHandler)
Returns the WAN network coordinates for all Consul servers, organized by DCs
|
ConsulClient |
ConsulClient.coordinateNodes(Handler<AsyncResult<CoordinateList>> resultHandler)
Returns the LAN network coordinates for all nodes in a given DC
|
ConsulClient |
ConsulClient.coordinateNodesWithOptions(BlockingQueryOptions options,
Handler<AsyncResult<CoordinateList>> resultHandler)
Returns the LAN network coordinates for all nodes in a given DC
This is blocking query unlike
ConsulClient.coordinateNodes(Handler) |
ConsulClient |
ConsulClient.createAclToken(AclToken token,
Handler<AsyncResult<String>> idHandler)
Create new Acl token
|
ConsulClient |
ConsulClient.createPreparedQuery(PreparedQueryDefinition definition,
Handler<AsyncResult<String>> resultHandler) |
ConsulClient |
ConsulClient.createSession(Handler<AsyncResult<String>> idHandler)
Initialize a new session
|
ConsulClient |
ConsulClient.createSessionWithOptions(SessionOptions options,
Handler<AsyncResult<String>> idHandler)
Initialize a new session
|
ConsulClient |
ConsulClient.deletePreparedQuery(String id,
Handler<AsyncResult<Void>> resultHandler)
Deletes an existing prepared query
|
ConsulClient |
ConsulClient.deleteValue(String key,
Handler<AsyncResult<Void>> resultHandler)
Remove the key/value pair that corresponding to the specified key
|
ConsulClient |
ConsulClient.deleteValues(String keyPrefix,
Handler<AsyncResult<Void>> resultHandler)
Removes all the key/value pair that corresponding to the specified key prefix
|
ConsulClient |
ConsulClient.deregisterCatalogService(String nodeId,
String serviceId,
Handler<AsyncResult<Void>> resultHandler)
Deregister entities from the node or deregister the node itself.
|
ConsulClient |
ConsulClient.deregisterCheck(String checkId,
Handler<AsyncResult<Void>> resultHandler)
Remove a check from the local agent.
|
ConsulClient |
ConsulClient.deregisterService(String id,
Handler<AsyncResult<Void>> resultHandler)
Remove a service from the local agent.
|
ConsulClient |
ConsulClient.destroyAclToken(String id,
Handler<AsyncResult<Void>> resultHandler)
Destroy Acl token
|
ConsulClient |
ConsulClient.destroySession(String id,
Handler<AsyncResult<Void>> resultHandler)
Destroys the given session
|
ConsulClient |
ConsulClient.executePreparedQuery(String query,
Handler<AsyncResult<PreparedQueryExecuteResponse>> resultHandler)
Executes an existing prepared query.
|
ConsulClient |
ConsulClient.executePreparedQueryWithOptions(String query,
PreparedQueryExecuteOptions options,
Handler<AsyncResult<PreparedQueryExecuteResponse>> resultHandler)
Executes an existing prepared query.
|
ConsulClient |
ConsulClient.failCheck(String checkId,
Handler<AsyncResult<Void>> resultHandler)
Set status of the check to "critical".
|
ConsulClient |
ConsulClient.failCheckWithNote(String checkId,
String note,
Handler<AsyncResult<Void>> resultHandler)
Set status of the check to "critical".
|
ConsulClient |
ConsulClient.fireEvent(String name,
Handler<AsyncResult<Event>> resultHandler)
Fires a new user event
|
ConsulClient |
ConsulClient.fireEventWithOptions(String name,
EventOptions options,
Handler<AsyncResult<Event>> resultHandler)
Fires a new user event
|
ConsulClient |
ConsulClient.getAllPreparedQueries(Handler<AsyncResult<List<PreparedQueryDefinition>>> resultHandler)
Returns a list of all prepared queries.
|
ConsulClient |
ConsulClient.getKeys(String keyPrefix,
Handler<AsyncResult<List<String>>> resultHandler)
Returns the list of keys that corresponding to the specified key prefix.
|
ConsulClient |
ConsulClient.getKeysWithOptions(String keyPrefix,
BlockingQueryOptions options,
Handler<AsyncResult<List<String>>> resultHandler)
Returns the list of keys that corresponding to the specified key prefix.
|
ConsulClient |
ConsulClient.getPreparedQuery(String id,
Handler<AsyncResult<PreparedQueryDefinition>> resultHandler)
Returns an existing prepared query
|
ConsulClient |
ConsulClient.getValue(String key,
Handler<AsyncResult<KeyValue>> resultHandler)
Returns key/value pair that corresponding to the specified key.
|
ConsulClient |
ConsulClient.getValues(String keyPrefix,
Handler<AsyncResult<KeyValueList>> resultHandler)
Returns the list of key/value pairs that corresponding to the specified key prefix.
|
ConsulClient |
ConsulClient.getValuesWithOptions(String keyPrefix,
BlockingQueryOptions options,
Handler<AsyncResult<KeyValueList>> resultHandler)
Returns the list of key/value pairs that corresponding to the specified key prefix.
|
ConsulClient |
ConsulClient.getValueWithOptions(String key,
BlockingQueryOptions options,
Handler<AsyncResult<KeyValue>> resultHandler)
Returns key/value pair that corresponding to the specified key.
|
ConsulClient |
ConsulClient.healthChecks(String service,
Handler<AsyncResult<CheckList>> resultHandler)
Returns the checks associated with the service
|
ConsulClient |
ConsulClient.healthChecksWithOptions(String service,
CheckQueryOptions options,
Handler<AsyncResult<CheckList>> resultHandler)
Returns the checks associated with the service
|
ConsulClient |
ConsulClient.healthServiceNodes(String service,
boolean passing,
Handler<AsyncResult<ServiceEntryList>> resultHandler)
Returns the nodes providing the service.
|
ConsulClient |
ConsulClient.healthServiceNodesWithOptions(String service,
boolean passing,
ServiceQueryOptions options,
Handler<AsyncResult<ServiceEntryList>> resultHandler)
Returns the nodes providing the service.
|
ConsulClient |
ConsulClient.healthState(HealthState healthState,
Handler<AsyncResult<CheckList>> resultHandler)
Returns the checks in the specified status
|
ConsulClient |
ConsulClient.healthStateWithOptions(HealthState healthState,
CheckQueryOptions options,
Handler<AsyncResult<CheckList>> resultHandler)
Returns the checks in the specified status
|
ConsulClient |
ConsulClient.infoAclToken(String id,
Handler<AsyncResult<AclToken>> tokenHandler)
Get info of Acl token
|
ConsulClient |
ConsulClient.infoSession(String id,
Handler<AsyncResult<Session>> resultHandler)
Returns the requested session information
|
ConsulClient |
ConsulClient.infoSessionWithOptions(String id,
BlockingQueryOptions options,
Handler<AsyncResult<Session>> resultHandler)
Returns the requested session information
This is blocking query unlike
ConsulClient.infoSession(String, Handler) |
ConsulClient |
ConsulClient.leaderStatus(Handler<AsyncResult<String>> resultHandler)
Get the Raft leader for the datacenter in which the agent is running.
|
ConsulClient |
ConsulClient.listAclTokens(Handler<AsyncResult<List<AclToken>>> resultHandler)
Get list of Acl token
|
ConsulClient |
ConsulClient.listEvents(Handler<AsyncResult<EventList>> resultHandler)
Returns the most recent events known by the agent
|
ConsulClient |
ConsulClient.listEventsWithOptions(EventListOptions options,
Handler<AsyncResult<EventList>> resultHandler)
Returns the most recent events known by the agent.
|
ConsulClient |
ConsulClient.listNodeSessions(String nodeId,
Handler<AsyncResult<SessionList>> resultHandler)
Returns the active sessions for a given node
|
ConsulClient |
ConsulClient.listNodeSessionsWithOptions(String nodeId,
BlockingQueryOptions options,
Handler<AsyncResult<SessionList>> resultHandler)
Returns the active sessions for a given node
This is blocking query unlike
ConsulClient.listNodeSessions(String, Handler) |
ConsulClient |
ConsulClient.listSessions(Handler<AsyncResult<SessionList>> resultHandler)
Returns the active sessions
|
ConsulClient |
ConsulClient.listSessionsWithOptions(BlockingQueryOptions options,
Handler<AsyncResult<SessionList>> resultHandler)
Returns the active sessions
This is blocking query unlike
ConsulClient.listSessions(Handler) |
ConsulClient |
ConsulClient.localChecks(Handler<AsyncResult<List<Check>>> resultHandler)
Return all the checks that are registered with the local agent.
|
ConsulClient |
ConsulClient.localServices(Handler<AsyncResult<List<Service>>> resultHandler)
Returns list of services registered with the local agent.
|
ConsulClient |
ConsulClient.maintenanceService(MaintenanceOptions maintenanceOptions,
Handler<AsyncResult<Void>> resultHandler)
Places a given service into "maintenance mode"
|
ConsulClient |
ConsulClient.passCheck(String checkId,
Handler<AsyncResult<Void>> resultHandler)
Set status of the check to "passing".
|
ConsulClient |
ConsulClient.passCheckWithNote(String checkId,
String note,
Handler<AsyncResult<Void>> resultHandler)
Set status of the check to "passing".
|
ConsulClient |
ConsulClient.peersStatus(Handler<AsyncResult<List<String>>> resultHandler)
Retrieves the Raft peers for the datacenter in which the the agent is running.
|
ConsulClient |
ConsulClient.putValue(String key,
String value,
Handler<AsyncResult<Boolean>> resultHandler)
Adds specified key/value pair
|
ConsulClient |
ConsulClient.putValueWithOptions(String key,
String value,
KeyValueOptions options,
Handler<AsyncResult<Boolean>> resultHandler) |
ConsulClient |
ConsulClient.registerCatalogService(Node nodeOptions,
ServiceOptions serviceOptions,
Handler<AsyncResult<Void>> resultHandler)
Register node with external service
|
ConsulClient |
ConsulClient.registerCheck(CheckOptions checkOptions,
Handler<AsyncResult<Void>> resultHandler)
Add a new check to the local agent.
|
ConsulClient |
ConsulClient.registerService(ServiceOptions serviceOptions,
Handler<AsyncResult<Void>> resultHandler)
Adds a new service, with an optional health check, to the local agent.
|
ConsulClient |
ConsulClient.renewSession(String id,
Handler<AsyncResult<Session>> resultHandler)
Renews the given session.
|
Watch<T> |
Watch.setHandler(Handler<WatchResult<T>> handler)
Set the result handler.
|
ConsulClient |
ConsulClient.transaction(TxnRequest request,
Handler<AsyncResult<TxnResponse>> resultHandler)
Manages multiple operations inside a single, atomic transaction.
|
ConsulClient |
ConsulClient.updateAclToken(AclToken token,
Handler<AsyncResult<String>> idHandler)
Update Acl token
|
ConsulClient |
ConsulClient.updateCheck(String checkId,
CheckStatus status,
Handler<AsyncResult<Void>> resultHandler)
Set status of the check to given status.
|
ConsulClient |
ConsulClient.updateCheckWithNote(String checkId,
CheckStatus status,
String note,
Handler<AsyncResult<Void>> resultHandler)
Set status of the check to given status.
|
ConsulClient |
ConsulClient.updatePreparedQuery(PreparedQueryDefinition definition,
Handler<AsyncResult<Void>> resultHandler) |
ConsulClient |
ConsulClient.warnCheck(String checkId,
Handler<AsyncResult<Void>> resultHandler)
Set status of the check to "warning".
|
ConsulClient |
ConsulClient.warnCheckWithNote(String checkId,
String note,
Handler<AsyncResult<Void>> resultHandler)
Set status of the check to "warning".
|
Modifier and Type | Interface and Description |
---|---|
interface |
BridgeEvent
Represents an event that occurs on the event bus bridge.
|
Modifier and Type | Method and Description |
---|---|
void |
TcpEventBusBridge.close(Handler<AsyncResult<Void>> handler)
Close the current socket.
|
static TcpEventBusBridge |
TcpEventBusBridge.create(Vertx vertx,
BridgeOptions options,
NetServerOptions netServerOptions,
Handler<BridgeEvent> eventHandler) |
TcpEventBusBridge |
TcpEventBusBridge.listen(Handler<AsyncResult<TcpEventBusBridge>> handler)
Listen on default port 7000 with a handler to report the state of the socket listen operation.
|
TcpEventBusBridge |
TcpEventBusBridge.listen(int port,
Handler<AsyncResult<TcpEventBusBridge>> handler)
Listen on specific port
|
TcpEventBusBridge |
TcpEventBusBridge.listen(int port,
String address,
Handler<AsyncResult<TcpEventBusBridge>> handler)
Listen on specific port and bind to specific address
|
Modifier and Type | Interface and Description |
---|---|
interface |
HealthCheckHandler
A Vert.x Web handler on which you register health check procedure.
|
Modifier and Type | Method and Description |
---|---|
void |
HealthChecks.checkStatus(Handler<AsyncResult<CheckResult>> resultHandler)
Invokes the registered procedures.
|
void |
HealthChecks.checkStatus(String name,
Handler<AsyncResult<CheckResult>> resultHandler)
Invokes the registered procedure with the given name and sub-procedures.
|
HealthChecks |
HealthChecks.invoke(Handler<JsonObject> resultHandler)
Invokes the registered procedures and computes the outcome.
|
HealthChecks |
HealthChecks.invoke(String name,
Handler<AsyncResult<JsonObject>> resultHandler)
Invokes the registered procedure with the given name and sub-procedures.
|
HealthChecks |
HealthChecks.register(String name,
Handler<Promise<Status>> procedure)
Registers a health check procedure.
|
HealthCheckHandler |
HealthCheckHandler.register(String name,
Handler<Promise<Status>> procedure)
Registers a health check procedure.
|
HealthChecks |
HealthChecks.register(String name,
long timeout,
Handler<Promise<Status>> procedure)
Registers a health check procedure.
|
HealthCheckHandler |
HealthCheckHandler.register(String name,
long timeout,
Handler<Promise<Status>> procedure)
Registers a health check procedure.
|
Modifier and Type | Method and Description |
---|---|
protected void |
HttpServiceFactory.doRequest(HttpClient client,
File file,
URI url,
File signatureFile,
URI signatureURL,
Handler<AsyncResult<io.vertx.ext.httpservicefactory.HttpServiceFactory.Result>> handler) |
Modifier and Type | Method and Description |
---|---|
MailClient |
MailClient.sendMail(MailMessage email,
Handler<AsyncResult<MailResult>> resultHandler)
send a single mail via MailClient
|
Modifier and Type | Method and Description |
---|---|
MongoClient |
MongoClient.bulkWrite(String collection,
List<BulkOperation> operations,
Handler<AsyncResult<MongoClientBulkWriteResult>> resultHandler)
Execute a bulk operation.
|
MongoClient |
MongoClient.bulkWriteWithOptions(String collection,
List<BulkOperation> operations,
BulkWriteOptions bulkWriteOptions,
Handler<AsyncResult<MongoClientBulkWriteResult>> resultHandler)
Execute a bulk operation with the specified write options.
|
void |
MongoClient.close(Handler<AsyncResult<Void>> handler)
Close the client and release its resources
|
MongoClient |
MongoClient.count(String collection,
JsonObject query,
Handler<AsyncResult<Long>> resultHandler)
Count matching documents in a collection.
|
MongoClient |
MongoClient.countWithOptions(String collection,
JsonObject query,
CountOptions countOptions,
Handler<AsyncResult<Long>> resultHandler)
Count matching documents in a collection.
|
MongoClient |
MongoClient.createCollection(String collectionName,
Handler<AsyncResult<Void>> resultHandler)
Create a new collection
|
MongoClient |
MongoClient.createCollectionWithOptions(String collectionName,
CreateCollectionOptions collectionOptions,
Handler<AsyncResult<Void>> resultHandler)
Create a new collection with options
|
MongoClient |
MongoClient.createDefaultGridFsBucketService(Handler<AsyncResult<MongoGridFsClient>> resultHandler)
Creates a
MongoGridFsClient used to interact with Mongo GridFS. |
MongoClient |
MongoClient.createGridFsBucketService(String bucketName,
Handler<AsyncResult<MongoGridFsClient>> resultHandler)
Creates a
MongoGridFsClient used to interact with Mongo GridFS. |
MongoClient |
MongoClient.createIndex(String collection,
JsonObject key,
Handler<AsyncResult<Void>> resultHandler)
Creates an index.
|
MongoClient |
MongoClient.createIndexes(String collection,
List<IndexModel> indexes,
Handler<AsyncResult<Void>> resultHandler)
creates an indexes
|
MongoClient |
MongoClient.createIndexWithOptions(String collection,
JsonObject key,
IndexOptions options,
Handler<AsyncResult<Void>> resultHandler)
Creates an index.
|
MongoGridFsClient |
MongoGridFsClient.delete(String id,
Handler<AsyncResult<Void>> resultHandler)
Deletes a file by it's ID
|
MongoClient |
MongoClient.distinct(String collection,
String fieldName,
String resultClassname,
DistinctOptions distinctOptions,
Handler<AsyncResult<JsonArray>> resultHandler)
Gets the distinct values of the specified field name.
|
MongoClient |
MongoClient.distinct(String collection,
String fieldName,
String resultClassname,
Handler<AsyncResult<JsonArray>> resultHandler)
Gets the distinct values of the specified field name.
|
MongoClient |
MongoClient.distinctWithQuery(String collection,
String fieldName,
String resultClassname,
JsonObject query,
DistinctOptions distinctOptions,
Handler<AsyncResult<JsonArray>> resultHandler)
Gets the distinct values of the specified field name filtered by specified query.
|
MongoClient |
MongoClient.distinctWithQuery(String collection,
String fieldName,
String resultClassname,
JsonObject query,
Handler<AsyncResult<JsonArray>> resultHandler)
Gets the distinct values of the specified field name filtered by specified query.
|
MongoGridFsClient |
MongoGridFsClient.downloadByFileName(WriteStream<Buffer> stream,
String fileName,
Handler<AsyncResult<Long>> resultHandler) |
MongoGridFsClient |
MongoGridFsClient.downloadByFileNameWithOptions(WriteStream<Buffer> stream,
String fileName,
GridFsDownloadOptions options,
Handler<AsyncResult<Long>> resultHandler) |
MongoGridFsClient |
MongoGridFsClient.downloadById(WriteStream<Buffer> stream,
String id,
Handler<AsyncResult<Long>> resultHandler) |
MongoGridFsClient |
MongoGridFsClient.downloadFile(String fileName,
Handler<AsyncResult<Long>> resultHandler)
Downloads a file.
|
MongoGridFsClient |
MongoGridFsClient.downloadFileAs(String fileName,
String newFileName,
Handler<AsyncResult<Long>> resultHandler)
Downloads a file and gives it a new name.
|
MongoGridFsClient |
MongoGridFsClient.downloadFileByID(String id,
String fileName,
Handler<AsyncResult<Long>> resultHandler)
Downloads a file using the ID generated by GridFs.
|
MongoGridFsClient |
MongoGridFsClient.drop(Handler<AsyncResult<Void>> resultHandler)
Drops the entire file bucket with all of its contents
|
MongoClient |
MongoClient.dropCollection(String collection,
Handler<AsyncResult<Void>> resultHandler)
Drop a collection
|
MongoClient |
MongoClient.dropIndex(String collection,
String indexName,
Handler<AsyncResult<Void>> resultHandler)
Drops the index given its name.
|
MongoClient |
MongoClient.find(String collection,
JsonObject query,
Handler<AsyncResult<List<JsonObject>>> resultHandler)
Find matching documents in the specified collection
|
MongoGridFsClient |
MongoGridFsClient.findAllIds(Handler<AsyncResult<List<String>>> resultHandler)
Finds all file ids in the bucket
|
MongoGridFsClient |
MongoGridFsClient.findIds(JsonObject query,
Handler<AsyncResult<List<String>>> resultHandler)
Finds all file ids that match a query.
|
MongoClient |
MongoClient.findOne(String collection,
JsonObject query,
JsonObject fields,
Handler<AsyncResult<JsonObject>> resultHandler)
Find a single matching document in the specified collection
|
MongoClient |
MongoClient.findOneAndDelete(String collection,
JsonObject query,
Handler<AsyncResult<JsonObject>> resultHandler)
Find a single matching document in the specified collection and delete it.
|
MongoClient |
MongoClient.findOneAndDeleteWithOptions(String collection,
JsonObject query,
FindOptions findOptions,
Handler<AsyncResult<JsonObject>> resultHandler)
Find a single matching document in the specified collection and delete it.
|
MongoClient |
MongoClient.findOneAndReplace(String collection,
JsonObject query,
JsonObject replace,
Handler<AsyncResult<JsonObject>> resultHandler)
Find a single matching document in the specified collection and replace it.
|
MongoClient |
MongoClient.findOneAndReplaceWithOptions(String collection,
JsonObject query,
JsonObject replace,
FindOptions findOptions,
UpdateOptions updateOptions,
Handler<AsyncResult<JsonObject>> resultHandler)
Find a single matching document in the specified collection and replace it.
|
MongoClient |
MongoClient.findOneAndUpdate(String collection,
JsonObject query,
JsonObject update,
Handler<AsyncResult<JsonObject>> resultHandler)
Find a single matching document in the specified collection and update it.
|
MongoClient |
MongoClient.findOneAndUpdateWithOptions(String collection,
JsonObject query,
JsonObject update,
FindOptions findOptions,
UpdateOptions updateOptions,
Handler<AsyncResult<JsonObject>> resultHandler)
Find a single matching document in the specified collection and update it.
|
MongoClient |
MongoClient.findWithOptions(String collection,
JsonObject query,
FindOptions options,
Handler<AsyncResult<List<JsonObject>>> resultHandler)
Find matching documents in the specified collection, specifying options
|
MongoClient |
MongoClient.getCollections(Handler<AsyncResult<List<String>>> resultHandler)
Get a list of all collections in the database.
|
MongoClient |
MongoClient.insert(String collection,
JsonObject document,
Handler<AsyncResult<String>> resultHandler)
Insert a document in the specified collection
|
MongoClient |
MongoClient.insertWithOptions(String collection,
JsonObject document,
WriteOption writeOption,
Handler<AsyncResult<String>> resultHandler)
Insert a document in the specified collection with the specified write option
|
MongoClient |
MongoClient.listIndexes(String collection,
Handler<AsyncResult<JsonArray>> resultHandler)
Get all the indexes in this collection.
|
MongoClient |
MongoClient.removeDocument(String collection,
JsonObject query,
Handler<AsyncResult<MongoClientDeleteResult>> resultHandler)
Remove a single matching document from a collection and return the handler with
MongoClientDeleteResult result |
MongoClient |
MongoClient.removeDocuments(String collection,
JsonObject query,
Handler<AsyncResult<MongoClientDeleteResult>> resultHandler)
Remove matching documents from a collection and return the handler with
MongoClientDeleteResult result |
MongoClient |
MongoClient.removeDocumentsWithOptions(String collection,
JsonObject query,
WriteOption writeOption,
Handler<AsyncResult<MongoClientDeleteResult>> resultHandler)
Remove matching documents from a collection with the specified write option and return the handler with
MongoClientDeleteResult result |
MongoClient |
MongoClient.removeDocumentWithOptions(String collection,
JsonObject query,
WriteOption writeOption,
Handler<AsyncResult<MongoClientDeleteResult>> resultHandler)
Remove a single matching document from a collection with the specified write option and return the handler with
MongoClientDeleteResult result |
MongoClient |
MongoClient.replaceDocuments(String collection,
JsonObject query,
JsonObject replace,
Handler<AsyncResult<MongoClientUpdateResult>> resultHandler)
Replace matching documents in the specified collection and return the handler with
MongoClientUpdateResult result |
MongoClient |
MongoClient.replaceDocumentsWithOptions(String collection,
JsonObject query,
JsonObject replace,
UpdateOptions options,
Handler<AsyncResult<MongoClientUpdateResult>> resultHandler)
Replace matching documents in the specified collection, specifying options and return the handler with
MongoClientUpdateResult result |
MongoClient |
MongoClient.runCommand(String commandName,
JsonObject command,
Handler<AsyncResult<JsonObject>> resultHandler)
Run an arbitrary MongoDB command.
|
MongoClient |
MongoClient.save(String collection,
JsonObject document,
Handler<AsyncResult<String>> resultHandler)
Save a document in the specified collection
|
MongoClient |
MongoClient.saveWithOptions(String collection,
JsonObject document,
WriteOption writeOption,
Handler<AsyncResult<String>> resultHandler)
Save a document in the specified collection with the specified write option
|
MongoClient |
MongoClient.updateCollection(String collection,
JsonObject query,
JsonArray update,
Handler<AsyncResult<MongoClientUpdateResult>> resultHandler)
Use an aggregation pipeline to update documents in the specified collection and return the handler with
MongoClientUpdateResult result |
MongoClient |
MongoClient.updateCollection(String collection,
JsonObject query,
JsonObject update,
Handler<AsyncResult<MongoClientUpdateResult>> resultHandler)
Update matching documents in the specified collection and return the handler with
MongoClientUpdateResult result |
MongoClient |
MongoClient.updateCollectionWithOptions(String collection,
JsonObject query,
JsonArray update,
UpdateOptions options,
Handler<AsyncResult<MongoClientUpdateResult>> resultHandler)
Use an aggregation pipeline to update documents in the specified collection, specifying options and return the handler with
MongoClientUpdateResult result |
MongoClient |
MongoClient.updateCollectionWithOptions(String collection,
JsonObject query,
JsonObject update,
UpdateOptions options,
Handler<AsyncResult<MongoClientUpdateResult>> resultHandler)
Update matching documents in the specified collection, specifying options and return the handler with
MongoClientUpdateResult result |
MongoGridFsClient |
MongoGridFsClient.uploadByFileName(ReadStream<Buffer> stream,
String fileName,
Handler<AsyncResult<String>> resultHandler) |
MongoGridFsClient |
MongoGridFsClient.uploadByFileNameWithOptions(ReadStream<Buffer> stream,
String fileName,
GridFsUploadOptions options,
Handler<AsyncResult<String>> resultHandler) |
MongoGridFsClient |
MongoGridFsClient.uploadFile(String fileName,
Handler<AsyncResult<String>> resultHandler)
Upload a file to gridfs
|
MongoGridFsClient |
MongoGridFsClient.uploadFileWithOptions(String fileName,
GridFsUploadOptions options,
Handler<AsyncResult<String>> resultHandler)
Upload a file to gridfs with options
|
Modifier and Type | Method and Description |
---|---|
ReactiveWriteStream<T> |
ReactiveWriteStream.drainHandler(Handler<Void> handler) |
void |
ReactiveWriteStream.end(Handler<AsyncResult<Void>> handler)
Calls
ReactiveWriteStream.close() . |
ReactiveReadStream<T> |
ReactiveReadStream.endHandler(Handler<Void> endHandler) |
ReactiveReadStream<T> |
ReactiveReadStream.exceptionHandler(Handler<Throwable> handler) |
ReactiveWriteStream<T> |
ReactiveWriteStream.exceptionHandler(Handler<Throwable> handler) |
ReactiveReadStream<T> |
ReactiveReadStream.handler(Handler<T> handler) |
void |
ReactiveWriteStream.write(T data,
Handler<AsyncResult<Void>> handler) |
Modifier and Type | Method and Description |
---|---|
void |
ShellServer.close(Handler<AsyncResult<Void>> completionHandler)
Close the shell server, this is an asynchronous close.
|
ShellServer |
ShellServer.listen(Handler<AsyncResult<Void>> listenHandler)
Start the shell service, this is an asynchronous start.
|
void |
ShellServer.shellHandler(Handler<Shell> shellHandler)
Called when a new shell is created.
|
void |
ShellService.start(Handler<AsyncResult<Void>> startHandler)
Start the shell service, this is an asynchronous start.
|
void |
ShellService.stop(Handler<AsyncResult<Void>> stopHandler)
Stop the shell service, this is an asynchronous start.
|
Modifier and Type | Method and Description |
---|---|
CommandProcess |
CommandProcess.backgroundHandler(Handler<Void> handler)
Set a background handler, this handler is called when the command is running and put to background.
|
CommandBuilder |
CommandBuilder.completionHandler(Handler<Completion> handler)
Set the command completion handler, the completion handler when the user asks for contextual command line
completion, usually hitting the tab key.
|
CommandProcess |
CommandProcess.endHandler(Handler<Void> handler)
Set an end handler, this handler is called when the command is ended, for instance the command is running
and the shell closes.
|
CommandProcess |
CommandProcess.foregroundHandler(Handler<Void> handler)
Set a foreground handler, this handler is called when the command is running and put to foreground.
|
CommandProcess |
CommandProcess.interruptHandler(Handler<Void> handler)
Set an interrupt handler, this handler is called when the command is interrupted, for instance user
press
Ctrl-C . |
CommandBuilder |
CommandBuilder.processHandler(Handler<CommandProcess> handler)
Set the command process handler, the process handler is called when the command is executed.
|
CommandRegistry |
CommandRegistry.registerCommand(Class<? extends AnnotatedCommand> command,
Handler<AsyncResult<Command>> completionHandler)
Register a single command.
|
CommandRegistry |
CommandRegistry.registerCommand(Command command,
Handler<AsyncResult<Command>> completionHandler)
Register a command
|
CommandRegistry |
CommandRegistry.registerCommands(List<Command> commands,
Handler<AsyncResult<List<Command>>> completionHandler)
Register a list of commands.
|
CommandProcess |
CommandProcess.resizehandler(Handler<Void> handler) |
CommandProcess |
CommandProcess.resumeHandler(Handler<Void> handler)
Set a resume handler, this handler is called when the command is resumed, for instance user
types
bg or fg to resume the command. |
CommandProcess |
CommandProcess.stdinHandler(Handler<String> handler) |
CommandProcess |
CommandProcess.suspendHandler(Handler<Void> handler)
Set a suspend handler, this handler is called when the command is suspended, for instance user
press
Ctrl-Z . |
CommandRegistry |
CommandRegistry.unregisterCommand(String commandName,
Handler<AsyncResult<Void>> completionHandler)
Unregister a command.
|
Modifier and Type | Method and Description |
---|---|
void |
CommandResolverFactory.resolver(Vertx vertx,
Handler<AsyncResult<CommandResolver>> resolveHandler)
Obtain a command resolver for a Vert.x instance.
|
Modifier and Type | Method and Description |
---|---|
void |
JobController.close(Handler<Void> completionHandler)
Close the controller and terminate all the underlying jobs, a closed controller does not accept anymore jobs.
|
boolean |
Process.interrupt(Handler<Void> completionHandler)
Attempt to interrupt the process.
|
void |
Process.resume(boolean foreground,
Handler<Void> completionHandler)
Suspend the process.
|
default void |
Process.resume(Handler<Void> completionHandler)
Suspend the process.
|
Job |
Job.statusUpdateHandler(Handler<ExecStatus> handler)
Set an handler called when the job terminates.
|
void |
Process.suspend(Handler<Void> completionHandler)
Resume the process.
|
void |
Process.terminate(Handler<Void> completionHandler)
Terminate the process.
|
Process |
Process.terminatedHandler(Handler<Integer> handler)
Set an handler for being notified when the process terminates.
|
void |
Process.toBackground(Handler<Void> completionHandler)
Set the process in background.
|
void |
Process.toForeground(Handler<Void> completionHandler)
Set the process in foreground.
|
Modifier and Type | Interface and Description |
---|---|
interface |
SockJSTermHandler |
Modifier and Type | Method and Description |
---|---|
void |
TermServer.close(Handler<AsyncResult<Void>> completionHandler)
Like
TermServer.close() but supplying a handler that will be notified when close is complete. |
Term |
Term.closeHandler(Handler<Void> handler)
Set a handler that will be called when the terminal is closed.
|
TermServer |
TermServer.listen(Handler<AsyncResult<Void>> listenHandler)
Bind the term server, the
TermServer.termHandler(Handler) must be set before. |
void |
Term.readline(String prompt,
Handler<String> lineHandler)
Prompt the user a line of text.
|
void |
Term.readline(String prompt,
Handler<String> lineHandler,
Handler<Completion> completionHandler)
Prompt the user a line of text, providing a completion handler to handle user's completion.
|
void |
Term.readline(String prompt,
Handler<String> lineHandler,
Handler<Completion> completionHandler)
Prompt the user a line of text, providing a completion handler to handle user's completion.
|
Tty |
Tty.resizehandler(Handler<Void> handler)
Set a resize handler, the handler is called when the tty size changes.
|
Term |
Term.resizehandler(Handler<Void> handler) |
Tty |
Tty.stdinHandler(Handler<String> handler)
Set a stream handler on the standard input to read the data.
|
Term |
Term.stdinHandler(Handler<String> handler) |
Pty |
Pty.stdoutHandler(Handler<String> handler)
Set the standard out handler of the pseudo terminal.
|
SockJSTermHandler |
SockJSTermHandler.termHandler(Handler<Term> handler) |
TermServer |
TermServer.termHandler(Handler<Term> handler)
Set the term handler that will receive incoming client connections.
|
Modifier and Type | Method and Description |
---|---|
SQLConnection |
SQLConnection.batch(List<String> sqlStatements,
Handler<AsyncResult<List<Integer>>> handler)
Batch simple SQL strings and execute the batch where the async result contains a array of Integers.
|
SQLConnection |
SQLConnection.batchCallableWithParams(String sqlStatement,
List<JsonArray> inArgs,
List<JsonArray> outArgs,
Handler<AsyncResult<List<Integer>>> handler)
Batch a callable statement with all entries from the args list.
|
SQLConnection |
SQLConnection.batchWithParams(String sqlStatement,
List<JsonArray> args,
Handler<AsyncResult<List<Integer>>> handler)
Batch a prepared statement with all entries from the args list.
|
SQLConnection |
SQLConnection.call(String sql,
Handler<AsyncResult<ResultSet>> resultHandler)
Calls the given SQL
PROCEDURE which returns the result from the procedure. |
default SQLClient |
SQLClient.call(String sql,
Handler<AsyncResult<ResultSet>> handler)
Calls the given SQL
PROCEDURE which returns the result from the procedure. |
SQLOperations |
SQLOperations.call(String sql,
Handler<AsyncResult<ResultSet>> resultHandler)
Calls the given SQL
PROCEDURE which returns the result from the procedure. |
SQLConnection |
SQLConnection.callWithParams(String sql,
JsonArray params,
JsonArray outputs,
Handler<AsyncResult<ResultSet>> resultHandler)
Calls the given SQL
PROCEDURE which returns the result from the procedure. |
default SQLClient |
SQLClient.callWithParams(String sql,
JsonArray params,
JsonArray outputs,
Handler<AsyncResult<ResultSet>> handler)
Calls the given SQL
PROCEDURE which returns the result from the procedure. |
SQLOperations |
SQLOperations.callWithParams(String sql,
JsonArray params,
JsonArray outputs,
Handler<AsyncResult<ResultSet>> resultHandler)
Calls the given SQL
PROCEDURE which returns the result from the procedure. |
void |
SQLRowStream.close(Handler<AsyncResult<Void>> handler)
Closes the stream/underlying cursor(s).
|
void |
SQLConnection.close(Handler<AsyncResult<Void>> handler)
Closes the connection.
|
void |
SQLClient.close(Handler<AsyncResult<Void>> handler)
Close the client and release all resources.
|
SQLConnection |
SQLConnection.commit(Handler<AsyncResult<Void>> handler)
Commits all changes made since the previous commit/rollback.
|
SQLRowStream |
SQLRowStream.endHandler(Handler<Void> endHandler) |
SQLRowStream |
SQLRowStream.exceptionHandler(Handler<Throwable> handler) |
SQLConnection |
SQLConnection.execute(String sql,
Handler<AsyncResult<Void>> resultHandler)
Executes the given SQL statement
|
SQLClient |
SQLClient.getConnection(Handler<AsyncResult<SQLConnection>> handler)
Returns a connection that can be used to perform SQL operations on.
|
SQLConnection |
SQLConnection.getTransactionIsolation(Handler<AsyncResult<TransactionIsolation>> handler)
Attempts to return the transaction isolation level for this Connection object to the one given.
|
SQLRowStream |
SQLRowStream.handler(Handler<JsonArray> handler) |
SQLConnection |
SQLConnection.query(String sql,
Handler<AsyncResult<ResultSet>> resultHandler)
Executes the given SQL
SELECT statement which returns the results of the query. |
default SQLClient |
SQLClient.query(String sql,
Handler<AsyncResult<ResultSet>> handler)
Execute a single SQL statement, this method acquires a connection from the the pool and executes the SQL
statement and returns it back after the execution.
|
SQLOperations |
SQLOperations.query(String sql,
Handler<AsyncResult<ResultSet>> resultHandler)
Executes the given SQL
SELECT statement which returns the results of the query. |
default SQLOperations |
SQLOperations.querySingle(String sql,
Handler<AsyncResult<JsonArray>> handler)
Execute a one shot SQL statement that returns a single SQL row.
|
default SQLOperations |
SQLOperations.querySingleWithParams(String sql,
JsonArray arguments,
Handler<AsyncResult<JsonArray>> handler)
Execute a one shot SQL statement with arguments that returns a single SQL row.
|
SQLConnection |
SQLConnection.queryStream(String sql,
Handler<AsyncResult<SQLRowStream>> handler)
Executes the given SQL
SELECT statement which returns the results of the query as a read stream. |
default SQLClient |
SQLClient.queryStream(String sql,
Handler<AsyncResult<SQLRowStream>> handler)
Executes the given SQL
SELECT statement which returns the results of the query as a read stream. |
SQLOperations |
SQLOperations.queryStream(String sql,
Handler<AsyncResult<SQLRowStream>> handler)
Executes the given SQL
SELECT statement which returns the results of the query as a read stream. |
SQLConnection |
SQLConnection.queryStreamWithParams(String sql,
JsonArray params,
Handler<AsyncResult<SQLRowStream>> handler)
Executes the given SQL
SELECT statement which returns the results of the query as a read stream. |
default SQLClient |
SQLClient.queryStreamWithParams(String sql,
JsonArray params,
Handler<AsyncResult<SQLRowStream>> handler)
Executes the given SQL
SELECT statement which returns the results of the query as a read stream. |
SQLOperations |
SQLOperations.queryStreamWithParams(String sql,
JsonArray params,
Handler<AsyncResult<SQLRowStream>> handler)
Executes the given SQL
SELECT statement which returns the results of the query as a read stream. |
SQLConnection |
SQLConnection.queryWithParams(String sql,
JsonArray params,
Handler<AsyncResult<ResultSet>> resultHandler)
Executes the given SQL
SELECT prepared statement which returns the results of the query. |
default SQLClient |
SQLClient.queryWithParams(String sql,
JsonArray arguments,
Handler<AsyncResult<ResultSet>> handler)
Execute a single SQL prepared statement, this method acquires a connection from the the pool and executes the SQL
prepared statement and returns it back after the execution.
|
SQLOperations |
SQLOperations.queryWithParams(String sql,
JsonArray params,
Handler<AsyncResult<ResultSet>> resultHandler)
Executes the given SQL
SELECT prepared statement which returns the results of the query. |
SQLRowStream |
SQLRowStream.resultSetClosedHandler(Handler<Void> handler)
Event handler when a resultset is closed.
|
SQLConnection |
SQLConnection.rollback(Handler<AsyncResult<Void>> handler)
Rolls back all changes made since the previous commit/rollback.
|
SQLConnection |
SQLConnection.setAutoCommit(boolean autoCommit,
Handler<AsyncResult<Void>> resultHandler)
Sets the auto commit flag for this connection.
|
SQLConnection |
SQLConnection.setTransactionIsolation(TransactionIsolation isolation,
Handler<AsyncResult<Void>> handler)
Attempts to change the transaction isolation level for this Connection object to the one given.
|
SQLConnection |
SQLConnection.update(String sql,
Handler<AsyncResult<UpdateResult>> resultHandler)
Executes the given SQL statement which may be an
INSERT , UPDATE , or DELETE
statement. |
default SQLClient |
SQLClient.update(String sql,
Handler<AsyncResult<UpdateResult>> handler)
Executes the given SQL statement which may be an
INSERT , UPDATE , or DELETE
statement. |
SQLOperations |
SQLOperations.update(String sql,
Handler<AsyncResult<UpdateResult>> resultHandler)
Executes the given SQL statement which may be an
INSERT , UPDATE , or DELETE
statement. |
SQLConnection |
SQLConnection.updateWithParams(String sql,
JsonArray params,
Handler<AsyncResult<UpdateResult>> resultHandler)
Executes the given prepared statement which may be an
INSERT , UPDATE , or DELETE
statement with the given parameters |
default SQLClient |
SQLClient.updateWithParams(String sql,
JsonArray params,
Handler<AsyncResult<UpdateResult>> handler)
Executes the given prepared statement which may be an
INSERT , UPDATE , or DELETE
statement with the given parameters |
SQLOperations |
SQLOperations.updateWithParams(String sql,
JsonArray params,
Handler<AsyncResult<UpdateResult>> resultHandler)
Executes the given prepared statement which may be an
INSERT , UPDATE , or DELETE
statement with the given parameters |
Modifier and Type | Interface and Description |
---|---|
interface |
StompServerHandler
STOMP server handler implements the behavior of the STOMP server when a specific event occurs.
|
Modifier and Type | Class and Description |
---|---|
class |
DefaultAbortHandler
STOMP compliant actions executed when receiving a
ABORT frame. |
class |
DefaultAckHandler
STOMP compliant actions executed when receiving a
ACK frame. |
class |
DefaultBeginHandler
STOMP compliant actions executed when receiving a
BEGIN frame. |
class |
DefaultCommitHandler
STOMP compliant actions executed when receiving a
COMMIT frame. |
class |
DefaultConnectHandler
STOMP compliant actions executed when receiving a
CONNECT frame. |
class |
DefaultNackHandler
STOMP compliant actions executed when receiving a
NACK sf.frame(). |
class |
DefaultSendHandler
STOMP compliant actions executed when receiving a
SEND sf.frame(). |
class |
DefaultSubscribeHandler
STOMP compliant actions executed when receiving a
SUBSCRIBE frame. |
class |
DefaultUnsubscribeHandler
STOMP compliant actions executed when receiving a
UNSUBSCRIBE frame. |
Modifier and Type | Method and Description |
---|---|
Handler<ServerWebSocket> |
StompServer.webSocketHandler()
Gets the
Handler able to manage web socket connections. |
Modifier and Type | Method and Description |
---|---|
StompClientConnection |
StompClientConnection.abort(String id,
Handler<AsyncResult<Frame>> receiptHandler)
Aborts a transaction.
|
StompClientConnection |
StompClientConnection.abort(String id,
Map<String,String> headers,
Handler<AsyncResult<Frame>> receiptHandler)
Aborts a transaction.
|
StompServerHandler |
StompServerHandler.abortHandler(Handler<ServerFrame> handler)
Configures the action to execute when a
ABORT frame is received. |
StompClientConnection |
StompClientConnection.ack(String id,
Handler<AsyncResult<Frame>> receiptHandler)
Sends an acknowledgement for a specific message.
|
StompClientConnection |
StompClientConnection.ack(String id,
String txId,
Handler<AsyncResult<Frame>> receiptHandler)
Sends an acknowledgement for the given frame.
|
StompServerHandler |
StompServerHandler.ackHandler(Handler<ServerFrame> handler)
Configures the action to execute when a
ACK frame is received. |
StompServerHandler |
StompServerHandler.beginHandler(Handler<ServerFrame> handler)
Configures the action to execute when a
BEGIN frame is received. |
StompClientConnection |
StompClientConnection.beginTX(String id,
Handler<AsyncResult<Frame>> receiptHandler)
Begins a transaction.
|
StompClientConnection |
StompClientConnection.beginTX(String id,
Map<String,String> headers,
Handler<AsyncResult<Frame>> receiptHandler)
Begins a transaction.
|
void |
StompServer.close(Handler<AsyncResult<Void>> completionHandler)
Closes the server.
|
StompClientConnection |
StompClientConnection.closeHandler(Handler<StompClientConnection> handler)
Sets a handler notified when the STOMP connection is closed.
|
StompServerHandler |
StompServerHandler.closeHandler(Handler<StompServerConnection> handler)
Configures the action to execute when a connection with the client is closed.
|
StompClientConnection |
StompClientConnection.commit(String id,
Handler<AsyncResult<Frame>> receiptHandler)
Commits a transaction.
|
StompClientConnection |
StompClientConnection.commit(String id,
Map<String,String> headers,
Handler<AsyncResult<Frame>> receiptHandler)
Commits a transaction.
|
StompServerHandler |
StompServerHandler.commitHandler(Handler<ServerFrame> handler)
Configures the action to execute when a
COMMIT frame is received. |
void |
StompServerConnection.configureHeartbeat(long ping,
long pong,
Handler<StompServerConnection> pingHandler)
Configures the heartbeat.
|
StompClient |
StompClient.connect(Handler<AsyncResult<StompClientConnection>> resultHandler)
Connects to the server using the host and port configured in the client's options.
|
StompClient |
StompClient.connect(int port,
String host,
Handler<AsyncResult<StompClientConnection>> resultHandler)
Connects to the server.
|
StompClient |
StompClient.connect(int port,
String host,
NetClient net,
Handler<AsyncResult<StompClientConnection>> resultHandler)
Connects to the server.
|
StompClient |
StompClient.connect(NetClient net,
Handler<AsyncResult<StompClientConnection>> resultHandler)
Connects to the server.
|
StompServerHandler |
StompServerHandler.connectHandler(Handler<ServerFrame> handler)
Configures the action to execute when a
CONNECT frame is received. |
StompClientConnection |
StompClientConnection.connectionDroppedHandler(Handler<StompClientConnection> handler)
Sets a handler notified when the server does not respond to a
ping request in time. |
StompClientConnection |
StompClientConnection.disconnect(Frame frame,
Handler<AsyncResult<Frame>> receiptHandler)
Disconnects the client.
|
StompClientConnection |
StompClientConnection.disconnect(Handler<AsyncResult<Frame>> receiptHandler)
Disconnects the client.
|
StompServerHandler |
StompServerHandler.disconnectHandler(Handler<ServerFrame> handler)
Configures the action to execute when a
DISCONNECT frame is received. |
StompClient |
StompClient.errorFrameHandler(Handler<Frame> handler)
A general error frame handler.
|
StompClientConnection |
StompClientConnection.errorHandler(Handler<Frame> handler)
Sets a handler notified when an
ERROR frame is received by the client. |
StompClientConnection |
StompClientConnection.exceptionHandler(Handler<Throwable> exceptionHandler)
Configures the exception handler notified upon TCP-level errors.
|
StompClient |
StompClient.exceptionHandler(Handler<Throwable> handler)
Sets an exception handler notified for TCP-level errors.
|
StompServer |
StompServer.listen(Handler<AsyncResult<StompServer>> handler)
Connects the STOMP server default port (61613) and network interface (
0.0.0.0 ). |
StompServer |
StompServer.listen(int port,
Handler<AsyncResult<StompServer>> handler)
Connects the STOMP server to the given port.
|
StompServer |
StompServer.listen(int port,
String host,
Handler<AsyncResult<StompServer>> handler)
Connects the STOMP server to the given port / interface.
|
StompClientConnection |
StompClientConnection.nack(String id,
Handler<AsyncResult<Frame>> receiptHandler)
Sends a non-acknowledgement for the given message.
|
StompClientConnection |
StompClientConnection.nack(String id,
String txId,
Handler<AsyncResult<Frame>> receiptHandler)
Sends a non-acknowledgement for the given frame.
|
StompServerHandler |
StompServerHandler.nackHandler(Handler<ServerFrame> handler)
Configures the action to execute when a
NACK frame is received. |
StompServerHandler |
StompServerHandler.onAckHandler(Handler<Acknowledgement> handler)
Configures the action to execute when messages are acknowledged.
|
StompServerHandler |
StompServerHandler.onAuthenticationRequest(StompServerConnection connection,
String login,
String passcode,
Handler<AsyncResult<Boolean>> handler)
Called when the client connects to a server requiring authentication.
|
StompServerHandler |
StompServerHandler.onNackHandler(Handler<Acknowledgement> handler)
Configures the action to execute when messages are not acknowledged.
|
StompClientConnection |
StompClientConnection.pingHandler(Handler<StompClientConnection> handler)
Sets a handler that let customize the behavior when a ping needs to be sent to the server.
|
StompServerHandler |
StompServerHandler.pingHandler(Handler<StompServerConnection> handler)
Allows customizing the action to do when the server needs to send a `PING` to the client.
|
StompClientConnection |
StompClientConnection.receivedFrameHandler(Handler<Frame> handler)
Configures a received handler that get notified when a STOMP frame is received by the client.
|
StompClient |
StompClient.receivedFrameHandler(Handler<Frame> handler)
Configures a received handler that gets notified when a STOMP frame is received by the client.
|
StompServerHandler |
StompServerHandler.receivedFrameHandler(Handler<ServerFrame> handler)
Configures a handler that get notified when a STOMP frame is received by the server.
|
StompClientConnection |
StompClientConnection.send(Frame frame,
Handler<AsyncResult<Frame>> receiptHandler)
Sends the given frame to the server.
|
StompClientConnection |
StompClientConnection.send(Map<String,String> headers,
Buffer body,
Handler<AsyncResult<Frame>> receiptHandler)
Sends a
SEND frame to the server. |
StompClientConnection |
StompClientConnection.send(String destination,
Buffer body,
Handler<AsyncResult<Frame>> receiptHandler)
Sends a
SEND frame to the server to the given destination. |
StompClientConnection |
StompClientConnection.send(String destination,
Map<String,String> headers,
Buffer body,
Handler<AsyncResult<Frame>> receiptHandler)
Sends a
SEND frame to the server to the given destination. |
StompServerHandler |
StompServerHandler.sendHandler(Handler<ServerFrame> handler)
Configures the action to execute when a
SEND frame is received. |
StompServerHandler |
StompServerHandler.stompHandler(Handler<ServerFrame> handler)
Configures the action to execute when a
STOMP frame is received. |
Future<String> |
StompClientConnection.subscribe(String destination,
Handler<Frame> handler)
Subscribes to the given destination.
|
StompClientConnection |
StompClientConnection.subscribe(String destination,
Handler<Frame> handler,
Handler<AsyncResult<String>> receiptHandler)
Subscribes to the given destination.
|
StompClientConnection |
StompClientConnection.subscribe(String destination,
Handler<Frame> handler,
Handler<AsyncResult<String>> receiptHandler)
Subscribes to the given destination.
|
Future<String> |
StompClientConnection.subscribe(String destination,
Map<String,String> headers,
Handler<Frame> handler)
Subscribes to the given destination.
|
StompClientConnection |
StompClientConnection.subscribe(String destination,
Map<String,String> headers,
Handler<Frame> handler,
Handler<AsyncResult<String>> receiptHandler)
Subscribes to the given destination.
|
StompClientConnection |
StompClientConnection.subscribe(String destination,
Map<String,String> headers,
Handler<Frame> handler,
Handler<AsyncResult<String>> receiptHandler)
Subscribes to the given destination.
|
StompServerHandler |
StompServerHandler.subscribeHandler(Handler<ServerFrame> handler)
Configures the action to execute when a
SUBSCRIBE frame is received. |
StompClientConnection |
StompClientConnection.unsubscribe(String destination,
Handler<AsyncResult<Frame>> receiptHandler)
Un-subscribes from the given destination.
|
StompClientConnection |
StompClientConnection.unsubscribe(String destination,
Map<String,String> headers,
Handler<AsyncResult<Frame>> receiptHandler)
Un-subscribes from the given destination.
|
StompServerHandler |
StompServerHandler.unsubscribeHandler(Handler<ServerFrame> handler)
Configures the action to execute when a
UNSUBSCRIBE frame is received. |
StompClientConnection |
StompClientConnection.writingFrameHandler(Handler<Frame> handler)
Configures a handler notified when a frame is going to be written on the wire.
|
StompClient |
StompClient.writingFrameHandler(Handler<Frame> handler)
Configures a writing handler that gets notified when a STOMP frame is written on the wire.
|
StompServer |
StompServer.writingFrameHandler(Handler<ServerFrame> handler)
Configures the handler that is invoked every time a frame is going to be written to the "wire".
|
Modifier and Type | Interface and Description |
---|---|
interface |
HandlerReceiverAdaptor<T>
Deprecated.
This project will be removed with Quasar being effectively abandoned
|
Modifier and Type | Method and Description |
---|---|
static <T> Handler<T> |
Sync.fiberHandler(Handler<T> handler)
Deprecated.
Convert a standard handler to a handler which runs on a fiber.
|
Modifier and Type | Method and Description |
---|---|
static <T> Handler<T> |
Sync.fiberHandler(Handler<T> handler)
Deprecated.
Convert a standard handler to a handler which runs on a fiber.
|
Modifier and Type | Method and Description |
---|---|
static <T> T |
Sync.awaitEvent(java.util.function.Consumer<Handler<T>> consumer)
Deprecated.
Receive a single event from a handler synchronously.
|
static <T> T |
Sync.awaitEvent(java.util.function.Consumer<Handler<T>> consumer,
long timeout)
Deprecated.
Receive a single event from a handler synchronously.
|
static <T> T |
Sync.awaitResult(java.util.function.Consumer<Handler<AsyncResult<T>>> consumer)
Deprecated.
Invoke an asynchronous operation and obtain the result synchronous.
|
static <T> T |
Sync.awaitResult(java.util.function.Consumer<Handler<AsyncResult<T>>> consumer,
long timeout)
Deprecated.
Invoke an asynchronous operation and obtain the result synchronous.
|
Modifier and Type | Method and Description |
---|---|
<T> Handler<AsyncResult<T>> |
TestContext.asyncAssertFailure()
Creates and returns a new async handler, the returned handler controls the completion of the test.
When the returned handler is called back with a failed result it completes the async operation.
When the returned handler is called back with a succeeded result it fails the test.
|
<T> Handler<AsyncResult<T>> |
TestContext.asyncAssertFailure(Handler<Throwable> causeHandler)
Creates and returns a new async handler, the returned handler controls the completion of the test.
When the returned handler is called back with a failed result it completes the async operation.
When the returned handler is called back with a succeeded result it fails the test.
|
<T> Handler<AsyncResult<T>> |
TestContext.asyncAssertSuccess()
Creates and returns a new async handler, the returned handler controls the completion of the test.
When the returned handler is called back with a succeeded result it completes the async operation.
When the returned handler is called back with a failed result it fails the test with the cause of the failure.
|
<T> Handler<AsyncResult<T>> |
TestContext.asyncAssertSuccess(Handler<T> resultHandler)
Creates and returns a new async handler, the returned handler controls the completion of the test.
When the returned handler is called back with a succeeded result it invokes the
resultHandler argument
with the async result. |
Handler<Throwable> |
TestContext.exceptionHandler() |
Modifier and Type | Method and Description |
---|---|
TestSuite |
TestSuite.after(Handler<TestContext> callback)
Set a callback executed after the tests.
|
TestSuite |
TestSuite.afterEach(Handler<TestContext> callback)
Set a callback executed after each test and before the suite
after callback. |
<T> Handler<AsyncResult<T>> |
TestContext.asyncAssertFailure(Handler<Throwable> causeHandler)
Creates and returns a new async handler, the returned handler controls the completion of the test.
When the returned handler is called back with a failed result it completes the async operation.
When the returned handler is called back with a succeeded result it fails the test.
|
<T> Handler<AsyncResult<T>> |
TestContext.asyncAssertSuccess(Handler<T> resultHandler)
Creates and returns a new async handler, the returned handler controls the completion of the test.
When the returned handler is called back with a succeeded result it invokes the
resultHandler argument
with the async result. |
TestSuite |
TestSuite.before(Handler<TestContext> callback)
Set a callback executed before the tests.
|
TestSuite |
TestSuite.beforeEach(Handler<TestContext> callback)
Set a callback executed before each test and after the suite
before callback. |
static TestCase |
TestCase.create(String name,
Handler<TestContext> testCase)
Create a test case.
|
void |
Completion.handler(Handler<AsyncResult<T>> completionHandler)
Completion handler to receive a completion signal when this completions completes.
|
TestSuite |
TestSuite.test(String name,
Handler<TestContext> testCase)
Add a new test case to the suite.
|
TestSuite |
TestSuite.test(String name,
int repeat,
Handler<TestContext> testCase)
Add a new test case to the suite.
|
TestContext |
TestContext.verify(Handler<Void> block)
Execute the provided handler, which may contain assertions, possibly from any third-party assertion framework.
|
Modifier and Type | Method and Description |
---|---|
Handler<Message<JsonObject>> |
EventBusCollector.asMessageHandler() |
Modifier and Type | Method and Description |
---|---|
static EventBusCollector |
EventBusCollector.create(Vertx vertx,
Handler<TestSuiteReport> reporter) |
Modifier and Type | Method and Description |
---|---|
TestCaseReport |
TestCaseReport.endHandler(Handler<TestResult> handler)
Set a callback for completion, the specified
handler is invoked when the test exec has completed. |
TestSuiteReport |
TestSuiteReport.endHandler(Handler<Void> endHandler) |
TestSuiteReport |
TestSuiteReport.exceptionHandler(Handler<Throwable> handler)
Set an exception handler, the exception handler reports the test suite errors, it can be called mulitple
times before the test ends.
|
TestSuiteReport |
TestSuiteReport.handler(Handler<TestCaseReport> handler) |
Modifier and Type | Interface and Description |
---|---|
interface |
Router
A router receives request from an
HttpServer and routes it to the first matching
Route that it contains. |
Modifier and Type | Method and Description |
---|---|
int |
RoutingContext.addBodyEndHandler(Handler<Void> handler)
Provides a handler that will be called after the last part of the body is written to the wire.
|
int |
RoutingContext.addEndHandler(Handler<AsyncResult<Void>> handler)
Add an end handler for the request/response context.
|
int |
RoutingContext.addHeadersEndHandler(Handler<Void> handler)
Add a handler that will be called just before headers are written to the response.
|
Route |
Route.blockingHandler(Handler<RoutingContext> requestHandler)
Like
Route.blockingHandler(Handler, boolean) called with ordered = true |
Route |
Route.blockingHandler(Handler<RoutingContext> requestHandler,
boolean ordered)
Specify a blocking request handler for the route.
|
default RoutingContext |
RoutingContext.end(Buffer buffer,
Handler<AsyncResult<Void>> handler)
|
default RoutingContext |
RoutingContext.end(Handler<AsyncResult<Void>> handler)
|
default RoutingContext |
RoutingContext.end(String chunk,
Handler<AsyncResult<Void>> handler)
|
Router |
Router.errorHandler(int statusCode,
Handler<RoutingContext> errorHandler)
Specify an handler to handle an error for a particular status code.
|
Route |
Route.failureHandler(Handler<RoutingContext> failureHandler)
Append a failure handler to the route failure handlers list.
|
Route |
Route.handler(Handler<RoutingContext> requestHandler)
Append a request handler to the route handlers list.
|
default RoutingContext |
RoutingContext.json(Object json,
Handler<AsyncResult<Void>> handler)
|
Router |
Router.modifiedHandler(Handler<Router> handler)
When a Router routes are changed this handler is notified.
|
default RoutingContext |
RoutingContext.redirect(String url,
Handler<AsyncResult<Void>> handler)
|
Modifier and Type | Method and Description |
---|---|
Handler<RoutingContext> |
RouterFactory.getValidationFailureHandler()
Deprecated.
Router Factory won't manage the validation errors anymore. You must use
Router.errorHandler(int, Handler) with 400 error |
Modifier and Type | Method and Description |
---|---|
RouterFactory |
RouterFactory.addGlobalHandler(Handler<RoutingContext> globalHandler)
Deprecated.
Add global handler to be applied prior to
Router being generated. |
RouterFactory |
RouterFactory.addSecurityHandler(String securitySchemaName,
Handler<RoutingContext> handler)
Deprecated.
Mount to paths that have to follow a security schema a security handler
|
RouterFactory |
RouterFactory.setNotImplementedFailureHandler(Handler<RoutingContext> notImplementedFailureHandler)
Deprecated.
You must use
Router.errorHandler(int, Handler) with 501 error |
RouterFactory |
RouterFactory.setValidationFailureHandler(Handler<RoutingContext> validationFailureHandler)
Deprecated.
Router Factory won't manage the validation errors anymore. You must use
Router.errorHandler(int, Handler) with 400 error |
Modifier and Type | Interface and Description |
---|---|
interface |
OpenAPI3RequestValidationHandler
Deprecated.
You should use the new module vertx-web-openapi
|
Modifier and Type | Method and Description |
---|---|
OpenAPI3RouterFactory |
OpenAPI3RouterFactory.addFailureHandlerByOperationId(String operationId,
Handler<RoutingContext> failureHandler)
Deprecated.
Add a failure handler by operation_id field in Operation object
|
OpenAPI3RouterFactory |
OpenAPI3RouterFactory.addHandlerByOperationId(String operationId,
Handler<RoutingContext> handler)
Deprecated.
Add an handler by operation_id field in Operation object
|
OpenAPI3RouterFactory |
OpenAPI3RouterFactory.addSecuritySchemaScopeValidator(String securitySchemaName,
String scopeName,
Handler<RoutingContext> handler)
Deprecated.
Add a particular scope validator.
|
static void |
OpenAPI3RouterFactory.create(Vertx vertx,
String url,
Handler<AsyncResult<OpenAPI3RouterFactory>> handler)
Deprecated.
Create a new OpenAPI3RouterFactory
|
static void |
OpenAPI3RouterFactory.create(Vertx vertx,
String url,
List<JsonObject> auth,
Handler<AsyncResult<OpenAPI3RouterFactory>> handler)
Deprecated.
Create a new OpenAPI3RouterFactory
|
Modifier and Type | Interface and Description |
---|---|
interface |
RouteToEBServiceHandler
Handler that proxy the request to an event bus endpoint, waits for the reply and then writes the HTTP response.
|
Modifier and Type | Interface and Description |
---|---|
interface |
HTTPRequestValidationHandler
Deprecated.
You should use the new module vertx-web-openapi
|
Modifier and Type | Method and Description |
---|---|
void |
HttpRequest.send(Handler<AsyncResult<HttpResponse<T>>> handler)
Send a request, the
handler will receive the response as an HttpResponse . |
void |
HttpRequest.sendBuffer(Buffer body,
Handler<AsyncResult<HttpResponse<T>>> handler)
Like
HttpRequest.send(Handler) but with an HTTP request body buffer. |
void |
HttpRequest.sendForm(MultiMap body,
Handler<AsyncResult<HttpResponse<T>>> handler)
Like
HttpRequest.send(Handler) but with an HTTP request body multimap encoded as form and the content type
set to application/x-www-form-urlencoded . |
void |
HttpRequest.sendForm(MultiMap body,
String charset,
Handler<AsyncResult<HttpResponse<T>>> handler)
Like
HttpRequest.send(Handler) but with an HTTP request body multimap encoded as form and the content type
set to application/x-www-form-urlencoded . |
void |
HttpRequest.sendJson(Object body,
Handler<AsyncResult<HttpResponse<T>>> handler)
Like
HttpRequest.send(Handler) but with an HTTP request body object encoded as json and the content type
set to application/json . |
void |
HttpRequest.sendJsonObject(JsonObject body,
Handler<AsyncResult<HttpResponse<T>>> handler)
Like
HttpRequest.send(Handler) but with an HTTP request body object encoded as json and the content type
set to application/json . |
void |
HttpRequest.sendMultipartForm(MultipartForm body,
Handler<AsyncResult<HttpResponse<T>>> handler)
Like
HttpRequest.send(Handler) but with an HTTP request body multimap encoded as form and the content type
set to multipart/form-data . |
void |
HttpRequest.sendStream(ReadStream<Buffer> body,
Handler<AsyncResult<HttpResponse<T>>> handler)
Like
HttpRequest.send(Handler) but with an HTTP request body stream. |
Modifier and Type | Method and Description |
---|---|
default void |
CacheStore.delete(io.vertx.ext.web.client.impl.cache.CacheKey key,
Handler<AsyncResult<Void>> handler)
Delete all variations of a key from the cache.
|
default void |
CacheStore.flush(Handler<AsyncResult<Void>> handler)
Delete all entries from the cache.
|
default void |
CacheStore.get(io.vertx.ext.web.client.impl.cache.CacheKey key,
Handler<AsyncResult<io.vertx.ext.web.client.impl.cache.CachedHttpResponse>> handler)
Retrieve a cached response.
|
default void |
CacheStore.set(io.vertx.ext.web.client.impl.cache.CacheKey key,
io.vertx.ext.web.client.impl.cache.CachedHttpResponse response,
Handler<AsyncResult<io.vertx.ext.web.client.impl.cache.CachedHttpResponse>> handler)
Add a response in the cache with the given key.
|
Modifier and Type | Method and Description |
---|---|
void |
BodyCodec.create(Handler<AsyncResult<BodyStream<T>>> handler)
Create the
BodyStream . |
Modifier and Type | Interface and Description |
---|---|
interface |
BodyStream<T>
The body stream decodes a
WriteStream into the a T instance. |
Modifier and Type | Method and Description |
---|---|
default void |
TemplateEngine.render(JsonObject context,
String templateFileName,
Handler<AsyncResult<Buffer>> handler)
Render the template.
|
void |
TemplateEngine.render(Map<String,Object> context,
String templateFileName,
Handler<AsyncResult<Buffer>> handler)
Render the template.
|
Modifier and Type | Interface and Description |
---|---|
interface |
APIKeyHandler
An authentication handler that provides API Key support.
|
interface |
AuthorizationHandler
Base interface for authorization handlers that provide authorization support.
|
interface |
BasicAuthHandler
An auth handler that provides HTTP Basic Authentication support.
|
interface |
BodyHandler
A handler which gathers the entire request body and sets it on the
RoutingContext . |
interface |
ChainAuthHandler
An auth handler that chains to a sequence of handlers.
|
interface |
CorsHandler
A handler which implements server side http://www.w3.org/TR/cors/[CORS] support for Vert.x-Web.
|
interface |
CSPHandler
Content Security Policy (CSP) is an added layer of security that helps to detect and mitigate certain types of
attacks, including Cross Site Scripting (XSS) and data injection attacks.
|
interface |
CSRFHandler
This handler adds a CSRF token to requests which mutate state.
|
interface |
DigestAuthHandler
An auth handler that provides HTTP Basic Authentication support.
|
interface |
ErrorHandler
A pretty error handler for rendering error pages.
|
interface |
FaviconHandler
A handler that serves favicons.
|
interface |
FormLoginHandler
Handler that handles login from a form on a custom login page.
|
interface |
HSTSHandler
HTTP Strict Transport Security (HSTS) RFC6797.
|
interface |
JWTAuthHandler
An auth handler that provides JWT Authentication support.
|
interface |
LoggerHandler
A handler which logs request information to the Vert.x logger.
|
interface |
MethodOverrideHandler |
interface |
MultiTenantHandler
A handler which selectively executes another handler if a precondition is met.
|
interface |
OAuth2AuthHandler
An auth handler that provides OAuth2 Authentication support.
|
interface |
OtpAuthHandler
An auth handler that provides One Time Password (Multi-Factor) Authentication support.
|
interface |
RedirectAuthHandler
An auth handler that's used to handle auth by redirecting user to a custom login page.
|
interface |
ResponseContentTypeHandler
A handler which sets the response content type automatically according to the best
Accept header match. |
interface |
ResponseTimeHandler
Handler which adds a header `x-response-time` in the response of matching requests containing the time taken
in ms to process the request.
|
interface |
SessionHandler
A handler that maintains a
Session for each browser
session. |
interface |
SimpleAuthenticationHandler
A user customizable authentication handler.
|
interface |
StaticHandler
A handler for serving static resources from the file system or classpath.
|
interface |
TemplateHandler
A handler which renders responses using a template engine and where the template name is selected from the URI
path.
|
interface |
TimeoutHandler
Handler that will timeout requests if the response has not been written after a certain time.
|
interface |
WebAuthnHandler
An auth handler that provides FIDO2 WebAuthN Relay Party support.
|
interface |
XFrameHandler
The X-Frame-Options HTTP response header can be used to indicate whether or not a browser should be allowed to render
a page in a
<frame> , <iframe> , <embed> or <object> . |
Modifier and Type | Method and Description |
---|---|
MultiTenantHandler |
MultiTenantHandler.addDefaultHandler(Handler<RoutingContext> handler)
Add a default handler for the case when no tenant was matched.
|
MultiTenantHandler |
MultiTenantHandler.addTenantHandler(String tenant,
Handler<RoutingContext> handler)
Add a handler for a given tenant to this handler.
|
default SessionHandler |
SessionHandler.flush(RoutingContext ctx,
boolean ignoreStatus,
Handler<AsyncResult<Void>> handler)
Flush a context session earlier to the store, this will allow the end user to have full control on the event of
a failure at the store level.
|
default SessionHandler |
SessionHandler.flush(RoutingContext ctx,
Handler<AsyncResult<Void>> handler)
Flush a context session earlier to the store, this will allow the end user to have full control on the event of
a failure at the store level.
|
default SessionHandler |
SessionHandler.setUser(RoutingContext context,
User user,
Handler<AsyncResult<Void>> handler)
Set the user for the session
|
Modifier and Type | Interface and Description |
---|---|
interface |
ApolloWSConnectionInitEvent |
interface |
ApolloWSHandler
A handler for GraphQL requests sent over Apollo's
subscriptions-transport-ws transport. |
interface |
GraphiQLHandler
A
Route handler for GraphiQL resources. |
interface |
GraphQLHandler
A
Route handler for GraphQL requests. |
Modifier and Type | Method and Description |
---|---|
ApolloWSHandler |
ApolloWSHandler.beforeExecute(Handler<ExecutionInputBuilderWithContext<ApolloWSMessage>> config)
Set a callback to invoke before executing a GraphQL query.
|
GraphQLHandler |
GraphQLHandler.beforeExecute(Handler<ExecutionInputBuilderWithContext<RoutingContext>> config)
Set a callback to invoke before executing a GraphQL query.
|
ApolloWSHandler |
ApolloWSHandler.connectionHandler(Handler<ServerWebSocket> connectionHandler)
Customize the connection
Handler . |
ApolloWSHandler |
ApolloWSHandler.connectionInitHandler(Handler<ApolloWSConnectionInitEvent> connectionInitHandler)
Customize the connection init
Handler . |
ApolloWSHandler |
ApolloWSHandler.endHandler(Handler<ServerWebSocket> endHandler)
Customize the end
Handler . |
ApolloWSHandler |
ApolloWSHandler.messageHandler(Handler<ApolloWSMessage> messageHandler)
Customize the message
Handler . |
Modifier and Type | Interface and Description |
---|---|
interface |
ConnectionInitEvent |
interface |
GraphQLWSHandler
A handler for the GraphQL over WebSocket Protocol.
|
Modifier and Type | Method and Description |
---|---|
GraphQLWSHandler |
GraphQLWSHandler.beforeExecute(Handler<ExecutionInputBuilderWithContext<Message>> config)
Set a callback to invoke before executing a GraphQL query.
|
GraphQLWSHandler |
GraphQLWSHandler.connectionInitHandler(Handler<ConnectionInitEvent> connectionInitHandler)
Customize the connection init
Handler . |
Modifier and Type | Interface and Description |
---|---|
interface |
SockJSHandler
A handler that allows you to handle SockJS connections from clients.
|
Modifier and Type | Method and Description |
---|---|
Router |
SockJSHandler.bridge(AuthorizationProvider authorizationProvider,
SockJSBridgeOptions bridgeOptions,
Handler<BridgeEvent> bridgeEventHandler)
Like
SockJSHandler.bridge(SockJSBridgeOptions) but specifying a handler
that will receive bridge events. |
default Router |
SockJSHandler.bridge(SockJSBridgeOptions bridgeOptions,
Handler<BridgeEvent> bridgeEventHandler)
Like
SockJSHandler.bridge(SockJSBridgeOptions) but specifying a handler
that will receive bridge events. |
SockJSSocket |
SockJSSocket.closeHandler(Handler<Void> closeHandler) |
SockJSSocket |
SockJSSocket.drainHandler(Handler<Void> handler) |
SockJSSocket |
SockJSSocket.endHandler(Handler<Void> endHandler) |
SockJSSocket |
SockJSSocket.exceptionHandler(Handler<Throwable> handler) |
SockJSSocket |
SockJSSocket.handler(Handler<Buffer> handler) |
Router |
SockJSHandler.socketHandler(Handler<SockJSSocket> handler)
Set a SockJS socket handler.
|
default void |
SockJSSocket.write(Buffer data,
Handler<AsyncResult<Void>> handler) |
default void |
SockJSSocket.write(String data,
Handler<AsyncResult<Void>> handler) |
Modifier and Type | Method and Description |
---|---|
static void |
RouterBuilder.create(Vertx vertx,
String url,
Handler<AsyncResult<RouterBuilder>> handler)
Like
this#create(Vertx, String) |
static void |
RouterBuilder.create(Vertx vertx,
String url,
OpenAPILoaderOptions options,
Handler<AsyncResult<RouterBuilder>> handler)
Like
this#create(Vertx, String, OpenAPILoaderOptions) |
Operation |
Operation.failureHandler(Handler<RoutingContext> handler)
Mount a failure handler for this operation
|
Operation |
Operation.handler(Handler<RoutingContext> handler)
Mount an handler for this operation
|
RouterBuilder |
RouterBuilder.rootHandler(Handler<RoutingContext> rootHandler)
Add global handler to be applied prior to
Router being generated. |
Modifier and Type | Interface and Description |
---|---|
interface |
ProxyHandler |
Modifier and Type | Method and Description |
---|---|
default SessionStore |
SessionStore.clear(Handler<AsyncResult<Void>> resultHandler)
Remove all sessions from the store.
|
default SessionStore |
SessionStore.delete(String id,
Handler<AsyncResult<Void>> resultHandler)
Delete the session with the specified ID.
|
default SessionStore |
SessionStore.get(String cookieValue,
Handler<AsyncResult<Session>> resultHandler)
Get the session with the specified ID.
|
default SessionStore |
SessionStore.put(Session session,
Handler<AsyncResult<Void>> resultHandler)
Add a session with the specified ID.
|
default SessionStore |
SessionStore.size(Handler<AsyncResult<Integer>> resultHandler)
Get the number of sessions in the store.
|
Modifier and Type | Method and Description |
---|---|
VertxServer |
VertxServer.shutdown(Handler<AsyncResult<Void>> completionHandler) |
VertxServer |
VertxServer.start(Handler<AsyncResult<Void>> completionHandler) |
VertxChannelBuilder |
VertxChannelBuilder.useSsl(Handler<ClientOptionsBase> handler) |
VertxServerBuilder |
VertxServerBuilder.useSsl(Handler<HttpServerOptions> handler) |
Modifier and Type | Method and Description |
---|---|
GrpcClientRequest<Req,Resp> |
GrpcClientRequest.drainHandler(Handler<Void> handler) |
GrpcClientResponse<Req,Resp> |
GrpcClientResponse.endHandler(Handler<Void> handler) |
GrpcClientResponse<Req,Resp> |
GrpcClientResponse.errorHandler(Handler<GrpcError> handler) |
GrpcClientResponse<Req,Resp> |
GrpcClientResponse.exceptionHandler(Handler<Throwable> handler) |
GrpcClientRequest<Req,Resp> |
GrpcClientRequest.exceptionHandler(Handler<Throwable> handler) |
GrpcClientResponse<Req,Resp> |
GrpcClientResponse.handler(Handler<Resp> handler) |
GrpcClientResponse<Req,Resp> |
GrpcClientResponse.messageHandler(Handler<GrpcMessage> handler) |
Modifier and Type | Method and Description |
---|---|
GrpcWriteStream<T> |
GrpcWriteStream.drainHandler(Handler<Void> handler) |
void |
GrpcWriteStream.end(Handler<AsyncResult<Void>> handler) |
default void |
GrpcWriteStream.end(T data,
Handler<AsyncResult<Void>> handler) |
GrpcReadStream<T> |
GrpcReadStream.endHandler(Handler<Void> handler) |
GrpcReadStream<T> |
GrpcReadStream.errorHandler(Handler<GrpcError> handler)
Set a handler to be notified with gRPC errors.
|
GrpcReadStream<T> |
GrpcReadStream.exceptionHandler(Handler<Throwable> handler) |
GrpcWriteStream<T> |
GrpcWriteStream.exceptionHandler(Handler<Throwable> handler) |
GrpcReadStream<T> |
GrpcReadStream.handler(Handler<T> handler) |
GrpcReadStream<T> |
GrpcReadStream.messageHandler(Handler<GrpcMessage> handler)
Set a handler to be notified with incoming encoded messages.
|
default void |
GrpcReadStream.pipeTo(WriteStream<T> dst,
Handler<AsyncResult<Void>> handler) |
void |
GrpcWriteStream.write(T t,
Handler<AsyncResult<Void>> handler) |
Modifier and Type |
---|