All Downloads are FREE. Search and download functionalities are using the official Maven repository.

io.vertx.core.Vertx Maven / Gradle / Ivy

There is a newer version: 5.0.0.CR1
Show newest version
/*
 * Copyright (c) 2011-2019 Contributors to the Eclipse Foundation
 *
 * This program and the accompanying materials are made available under the
 * terms of the Eclipse Public License 2.0 which is available at
 * http://www.eclipse.org/legal/epl-2.0, or the Apache License, Version 2.0
 * which is available at https://www.apache.org/licenses/LICENSE-2.0.
 *
 * SPDX-License-Identifier: EPL-2.0 OR Apache-2.0
 */

package io.vertx.core;

import io.netty.channel.EventLoopGroup;
import io.vertx.codegen.annotations.*;
import io.vertx.core.datagram.DatagramSocket;
import io.vertx.core.datagram.DatagramSocketOptions;
import io.vertx.core.dns.DnsClient;
import io.vertx.core.dns.DnsClientOptions;
import io.vertx.core.eventbus.EventBus;
import io.vertx.core.file.FileSystem;
import io.vertx.core.http.*;
import io.vertx.core.impl.ContextInternal;
import io.vertx.core.impl.VertxImpl;
import io.vertx.core.metrics.Measured;
import io.vertx.core.metrics.MetricsOptions;
import io.vertx.core.net.NetClient;
import io.vertx.core.net.NetClientOptions;
import io.vertx.core.net.NetServer;
import io.vertx.core.net.NetServerOptions;
import io.vertx.core.shareddata.SharedData;
import io.vertx.core.spi.VerticleFactory;
import io.vertx.core.spi.VertxMetricsFactory;
import io.vertx.core.spi.VertxTracerFactory;
import io.vertx.core.spi.cluster.ClusterManager;
import io.vertx.core.streams.ReadStream;
import io.vertx.core.tracing.TracingOptions;

import java.util.Objects;
import java.util.Set;
import java.util.concurrent.Callable;
import java.util.concurrent.TimeUnit;
import java.util.function.Supplier;

/**
 * The entry point into the Vert.x Core API.
 * 

* You use an instance of this class for functionality including: *

    *
  • Creating TCP clients and servers
  • *
  • Creating HTTP clients and servers
  • *
  • Creating DNS clients
  • *
  • Creating Datagram sockets
  • *
  • Setting and cancelling periodic and one-shot timers
  • *
  • Getting a reference to the event bus API
  • *
  • Getting a reference to the file system API
  • *
  • Getting a reference to the shared data API
  • *
  • Deploying and undeploying verticles
  • *
*

* Most functionality in Vert.x core is fairly low level. *

* To create an instance of this class you can use the static factory methods: {@link #vertx}, * {@link #vertx(io.vertx.core.VertxOptions)} and {@link #clusteredVertx(io.vertx.core.VertxOptions, Handler)}. *

* Please see the user manual for more detailed usage information. * * @author Tim Fox * @author Julien Viet */ @VertxGen public interface Vertx extends Measured { static VertxBuilder builder() { return new io.vertx.core.VertxBuilder() { VertxOptions options; VertxTracerFactory tracerFactory; VertxMetricsFactory metricsFactory; ClusterManager clusterManager; @Override public VertxBuilder with(VertxOptions options) { this.options = options; return this; } @Override public VertxBuilder withTracer(VertxTracerFactory factory) { this.tracerFactory = factory; return this; } @Override public VertxBuilder withClusterManager(ClusterManager clusterManager) { this.clusterManager = clusterManager; return this; } @Override public VertxBuilder withMetrics(VertxMetricsFactory factory) { this.metricsFactory = factory; return this; } private io.vertx.core.impl.VertxBuilder internalBuilder() { VertxOptions opts = options != null ? options : new VertxOptions(); if (clusterManager != null) { opts.setClusterManager(clusterManager); } if (metricsFactory != null) { MetricsOptions metricsOptions = opts.getMetricsOptions(); if (metricsOptions != null) { metricsOptions.setFactory(metricsFactory); } else { opts.setMetricsOptions(new MetricsOptions().setFactory(metricsFactory)); } metricsOptions.setEnabled(true); } if (tracerFactory != null) { TracingOptions tracingOptions = opts.getTracingOptions(); if (tracingOptions != null) { tracingOptions.setFactory(tracerFactory); } else { opts.setTracingOptions(new TracingOptions().setFactory(tracerFactory)); } } return new io.vertx.core.impl.VertxBuilder(opts).init(); } @Override public Vertx build() { return internalBuilder().vertx(); } @Override public Future buildClustered() { return Future.future(p -> internalBuilder().clusteredVertx(p)); } }; } /** * Creates a non clustered instance using default options. * * @return the instance */ static Vertx vertx() { return vertx(new VertxOptions()); } /** * Creates a non clustered instance using the specified options * * @param options the options to use * @return the instance */ static Vertx vertx(VertxOptions options) { return builder().with(options).build(); } /** * Creates a clustered instance using the specified options. *

* The instance is created asynchronously and the resultHandler is called with the result when it is ready. * * @param options the options to use * @param resultHandler the result handler that will receive the result */ static void clusteredVertx(VertxOptions options, Handler> resultHandler) { Objects.requireNonNull(resultHandler); Future fut = clusteredVertx(options); fut.onComplete(resultHandler); } /** * Same as {@link #clusteredVertx(VertxOptions, Handler)} but with an {@code handler} called when the operation completes */ static Future clusteredVertx(VertxOptions options) { return builder().with(options).buildClustered(); } /** * Gets the current context * * @return The current context or {@code null} if there is no current context */ static @Nullable Context currentContext() { return VertxImpl.currentContext(Thread.currentThread()); } /** * Gets the current context, or creates one if there isn't one * * @return The current context (created if didn't exist) */ Context getOrCreateContext(); /** * Create a TCP/SSL server using the specified options * * @param options the options to use * @return the server */ NetServer createNetServer(NetServerOptions options); /** * Create a TCP/SSL server using default options * * @return the server */ default NetServer createNetServer() { return createNetServer(new NetServerOptions()); } /** * Create a TCP/SSL client using the specified options * * @param options the options to use * @return the client */ NetClient createNetClient(NetClientOptions options); /** * Create a TCP/SSL client using default options * * @return the client */ default NetClient createNetClient() { return createNetClient(new NetClientOptions()); } /** * Create an HTTP/HTTPS server using the specified options * * @param options the options to use * @return the server */ HttpServer createHttpServer(HttpServerOptions options); /** * Create an HTTP/HTTPS server using default options * * @return the server */ default HttpServer createHttpServer() { return createHttpServer(new HttpServerOptions()); } /** * Create a WebSocket client using default options * * @return the client */ default WebSocketClient createWebSocketClient() { return createWebSocketClient(new WebSocketClientOptions()); } /** * Create a WebSocket client using the specified options * * @param options the options to use * @return the client */ WebSocketClient createWebSocketClient(WebSocketClientOptions options); /** * Provide a builder for {@link HttpClient}, it can be used to configure advanced * HTTP client settings like a redirect handler or a connection handler. *

* Example usage: {@code HttpClient client = vertx.httpClientBuilder().with(options).withConnectHandler(conn -> ...).build()} */ HttpClientBuilder httpClientBuilder(); /** * Create a HTTP/HTTPS client using the specified client and pool options * * @param clientOptions the client options to use * @param poolOptions the pool options to use * @return the client */ default HttpClient createHttpClient(HttpClientOptions clientOptions, PoolOptions poolOptions) { return httpClientBuilder().with(clientOptions).with(poolOptions).build(); } /** * Create a HTTP/HTTPS client using the specified client options * * @param clientOptions the options to use * @return the client */ default HttpClient createHttpClient(HttpClientOptions clientOptions) { return createHttpClient(clientOptions, clientOptions.getPoolOptions()); } /** * Create a HTTP/HTTPS client using the specified pool options * * @param poolOptions the pool options to use * @return the client */ default HttpClient createHttpClient(PoolOptions poolOptions) { return createHttpClient(new HttpClientOptions(), poolOptions); } /** * Create a HTTP/HTTPS client using default options * * @return the client */ default HttpClient createHttpClient() { return createHttpClient(new HttpClientOptions(), new PoolOptions()); } /** * Create a datagram socket using the specified options * * @param options the options to use * @return the socket */ DatagramSocket createDatagramSocket(DatagramSocketOptions options); /** * Create a datagram socket using default options * * @return the socket */ default DatagramSocket createDatagramSocket() { return createDatagramSocket(new DatagramSocketOptions()); } /** * Get the filesystem object. There is a single instance of FileSystem per Vertx instance. * * @return the filesystem object */ @CacheReturn FileSystem fileSystem(); /** * Get the event bus object. There is a single instance of EventBus per Vertx instance. * * @return the event bus object */ @CacheReturn EventBus eventBus(); /** * Create a DNS client to connect to a DNS server at the specified host and port, with the default query timeout (5 seconds) *

* * @param port the port * @param host the host * @return the DNS client */ DnsClient createDnsClient(int port, String host); /** * Create a DNS client to connect to the DNS server configured by {@link VertxOptions#getAddressResolverOptions()} *

* DNS client takes the first configured resolver address provided by {@link DnsResolverProvider#nameServerAddresses()}} * * @return the DNS client */ DnsClient createDnsClient(); /** * Create a DNS client to connect to a DNS server * * @param options the client options * @return the DNS client */ DnsClient createDnsClient(DnsClientOptions options); /** * Get the shared data object. There is a single instance of SharedData per Vertx instance. * * @return the shared data object */ @CacheReturn SharedData sharedData(); /** * Like {@link #timer(long, TimeUnit)} with a unit in millis. */ default Timer timer(long delay) { return timer(delay, TimeUnit.MILLISECONDS); } /** * Create a timer task configured with the specified {@code delay}, when the timeout fires the timer future * is succeeded, when the timeout is cancelled the timer future is failed with a {@link java.util.concurrent.CancellationException} * instance. * * @param delay the delay * @param unit the delay unit * @return the timer object */ Timer timer(long delay, TimeUnit unit); /** * Set a one-shot timer to fire after {@code delay} milliseconds, at which point {@code handler} will be called with * the id of the timer. * * @param delay the delay in milliseconds, after which the timer will fire * @param handler the handler that will be called with the timer ID when the timer fires * @return the unique ID of the timer */ long setTimer(long delay, Handler handler); /** * Returns a one-shot timer as a read stream. The timer will be fired after {@code delay} milliseconds after * the {@link ReadStream#handler} has been called. * * @param delay the delay in milliseconds, after which the timer will fire * @return the timer stream * @deprecated use {@link Vertx#setTimer} instead. RxJava like integrations should use the Vert.x scheduler integration. */ @Deprecated TimeoutStream timerStream(long delay); /** * Set a periodic timer to fire every {@code delay} milliseconds, at which point {@code handler} will be called with * the id of the timer. * * @param delay the delay in milliseconds, after which the timer will fire * @param handler the handler that will be called with the timer ID when the timer fires * @return the unique ID of the timer */ default long setPeriodic(long delay, Handler handler) { return setPeriodic(delay, delay, handler); } /** * Set a periodic timer to fire every {@code delay} milliseconds with initial delay, at which point {@code handler} will be called with * the id of the timer. * * @param initialDelay the initial delay in milliseconds * @param delay the delay in milliseconds, after which the timer will fire * @param handler the handler that will be called with the timer ID when the timer fires * @return the unique ID of the timer */ long setPeriodic(long initialDelay, long delay, Handler handler); /** * Returns a periodic timer as a read stream. The timer will be fired every {@code delay} milliseconds after * the {@link ReadStream#handler} has been called. * * @param delay the delay in milliseconds, after which the timer will fire * @return the periodic stream * @deprecated use {@link Vertx#setPeriodic} instead. RxJava like integrations should use the Vert.x scheduler integration. */ @Deprecated default TimeoutStream periodicStream(long delay) { return periodicStream(0L, delay); } /** * Returns a periodic timer as a read stream. The timer will be fired every {@code delay} milliseconds after * the {@link ReadStream#handler} has been called. * * @param initialDelay the initial delay in milliseconds * @param delay the delay in milliseconds, after which the timer will fire * @return the periodic stream * @deprecated use {@link Vertx#setPeriodic} instead. RxJava like integrations should use the Vert.x scheduler integration. */ @Deprecated TimeoutStream periodicStream(long initialDelay, long delay); /** * Cancels the timer with the specified {@code id}. * * @param id The id of the timer to cancel * @return true if the timer was successfully cancelled, or false if the timer does not exist. */ boolean cancelTimer(long id); /** * 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. * * @param action - a handler representing the action to execute */ void runOnContext(Handler action); /** * Stop the Vertx instance and release any resources held by it. *

* The instance cannot be used after it has been closed. *

* The actual close is asynchronous and may not complete until after the call has returned. * * @return a future completed with the result */ Future close(); /** * Like {@link #close} but the completionHandler will be called when the close is complete * * @param completionHandler The handler will be notified when the close is complete. */ void close(Handler> completionHandler); /** * Deploy a verticle instance that you have created yourself. *

* Vert.x will assign the verticle a context and start the verticle. *

* The actual deploy happens asynchronously and may not complete until after the call has returned. * * @param verticle the verticle instance to deploy. * @return a future completed with the result */ @GenIgnore(GenIgnore.PERMITTED_TYPE) default Future deployVerticle(Verticle verticle) { return deployVerticle(verticle, new DeploymentOptions()); } /** * Like {@link #deployVerticle(Verticle)} but the completionHandler will be notified when the deployment is complete. *

* If the deployment is successful the result will contain a string representing the unique deployment ID of the * deployment. *

* This deployment ID can subsequently be used to undeploy the verticle. * * @param verticle the verticle instance to deploy * @param completionHandler a handler which will be notified when the deployment is complete */ @GenIgnore(GenIgnore.PERMITTED_TYPE) void deployVerticle(Verticle verticle, Handler> completionHandler); /** * Like {@link #deployVerticle(Verticle)} but {@link io.vertx.core.DeploymentOptions} are provided to configure the * deployment. * * @param verticle the verticle instance to deploy * @param options the deployment options. * @return a future completed with the result */ @GenIgnore(GenIgnore.PERMITTED_TYPE) Future deployVerticle(Verticle verticle, DeploymentOptions options); /** * Like {@link #deployVerticle(Verticle, DeploymentOptions)} but {@link Verticle} instance is created by invoking the * default constructor of {@code verticleClass}. * @return a future completed with the result */ @GenIgnore Future deployVerticle(Class verticleClass, DeploymentOptions options); /** * Like {@link #deployVerticle(Verticle, DeploymentOptions)} but {@link Verticle} instance is created by invoking the * {@code verticleSupplier}. *

* The supplier will be invoked as many times as {@link DeploymentOptions#getInstances()}. * It must not return the same instance twice. *

* Note that the supplier will be invoked on the caller thread. * * @return a future completed with the result */ @GenIgnore(GenIgnore.PERMITTED_TYPE) Future deployVerticle(Supplier verticleSupplier, DeploymentOptions options); /** * Like {@link #deployVerticle(Verticle, Handler)} but {@link io.vertx.core.DeploymentOptions} are provided to configure the * deployment. * * @param verticle the verticle instance to deploy * @param options the deployment options. * @param completionHandler a handler which will be notified when the deployment is complete */ @GenIgnore(GenIgnore.PERMITTED_TYPE) void deployVerticle(Verticle verticle, DeploymentOptions options, Handler> completionHandler); /** * Like {@link #deployVerticle(Verticle, DeploymentOptions, Handler)} but {@link Verticle} instance is created by * invoking the default constructor of {@code verticleClass}. */ @GenIgnore void deployVerticle(Class verticleClass, DeploymentOptions options, Handler> completionHandler); /** * Like {@link #deployVerticle(Verticle, DeploymentOptions, Handler)} but {@link Verticle} instance is created by * invoking the {@code verticleSupplier}. *

* The supplier will be invoked as many times as {@link DeploymentOptions#getInstances()}. * It must not return the same instance twice. *

* Note that the supplier will be invoked on the caller thread. */ @GenIgnore(GenIgnore.PERMITTED_TYPE) void deployVerticle(Supplier verticleSupplier, DeploymentOptions options, Handler> completionHandler); /** * Deploy a verticle instance given a name. *

* Given the name, Vert.x selects a {@link VerticleFactory} instance to use to instantiate the verticle. *

* For the rules on how factories are selected please consult the user manual. * * @param name the name. * @return a future completed with the result */ default Future deployVerticle(String name) { return deployVerticle(name, new DeploymentOptions()); } /** * Like {@link #deployVerticle(String)} but the completionHandler will be notified when the deployment is complete. *

* If the deployment is successful the result will contain a String representing the unique deployment ID of the * deployment. *

* This deployment ID can subsequently be used to undeploy the verticle. * * @param name The identifier * @param completionHandler a handler which will be notified when the deployment is complete */ default void deployVerticle(String name, Handler> completionHandler) { deployVerticle(name, new DeploymentOptions(), completionHandler); } /** * Like {@link #deployVerticle(Verticle)} but {@link io.vertx.core.DeploymentOptions} are provided to configure the * deployment. * * @param name the name * @param options the deployment options. * @return a future completed with the result */ Future deployVerticle(String name, DeploymentOptions options); /** * Like {@link #deployVerticle(String, Handler)} but {@link io.vertx.core.DeploymentOptions} are provided to configure the * deployment. * * @param name the name * @param options the deployment options. * @param completionHandler a handler which will be notified when the deployment is complete */ void deployVerticle(String name, DeploymentOptions options, Handler> completionHandler); /** * Undeploy a verticle deployment. *

* The actual undeployment happens asynchronously and may not complete until after the method has returned. * * @param deploymentID the deployment ID * @return a future completed with the result */ Future undeploy(String deploymentID); /** * Like {@link #undeploy(String) } but the completionHandler will be notified when the undeployment is complete. * * @param deploymentID the deployment ID * @param completionHandler a handler which will be notified when the undeployment is complete */ void undeploy(String deploymentID, Handler> completionHandler); /** * Return a Set of deployment IDs for the currently deployed deploymentIDs. * * @return Set of deployment IDs */ Set deploymentIDs(); /** * Register a {@code VerticleFactory} that can be used for deploying Verticles based on an identifier. * * @param factory the factory to register */ @GenIgnore(GenIgnore.PERMITTED_TYPE) void registerVerticleFactory(VerticleFactory factory); /** * Unregister a {@code VerticleFactory} * * @param factory the factory to unregister */ @GenIgnore(GenIgnore.PERMITTED_TYPE) void unregisterVerticleFactory(VerticleFactory factory); /** * Return the Set of currently registered verticle factories. * * @return the set of verticle factories */ @GenIgnore(GenIgnore.PERMITTED_TYPE) Set verticleFactories(); /** * Is this Vert.x instance clustered? * * @return true if clustered */ boolean isClustered(); /** * Safely execute some blocking code. *

* Executes the blocking code in the handler {@code blockingCodeHandler} using a thread from the worker pool. *

* The returned future will be completed with the result on the original context (i.e. on the original event loop of the caller) * or failed when the handler throws an exception. *

* A {@code Future} instance is passed into {@code blockingCodeHandler}. When the blocking code successfully completes, * the handler should call the {@link Promise#complete} or {@link Promise#complete(Object)} method, or the {@link Promise#fail} * method if it failed. *

* In the {@code blockingCodeHandler} the current context remains the original context and therefore any task * scheduled in the {@code blockingCodeHandler} will be executed on this context and not on the worker thread. *

* The blocking code should block for a reasonable amount of time (i.e no more than a few seconds). Long blocking operations * or polling operations (i.e a thread that spin in a loop polling events in a blocking fashion) are precluded. *

* When the blocking operation lasts more than the 10 seconds, a message will be printed on the console by the * blocked thread checker. *

* Long blocking operations should use a dedicated thread managed by the application, which can interact with * verticles using the event-bus or {@link Context#runOnContext(Handler)} * * @param blockingCodeHandler handler representing the blocking code to run * @param resultHandler handler that will be called when the blocking code is complete * @param ordered if true then if executeBlocking is called several times on the same context, the executions * for that context will be executed serially, not in parallel. if false then they will be no ordering * guarantees * @param the type of the result * @deprecated use instead {@link #executeBlocking(Callable, boolean)} */ @Deprecated default void executeBlocking(Handler> blockingCodeHandler, boolean ordered, Handler> resultHandler) { Context context = getOrCreateContext(); context.executeBlocking(blockingCodeHandler, ordered, resultHandler); } /** * Like {@link #executeBlocking(Handler, boolean, Handler)} called with ordered = true. * * @deprecated instead use {@link #executeBlocking(Callable)} */ @Deprecated default void executeBlocking(Handler> blockingCodeHandler, Handler> resultHandler) { executeBlocking(blockingCodeHandler, true, resultHandler); } /** * Same as {@link #executeBlocking(Handler, boolean, Handler)} but with an {@code handler} called when the operation completes * * @deprecated instead use {@link #executeBlocking(Callable, boolean)} */ @Deprecated default Future<@Nullable T> executeBlocking(Handler> blockingCodeHandler, boolean ordered) { Context context = getOrCreateContext(); return context.executeBlocking(blockingCodeHandler, ordered); } /** * Safely execute some blocking code. *

* Executes the blocking code in the handler {@code blockingCodeHandler} using a thread from the worker pool. *

* The returned future will be completed with the result on the original context (i.e. on the original event loop of the caller) * or failed when the handler throws an exception. *

* In the {@code blockingCodeHandler} the current context remains the original context and therefore any task * scheduled in the {@code blockingCodeHandler} will be executed on this context and not on the worker thread. *

* The blocking code should block for a reasonable amount of time (i.e no more than a few seconds). Long blocking operations * or polling operations (i.e a thread that spin in a loop polling events in a blocking fashion) are precluded. *

* When the blocking operation lasts more than the 10 seconds, a message will be printed on the console by the * blocked thread checker. *

* Long blocking operations should use a dedicated thread managed by the application, which can interact with * verticles using the event-bus or {@link Context#runOnContext(Handler)} * * @param blockingCodeHandler handler representing the blocking code to run * @param ordered if true then if executeBlocking is called several times on the same context, the executions * for that context will be executed serially, not in parallel. if false then they will be no ordering * guarantees * @param the type of the result * @return a future completed when the blocking code is complete */ @GenIgnore(GenIgnore.PERMITTED_TYPE) default Future<@Nullable T> executeBlocking(Callable blockingCodeHandler, boolean ordered) { Context context = getOrCreateContext(); return context.executeBlocking(blockingCodeHandler, ordered); } /** * Like {@link #executeBlocking(Callable)} but using a callback. */ @GenIgnore(GenIgnore.PERMITTED_TYPE) default void executeBlocking(Callable blockingCodeHandler, Handler> resultHandler) { Future future = executeBlocking(blockingCodeHandler, true); if (resultHandler != null) { future.onComplete(resultHandler); } } /** * Like {@link #executeBlocking(Callable, boolean)} but using a callback. */ @GenIgnore(GenIgnore.PERMITTED_TYPE) default void executeBlocking(Callable blockingCodeHandler, boolean ordered, Handler> resultHandler) { Future future = executeBlocking(blockingCodeHandler, ordered); if (resultHandler != null) { future.onComplete(resultHandler); } } /** * Same as {@link #executeBlocking(Handler, Handler)} but with an {@code handler} called when the operation completes * * @deprecated instead use {@link #executeBlocking(Callable)} */ @Deprecated default Future<@Nullable T> executeBlocking(Handler> blockingCodeHandler) { return executeBlocking(blockingCodeHandler, true); } /** * Like {@link #executeBlocking(Callable, boolean)} called with ordered = true. */ @GenIgnore(GenIgnore.PERMITTED_TYPE) default Future<@Nullable T> executeBlocking(Callable blockingCodeHandler) { return executeBlocking(blockingCodeHandler, true); } /** * Return the Netty EventLoopGroup used by Vert.x * * @return the EventLoopGroup * @deprecated removed from public API in Vert.x 5 */ @GenIgnore(GenIgnore.PERMITTED_TYPE) @Deprecated EventLoopGroup nettyEventLoopGroup(); /** * Like {@link #createSharedWorkerExecutor(String, int)} but with the {@link VertxOptions#setWorkerPoolSize} {@code poolSize}. */ WorkerExecutor createSharedWorkerExecutor(String name); /** * Like {@link #createSharedWorkerExecutor(String, int, long)} but with the {@link VertxOptions#setMaxWorkerExecuteTime} {@code maxExecuteTime}. */ WorkerExecutor createSharedWorkerExecutor(String name, int poolSize); /** * Like {@link #createSharedWorkerExecutor(String, int, long, TimeUnit)} but with the {@link VertxOptions#setMaxWorkerExecuteTimeUnit(TimeUnit)} {@code maxExecuteTimeUnit}. */ WorkerExecutor createSharedWorkerExecutor(String name, int poolSize, long maxExecuteTime); /** * Create a named worker executor, the executor should be closed when it's not needed anymore to release * resources.

* * This method can be called mutiple times with the same {@code name}. Executors with the same name will share * the same worker pool. The worker pool size , max execute time and unit of max execute time are set when the worker pool is created and * won't change after.

* * The worker pool is released when all the {@link WorkerExecutor} sharing the same name are closed. * * @param name the name of the worker executor * @param poolSize the size of the pool * @param maxExecuteTime the value of max worker execute time * @param maxExecuteTimeUnit the value of unit of max worker execute time * @return the named worker executor */ WorkerExecutor createSharedWorkerExecutor(String name, int poolSize, long maxExecuteTime, TimeUnit maxExecuteTimeUnit); /** * @return whether the native transport is used */ @CacheReturn boolean isNativeTransportEnabled(); /** * @return the error (if any) that cause the unavailability of native transport when {@link #isNativeTransportEnabled()} returns {@code false}. */ @CacheReturn Throwable unavailableNativeTransportCause(); /** * Set a default exception handler for {@link Context}, set on {@link Context#exceptionHandler(Handler)} at creation. * * @param handler the exception handler * @return a reference to this, so the API can be used fluently */ @Fluent Vertx exceptionHandler(@Nullable Handler handler); /** * @return the current default exception handler */ @GenIgnore @Nullable Handler exceptionHandler(); }





© 2015 - 2024 Weber Informatics LLC | Privacy Policy