Uses of Interface
io.netty.util.concurrent.Future
Packages that use Future
Package
Description
The helper classes with fluent API which enable an easy implementation of
typical client side and server side channel initialization.
The core channel API which is asynchronous and event-driven abstraction of
various transports such as a
NIO Channel.
A virtual
Channel
that helps wrapping a series of handlers to
unit test the handlers or use them in non-I/O context.Optimized transport for linux which uses EPOLL Edge-Triggered Mode
for maximal performance.
A channel registry which helps a user maintain the list of open
Channel
s and perform bulk operations on them.BSD specific transport.
A virtual transport that enables the communication between the two
parties in the same virtual machine.
NIO-based channel
API implementation - recommended for a large number of connections (>= 1000).
Implementations and API for
Channel
pools.Handlers for sending and receiving HTTP/2 frames.
Adds support for client connections via proxy protocols such as
SOCKS and
HTTP CONNECT tunneling
Adds support for read and write timeout and idle connection notification
using a
Timer
.Resolves an arbitrary string that represents the name of an endpoint into an address.
An alternative to Java's built-in domain name lookup mechanism that resolves a domain name asynchronously,
which supports the queries of an arbitrary DNS record type as well.
Utility classes used across multiple packages.
Utility classes for concurrent / async tasks.
-
Uses of Future in io.netty.bootstrap
Classes in io.netty.bootstrap that implement FutureModifier and TypeClassDescription(package private) static final class
-
Uses of Future in io.netty.channel
Subinterfaces of Future in io.netty.channelModifier and TypeInterfaceDescriptioninterface
The result of an asynchronousChannel
I/O operation.interface
An specialChannelFuture
which is used to indicate theFileRegion
transfer progressinterface
SpecialChannelPromise
which will be notified once the associated bytes is transferring.interface
SpecialChannelFuture
which is writable.Classes in io.netty.channel that implement FutureModifier and TypeClassDescription(package private) static final class
(package private) class
A skeletalChannelFuture
implementation which represents aChannelFuture
which has been completed already.class
The defaultChannelProgressivePromise
implementation.class
The defaultChannelPromise
implementation.final class
(package private) final class
TheCompleteChannelFuture
which is failed already.(package private) final class
TheCompleteChannelFuture
which is succeeded already.final class
Methods in io.netty.channel that return FutureModifier and TypeMethodDescriptionFuture
<?> ThreadPerChannelEventLoopGroup.shutdownGracefully
(long quietPeriod, long timeout, TimeUnit unit) Deprecated.Future
<?> ThreadPerChannelEventLoopGroup.terminationFuture()
Deprecated.Method parameters in io.netty.channel with type arguments of type FutureModifier and TypeMethodDescriptionChannelFuture.addListener
(GenericFutureListener<? extends Future<? super Void>> listener) ChannelProgressiveFuture.addListener
(GenericFutureListener<? extends Future<? super Void>> listener) ChannelProgressivePromise.addListener
(GenericFutureListener<? extends Future<? super Void>> listener) ChannelPromise.addListener
(GenericFutureListener<? extends Future<? super Void>> listener) CompleteChannelFuture.addListener
(GenericFutureListener<? extends Future<? super Void>> listener) DefaultChannelProgressivePromise.addListener
(GenericFutureListener<? extends Future<? super Void>> listener) DefaultChannelPromise.addListener
(GenericFutureListener<? extends Future<? super Void>> listener) DelegatingChannelPromiseNotifier.addListener
(GenericFutureListener<? extends Future<? super Void>> listener) VoidChannelPromise.addListener
(GenericFutureListener<? extends Future<? super Void>> listener) ChannelFuture.removeListener
(GenericFutureListener<? extends Future<? super Void>> listener) ChannelProgressiveFuture.removeListener
(GenericFutureListener<? extends Future<? super Void>> listener) ChannelProgressivePromise.removeListener
(GenericFutureListener<? extends Future<? super Void>> listener) ChannelPromise.removeListener
(GenericFutureListener<? extends Future<? super Void>> listener) CompleteChannelFuture.removeListener
(GenericFutureListener<? extends Future<? super Void>> listener) DefaultChannelProgressivePromise.removeListener
(GenericFutureListener<? extends Future<? super Void>> listener) DefaultChannelPromise.removeListener
(GenericFutureListener<? extends Future<? super Void>> listener) DelegatingChannelPromiseNotifier.removeListener
(GenericFutureListener<? extends Future<? super Void>> listener) VoidChannelPromise.removeListener
(GenericFutureListener<? extends Future<? super Void>> listener) -
Uses of Future in io.netty.channel.embedded
Methods in io.netty.channel.embedded that return FutureModifier and TypeMethodDescriptionFuture
<?> EmbeddedEventLoop.shutdownGracefully
(long quietPeriod, long timeout, TimeUnit unit) Future
<?> EmbeddedEventLoop.terminationFuture()
-
Uses of Future in io.netty.channel.epoll
Fields in io.netty.channel.epoll declared as Future -
Uses of Future in io.netty.channel.group
Subinterfaces of Future in io.netty.channel.groupModifier and TypeInterfaceDescriptioninterface
The result of an asynchronousChannelGroup
operation.Classes in io.netty.channel.group that implement FutureModifier and TypeClassDescription(package private) final class
The defaultChannelGroupFuture
implementation.(package private) final class
Method parameters in io.netty.channel.group with type arguments of type FutureModifier and TypeMethodDescriptionChannelGroupFuture.addListener
(GenericFutureListener<? extends Future<? super Void>> listener) DefaultChannelGroupFuture.addListener
(GenericFutureListener<? extends Future<? super Void>> listener) VoidChannelGroupFuture.addListener
(GenericFutureListener<? extends Future<? super Void>> listener) ChannelGroupFuture.removeListener
(GenericFutureListener<? extends Future<? super Void>> listener) DefaultChannelGroupFuture.removeListener
(GenericFutureListener<? extends Future<? super Void>> listener) VoidChannelGroupFuture.removeListener
(GenericFutureListener<? extends Future<? super Void>> listener) -
Uses of Future in io.netty.channel.kqueue
Fields in io.netty.channel.kqueue declared as Future -
Uses of Future in io.netty.channel.local
Fields in io.netty.channel.local declared as FutureFields in io.netty.channel.local with type parameters of type FutureModifier and TypeFieldDescriptionprivate static final AtomicReferenceFieldUpdater
<LocalChannel, Future> LocalChannel.FINISH_READ_FUTURE_UPDATER
-
Uses of Future in io.netty.channel.nio
Fields in io.netty.channel.nio declared as Future -
Uses of Future in io.netty.channel.pool
Methods in io.netty.channel.pool that return FutureModifier and TypeMethodDescriptionChannelPool.acquire()
Acquire aChannel
from thisChannelPool
.Acquire aChannel
from thisChannelPool
.SimpleChannelPool.acquire()
SimpleChannelPool.acquireHealthyFromPoolOrNew
(Promise<Channel> promise) Tries to retrieve healthy channel from the pool if any or creates a new channel otherwise.FixedChannelPool.close0()
FixedChannelPool.closeAsync()
Closes the pool in an async manner.SimpleChannelPool.closeAsync()
Closes the pool in an async manner.Check if the given channel is healthy which means it can be used.AbstractChannelPoolMap.poolCloseAsyncIfSupported
(ChannelPool pool) If the pool implementation supports asynchronous close, then use it to avoid a blocking close call in case the ChannelPoolMap operations are called from an EventLoop.Release aChannel
back to thisChannelPool
.Release aChannel
back to thisChannelPool
.AbstractChannelPoolMap.removeAsyncIfSupported
(K key) Remove theChannelPool
from thisAbstractChannelPoolMap
.Methods in io.netty.channel.pool with parameters of type FutureModifier and TypeMethodDescriptionprivate void
SimpleChannelPool.notifyHealthCheck
(Future<Boolean> future, Channel channel, Promise<Channel> promise) void
FixedChannelPool.AcquireListener.operationComplete
(Future<Channel> future) private void
SimpleChannelPool.releaseAndOfferIfHealthy
(Channel channel, Promise<Void> promise, Future<Boolean> future) Adds the channel back to the pool only if the channel is healthy. -
Uses of Future in io.netty.handler.codec.http2
Classes in io.netty.handler.codec.http2 that implement FutureModifier and TypeClassDescription(package private) static final class
Provides the ability to associate the outcome of multipleChannelPromise
objects into a singleChannelPromise
object.Fields in io.netty.handler.codec.http2 declared as FutureModifier and TypeFieldDescriptionprivate final Future
<?> Http2ConnectionHandler.ClosingChannelFutureListener.timeoutTask
Methods in io.netty.handler.codec.http2 that return FutureModifier and TypeMethodDescriptionClose this connection.Http2StreamChannelBootstrap.open()
Open a newHttp2StreamChannel
to use.Http2StreamChannelBootstrap.open
(Promise<Http2StreamChannel> promise) Open a newHttp2StreamChannel
to use and notifies the givenPromise
. -
Uses of Future in io.netty.handler.proxy
Classes in io.netty.handler.proxy that implement FutureFields in io.netty.handler.proxy declared as FutureMethods in io.netty.handler.proxy that return FutureModifier and TypeMethodDescriptionProxyHandler.connectFuture()
Returns aFuture
that is notified when the connection to the destination has been established or the connection attempt has failed. -
Uses of Future in io.netty.handler.ssl
Classes in io.netty.handler.ssl that implement FutureMethods in io.netty.handler.ssl that return FutureModifier and TypeMethodDescriptionFuture
<byte[]> Decrypts the input with the given key and notifies the returnedFuture
with the decrypted bytes.SslHandler.handshakeFuture()
Returns aFuture
that will get notified once the current TLS handshake completes.AbstractSniHandler.lookup
(ChannelHandlerContext ctx, ByteBuf clientHello) AbstractSniHandler.lookup
(ChannelHandlerContext ctx, String hostname) Kicks off a lookup for the given SNI value and returns aFuture
which in turn will notify theAbstractSniHandler.onLookupComplete(ChannelHandlerContext, String, Future)
on completion.protected Future
<SslContext> SniHandler.lookup
(ChannelHandlerContext ctx, String hostname) The default implementation will simply callAsyncMapping.map(Object, Promise)
but users can override this method to implement custom behavior.SslClientHelloHandler.lookup
(ChannelHandlerContext ctx, ByteBuf clientHello) Kicks off a lookup for the givenClientHello
and returns aFuture
which in turn will notify theSslClientHelloHandler.onLookupComplete(ChannelHandlerContext, Future)
on completion.SniHandler.AsyncMappingAdapter.map
(String input, Promise<SslContext> promise) SslHandler.renegotiate()
Performs TLS renegotiation.SslHandler.renegotiate
(Promise<Channel> promise) Performs TLS renegotiation.Future
<byte[]> Signs the input with the given key and notifies the returnedFuture
with the signed bytes.SslHandler.sslCloseFuture()
Methods in io.netty.handler.ssl with parameters of type FutureModifier and TypeMethodDescriptionprivate static void
AbstractSniHandler.fireSniCompletionEvent
(ChannelHandlerContext ctx, String hostname, Future<?> future) protected void
AbstractSniHandler.onLookupComplete
(ChannelHandlerContext ctx, Future<T> future) protected abstract void
AbstractSniHandler.onLookupComplete
(ChannelHandlerContext ctx, String hostname, Future<T> future) Called upon completion of theAbstractSniHandler.lookup(ChannelHandlerContext, String)
Future
.protected final void
SniHandler.onLookupComplete
(ChannelHandlerContext ctx, String hostname, Future<SslContext> future) protected abstract void
SslClientHelloHandler.onLookupComplete
(ChannelHandlerContext ctx, Future<T> future) Called upon completion of theSslClientHelloHandler.lookup(ChannelHandlerContext, ByteBuf)
Future
.void
ReferenceCountedOpenSslContext.AsyncPrivateKeyMethod.ResultCallbackListener.operationComplete
(Future<byte[]> future) -
Uses of Future in io.netty.handler.timeout
Fields in io.netty.handler.timeout declared as FutureModifier and TypeFieldDescriptionprivate Future
<?> IdleStateHandler.allIdleTimeout
private Future
<?> IdleStateHandler.readerIdleTimeout
(package private) Future
<?> WriteTimeoutHandler.WriteTimeoutTask.scheduledFuture
private Future
<?> IdleStateHandler.writerIdleTimeout
Methods in io.netty.handler.timeout that return FutureModifier and TypeMethodDescription(package private) Future
<?> IdleStateHandler.schedule
(ChannelHandlerContext ctx, Runnable task, long delay, TimeUnit unit) This method is visible for testing! -
Uses of Future in io.netty.resolver
Fields in io.netty.resolver with type parameters of type FutureModifier and TypeFieldDescriptionprivate final Map
<EventExecutor, GenericFutureListener<Future<Object>>> AddressResolverGroup.executorTerminationListeners
Methods in io.netty.resolver that return FutureModifier and TypeMethodDescriptionAbstractAddressResolver.resolve
(SocketAddress address) AbstractAddressResolver.resolve
(SocketAddress address, Promise<T> promise) AddressResolver.resolve
(SocketAddress address) Resolves the specified address.AddressResolver.resolve
(SocketAddress address, Promise<T> promise) Resolves the specified address.Resolves the specified name into an address.Resolves the specified name into an address.AbstractAddressResolver.resolveAll
(SocketAddress address) AbstractAddressResolver.resolveAll
(SocketAddress address, Promise<List<T>> promise) AddressResolver.resolveAll
(SocketAddress address) Resolves the specified address.AddressResolver.resolveAll
(SocketAddress address, Promise<List<T>> promise) Resolves the specified address.NameResolver.resolveAll
(String inetHost) Resolves the specified host name and port into a list of address.NameResolver.resolveAll
(String inetHost, Promise<List<T>> promise) Resolves the specified host name and port into a list of address.SimpleNameResolver.resolveAll
(String inetHost) SimpleNameResolver.resolveAll
(String inetHost, Promise<List<T>> promise) -
Uses of Future in io.netty.resolver.dns
Fields in io.netty.resolver.dns declared as FutureModifier and TypeFieldDescriptionDnsQueryContext.channelReadyFuture
DnsResolveContext.channelReadyFuture
private Future
<?> DnsQueryContext.timeoutFuture
Fields in io.netty.resolver.dns with type parameters of type FutureModifier and TypeFieldDescriptionprivate final Map
<String, Future<List<InetAddress>>> DnsNameResolver.inflightLookups
private final Set
<Future<AddressedEnvelope<DnsResponse, InetSocketAddress>>> DnsResolveContext.queriesInProgress
Methods in io.netty.resolver.dns that return FutureModifier and TypeMethodDescription(package private) final Future
<AddressedEnvelope<DnsResponse, InetSocketAddress>> DnsNameResolver.doQuery
(Channel channel, Future<? extends Channel> channelReadyFuture, InetSocketAddress nameServerAddr, DnsQuestion question, DnsQueryLifecycleObserver queryLifecycleObserver, DnsRecord[] additionals, boolean flush, Promise<AddressedEnvelope<? extends DnsResponse, InetSocketAddress>> promise) DnsNameResolver.query
(DnsQuestion question) Sends a DNS query with the specified question.DnsNameResolver.query
(DnsQuestion question, Promise<AddressedEnvelope<? extends DnsResponse, InetSocketAddress>> promise) Sends a DNS query with the specified question.DnsNameResolver.query
(DnsQuestion question, Iterable<DnsRecord> additionals) Sends a DNS query with the specified question with additional records.DnsNameResolver.query
(InetSocketAddress nameServerAddr, DnsQuestion question) Sends a DNS query with the specified question using the specified name server list.DnsNameResolver.query
(InetSocketAddress nameServerAddr, DnsQuestion question, Promise<AddressedEnvelope<? extends DnsResponse, InetSocketAddress>> promise) Sends a DNS query with the specified question using the specified name server list.DnsNameResolver.query
(InetSocketAddress nameServerAddr, DnsQuestion question, Iterable<DnsRecord> additionals) Sends a DNS query with the specified question with additional records using the specified name server list.DnsNameResolver.query
(InetSocketAddress nameServerAddr, DnsQuestion question, Iterable<DnsRecord> additionals, Promise<AddressedEnvelope<? extends DnsResponse, InetSocketAddress>> promise) Sends a DNS query with the specified question with additional records using the specified name server list.final Future
<InetAddress> Resolves the specified name into an address.final Future
<InetAddress> DnsNameResolver.resolve
(String inetHost, Iterable<DnsRecord> additionals, Promise<InetAddress> promise) Resolves the specified name into an address.DnsNameResolver.resolveAll
(DnsQuestion question) Resolves theDnsRecord
s that are matched by the specifiedDnsQuestion
.DnsNameResolver.resolveAll
(DnsQuestion question, DnsRecord[] additionals, Promise<List<DnsRecord>> promise) DnsNameResolver.resolveAll
(DnsQuestion question, Iterable<DnsRecord> additionals) Resolves theDnsRecord
s that are matched by the specifiedDnsQuestion
.DnsNameResolver.resolveAll
(DnsQuestion question, Iterable<DnsRecord> additionals, Promise<List<DnsRecord>> promise) Resolves theDnsRecord
s that are matched by the specifiedDnsQuestion
.final Future
<List<InetAddress>> DnsNameResolver.resolveAll
(String inetHost, Iterable<DnsRecord> additionals) Resolves the specified host name and port into a list of address.final Future
<List<InetAddress>> DnsNameResolver.resolveAll
(String inetHost, Iterable<DnsRecord> additionals, Promise<List<InetAddress>> promise) Resolves the specified host name and port into a list of address.InflightNameResolver.resolveAll
(String inetHost) Methods in io.netty.resolver.dns with parameters of type FutureModifier and TypeMethodDescription(package private) final Future
<AddressedEnvelope<DnsResponse, InetSocketAddress>> DnsNameResolver.doQuery
(Channel channel, Future<? extends Channel> channelReadyFuture, InetSocketAddress nameServerAddr, DnsQuestion question, DnsQueryLifecycleObserver queryLifecycleObserver, DnsRecord[] additionals, boolean flush, Promise<AddressedEnvelope<? extends DnsResponse, InetSocketAddress>> promise) private void
DnsQueryContext.finishOriginal
(Object originalResult, Future<?> future) (package private) DnsResolveContext
<InetAddress> DnsAddressResolveContext.newResolverContext
(DnsNameResolver parent, Channel channel, Future<? extends Channel> channelReadyFuture, Promise<?> originalPromise, String hostname, int dnsClass, DnsRecordType[] expectedTypes, DnsRecord[] additionals, DnsServerAddressStream nameServerAddrs, int allowedQueries) (package private) DnsResolveContext
<DnsRecord> DnsRecordResolveContext.newResolverContext
(DnsNameResolver parent, Channel channel, Future<? extends Channel> channelReadyFuture, Promise<?> originalPromise, String hostname, int dnsClass, DnsRecordType[] expectedTypes, DnsRecord[] additionals, DnsServerAddressStream nameServerAddrs, int allowedQueries) (package private) abstract DnsResolveContext
<T> DnsResolveContext.newResolverContext
(DnsNameResolver parent, Channel channel, Future<? extends Channel> channelReadyFuture, Promise<?> originalPromise, String hostname, int dnsClass, DnsRecordType[] expectedTypes, DnsRecord[] additionals, DnsServerAddressStream nameServerAddrs, int allowedQueries) Creates a new context with the given parameters.private static <T> void
InflightNameResolver.transferResult
(Future<T> src, Promise<T> dst) Constructors in io.netty.resolver.dns with parameters of type FutureModifierConstructorDescription(package private)
DatagramDnsQueryContext
(Channel channel, Future<? extends Channel> channelReadyFuture, InetSocketAddress nameServerAddr, DnsQueryContextManager queryContextManager, int maxPayLoadSize, boolean recursionDesired, long queryTimeoutMillis, DnsQuestion question, DnsRecord[] additionals, Promise<AddressedEnvelope<DnsResponse, InetSocketAddress>> promise, Bootstrap socketBootstrap, boolean retryWithTcpOnTimeout) (package private)
DnsAddressResolveContext
(DnsNameResolver parent, Channel channel, Future<? extends Channel> channelReadyFuture, Promise<?> originalPromise, String hostname, DnsRecord[] additionals, DnsServerAddressStream nameServerAddrs, int allowedQueries, DnsCache resolveCache, AuthoritativeDnsServerCache authoritativeDnsServerCache, boolean completeEarlyIfPossible) (package private)
DnsQueryContext
(Channel channel, Future<? extends Channel> channelReadyFuture, InetSocketAddress nameServerAddr, DnsQueryContextManager queryContextManager, int maxPayLoadSize, boolean recursionDesired, long queryTimeoutMillis, DnsQuestion question, DnsRecord[] additionals, Promise<AddressedEnvelope<DnsResponse, InetSocketAddress>> promise, Bootstrap socketBootstrap, boolean retryWithTcpOnTimeout) (package private)
DnsRecordResolveContext
(DnsNameResolver parent, Channel channel, Future<? extends Channel> channelReadyFuture, Promise<?> originalPromise, DnsQuestion question, DnsRecord[] additionals, DnsServerAddressStream nameServerAddrs, int allowedQueries) private
DnsRecordResolveContext
(DnsNameResolver parent, Channel channel, Future<? extends Channel> channelReadyFuture, Promise<?> originalPromise, String hostname, int dnsClass, DnsRecordType[] expectedTypes, DnsRecord[] additionals, DnsServerAddressStream nameServerAddrs, int allowedQueries) (package private)
DnsResolveContext
(DnsNameResolver parent, Channel channel, Future<? extends Channel> channelReadyFuture, Promise<?> originalPromise, String hostname, int dnsClass, DnsRecordType[] expectedTypes, DnsRecord[] additionals, DnsServerAddressStream nameServerAddrs, int allowedQueries) (package private)
TcpDnsQueryContext
(Channel channel, Future<? extends Channel> channelReadyFuture, InetSocketAddress nameServerAddr, DnsQueryContextManager queryContextManager, int maxPayLoadSize, boolean recursionDesired, long queryTimeoutMillis, DnsQuestion question, DnsRecord[] additionals, Promise<AddressedEnvelope<DnsResponse, InetSocketAddress>> promise) -
Uses of Future in io.netty.util
Methods in io.netty.util that return Future -
Uses of Future in io.netty.util.concurrent
Classes in io.netty.util.concurrent with type parameters of type FutureModifier and TypeInterfaceDescriptioninterface
GenericFutureListener<F extends Future<?>>
Listens to the result of aFuture
.class
PromiseAggregator<V,
F extends Future<V>> Deprecated.class
PromiseNotifier<V,
F extends Future<V>> GenericFutureListener
implementation which takes otherPromise
s and notifies them on completion.Subinterfaces of Future in io.netty.util.concurrentModifier and TypeInterfaceDescriptioninterface
AFuture
which is used to indicate the progress of an operation.interface
SpecialProgressiveFuture
which is writable.interface
Promise<V>
SpecialFuture
which is writable.interface
The result of a scheduled asynchronous operation.Classes in io.netty.util.concurrent that implement FutureModifier and TypeClassDescriptionclass
AbstractFuture
implementation which does not allow for cancellation.class
class
class
final class
FailedFuture<V>
TheCompleteFuture
which is failed already.(package private) static class
(package private) static class
(package private) class
PromiseTask<V>
(package private) final class
final class
TheCompleteFuture
which is succeeded already.private static final class
Fields in io.netty.util.concurrent declared as FutureModifier and TypeFieldDescriptionprivate final Future
<?> GlobalEventExecutor.terminationFuture
private final Future
<?> ImmediateEventExecutor.terminationFuture
Fields in io.netty.util.concurrent with type parameters of type FutureModifier and TypeFieldDescriptionprivate GenericFutureListener
<? extends Future<?>> DefaultPromise.listener
One or more listeners.private final GenericFutureListener
<Future<?>> PromiseCombiner.listener
Methods in io.netty.util.concurrent with type parameters of type FutureModifier and TypeMethodDescriptionstatic <V,
F extends Future<V>>
Fstatic <V,
F extends Future<V>>
FMethods in io.netty.util.concurrent that return FutureModifier and TypeMethodDescriptionCompleteFuture.addListener
(GenericFutureListener<? extends Future<? super V>> listener) Future.addListener
(GenericFutureListener<? extends Future<? super V>> listener) Adds the specified listener to this future.CompleteFuture.addListeners
(GenericFutureListener<? extends Future<? super V>>... listeners) Future.addListeners
(GenericFutureListener<? extends Future<? super V>>... listeners) Adds the specified listeners to this future.CompleteFuture.await()
Future.await()
Waits for this future to be completed.CompleteFuture.awaitUninterruptibly()
Future.awaitUninterruptibly()
Waits for this future to be completed without interruption.<V> Future
<V> AbstractEventExecutor.newFailedFuture
(Throwable cause) <V> Future
<V> EventExecutor.newFailedFuture
(Throwable cause) Create a newFuture
which is marked as failed already.<V> Future
<V> UnorderedThreadPoolEventExecutor.newFailedFuture
(Throwable cause) <V> Future
<V> AbstractEventExecutor.newSucceededFuture
(V result) <V> Future
<V> EventExecutor.newSucceededFuture
(V result) Create a newFuture
which is marked as succeeded already.<V> Future
<V> UnorderedThreadPoolEventExecutor.newSucceededFuture
(V result) CompleteFuture.removeListener
(GenericFutureListener<? extends Future<? super V>> listener) Future.removeListener
(GenericFutureListener<? extends Future<? super V>> listener) Removes the first occurrence of the specified listener from this future.CompleteFuture.removeListeners
(GenericFutureListener<? extends Future<? super V>>... listeners) Future.removeListeners
(GenericFutureListener<? extends Future<? super V>>... listeners) Removes the first occurrence for each of the listeners from this future.Future
<?> AbstractEventExecutor.shutdownGracefully()
Future
<?> AbstractEventExecutorGroup.shutdownGracefully()
Future
<?> EventExecutorGroup.shutdownGracefully()
Shortcut method forEventExecutorGroup.shutdownGracefully(long, long, TimeUnit)
with sensible default values.Future
<?> EventExecutorGroup.shutdownGracefully
(long quietPeriod, long timeout, TimeUnit unit) Signals this executor that the caller wants the executor to be shut down.Future
<?> GlobalEventExecutor.shutdownGracefully
(long quietPeriod, long timeout, TimeUnit unit) Future
<?> ImmediateEventExecutor.shutdownGracefully
(long quietPeriod, long timeout, TimeUnit unit) Future
<?> MultithreadEventExecutorGroup.shutdownGracefully
(long quietPeriod, long timeout, TimeUnit unit) Future
<?> NonStickyEventExecutorGroup.NonStickyOrderedEventExecutor.shutdownGracefully
(long quietPeriod, long timeout, TimeUnit unit) Future
<?> NonStickyEventExecutorGroup.shutdownGracefully()
Future
<?> NonStickyEventExecutorGroup.shutdownGracefully
(long quietPeriod, long timeout, TimeUnit unit) Future
<?> SingleThreadEventExecutor.shutdownGracefully
(long quietPeriod, long timeout, TimeUnit unit) Future
<?> UnorderedThreadPoolEventExecutor.shutdownGracefully()
Future
<?> UnorderedThreadPoolEventExecutor.shutdownGracefully
(long quietPeriod, long timeout, TimeUnit unit) Future
<?> <T> Future
<T> <T> Future
<T> Future
<?> <T> Future
<T> <T> Future
<T> Future
<?> <T> Future
<T> <T> Future
<T> Future
<?> <T> Future
<T> <T> Future
<T> Future
<?> <T> Future
<T> <T> Future
<T> CompleteFuture.sync()
FailedFuture.sync()
Future.sync()
Waits for this future until it is done, and rethrows the cause of the failure if this future failed.CompleteFuture.syncUninterruptibly()
FailedFuture.syncUninterruptibly()
Future.syncUninterruptibly()
Waits for this future until it is done, and rethrows the cause of the failure if this future failed.Future
<?> EventExecutorGroup.terminationFuture()
Returns theFuture
which is notified when allEventExecutor
s managed by thisEventExecutorGroup
have been terminated.Future
<?> GlobalEventExecutor.terminationFuture()
Future
<?> ImmediateEventExecutor.terminationFuture()
Future
<?> MultithreadEventExecutorGroup.terminationFuture()
Future
<?> NonStickyEventExecutorGroup.NonStickyOrderedEventExecutor.terminationFuture()
Future
<?> NonStickyEventExecutorGroup.terminationFuture()
Future
<?> SingleThreadEventExecutor.terminationFuture()
Future
<?> UnorderedThreadPoolEventExecutor.terminationFuture()
Methods in io.netty.util.concurrent that return types with arguments of type FutureModifier and TypeMethodDescriptionGenericFutureListener<? extends Future<?>>[]
DefaultFutureListeners.listeners()
Methods in io.netty.util.concurrent with parameters of type FutureModifier and TypeMethodDescriptionvoid
Adds a new future to be combined.void
Adds new futures to be combined.static <X> void
Deprecated.protected static void
DefaultPromise.notifyListener
(EventExecutor eventExecutor, Future<?> future, GenericFutureListener<?> listener) Notify a listener that a future has completed.private static void
DefaultPromise.notifyListener0
(Future future, GenericFutureListener l) private static void
DefaultPromise.notifyListenerWithStackOverFlowProtection
(EventExecutor executor, Future<?> future, GenericFutureListener<?> listener) The logic in this method should be identical toDefaultPromise.notifyListeners()
but cannot share code because the listener(s) cannot be cached for an instance ofDefaultPromise
since the listener(s) may be changed and is protected by a synchronized operation.void
UnaryPromiseNotifier.operationComplete
(Future<T> future) Deprecated.Method parameters in io.netty.util.concurrent with type arguments of type FutureModifier and TypeMethodDescriptionvoid
DefaultFutureListeners.add
(GenericFutureListener<? extends Future<?>> l) CompleteFuture.addListener
(GenericFutureListener<? extends Future<? super V>> listener) DefaultProgressivePromise.addListener
(GenericFutureListener<? extends Future<? super V>> listener) DefaultPromise.addListener
(GenericFutureListener<? extends Future<? super V>> listener) Future.addListener
(GenericFutureListener<? extends Future<? super V>> listener) Adds the specified listener to this future.ProgressiveFuture.addListener
(GenericFutureListener<? extends Future<? super V>> listener) ProgressivePromise.addListener
(GenericFutureListener<? extends Future<? super V>> listener) Promise.addListener
(GenericFutureListener<? extends Future<? super V>> listener) private void
DefaultPromise.addListener0
(GenericFutureListener<? extends Future<? super V>> listener) void
DefaultFutureListeners.remove
(GenericFutureListener<? extends Future<?>> l) CompleteFuture.removeListener
(GenericFutureListener<? extends Future<? super V>> listener) DefaultProgressivePromise.removeListener
(GenericFutureListener<? extends Future<? super V>> listener) DefaultPromise.removeListener
(GenericFutureListener<? extends Future<? super V>> listener) Future.removeListener
(GenericFutureListener<? extends Future<? super V>> listener) Removes the first occurrence of the specified listener from this future.ProgressiveFuture.removeListener
(GenericFutureListener<? extends Future<? super V>> listener) ProgressivePromise.removeListener
(GenericFutureListener<? extends Future<? super V>> listener) Promise.removeListener
(GenericFutureListener<? extends Future<? super V>> listener) private void
DefaultPromise.removeListener0
(GenericFutureListener<? extends Future<? super V>> toRemove) Constructor parameters in io.netty.util.concurrent with type arguments of type FutureModifierConstructorDescription(package private)
DefaultFutureListeners
(GenericFutureListener<? extends Future<?>> first, GenericFutureListener<? extends Future<?>> second)
PromiseCombiner(EventExecutor)
.