Uses of Interface
io.netty.channel.ChannelPromise
Packages that use ChannelPromise
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.
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).
Old blocking I/O based channel API implementation - recommended for
a small number of connections (< 1000).
Abstract SCTP socket interfaces which extend the core channel API.
NIO-based SCTP Channel
API implementation - recommended for a large number of connections (>= 1000).
Old blocking I/O based SCTP channel API implementation - recommended for
a small number of connections (< 1000).
Abstract TCP and UDP socket interfaces which extend the core channel API.
NIO-based socket channel
API implementation - recommended for a large number of connections (>= 1000).
Old blocking I/O based socket channel API implementation - recommended for
a small number of connections (< 1000).
Package to dynamically replace local / remote
SocketAddress
.Extensible decoder and its common implementations which deal with the
packet fragmentation and reassembly issue found in a stream-based transport
such as TCP/IP.
Encoder, decoder and their related message types for HTTP.
This package contains Cross Origin Resource Sharing (CORS) related classes.
Encoder, decoder, handshakers and their related message types for
Web Socket data frames.
Encoder, decoder, handshakers to handle
WebSocket Extensions.
Handlers for sending and receiving HTTP/2 frames.
Encoder, decoder, session handler and their related message types for the SPDY protocol.
Package to control flush behavior.
Logs the I/O events for debugging purpose.
Capture data and write into Pcap format which helps in troubleshooting.
Adds support for client connections via proxy protocols such as
SOCKS and
HTTP CONNECT tunneling
Writes very large data stream asynchronously neither spending a lot of
memory nor getting
OutOfMemoryError
.Adds support for read and write timeout and idle connection notification
using a
Timer
.Implementation of a Traffic Shaping Handler and Dynamic Statistics.
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.
-
Uses of ChannelPromise in io.netty.bootstrap
Classes in io.netty.bootstrap that implement ChannelPromiseModifier and TypeClassDescription(package private) static final class
Methods in io.netty.bootstrap with parameters of type ChannelPromiseModifier and TypeMethodDescriptionvoid
FailedChannel.FailedChannelUnsafe.connect
(SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) private static void
AbstractBootstrap.doBind0
(ChannelFuture regFuture, Channel channel, SocketAddress localAddress, ChannelPromise promise) private static void
Bootstrap.doConnect
(SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise connectPromise) private ChannelFuture
Bootstrap.doResolveAndConnect0
(Channel channel, SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) -
Uses of ChannelPromise in io.netty.channel
Subinterfaces of ChannelPromise in io.netty.channelModifier and TypeInterfaceDescriptioninterface
SpecialChannelPromise
which will be notified once the associated bytes is transferring.Classes in io.netty.channel that implement ChannelPromiseModifier and TypeClassDescription(package private) static final class
class
The defaultChannelProgressivePromise
implementation.class
The defaultChannelPromise
implementation.final class
final class
Fields in io.netty.channel declared as ChannelPromiseModifier and TypeFieldDescriptionprivate final ChannelPromise
DelegatingChannelPromiseNotifier.delegate
private final ChannelPromise
ChannelFlushPromiseNotifier.DefaultFlushCheckpoint.future
private ChannelPromise
AbstractChannelHandlerContext.WriteTask.promise
(package private) ChannelPromise
ChannelOutboundBuffer.Entry.promise
private ChannelPromise
PendingWriteQueue.PendingWrite.promise
Methods in io.netty.channel that return ChannelPromiseModifier and TypeMethodDescriptionChannelPromise.addListener
(GenericFutureListener<? extends Future<? super Void>> listener) DefaultChannelPromise.addListener
(GenericFutureListener<? extends Future<? super Void>> listener) DelegatingChannelPromiseNotifier.addListener
(GenericFutureListener<? extends Future<? super Void>> listener) ChannelPromise.addListeners
(GenericFutureListener<? extends Future<? super Void>>... listeners) DefaultChannelPromise.addListeners
(GenericFutureListener<? extends Future<? super Void>>... listeners) DelegatingChannelPromiseNotifier.addListeners
(GenericFutureListener<? extends Future<? super Void>>... listeners) ChannelPromise.await()
DefaultChannelPromise.await()
DelegatingChannelPromiseNotifier.await()
ChannelPromise.awaitUninterruptibly()
DefaultChannelPromise.awaitUninterruptibly()
DelegatingChannelPromiseNotifier.awaitUninterruptibly()
AbstractChannel.newPromise()
AbstractChannelHandlerContext.newPromise()
ChannelOutboundInvoker.newPromise()
Return a newChannelPromise
.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext.newPromise()
final ChannelPromise
DefaultChannelPipeline.newPromise()
ChannelFlushPromiseNotifier.DefaultFlushCheckpoint.promise()
ChannelFlushPromiseNotifier.FlushCheckpoint.promise()
DefaultChannelPromise.promise()
PendingWriteQueue.remove()
Removes a pending write operation and release it's message viaReferenceCountUtil.safeRelease(Object)
.ChannelPromise.removeListener
(GenericFutureListener<? extends Future<? super Void>> listener) DefaultChannelPromise.removeListener
(GenericFutureListener<? extends Future<? super Void>> listener) DelegatingChannelPromiseNotifier.removeListener
(GenericFutureListener<? extends Future<? super Void>> listener) ChannelPromise.removeListeners
(GenericFutureListener<? extends Future<? super Void>>... listeners) DefaultChannelPromise.removeListeners
(GenericFutureListener<? extends Future<? super Void>>... listeners) DelegatingChannelPromiseNotifier.removeListeners
(GenericFutureListener<? extends Future<? super Void>>... listeners) AbstractChannel.CloseFuture.setFailure
(Throwable cause) ChannelPromise.setFailure
(Throwable cause) DefaultChannelPromise.setFailure
(Throwable cause) DelegatingChannelPromiseNotifier.setFailure
(Throwable cause) AbstractChannel.CloseFuture.setSuccess()
ChannelPromise.setSuccess()
ChannelPromise.setSuccess
(Void result) DefaultChannelPromise.setSuccess()
DefaultChannelPromise.setSuccess
(Void result) DelegatingChannelPromiseNotifier.setSuccess()
DelegatingChannelPromiseNotifier.setSuccess
(Void result) ChannelPromise.sync()
DefaultChannelPromise.sync()
DelegatingChannelPromiseNotifier.sync()
ChannelPromise.syncUninterruptibly()
DefaultChannelPromise.syncUninterruptibly()
DelegatingChannelPromiseNotifier.syncUninterruptibly()
ChannelPromise.unvoid()
DefaultChannelPromise.unvoid()
DelegatingChannelPromiseNotifier.unvoid()
VoidChannelPromise.unvoid()
final ChannelPromise
AbstractChannel.AbstractUnsafe.voidPromise()
final ChannelPromise
AbstractChannel.voidPromise()
AbstractChannelHandlerContext.voidPromise()
Channel.Unsafe.voidPromise()
Return a special ChannelPromise which can be reused and passed to the operations inChannel.Unsafe
.ChannelOutboundInvoker.voidPromise()
Return a special ChannelPromise which can be reused for different operations.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext.voidPromise()
final ChannelPromise
DefaultChannelPipeline.voidPromise()
Methods in io.netty.channel with parameters of type ChannelPromiseModifier and TypeMethodDescriptionfinal void
AbstractCoalescingBufferQueue.add
(ByteBuf buf, ChannelPromise promise) Add a buffer to the end of the queue and associate a promise with it that should be completed when all the buffer's bytes have been consumed from the queue and written.ChannelFlushPromiseNotifier.add
(ChannelPromise promise, int pendingDataSize) Deprecated.ChannelFlushPromiseNotifier.add
(ChannelPromise promise, long pendingDataSize) Add aChannelPromise
to thisChannelFlushPromiseNotifier
which will be notified after the givenpendingDataSize
was reached.void
PendingWriteQueue.add
(Object msg, ChannelPromise promise) Add the givenmsg
andChannelPromise
.final void
AbstractCoalescingBufferQueue.addFirst
(ByteBuf buf, ChannelPromise promise) Add a buffer to the front of the queue and associate a promise with it that should be completed when all the buffer's bytes have been consumed from the queue and written.void
ChannelOutboundBuffer.addMessage
(Object msg, int size, ChannelPromise promise) Add given message to thisChannelOutboundBuffer
.final void
AbstractChannel.AbstractUnsafe.bind
(SocketAddress localAddress, ChannelPromise promise) AbstractChannel.bind
(SocketAddress localAddress, ChannelPromise promise) AbstractChannelHandlerContext.bind
(SocketAddress localAddress, ChannelPromise promise) void
Channel.Unsafe.bind
(SocketAddress localAddress, ChannelPromise promise) void
ChannelDuplexHandler.bind
(ChannelHandlerContext ctx, SocketAddress localAddress, ChannelPromise promise) CallsChannelOutboundInvoker.bind(SocketAddress, ChannelPromise)
to forward to the nextChannelOutboundHandler
in theChannelPipeline
.void
ChannelOutboundHandler.bind
(ChannelHandlerContext ctx, SocketAddress localAddress, ChannelPromise promise) Called once a bind operation is made.void
ChannelOutboundHandlerAdapter.bind
(ChannelHandlerContext ctx, SocketAddress localAddress, ChannelPromise promise) CallsChannelOutboundInvoker.bind(SocketAddress, ChannelPromise)
to forward to the nextChannelOutboundHandler
in theChannelPipeline
.ChannelOutboundInvoker.bind
(SocketAddress localAddress, ChannelPromise promise) Request to bind to the givenSocketAddress
and notify theChannelFuture
once the operation completes, either because the operation was successful or because of an error.void
CombinedChannelDuplexHandler.bind
(ChannelHandlerContext ctx, SocketAddress localAddress, ChannelPromise promise) CombinedChannelDuplexHandler.DelegatingChannelHandlerContext.bind
(SocketAddress localAddress, ChannelPromise promise) final ChannelFuture
DefaultChannelPipeline.bind
(SocketAddress localAddress, ChannelPromise promise) void
DefaultChannelPipeline.HeadContext.bind
(ChannelHandlerContext ctx, SocketAddress localAddress, ChannelPromise promise) void
AbstractChannel.AbstractUnsafe.close
(ChannelPromise promise) private void
AbstractChannel.AbstractUnsafe.close
(ChannelPromise promise, Throwable cause, ClosedChannelException closeCause, boolean notify) AbstractChannel.close
(ChannelPromise promise) AbstractChannelHandlerContext.close
(ChannelPromise promise) void
Channel.Unsafe.close
(ChannelPromise promise) Close theChannel
of theChannelPromise
and notify theChannelPromise
once the operation was complete.void
ChannelDuplexHandler.close
(ChannelHandlerContext ctx, ChannelPromise promise) CallsChannelOutboundInvoker.close(ChannelPromise)
to forward to the nextChannelOutboundHandler
in theChannelPipeline
.void
ChannelOutboundHandler.close
(ChannelHandlerContext ctx, ChannelPromise promise) Called once a close operation is made.void
ChannelOutboundHandlerAdapter.close
(ChannelHandlerContext ctx, ChannelPromise promise) CallsChannelOutboundInvoker.close(ChannelPromise)
to forward to the nextChannelOutboundHandler
in theChannelPipeline
.ChannelOutboundInvoker.close
(ChannelPromise promise) Request to close theChannel
and notify theChannelFuture
once the operation completes, either because the operation was successful or because of an error.void
CombinedChannelDuplexHandler.close
(ChannelHandlerContext ctx, ChannelPromise promise) CombinedChannelDuplexHandler.DelegatingChannelHandlerContext.close
(ChannelPromise promise) final ChannelFuture
DefaultChannelPipeline.close
(ChannelPromise promise) void
DefaultChannelPipeline.HeadContext.close
(ChannelHandlerContext ctx, ChannelPromise promise) AbstractChannel.connect
(SocketAddress remoteAddress, ChannelPromise promise) AbstractChannel.connect
(SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) AbstractChannelHandlerContext.connect
(SocketAddress remoteAddress, ChannelPromise promise) AbstractChannelHandlerContext.connect
(SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) void
AbstractServerChannel.DefaultServerUnsafe.connect
(SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) void
Channel.Unsafe.connect
(SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) void
ChannelDuplexHandler.connect
(ChannelHandlerContext ctx, SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) CallsChannelOutboundInvoker.connect(SocketAddress, SocketAddress, ChannelPromise)
to forward to the nextChannelOutboundHandler
in theChannelPipeline
.void
ChannelOutboundHandler.connect
(ChannelHandlerContext ctx, SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) Called once a connect operation is made.void
ChannelOutboundHandlerAdapter.connect
(ChannelHandlerContext ctx, SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) CallsChannelOutboundInvoker.connect(SocketAddress, SocketAddress, ChannelPromise)
to forward to the nextChannelOutboundHandler
in theChannelPipeline
.ChannelOutboundInvoker.connect
(SocketAddress remoteAddress, ChannelPromise promise) Request to connect to the givenSocketAddress
and notify theChannelFuture
once the operation completes, either because the operation was successful or because of an error.ChannelOutboundInvoker.connect
(SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) Request to connect to the givenSocketAddress
while bind to the localAddress and notify theChannelFuture
once the operation completes, either because the operation was successful or because of an error.void
CombinedChannelDuplexHandler.connect
(ChannelHandlerContext ctx, SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) CombinedChannelDuplexHandler.DelegatingChannelHandlerContext.connect
(SocketAddress remoteAddress, ChannelPromise promise) CombinedChannelDuplexHandler.DelegatingChannelHandlerContext.connect
(SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) final ChannelFuture
DefaultChannelPipeline.connect
(SocketAddress remoteAddress, ChannelPromise promise) final ChannelFuture
DefaultChannelPipeline.connect
(SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) void
DefaultChannelPipeline.HeadContext.connect
(ChannelHandlerContext ctx, SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) final void
AbstractChannel.AbstractUnsafe.deregister
(ChannelPromise promise) private void
AbstractChannel.AbstractUnsafe.deregister
(ChannelPromise promise, boolean fireChannelInactive) AbstractChannel.deregister
(ChannelPromise promise) AbstractChannelHandlerContext.deregister
(ChannelPromise promise) void
Channel.Unsafe.deregister
(ChannelPromise promise) Deregister theChannel
of theChannelPromise
fromEventLoop
and notify theChannelPromise
once the operation was complete.void
ChannelDuplexHandler.deregister
(ChannelHandlerContext ctx, ChannelPromise promise) CallsChannelOutboundInvoker.deregister(ChannelPromise)
to forward to the nextChannelOutboundHandler
in theChannelPipeline
.void
ChannelOutboundHandler.deregister
(ChannelHandlerContext ctx, ChannelPromise promise) Called once a deregister operation is made from the current registeredEventLoop
.void
ChannelOutboundHandlerAdapter.deregister
(ChannelHandlerContext ctx, ChannelPromise promise) CallsChannelOutboundInvoker.deregister(ChannelPromise)
to forward to the nextChannelOutboundHandler
in theChannelPipeline
.ChannelOutboundInvoker.deregister
(ChannelPromise promise) Request to deregister from the previous assignedEventExecutor
and notify theChannelFuture
once the operation completes, either because the operation was successful or because of an error.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext.deregister
(ChannelPromise promise) void
CombinedChannelDuplexHandler.deregister
(ChannelHandlerContext ctx, ChannelPromise promise) final ChannelFuture
DefaultChannelPipeline.deregister
(ChannelPromise promise) void
DefaultChannelPipeline.HeadContext.deregister
(ChannelHandlerContext ctx, ChannelPromise promise) final void
AbstractChannel.AbstractUnsafe.disconnect
(ChannelPromise promise) AbstractChannel.disconnect
(ChannelPromise promise) AbstractChannelHandlerContext.disconnect
(ChannelPromise promise) void
Channel.Unsafe.disconnect
(ChannelPromise promise) Disconnect theChannel
of theChannelFuture
and notify theChannelPromise
once the operation was complete.void
ChannelDuplexHandler.disconnect
(ChannelHandlerContext ctx, ChannelPromise promise) CallsChannelOutboundInvoker.disconnect(ChannelPromise)
to forward to the nextChannelOutboundHandler
in theChannelPipeline
.void
ChannelOutboundHandler.disconnect
(ChannelHandlerContext ctx, ChannelPromise promise) Called once a disconnect operation is made.void
ChannelOutboundHandlerAdapter.disconnect
(ChannelHandlerContext ctx, ChannelPromise promise) CallsChannelOutboundInvoker.disconnect(ChannelPromise)
to forward to the nextChannelOutboundHandler
in theChannelPipeline
.ChannelOutboundInvoker.disconnect
(ChannelPromise promise) Request to disconnect from the remote peer and notify theChannelFuture
once the operation completes, either because the operation was successful or because of an error.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext.disconnect
(ChannelPromise promise) void
CombinedChannelDuplexHandler.disconnect
(ChannelHandlerContext ctx, ChannelPromise promise) final ChannelFuture
DefaultChannelPipeline.disconnect
(ChannelPromise promise) void
DefaultChannelPipeline.HeadContext.disconnect
(ChannelHandlerContext ctx, ChannelPromise promise) private void
AbstractChannel.AbstractUnsafe.doClose0
(ChannelPromise promise) protected final boolean
AbstractChannel.AbstractUnsafe.ensureOpen
(ChannelPromise promise) protected static void
AbstractChannelHandlerContext.WriteTask.init
(AbstractChannelHandlerContext.WriteTask task, AbstractChannelHandlerContext ctx, Object msg, ChannelPromise promise, boolean flush) private void
AbstractChannelHandlerContext.invokeBind
(SocketAddress localAddress, ChannelPromise promise) private void
AbstractChannelHandlerContext.invokeClose
(ChannelPromise promise) private void
AbstractChannelHandlerContext.invokeConnect
(SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) private void
AbstractChannelHandlerContext.invokeDeregister
(ChannelPromise promise) private void
AbstractChannelHandlerContext.invokeDisconnect
(ChannelPromise promise) (package private) void
AbstractChannelHandlerContext.invokeWrite
(Object msg, ChannelPromise promise) private void
AbstractChannelHandlerContext.invokeWrite0
(Object msg, ChannelPromise promise) (package private) void
AbstractChannelHandlerContext.invokeWriteAndFlush
(Object msg, ChannelPromise promise) private boolean
AbstractChannelHandlerContext.isNotValidPromise
(ChannelPromise promise, boolean allowVoidPromise) (package private) static AbstractChannelHandlerContext.WriteTask
AbstractChannelHandlerContext.WriteTask.newInstance
(AbstractChannelHandlerContext ctx, Object msg, ChannelPromise promise, boolean flush) (package private) static ChannelOutboundBuffer.Entry
ChannelOutboundBuffer.Entry.newInstance
(Object msg, int size, long total, ChannelPromise promise) (package private) static PendingWriteQueue.PendingWrite
PendingWriteQueue.PendingWrite.newInstance
(Object msg, int size, ChannelPromise promise) private static void
AbstractChannelHandlerContext.notifyOutboundHandlerException
(Throwable cause, ChannelPromise promise) final void
AbstractChannel.AbstractUnsafe.register
(EventLoop eventLoop, ChannelPromise promise) void
Channel.Unsafe.register
(EventLoop eventLoop, ChannelPromise promise) Register theChannel
of theChannelPromise
and notify theChannelFuture
once the registration was complete.EventLoopGroup.register
(ChannelPromise promise) EventLoopGroup.register
(Channel channel, ChannelPromise promise) Deprecated.UseEventLoopGroup.register(ChannelPromise)
instead.MultithreadEventLoopGroup.register
(ChannelPromise promise) MultithreadEventLoopGroup.register
(Channel channel, ChannelPromise promise) Deprecated.SingleThreadEventLoop.register
(ChannelPromise promise) SingleThreadEventLoop.register
(Channel channel, ChannelPromise promise) Deprecated.ThreadPerChannelEventLoop.register
(ChannelPromise promise) Deprecated.ThreadPerChannelEventLoop.register
(Channel channel, ChannelPromise promise) Deprecated.ThreadPerChannelEventLoopGroup.register
(ChannelPromise promise) Deprecated.ThreadPerChannelEventLoopGroup.register
(Channel channel, ChannelPromise promise) Deprecated.private void
AbstractChannel.AbstractUnsafe.register0
(ChannelPromise promise) final ByteBuf
AbstractCoalescingBufferQueue.remove
(ByteBufAllocator alloc, int bytes, ChannelPromise aggregatePromise) Remove aByteBuf
from the queue with the specified number of bytes.CoalescingBufferQueue.remove
(int bytes, ChannelPromise aggregatePromise) Remove aByteBuf
from the queue with the specified number of bytes.final ByteBuf
AbstractCoalescingBufferQueue.removeFirst
(ChannelPromise aggregatePromise) Remove the firstByteBuf
from the queue.private static boolean
AbstractChannelHandlerContext.safeExecute
(EventExecutor executor, Runnable runnable, ChannelPromise promise, Object msg, boolean lazy) private static void
ChannelOutboundBuffer.safeFail
(ChannelPromise promise, Throwable cause) private static void
PendingWriteQueue.safeFail
(ChannelPromise promise, Throwable cause) protected final void
AbstractChannel.AbstractUnsafe.safeSetFailure
(ChannelPromise promise, Throwable cause) Marks the specifiedpromise
as failure.protected final void
AbstractChannel.AbstractUnsafe.safeSetSuccess
(ChannelPromise promise) Marks the specifiedpromise
as success.private static void
ChannelOutboundBuffer.safeSuccess
(ChannelPromise promise) final void
AbstractChannel.AbstractUnsafe.shutdownOutput
(ChannelPromise promise) Shutdown the output portion of the correspondingChannel
.private void
AbstractChannel.AbstractUnsafe.shutdownOutput
(ChannelPromise promise, Throwable cause) Shutdown the output portion of the correspondingChannel
.private static ChannelFutureListener
AbstractCoalescingBufferQueue.toChannelFutureListener
(ChannelPromise promise) final void
AbstractChannel.AbstractUnsafe.write
(Object msg, ChannelPromise promise) AbstractChannel.write
(Object msg, ChannelPromise promise) private void
AbstractChannelHandlerContext.write
(Object msg, boolean flush, ChannelPromise promise) AbstractChannelHandlerContext.write
(Object msg, ChannelPromise promise) void
Channel.Unsafe.write
(Object msg, ChannelPromise promise) Schedules a write operation.void
ChannelDuplexHandler.write
(ChannelHandlerContext ctx, Object msg, ChannelPromise promise) CallsChannelOutboundInvoker.write(Object, ChannelPromise)
to forward to the nextChannelOutboundHandler
in theChannelPipeline
.void
ChannelOutboundHandler.write
(ChannelHandlerContext ctx, Object msg, ChannelPromise promise) Called once a write operation is made.void
ChannelOutboundHandlerAdapter.write
(ChannelHandlerContext ctx, Object msg, ChannelPromise promise) CallsChannelOutboundInvoker.write(Object, ChannelPromise)
to forward to the nextChannelOutboundHandler
in theChannelPipeline
.ChannelOutboundInvoker.write
(Object msg, ChannelPromise promise) Request to write a message via thisChannelHandlerContext
through theChannelPipeline
.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext.write
(Object msg, ChannelPromise promise) void
CombinedChannelDuplexHandler.write
(ChannelHandlerContext ctx, Object msg, ChannelPromise promise) void
DefaultChannelPipeline.HeadContext.write
(ChannelHandlerContext ctx, Object msg, ChannelPromise promise) final ChannelFuture
DefaultChannelPipeline.write
(Object msg, ChannelPromise promise) AbstractChannel.writeAndFlush
(Object msg, ChannelPromise promise) AbstractChannelHandlerContext.writeAndFlush
(Object msg, ChannelPromise promise) ChannelOutboundInvoker.writeAndFlush
(Object msg, ChannelPromise promise) Shortcut for callChannelOutboundInvoker.write(Object, ChannelPromise)
andChannelOutboundInvoker.flush()
.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext.writeAndFlush
(Object msg, ChannelPromise promise) final ChannelFuture
DefaultChannelPipeline.writeAndFlush
(Object msg, ChannelPromise promise) Constructors in io.netty.channel with parameters of type ChannelPromiseModifierConstructorDescriptionChannelPromiseAggregator
(ChannelPromise aggregatePromise) Deprecated.ChannelPromiseNotifier
(boolean logNotifyFailure, ChannelPromise... promises) Deprecated.Create a new instanceChannelPromiseNotifier
(ChannelPromise... promises) Deprecated.Create a new instance(package private)
DefaultFlushCheckpoint
(long checkpoint, ChannelPromise future) DelegatingChannelPromiseNotifier
(ChannelPromise delegate, boolean logNotifyFailure) -
Uses of ChannelPromise in io.netty.channel.embedded
Methods in io.netty.channel.embedded with parameters of type ChannelPromiseModifier and TypeMethodDescriptionEmbeddedChannel.bind
(SocketAddress localAddress, ChannelPromise promise) private ChannelFuture
EmbeddedChannel.checkException
(ChannelPromise promise) Checks for the presence of anException
.final ChannelFuture
EmbeddedChannel.close
(ChannelPromise promise) EmbeddedChannel.connect
(SocketAddress remoteAddress, ChannelPromise promise) EmbeddedChannel.connect
(SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) void
EmbeddedChannel.EmbeddedUnsafe.connect
(SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) EmbeddedChannel.deregister
(ChannelPromise promise) final ChannelFuture
EmbeddedChannel.disconnect
(ChannelPromise promise) private ChannelFuture
EmbeddedChannel.flushInbound
(boolean recordException, ChannelPromise promise) EmbeddedEventLoop.register
(ChannelPromise promise) EmbeddedEventLoop.register
(Channel channel, ChannelPromise promise) Deprecated.EmbeddedChannel.write
(Object msg, ChannelPromise promise) EmbeddedChannel.writeAndFlush
(Object msg, ChannelPromise promise) EmbeddedChannel.writeOneInbound
(Object msg, ChannelPromise promise) Writes one message to the inbound of thisChannel
and does not flush it.EmbeddedChannel.writeOneOutbound
(Object msg, ChannelPromise promise) Writes one message to the outbound of thisChannel
and does not flush it. -
Uses of ChannelPromise in io.netty.channel.epoll
Fields in io.netty.channel.epoll declared as ChannelPromiseModifier and TypeFieldDescriptionprivate ChannelPromise
AbstractEpollChannel.connectPromise
The future of the current connection attempt.private final ChannelPromise
AbstractEpollStreamChannel.SpliceFdTask.promise
(package private) final ChannelPromise
AbstractEpollStreamChannel.SpliceInTask.promise
Methods in io.netty.channel.epoll with parameters of type ChannelPromiseModifier and TypeMethodDescriptionEpollDatagramChannel.block
(InetAddress multicastAddress, InetAddress sourceToBlock, ChannelPromise promise) EpollDatagramChannel.block
(InetAddress multicastAddress, NetworkInterface networkInterface, InetAddress sourceToBlock, ChannelPromise promise) void
AbstractEpollChannel.AbstractEpollUnsafe.connect
(SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) void
AbstractEpollServerChannel.EpollServerSocketUnsafe.connect
(SocketAddress socketAddress, SocketAddress socketAddress2, ChannelPromise channelPromise) private void
AbstractEpollStreamChannel.failSpliceIfClosed
(ChannelPromise promise) private void
AbstractEpollChannel.AbstractEpollUnsafe.fulfillConnectPromise
(ChannelPromise promise, boolean wasActive) private void
AbstractEpollChannel.AbstractEpollUnsafe.fulfillConnectPromise
(ChannelPromise promise, Throwable cause) EpollDatagramChannel.joinGroup
(InetAddress multicastAddress, ChannelPromise promise) EpollDatagramChannel.joinGroup
(InetAddress multicastAddress, NetworkInterface networkInterface, InetAddress source, ChannelPromise promise) EpollDatagramChannel.joinGroup
(InetSocketAddress multicastAddress, NetworkInterface networkInterface, ChannelPromise promise) private void
EpollDatagramChannel.joinGroup0
(InetAddress multicastAddress, NetworkInterface networkInterface, InetAddress source, ChannelPromise promise) EpollDatagramChannel.leaveGroup
(InetAddress multicastAddress, ChannelPromise promise) EpollDatagramChannel.leaveGroup
(InetAddress multicastAddress, NetworkInterface networkInterface, InetAddress source, ChannelPromise promise) EpollDatagramChannel.leaveGroup
(InetSocketAddress multicastAddress, NetworkInterface networkInterface, ChannelPromise promise) private void
EpollDatagramChannel.leaveGroup0
(InetAddress multicastAddress, NetworkInterface networkInterface, InetAddress source, ChannelPromise promise) AbstractEpollStreamChannel.shutdown
(ChannelPromise promise) private static void
AbstractEpollStreamChannel.shutdownDone
(ChannelFuture shutdownOutputFuture, ChannelFuture shutdownInputFuture, ChannelPromise promise) AbstractEpollStreamChannel.shutdownInput
(ChannelPromise promise) private void
AbstractEpollStreamChannel.shutdownInput0
(ChannelPromise promise) AbstractEpollStreamChannel.shutdownOutput
(ChannelPromise promise) private void
AbstractEpollStreamChannel.shutdownOutputDone
(ChannelFuture shutdownOutputFuture, ChannelPromise promise) final ChannelFuture
AbstractEpollStreamChannel.spliceTo
(AbstractEpollStreamChannel ch, int len, ChannelPromise promise) Splice from thisAbstractEpollStreamChannel
to anotherAbstractEpollStreamChannel
.final ChannelFuture
AbstractEpollStreamChannel.spliceTo
(FileDescriptor ch, int offset, int len, ChannelPromise promise) Splice from thisAbstractEpollStreamChannel
to anotherFileDescriptor
.Constructors in io.netty.channel.epoll with parameters of type ChannelPromiseModifierConstructorDescription(package private)
SpliceFdTask
(FileDescriptor fd, int offset, int len, ChannelPromise promise) (package private)
SpliceInChannelTask
(AbstractEpollStreamChannel ch, int len, ChannelPromise promise) protected
SpliceInTask
(int len, ChannelPromise promise) -
Uses of ChannelPromise in io.netty.channel.kqueue
Fields in io.netty.channel.kqueue declared as ChannelPromiseModifier and TypeFieldDescriptionprivate ChannelPromise
AbstractKQueueChannel.connectPromise
The future of the current connection attempt.Methods in io.netty.channel.kqueue with parameters of type ChannelPromiseModifier and TypeMethodDescriptionKQueueDatagramChannel.block
(InetAddress multicastAddress, InetAddress sourceToBlock, ChannelPromise promise) KQueueDatagramChannel.block
(InetAddress multicastAddress, NetworkInterface networkInterface, InetAddress sourceToBlock, ChannelPromise promise) void
AbstractKQueueChannel.AbstractKQueueUnsafe.connect
(SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) private void
AbstractKQueueChannel.AbstractKQueueUnsafe.fulfillConnectPromise
(ChannelPromise promise, boolean wasActive) private void
AbstractKQueueChannel.AbstractKQueueUnsafe.fulfillConnectPromise
(ChannelPromise promise, Throwable cause) KQueueDatagramChannel.joinGroup
(InetAddress multicastAddress, ChannelPromise promise) KQueueDatagramChannel.joinGroup
(InetAddress multicastAddress, NetworkInterface networkInterface, InetAddress source, ChannelPromise promise) KQueueDatagramChannel.joinGroup
(InetSocketAddress multicastAddress, NetworkInterface networkInterface, ChannelPromise promise) KQueueDatagramChannel.leaveGroup
(InetAddress multicastAddress, ChannelPromise promise) KQueueDatagramChannel.leaveGroup
(InetAddress multicastAddress, NetworkInterface networkInterface, InetAddress source, ChannelPromise promise) KQueueDatagramChannel.leaveGroup
(InetSocketAddress multicastAddress, NetworkInterface networkInterface, ChannelPromise promise) AbstractKQueueStreamChannel.shutdown
(ChannelPromise promise) private static void
AbstractKQueueStreamChannel.shutdownDone
(ChannelFuture shutdownOutputFuture, ChannelFuture shutdownInputFuture, ChannelPromise promise) AbstractKQueueStreamChannel.shutdownInput
(ChannelPromise promise) private void
AbstractKQueueStreamChannel.shutdownInput0
(ChannelPromise promise) AbstractKQueueStreamChannel.shutdownOutput
(ChannelPromise promise) private void
AbstractKQueueStreamChannel.shutdownOutputDone
(ChannelFuture shutdownOutputFuture, ChannelPromise promise) -
Uses of ChannelPromise in io.netty.channel.local
Fields in io.netty.channel.local declared as ChannelPromiseMethods in io.netty.channel.local with parameters of type ChannelPromiseModifier and TypeMethodDescriptionvoid
LocalChannel.LocalUnsafe.connect
(SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) -
Uses of ChannelPromise in io.netty.channel.nio
Fields in io.netty.channel.nio declared as ChannelPromiseModifier and TypeFieldDescriptionprivate ChannelPromise
AbstractNioChannel.connectPromise
The future of the current connection attempt.Methods in io.netty.channel.nio with parameters of type ChannelPromiseModifier and TypeMethodDescriptionfinal void
AbstractNioChannel.AbstractNioUnsafe.connect
(SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) private void
AbstractNioChannel.AbstractNioUnsafe.fulfillConnectPromise
(ChannelPromise promise, boolean wasActive) private void
AbstractNioChannel.AbstractNioUnsafe.fulfillConnectPromise
(ChannelPromise promise, Throwable cause) -
Uses of ChannelPromise in io.netty.channel.oio
Methods in io.netty.channel.oio with parameters of type ChannelPromiseModifier and TypeMethodDescriptionvoid
AbstractOioChannel.DefaultOioUnsafe.connect
(SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) -
Uses of ChannelPromise in io.netty.channel.sctp
Methods in io.netty.channel.sctp with parameters of type ChannelPromiseModifier and TypeMethodDescriptionSctpChannel.bindAddress
(InetAddress localAddress, ChannelPromise promise) Bind a address to the already bound channel to enable multi-homing.SctpServerChannel.bindAddress
(InetAddress localAddress, ChannelPromise promise) Bind a address to the already bound channel to enable multi-homing.SctpChannel.unbindAddress
(InetAddress localAddress, ChannelPromise promise) Unbind the address from channel's multi-homing address list.SctpServerChannel.unbindAddress
(InetAddress localAddress, ChannelPromise promise) Unbind the address from channel's multi-homing address list. -
Uses of ChannelPromise in io.netty.channel.sctp.nio
Methods in io.netty.channel.sctp.nio with parameters of type ChannelPromiseModifier and TypeMethodDescriptionNioSctpChannel.bindAddress
(InetAddress localAddress, ChannelPromise promise) NioSctpServerChannel.bindAddress
(InetAddress localAddress, ChannelPromise promise) NioSctpChannel.unbindAddress
(InetAddress localAddress, ChannelPromise promise) NioSctpServerChannel.unbindAddress
(InetAddress localAddress, ChannelPromise promise) -
Uses of ChannelPromise in io.netty.channel.sctp.oio
Methods in io.netty.channel.sctp.oio with parameters of type ChannelPromiseModifier and TypeMethodDescriptionOioSctpChannel.bindAddress
(InetAddress localAddress, ChannelPromise promise) Deprecated.OioSctpServerChannel.bindAddress
(InetAddress localAddress, ChannelPromise promise) Deprecated.OioSctpChannel.unbindAddress
(InetAddress localAddress, ChannelPromise promise) Deprecated.OioSctpServerChannel.unbindAddress
(InetAddress localAddress, ChannelPromise promise) Deprecated. -
Uses of ChannelPromise in io.netty.channel.socket
Methods in io.netty.channel.socket with parameters of type ChannelPromiseModifier and TypeMethodDescriptionDatagramChannel.block
(InetAddress multicastAddress, InetAddress sourceToBlock, ChannelPromise future) Block the given sourceToBlock address for the given multicastAddress and notifies theChannelFuture
once the operation completes.DatagramChannel.block
(InetAddress multicastAddress, NetworkInterface networkInterface, InetAddress sourceToBlock, ChannelPromise future) Block the given sourceToBlock address for the given multicastAddress on the given networkInterface and notifies theChannelFuture
once the operation completes.DatagramChannel.joinGroup
(InetAddress multicastAddress, ChannelPromise future) Joins a multicast group and notifies theChannelFuture
once the operation completes.DatagramChannel.joinGroup
(InetAddress multicastAddress, NetworkInterface networkInterface, InetAddress source, ChannelPromise future) Joins the specified multicast group at the specified interface and notifies theChannelFuture
once the operation completes.DatagramChannel.joinGroup
(InetSocketAddress multicastAddress, NetworkInterface networkInterface, ChannelPromise future) Joins the specified multicast group at the specified interface and notifies theChannelFuture
once the operation completes.DatagramChannel.leaveGroup
(InetAddress multicastAddress, ChannelPromise future) Leaves a multicast group and notifies theChannelFuture
once the operation completes.DatagramChannel.leaveGroup
(InetAddress multicastAddress, NetworkInterface networkInterface, InetAddress source, ChannelPromise future) Leave the specified multicast group at the specified interface using the specified source and notifies theChannelFuture
once the operation completes.DatagramChannel.leaveGroup
(InetSocketAddress multicastAddress, NetworkInterface networkInterface, ChannelPromise future) Leaves a multicast group on a specified local interface and notifies theChannelFuture
once the operation completes.DuplexChannel.shutdown
(ChannelPromise promise) Will shutdown the input and output sides of this channel.DuplexChannel.shutdownInput
(ChannelPromise promise) Will shutdown the input and notifyChannelPromise
.DuplexChannel.shutdownOutput
(ChannelPromise promise) Will shutdown the output and notifyChannelPromise
. -
Uses of ChannelPromise in io.netty.channel.socket.nio
Methods in io.netty.channel.socket.nio with parameters of type ChannelPromiseModifier and TypeMethodDescriptionNioDatagramChannel.block
(InetAddress multicastAddress, InetAddress sourceToBlock, ChannelPromise promise) Block the given sourceToBlock address for the given multicastAddressNioDatagramChannel.block
(InetAddress multicastAddress, NetworkInterface networkInterface, InetAddress sourceToBlock, ChannelPromise promise) Block the given sourceToBlock address for the given multicastAddress on the given networkInterfaceNioDatagramChannel.joinGroup
(InetAddress multicastAddress, ChannelPromise promise) NioDatagramChannel.joinGroup
(InetAddress multicastAddress, NetworkInterface networkInterface, InetAddress source, ChannelPromise promise) NioDatagramChannel.joinGroup
(InetSocketAddress multicastAddress, NetworkInterface networkInterface, ChannelPromise promise) NioDatagramChannel.leaveGroup
(InetAddress multicastAddress, ChannelPromise promise) NioDatagramChannel.leaveGroup
(InetAddress multicastAddress, NetworkInterface networkInterface, InetAddress source, ChannelPromise promise) NioDatagramChannel.leaveGroup
(InetSocketAddress multicastAddress, NetworkInterface networkInterface, ChannelPromise promise) NioDomainSocketChannel.shutdown
(ChannelPromise promise) NioSocketChannel.shutdown
(ChannelPromise promise) private static void
NioDomainSocketChannel.shutdownDone
(ChannelFuture shutdownOutputFuture, ChannelFuture shutdownInputFuture, ChannelPromise promise) private static void
NioSocketChannel.shutdownDone
(ChannelFuture shutdownOutputFuture, ChannelFuture shutdownInputFuture, ChannelPromise promise) NioDomainSocketChannel.shutdownInput
(ChannelPromise promise) NioSocketChannel.shutdownInput
(ChannelPromise promise) private void
NioDomainSocketChannel.shutdownInput0
(ChannelPromise promise) private void
NioSocketChannel.shutdownInput0
(ChannelPromise promise) NioDomainSocketChannel.shutdownOutput
(ChannelPromise promise) NioSocketChannel.shutdownOutput
(ChannelPromise promise) private void
NioDomainSocketChannel.shutdownOutputDone
(ChannelFuture shutdownOutputFuture, ChannelPromise promise) private void
NioSocketChannel.shutdownOutputDone
(ChannelFuture shutdownOutputFuture, ChannelPromise promise) -
Uses of ChannelPromise in io.netty.channel.socket.oio
Methods in io.netty.channel.socket.oio with parameters of type ChannelPromiseModifier and TypeMethodDescriptionOioDatagramChannel.block
(InetAddress multicastAddress, InetAddress sourceToBlock, ChannelPromise promise) Deprecated.OioDatagramChannel.block
(InetAddress multicastAddress, NetworkInterface networkInterface, InetAddress sourceToBlock, ChannelPromise promise) Deprecated.OioDatagramChannel.joinGroup
(InetAddress multicastAddress, ChannelPromise promise) Deprecated.OioDatagramChannel.joinGroup
(InetAddress multicastAddress, NetworkInterface networkInterface, InetAddress source, ChannelPromise promise) Deprecated.OioDatagramChannel.joinGroup
(InetSocketAddress multicastAddress, NetworkInterface networkInterface, ChannelPromise promise) Deprecated.OioDatagramChannel.leaveGroup
(InetAddress multicastAddress, ChannelPromise promise) Deprecated.OioDatagramChannel.leaveGroup
(InetAddress multicastAddress, NetworkInterface networkInterface, InetAddress source, ChannelPromise promise) Deprecated.OioDatagramChannel.leaveGroup
(InetSocketAddress multicastAddress, NetworkInterface networkInterface, ChannelPromise promise) Deprecated.OioSocketChannel.shutdown
(ChannelPromise promise) Deprecated.private static void
OioSocketChannel.shutdownDone
(ChannelFuture shutdownOutputFuture, ChannelFuture shutdownInputFuture, ChannelPromise promise) Deprecated.OioSocketChannel.shutdownInput
(ChannelPromise promise) Deprecated.private void
OioSocketChannel.shutdownInput0
(ChannelPromise promise) Deprecated.OioSocketChannel.shutdownOutput
(ChannelPromise promise) Deprecated.private void
OioSocketChannel.shutdownOutput0
(ChannelPromise promise) Deprecated.private void
OioSocketChannel.shutdownOutputDone
(ChannelFuture shutdownOutputFuture, ChannelPromise promise) Deprecated. -
Uses of ChannelPromise in io.netty.handler.address
Methods in io.netty.handler.address with parameters of type ChannelPromiseModifier and TypeMethodDescriptionfinal void
DynamicAddressConnectHandler.connect
(ChannelHandlerContext ctx, SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) void
ResolveAddressHandler.connect
(ChannelHandlerContext ctx, SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) -
Uses of ChannelPromise in io.netty.handler.codec
Methods in io.netty.handler.codec with parameters of type ChannelPromiseModifier and TypeMethodDescriptionvoid
DatagramPacketEncoder.bind
(ChannelHandlerContext ctx, SocketAddress localAddress, ChannelPromise promise) void
DatagramPacketEncoder.close
(ChannelHandlerContext ctx, ChannelPromise promise) void
DatagramPacketEncoder.connect
(ChannelHandlerContext ctx, SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) void
DatagramPacketEncoder.deregister
(ChannelHandlerContext ctx, ChannelPromise promise) void
DatagramPacketEncoder.disconnect
(ChannelHandlerContext ctx, ChannelPromise promise) void
ByteToMessageCodec.write
(ChannelHandlerContext ctx, Object msg, ChannelPromise promise) void
MessageToByteEncoder.write
(ChannelHandlerContext ctx, Object msg, ChannelPromise promise) void
MessageToMessageCodec.write
(ChannelHandlerContext ctx, Object msg, ChannelPromise promise) void
MessageToMessageEncoder.write
(ChannelHandlerContext ctx, Object msg, ChannelPromise promise) private static void
MessageToMessageEncoder.writePromiseCombiner
(ChannelHandlerContext ctx, CodecOutputList out, ChannelPromise promise) -
Uses of ChannelPromise in io.netty.handler.codec.compression
Methods in io.netty.handler.codec.compression with parameters of type ChannelPromiseModifier and TypeMethodDescriptionvoid
Bzip2Encoder.close
(ChannelHandlerContext ctx, ChannelPromise promise) Bzip2Encoder.close
(ChannelPromise promise) Close thisBzip2Encoder
and so finish the encoding.void
JdkZlibEncoder.close
(ChannelHandlerContext ctx, ChannelPromise promise) JdkZlibEncoder.close
(ChannelPromise promise) void
JZlibEncoder.close
(ChannelHandlerContext ctx, ChannelPromise promise) JZlibEncoder.close
(ChannelPromise promise) abstract ChannelFuture
ZlibEncoder.close
(ChannelPromise promise) Close thisZlibEncoder
and so finish the encoding.(package private) static void
EncoderUtil.closeAfterFinishEncode
(ChannelHandlerContext ctx, ChannelFuture finishFuture, ChannelPromise promise) private ChannelFuture
Bzip2Encoder.finishEncode
(ChannelHandlerContext ctx, ChannelPromise promise) private ChannelFuture
JdkZlibEncoder.finishEncode
(ChannelHandlerContext ctx, ChannelPromise promise) private ChannelFuture
JZlibEncoder.finishEncode
(ChannelHandlerContext ctx, ChannelPromise promise) -
Uses of ChannelPromise in io.netty.handler.codec.http
Methods in io.netty.handler.codec.http with parameters of type ChannelPromiseModifier and TypeMethodDescriptionvoid
HttpClientUpgradeHandler.bind
(ChannelHandlerContext ctx, SocketAddress localAddress, ChannelPromise promise) void
HttpClientUpgradeHandler.close
(ChannelHandlerContext ctx, ChannelPromise promise) void
HttpClientUpgradeHandler.connect
(ChannelHandlerContext ctx, SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) void
HttpClientUpgradeHandler.deregister
(ChannelHandlerContext ctx, ChannelPromise promise) void
HttpClientUpgradeHandler.disconnect
(ChannelHandlerContext ctx, ChannelPromise promise) void
HttpClientUpgradeHandler.write
(ChannelHandlerContext ctx, Object msg, ChannelPromise promise) void
HttpObjectEncoder.write
(ChannelHandlerContext ctx, Object msg, ChannelPromise promise) void
HttpServerKeepAliveHandler.write
(ChannelHandlerContext ctx, Object msg, ChannelPromise promise) private static void
HttpObjectEncoder.writeOutList
(ChannelHandlerContext ctx, List<Object> out, ChannelPromise promise) private static void
HttpObjectEncoder.writePromiseCombiner
(ChannelHandlerContext ctx, List<Object> out, ChannelPromise promise) -
Uses of ChannelPromise in io.netty.handler.codec.http.cors
Methods in io.netty.handler.codec.http.cors with parameters of type ChannelPromiseModifier and TypeMethodDescriptionvoid
CorsHandler.write
(ChannelHandlerContext ctx, Object msg, ChannelPromise promise) -
Uses of ChannelPromise in io.netty.handler.codec.http.websocketx
Fields in io.netty.handler.codec.http.websocketx declared as ChannelPromiseModifier and TypeFieldDescriptionprivate ChannelPromise
WebSocketProtocolHandler.closeSent
private ChannelPromise
WebSocketClientProtocolHandshakeHandler.handshakePromise
private ChannelPromise
WebSocketServerProtocolHandshakeHandler.handshakePromise
Methods in io.netty.handler.codec.http.websocketx with parameters of type ChannelPromiseModifier and TypeMethodDescriptionvoid
WebSocketProtocolHandler.bind
(ChannelHandlerContext ctx, SocketAddress localAddress, ChannelPromise promise) WebSocketClientHandshaker.close
(ChannelHandlerContext ctx, CloseWebSocketFrame frame, ChannelPromise promise) Performs the closing handshakeWebSocketClientHandshaker.close
(Channel channel, CloseWebSocketFrame frame, ChannelPromise promise) Performs the closing handshake When called from within aChannelHandler
you most likely want to useWebSocketClientHandshaker.close(ChannelHandlerContext, CloseWebSocketFrame, ChannelPromise)
.void
WebSocketProtocolHandler.close
(ChannelHandlerContext ctx, ChannelPromise promise) WebSocketServerHandshaker.close
(ChannelHandlerContext ctx, CloseWebSocketFrame frame, ChannelPromise promise) Performs the closing handshake.WebSocketServerHandshaker.close
(Channel channel, CloseWebSocketFrame frame, ChannelPromise promise) Performs the closing handshake.WebSocketServerHandshaker00.close
(ChannelHandlerContext ctx, CloseWebSocketFrame frame, ChannelPromise promise) Echo back the closing frameWebSocketServerHandshaker00.close
(Channel channel, CloseWebSocketFrame frame, ChannelPromise promise) Echo back the closing frameprivate ChannelFuture
WebSocketClientHandshaker.close0
(ChannelOutboundInvoker invoker, Channel channel, CloseWebSocketFrame frame, ChannelPromise promise) private ChannelFuture
WebSocketServerHandshaker.close0
(ChannelOutboundInvoker invoker, CloseWebSocketFrame frame, ChannelPromise promise) (package private) void
WebSocketProtocolHandler.closeSent
(ChannelPromise promise) void
WebSocketProtocolHandler.connect
(ChannelHandlerContext ctx, SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) void
WebSocketProtocolHandler.deregister
(ChannelHandlerContext ctx, ChannelPromise promise) void
WebSocketProtocolHandler.disconnect
(ChannelHandlerContext ctx, ChannelPromise promise) final ChannelFuture
WebSocketClientHandshaker.handshake
(Channel channel, ChannelPromise promise) Begins the opening handshakefinal ChannelFuture
WebSocketServerHandshaker.handshake
(Channel channel, FullHttpRequest req, HttpHeaders responseHeaders, ChannelPromise promise) Performs the opening handshake When call this method you MUST NOT retain theFullHttpRequest
which is passed in.final ChannelFuture
WebSocketServerHandshaker.handshake
(Channel channel, HttpRequest req, HttpHeaders responseHeaders, ChannelPromise promise) Performs the opening handshake When call this method you MUST NOT retain theHttpRequest
which is passed in.final ChannelFuture
WebSocketClientHandshaker.processHandshake
(Channel channel, HttpResponse response, ChannelPromise promise) Process the opening handshake initiated byWebSocketClientHandshaker.handshake(io.netty.channel.Channel)
}.static ChannelFuture
WebSocketServerHandshakerFactory.sendUnsupportedVersionResponse
(Channel channel, ChannelPromise promise) Return that we need cannot support the web socket versionvoid
WebSocketProtocolHandler.write
(ChannelHandlerContext ctx, Object msg, ChannelPromise promise) -
Uses of ChannelPromise in io.netty.handler.codec.http.websocketx.extensions
Methods in io.netty.handler.codec.http.websocketx.extensions with parameters of type ChannelPromiseModifier and TypeMethodDescriptionprivate void
WebSocketServerExtensionHandler.handlePotentialUpgrade
(ChannelHandlerContext ctx, ChannelPromise promise, HttpResponse httpResponse, List<WebSocketServerExtension> validExtensionsList) protected void
WebSocketServerExtensionHandler.onHttpResponseWrite
(ChannelHandlerContext ctx, HttpResponse response, ChannelPromise promise) This is a method exposed to perform fail-fast checks of user-defined http types.void
WebSocketClientExtensionHandler.write
(ChannelHandlerContext ctx, Object msg, ChannelPromise promise) void
WebSocketServerExtensionHandler.write
(ChannelHandlerContext ctx, Object msg, ChannelPromise promise) -
Uses of ChannelPromise in io.netty.handler.codec.http2
Classes in io.netty.handler.codec.http2 that implement ChannelPromiseModifier 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 ChannelPromiseModifier and TypeFieldDescriptionprivate final ChannelPromise
AbstractHttp2StreamChannel.closePromise
protected ChannelPromise
DefaultHttp2ConnectionEncoder.FlowControlledBase.promise
private final ChannelPromise
Http2CodecUtil.SimpleChannelPromiseAggregator.promise
private final ChannelPromise
Http2ConnectionHandler.ClosingChannelFutureListener.promise
(package private) final ChannelPromise
StreamBufferingEncoder.Frame.promise
Methods in io.netty.handler.codec.http2 that return ChannelPromiseModifier and TypeMethodDescriptionHttp2CodecUtil.SimpleChannelPromiseAggregator.doneAllocatingPromises()
Signify that no moreHttp2CodecUtil.SimpleChannelPromiseAggregator.newPromise()
allocations will be made.private ChannelPromise
Http2ControlFrameLimitEncoder.handleOutstandingControlFrames
(ChannelHandlerContext ctx, ChannelPromise promise) AbstractHttp2StreamChannel.newPromise()
Http2CodecUtil.SimpleChannelPromiseAggregator.newPromise()
Allocate a new promise which will be used to aggregate the overall success of this promise aggregator.Http2CodecUtil.SimpleChannelPromiseAggregator.setFailure
(Throwable cause) Fail this object if it has not already been failed.private ChannelPromise
Http2CodecUtil.SimpleChannelPromiseAggregator.setPromise()
Http2CodecUtil.SimpleChannelPromiseAggregator.setSuccess
(Void result) AbstractHttp2StreamChannel.Http2ChannelUnsafe.voidPromise()
AbstractHttp2StreamChannel.voidPromise()
Methods in io.netty.handler.codec.http2 with parameters of type ChannelPromiseModifier and TypeMethodDescriptionAbstractHttp2StreamChannel.bind
(SocketAddress localAddress, ChannelPromise promise) void
AbstractHttp2StreamChannel.Http2ChannelUnsafe.bind
(SocketAddress localAddress, ChannelPromise promise) void
Http2ConnectionHandler.bind
(ChannelHandlerContext ctx, SocketAddress localAddress, ChannelPromise promise) AbstractHttp2StreamChannel.close
(ChannelPromise promise) void
AbstractHttp2StreamChannel.Http2ChannelUnsafe.close
(ChannelPromise promise) (package private) void
AbstractHttp2StreamChannel.Http2ChannelUnsafe.close
(ChannelPromise promise, Http2Error error) void
Http2ConnectionHandler.close
(ChannelHandlerContext ctx, ChannelPromise promise) AbstractHttp2StreamChannel.connect
(SocketAddress remoteAddress, ChannelPromise promise) AbstractHttp2StreamChannel.connect
(SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) void
AbstractHttp2StreamChannel.Http2ChannelUnsafe.connect
(SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) void
Http2ConnectionHandler.connect
(ChannelHandlerContext ctx, SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) AbstractHttp2StreamChannel.deregister
(ChannelPromise promise) void
AbstractHttp2StreamChannel.Http2ChannelUnsafe.deregister
(ChannelPromise promise) void
Http2ConnectionHandler.deregister
(ChannelHandlerContext ctx, ChannelPromise promise) AbstractHttp2StreamChannel.disconnect
(ChannelPromise promise) void
AbstractHttp2StreamChannel.Http2ChannelUnsafe.disconnect
(ChannelPromise promise) void
Http2ConnectionHandler.disconnect
(ChannelHandlerContext ctx, ChannelPromise promise) private void
Http2ConnectionHandler.doGracefulShutdown
(ChannelHandlerContext ctx, ChannelFuture future, ChannelPromise promise) private void
AbstractHttp2StreamChannel.Http2ChannelUnsafe.fireChannelInactiveAndDeregister
(ChannelPromise promise, boolean fireChannelInactive) private void
AbstractHttp2StreamChannel.Http2ChannelUnsafe.firstWriteComplete
(ChannelFuture future, ChannelPromise promise) Http2ConnectionHandler.goAway
(ChannelHandlerContext ctx, int lastStreamId, long errorCode, ByteBuf debugData, ChannelPromise promise) private ChannelFuture
Http2ConnectionHandler.goAway
(ChannelHandlerContext ctx, Http2Exception cause, ChannelPromise promise) Close the remote endpoint with aGO_AWAY
frame.Http2LifecycleManager.goAway
(ChannelHandlerContext ctx, int lastStreamId, long errorCode, ByteBuf debugData, ChannelPromise promise) Prevents the peer from creating streams and close the connection iferrorCode
is notHttp2Error.NO_ERROR
.private ChannelPromise
Http2ControlFrameLimitEncoder.handleOutstandingControlFrames
(ChannelHandlerContext ctx, ChannelPromise promise) private boolean
Http2FrameCodec.initializeNewStream
(ChannelHandlerContext ctx, Http2FrameCodec.DefaultHttp2FrameStream http2FrameStream, ChannelPromise promise) private ChannelFutureListener
Http2ConnectionHandler.newClosingChannelFutureListener
(ChannelHandlerContext ctx, ChannelPromise promise) void
AbstractHttp2StreamChannel.Http2ChannelUnsafe.register
(EventLoop eventLoop, ChannelPromise promise) Http2ConnectionHandler.resetStream
(ChannelHandlerContext ctx, int streamId, long errorCode, ChannelPromise promise) private ChannelFuture
Http2ConnectionHandler.resetStream
(ChannelHandlerContext ctx, Http2Stream stream, long errorCode, ChannelPromise promise) Http2LifecycleManager.resetStream
(ChannelHandlerContext ctx, int streamId, long errorCode, ChannelPromise promise) Ensure the stream identified bystreamId
is reset.private ChannelFuture
Http2ConnectionHandler.resetUnknownStream
(ChannelHandlerContext ctx, int streamId, long errorCode, ChannelPromise promise) Sends aRST_STREAM
frame even if we don't know about the stream.private void
AbstractHttp2StreamChannel.Http2ChannelUnsafe.safeSetSuccess
(ChannelPromise promise) private static ChannelFuture
DefaultHttp2ConnectionEncoder.sendHeaders
(Http2FrameWriter frameWriter, ChannelHandlerContext ctx, int streamId, Http2Headers headers, boolean hasPriority, int streamDependency, short weight, boolean exclusive, int padding, boolean endOfStream, ChannelPromise promise) Write headers viaHttp2FrameWriter
.void
AbstractHttp2StreamChannel.Http2ChannelUnsafe.write
(Object msg, ChannelPromise promise) AbstractHttp2StreamChannel.write
(Object msg, ChannelPromise promise) void
Http2ConnectionHandler.write
(ChannelHandlerContext ctx, Object msg, ChannelPromise promise) void
Http2FrameCodec.write
(ChannelHandlerContext ctx, Object msg, ChannelPromise promise) Processes allHttp2Frame
s.void
HttpToHttp2ConnectionHandler.write
(ChannelHandlerContext ctx, Object msg, ChannelPromise promise) Handles conversion ofHttpMessage
andHttpContent
to HTTP/2 frames.AbstractHttp2StreamChannel.writeAndFlush
(Object msg, ChannelPromise promise) private void
AbstractHttp2StreamChannel.Http2ChannelUnsafe.writeComplete
(ChannelFuture future, ChannelPromise promise) CompressorHttp2ConnectionEncoder.writeData
(ChannelHandlerContext ctx, int streamId, ByteBuf data, int padding, boolean endOfStream, ChannelPromise promise) DecoratingHttp2FrameWriter.writeData
(ChannelHandlerContext ctx, int streamId, ByteBuf data, int padding, boolean endStream, ChannelPromise promise) DefaultHttp2ConnectionEncoder.writeData
(ChannelHandlerContext ctx, int streamId, ByteBuf data, int padding, boolean endOfStream, ChannelPromise promise) DefaultHttp2FrameWriter.writeData
(ChannelHandlerContext ctx, int streamId, ByteBuf data, int padding, boolean endStream, ChannelPromise promise) Http2DataWriter.writeData
(ChannelHandlerContext ctx, int streamId, ByteBuf data, int padding, boolean endStream, ChannelPromise promise) Writes aDATA
frame to the remote endpoint.Http2OutboundFrameLogger.writeData
(ChannelHandlerContext ctx, int streamId, ByteBuf data, int padding, boolean endStream, ChannelPromise promise) StreamBufferingEncoder.writeData
(ChannelHandlerContext ctx, int streamId, ByteBuf data, int padding, boolean endOfStream, ChannelPromise promise) DecoratingHttp2FrameWriter.writeFrame
(ChannelHandlerContext ctx, byte frameType, int streamId, Http2Flags flags, ByteBuf payload, ChannelPromise promise) DefaultHttp2ConnectionEncoder.writeFrame
(ChannelHandlerContext ctx, byte frameType, int streamId, Http2Flags flags, ByteBuf payload, ChannelPromise promise) DefaultHttp2FrameWriter.writeFrame
(ChannelHandlerContext ctx, byte frameType, int streamId, Http2Flags flags, ByteBuf payload, ChannelPromise promise) Http2ConnectionEncoder.writeFrame
(ChannelHandlerContext ctx, byte frameType, int streamId, Http2Flags flags, ByteBuf payload, ChannelPromise promise) Writes the given data to the internalHttp2FrameWriter
without performing any state checks on the connection/stream.Http2FrameWriter.writeFrame
(ChannelHandlerContext ctx, byte frameType, int streamId, Http2Flags flags, ByteBuf payload, ChannelPromise promise) Generic write method for any HTTP/2 frame.Http2OutboundFrameLogger.writeFrame
(ChannelHandlerContext ctx, byte frameType, int streamId, Http2Flags flags, ByteBuf payload, ChannelPromise promise) DecoratingHttp2FrameWriter.writeGoAway
(ChannelHandlerContext ctx, int lastStreamId, long errorCode, ByteBuf debugData, ChannelPromise promise) DefaultHttp2ConnectionEncoder.writeGoAway
(ChannelHandlerContext ctx, int lastStreamId, long errorCode, ByteBuf debugData, ChannelPromise promise) DefaultHttp2FrameWriter.writeGoAway
(ChannelHandlerContext ctx, int lastStreamId, long errorCode, ByteBuf debugData, ChannelPromise promise) Http2FrameWriter.writeGoAway
(ChannelHandlerContext ctx, int lastStreamId, long errorCode, ByteBuf debugData, ChannelPromise promise) Writes a GO_AWAY frame to the remote endpoint.Http2OutboundFrameLogger.writeGoAway
(ChannelHandlerContext ctx, int lastStreamId, long errorCode, ByteBuf debugData, ChannelPromise promise) private void
Http2FrameCodec.writeGoAwayFrame
(ChannelHandlerContext ctx, Http2GoAwayFrame frame, ChannelPromise promise) CompressorHttp2ConnectionEncoder.writeHeaders
(ChannelHandlerContext ctx, int streamId, Http2Headers headers, int padding, boolean endStream, ChannelPromise promise) CompressorHttp2ConnectionEncoder.writeHeaders
(ChannelHandlerContext ctx, int streamId, Http2Headers headers, int streamDependency, short weight, boolean exclusive, int padding, boolean endOfStream, ChannelPromise promise) DecoratingHttp2FrameWriter.writeHeaders
(ChannelHandlerContext ctx, int streamId, Http2Headers headers, int padding, boolean endStream, ChannelPromise promise) DecoratingHttp2FrameWriter.writeHeaders
(ChannelHandlerContext ctx, int streamId, Http2Headers headers, int streamDependency, short weight, boolean exclusive, int padding, boolean endStream, ChannelPromise promise) DefaultHttp2ConnectionEncoder.writeHeaders
(ChannelHandlerContext ctx, int streamId, Http2Headers headers, int padding, boolean endStream, ChannelPromise promise) DefaultHttp2ConnectionEncoder.writeHeaders
(ChannelHandlerContext ctx, int streamId, Http2Headers headers, int streamDependency, short weight, boolean exclusive, int padding, boolean endOfStream, ChannelPromise promise) DefaultHttp2FrameWriter.writeHeaders
(ChannelHandlerContext ctx, int streamId, Http2Headers headers, int padding, boolean endStream, ChannelPromise promise) DefaultHttp2FrameWriter.writeHeaders
(ChannelHandlerContext ctx, int streamId, Http2Headers headers, int streamDependency, short weight, boolean exclusive, int padding, boolean endStream, ChannelPromise promise) Http2FrameWriter.writeHeaders
(ChannelHandlerContext ctx, int streamId, Http2Headers headers, int padding, boolean endStream, ChannelPromise promise) Writes a HEADERS frame to the remote endpoint.Http2FrameWriter.writeHeaders
(ChannelHandlerContext ctx, int streamId, Http2Headers headers, int streamDependency, short weight, boolean exclusive, int padding, boolean endStream, ChannelPromise promise) Writes a HEADERS frame with priority specified to the remote endpoint.Http2OutboundFrameLogger.writeHeaders
(ChannelHandlerContext ctx, int streamId, Http2Headers headers, int padding, boolean endStream, ChannelPromise promise) Http2OutboundFrameLogger.writeHeaders
(ChannelHandlerContext ctx, int streamId, Http2Headers headers, int streamDependency, short weight, boolean exclusive, int padding, boolean endStream, ChannelPromise promise) StreamBufferingEncoder.writeHeaders
(ChannelHandlerContext ctx, int streamId, Http2Headers headers, int padding, boolean endStream, ChannelPromise promise) StreamBufferingEncoder.writeHeaders
(ChannelHandlerContext ctx, int streamId, Http2Headers headers, int streamDependency, short weight, boolean exclusive, int padding, boolean endOfStream, ChannelPromise promise) private ChannelFuture
DefaultHttp2ConnectionEncoder.writeHeaders0
(ChannelHandlerContext ctx, int streamId, Http2Headers headers, boolean hasPriority, int streamDependency, short weight, boolean exclusive, int padding, boolean endOfStream, ChannelPromise promise) private ChannelFuture
StreamBufferingEncoder.writeHeaders0
(ChannelHandlerContext ctx, int streamId, Http2Headers headers, boolean hasPriority, int streamDependency, short weight, boolean exclusive, int padding, boolean endOfStream, ChannelPromise promise) private void
Http2FrameCodec.writeHeadersFrame
(ChannelHandlerContext ctx, Http2HeadersFrame headersFrame, ChannelPromise promise) private ChannelFuture
DefaultHttp2FrameWriter.writeHeadersInternal
(ChannelHandlerContext ctx, int streamId, Http2Headers headers, int padding, boolean endStream, boolean hasPriority, int streamDependency, short weight, boolean exclusive, ChannelPromise promise) private void
AbstractHttp2StreamChannel.Http2ChannelUnsafe.writeHttp2StreamFrame
(Http2StreamFrame frame, ChannelPromise promise) DecoratingHttp2FrameWriter.writePing
(ChannelHandlerContext ctx, boolean ack, long data, ChannelPromise promise) DefaultHttp2ConnectionEncoder.writePing
(ChannelHandlerContext ctx, boolean ack, long data, ChannelPromise promise) DefaultHttp2FrameWriter.writePing
(ChannelHandlerContext ctx, boolean ack, long data, ChannelPromise promise) Http2ControlFrameLimitEncoder.writePing
(ChannelHandlerContext ctx, boolean ack, long data, ChannelPromise promise) Http2FrameWriter.writePing
(ChannelHandlerContext ctx, boolean ack, long data, ChannelPromise promise) Writes a PING frame to the remote endpoint.Http2OutboundFrameLogger.writePing
(ChannelHandlerContext ctx, boolean ack, long data, ChannelPromise promise) DecoratingHttp2FrameWriter.writePriority
(ChannelHandlerContext ctx, int streamId, int streamDependency, short weight, boolean exclusive, ChannelPromise promise) DefaultHttp2ConnectionEncoder.writePriority
(ChannelHandlerContext ctx, int streamId, int streamDependency, short weight, boolean exclusive, ChannelPromise promise) DefaultHttp2FrameWriter.writePriority
(ChannelHandlerContext ctx, int streamId, int streamDependency, short weight, boolean exclusive, ChannelPromise promise) Http2FrameWriter.writePriority
(ChannelHandlerContext ctx, int streamId, int streamDependency, short weight, boolean exclusive, ChannelPromise promise) Writes a PRIORITY frame to the remote endpoint.Http2OutboundFrameLogger.writePriority
(ChannelHandlerContext ctx, int streamId, int streamDependency, short weight, boolean exclusive, ChannelPromise promise) DecoratingHttp2FrameWriter.writePushPromise
(ChannelHandlerContext ctx, int streamId, int promisedStreamId, Http2Headers headers, int padding, ChannelPromise promise) DefaultHttp2ConnectionEncoder.writePushPromise
(ChannelHandlerContext ctx, int streamId, int promisedStreamId, Http2Headers headers, int padding, ChannelPromise promise) DefaultHttp2FrameWriter.writePushPromise
(ChannelHandlerContext ctx, int streamId, int promisedStreamId, Http2Headers headers, int padding, ChannelPromise promise) private void
Http2FrameCodec.writePushPromise
(ChannelHandlerContext ctx, Http2PushPromiseFrame pushPromiseFrame, ChannelPromise promise) Http2FrameWriter.writePushPromise
(ChannelHandlerContext ctx, int streamId, int promisedStreamId, Http2Headers headers, int padding, ChannelPromise promise) Writes a PUSH_PROMISE frame to the remote endpoint.Http2OutboundFrameLogger.writePushPromise
(ChannelHandlerContext ctx, int streamId, int promisedStreamId, Http2Headers headers, int padding, ChannelPromise promise) DecoratingHttp2FrameWriter.writeRstStream
(ChannelHandlerContext ctx, int streamId, long errorCode, ChannelPromise promise) DefaultHttp2ConnectionEncoder.writeRstStream
(ChannelHandlerContext ctx, int streamId, long errorCode, ChannelPromise promise) DefaultHttp2FrameWriter.writeRstStream
(ChannelHandlerContext ctx, int streamId, long errorCode, ChannelPromise promise) Http2ControlFrameLimitEncoder.writeRstStream
(ChannelHandlerContext ctx, int streamId, long errorCode, ChannelPromise promise) Http2FrameWriter.writeRstStream
(ChannelHandlerContext ctx, int streamId, long errorCode, ChannelPromise promise) Writes a RST_STREAM frame to the remote endpoint.Http2OutboundFrameLogger.writeRstStream
(ChannelHandlerContext ctx, int streamId, long errorCode, ChannelPromise promise) StreamBufferingEncoder.writeRstStream
(ChannelHandlerContext ctx, int streamId, long errorCode, ChannelPromise promise) DecoratingHttp2FrameWriter.writeSettings
(ChannelHandlerContext ctx, Http2Settings settings, ChannelPromise promise) DefaultHttp2ConnectionEncoder.writeSettings
(ChannelHandlerContext ctx, Http2Settings settings, ChannelPromise promise) DefaultHttp2FrameWriter.writeSettings
(ChannelHandlerContext ctx, Http2Settings settings, ChannelPromise promise) Http2FrameWriter.writeSettings
(ChannelHandlerContext ctx, Http2Settings settings, ChannelPromise promise) Writes a SETTINGS frame to the remote endpoint.Http2OutboundFrameLogger.writeSettings
(ChannelHandlerContext ctx, Http2Settings settings, ChannelPromise promise) DecoratingHttp2FrameWriter.writeSettingsAck
(ChannelHandlerContext ctx, ChannelPromise promise) DefaultHttp2ConnectionEncoder.writeSettingsAck
(ChannelHandlerContext ctx, ChannelPromise promise) DefaultHttp2FrameWriter.writeSettingsAck
(ChannelHandlerContext ctx, ChannelPromise promise) Http2ControlFrameLimitEncoder.writeSettingsAck
(ChannelHandlerContext ctx, ChannelPromise promise) Http2FrameWriter.writeSettingsAck
(ChannelHandlerContext ctx, ChannelPromise promise) Writes a SETTINGS acknowledgment to the remote endpoint.Http2OutboundFrameLogger.writeSettingsAck
(ChannelHandlerContext ctx, ChannelPromise promise) DecoratingHttp2FrameWriter.writeWindowUpdate
(ChannelHandlerContext ctx, int streamId, int windowSizeIncrement, ChannelPromise promise) DefaultHttp2ConnectionEncoder.writeWindowUpdate
(ChannelHandlerContext ctx, int streamId, int windowSizeIncrement, ChannelPromise promise) DefaultHttp2FrameWriter.writeWindowUpdate
(ChannelHandlerContext ctx, int streamId, int windowSizeIncrement, ChannelPromise promise) Http2FrameWriter.writeWindowUpdate
(ChannelHandlerContext ctx, int streamId, int windowSizeIncrement, ChannelPromise promise) Writes a WINDOW_UPDATE frame to the remote endpoint.Http2OutboundFrameLogger.writeWindowUpdate
(ChannelHandlerContext ctx, int streamId, int windowSizeIncrement, ChannelPromise promise) Constructors in io.netty.handler.codec.http2 with parameters of type ChannelPromiseModifierConstructorDescription(package private)
ClosingChannelFutureListener
(ChannelHandlerContext ctx, ChannelPromise promise) (package private)
ClosingChannelFutureListener
(ChannelHandlerContext ctx, ChannelPromise promise, long timeout, TimeUnit unit) (package private)
DataFrame
(ByteBuf data, int padding, boolean endOfStream, ChannelPromise promise) (package private)
FlowControlledBase
(Http2Stream stream, int padding, boolean endOfStream, ChannelPromise promise) (package private)
FlowControlledData
(Http2Stream stream, ByteBuf buf, int padding, boolean endOfStream, ChannelPromise promise) (package private)
FlowControlledHeaders
(Http2Stream stream, Http2Headers headers, boolean hasPriority, int streamDependency, short weight, boolean exclusive, int padding, boolean endOfStream, ChannelPromise promise) (package private)
Frame
(ChannelPromise promise) (package private)
HeadersFrame
(Http2Headers headers, boolean hasPriority, int streamDependency, short weight, boolean exclusive, int padding, boolean endOfStream, ChannelPromise promise) (package private)
SimpleChannelPromiseAggregator
(ChannelPromise promise, Channel c, EventExecutor e) -
Uses of ChannelPromise in io.netty.handler.codec.spdy
Fields in io.netty.handler.codec.spdy declared as ChannelPromiseModifier and TypeFieldDescription(package private) final ChannelPromise
SpdySession.PendingWrite.promise
private final ChannelPromise
SpdySessionHandler.ClosingChannelFutureListener.promise
Methods in io.netty.handler.codec.spdy with parameters of type ChannelPromiseModifier and TypeMethodDescriptionvoid
SpdyFrameCodec.bind
(ChannelHandlerContext ctx, SocketAddress localAddress, ChannelPromise promise) void
SpdyFrameCodec.close
(ChannelHandlerContext ctx, ChannelPromise promise) void
SpdySessionHandler.close
(ChannelHandlerContext ctx, ChannelPromise promise) void
SpdyFrameCodec.connect
(ChannelHandlerContext ctx, SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) void
SpdyFrameCodec.deregister
(ChannelHandlerContext ctx, ChannelPromise promise) void
SpdyFrameCodec.disconnect
(ChannelHandlerContext ctx, ChannelPromise promise) private void
SpdySessionHandler.handleOutboundMessage
(ChannelHandlerContext ctx, Object msg, ChannelPromise promise) private void
SpdySessionHandler.sendGoAwayFrame
(ChannelHandlerContext ctx, ChannelPromise future) void
SpdyFrameCodec.write
(ChannelHandlerContext ctx, Object msg, ChannelPromise promise) void
SpdySessionHandler.write
(ChannelHandlerContext ctx, Object msg, ChannelPromise promise) Constructors in io.netty.handler.codec.spdy with parameters of type ChannelPromiseModifierConstructorDescription(package private)
ClosingChannelFutureListener
(ChannelHandlerContext ctx, ChannelPromise promise) (package private)
PendingWrite
(SpdyDataFrame spdyDataFrame, ChannelPromise promise) -
Uses of ChannelPromise in io.netty.handler.flush
Methods in io.netty.handler.flush with parameters of type ChannelPromiseModifier and TypeMethodDescriptionvoid
FlushConsolidationHandler.close
(ChannelHandlerContext ctx, ChannelPromise promise) void
FlushConsolidationHandler.disconnect
(ChannelHandlerContext ctx, ChannelPromise promise) -
Uses of ChannelPromise in io.netty.handler.logging
Methods in io.netty.handler.logging with parameters of type ChannelPromiseModifier and TypeMethodDescriptionvoid
LoggingHandler.bind
(ChannelHandlerContext ctx, SocketAddress localAddress, ChannelPromise promise) void
LoggingHandler.close
(ChannelHandlerContext ctx, ChannelPromise promise) void
LoggingHandler.connect
(ChannelHandlerContext ctx, SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) void
LoggingHandler.deregister
(ChannelHandlerContext ctx, ChannelPromise promise) void
LoggingHandler.disconnect
(ChannelHandlerContext ctx, ChannelPromise promise) void
LoggingHandler.write
(ChannelHandlerContext ctx, Object msg, ChannelPromise promise) -
Uses of ChannelPromise in io.netty.handler.pcap
Methods in io.netty.handler.pcap with parameters of type ChannelPromiseModifier and TypeMethodDescriptionvoid
PcapWriteHandler.write
(ChannelHandlerContext ctx, Object msg, ChannelPromise promise) -
Uses of ChannelPromise in io.netty.handler.proxy
Methods in io.netty.handler.proxy with parameters of type ChannelPromiseModifier and TypeMethodDescriptionprivate void
ProxyHandler.addPendingWrite
(ChannelHandlerContext ctx, Object msg, ChannelPromise promise) void
HttpProxyHandler.HttpClientCodecWrapper.bind
(ChannelHandlerContext ctx, SocketAddress localAddress, ChannelPromise promise) void
HttpProxyHandler.HttpClientCodecWrapper.close
(ChannelHandlerContext ctx, ChannelPromise promise) void
HttpProxyHandler.HttpClientCodecWrapper.connect
(ChannelHandlerContext ctx, SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) final void
ProxyHandler.connect
(ChannelHandlerContext ctx, SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) void
HttpProxyHandler.HttpClientCodecWrapper.deregister
(ChannelHandlerContext ctx, ChannelPromise promise) void
HttpProxyHandler.HttpClientCodecWrapper.disconnect
(ChannelHandlerContext ctx, ChannelPromise promise) void
HttpProxyHandler.HttpClientCodecWrapper.write
(ChannelHandlerContext ctx, Object msg, ChannelPromise promise) final void
ProxyHandler.write
(ChannelHandlerContext ctx, Object msg, ChannelPromise promise) -
Uses of ChannelPromise in io.netty.handler.ssl
Methods in io.netty.handler.ssl with parameters of type ChannelPromiseModifier and TypeMethodDescriptionprivate static void
SslHandler.addCloseListener
(ChannelFuture future, ChannelPromise promise) void
SslClientHelloHandler.bind
(ChannelHandlerContext ctx, SocketAddress localAddress, ChannelPromise promise) void
SslHandler.bind
(ChannelHandlerContext ctx, SocketAddress localAddress, ChannelPromise promise) void
SslClientHelloHandler.close
(ChannelHandlerContext ctx, ChannelPromise promise) void
SslHandler.close
(ChannelHandlerContext ctx, ChannelPromise promise) SslHandler.close
(ChannelPromise promise) Deprecated.SslHandler.closeOutbound
(ChannelPromise promise) Sends an SSLclose_notify
message to the specified channel and destroys the underlyingSSLEngine
.private void
SslHandler.closeOutbound0
(ChannelPromise promise) private void
SslHandler.closeOutboundAndChannel
(ChannelHandlerContext ctx, ChannelPromise promise, boolean disconnect) void
SslClientHelloHandler.connect
(ChannelHandlerContext ctx, SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) void
SslHandler.connect
(ChannelHandlerContext ctx, SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) void
SslClientHelloHandler.deregister
(ChannelHandlerContext ctx, ChannelPromise promise) void
SslHandler.deregister
(ChannelHandlerContext ctx, ChannelPromise promise) void
SslClientHelloHandler.disconnect
(ChannelHandlerContext ctx, ChannelPromise promise) void
SslHandler.disconnect
(ChannelHandlerContext ctx, ChannelPromise promise) private void
SslHandler.flush
(ChannelHandlerContext ctx, ChannelPromise promise) private void
SslHandler.safeClose
(ChannelHandlerContext ctx, ChannelFuture flushFuture, ChannelPromise promise) void
SslClientHelloHandler.write
(ChannelHandlerContext ctx, Object msg, ChannelPromise promise) void
SslHandler.write
(ChannelHandlerContext ctx, Object msg, ChannelPromise promise) -
Uses of ChannelPromise in io.netty.handler.stream
Fields in io.netty.handler.stream declared as ChannelPromiseModifier and TypeFieldDescription(package private) final ChannelPromise
ChunkedWriteHandler.PendingWrite.promise
Methods in io.netty.handler.stream with parameters of type ChannelPromiseModifier and TypeMethodDescriptionvoid
ChunkedWriteHandler.write
(ChannelHandlerContext ctx, Object msg, ChannelPromise promise) Constructors in io.netty.handler.stream with parameters of type ChannelPromise -
Uses of ChannelPromise in io.netty.handler.timeout
Fields in io.netty.handler.timeout declared as ChannelPromiseModifier and TypeFieldDescriptionprivate final ChannelPromise
WriteTimeoutHandler.WriteTimeoutTask.promise
Methods in io.netty.handler.timeout with parameters of type ChannelPromiseModifier and TypeMethodDescriptionprivate void
WriteTimeoutHandler.scheduleTimeout
(ChannelHandlerContext ctx, ChannelPromise promise) void
IdleStateHandler.write
(ChannelHandlerContext ctx, Object msg, ChannelPromise promise) void
WriteTimeoutHandler.write
(ChannelHandlerContext ctx, Object msg, ChannelPromise promise) Constructors in io.netty.handler.timeout with parameters of type ChannelPromiseModifierConstructorDescription(package private)
WriteTimeoutTask
(ChannelHandlerContext ctx, ChannelPromise promise) -
Uses of ChannelPromise in io.netty.handler.traffic
Fields in io.netty.handler.traffic declared as ChannelPromiseModifier and TypeFieldDescription(package private) final ChannelPromise
ChannelTrafficShapingHandler.ToSend.promise
(package private) final ChannelPromise
GlobalChannelTrafficShapingHandler.ToSend.promise
(package private) final ChannelPromise
GlobalTrafficShapingHandler.ToSend.promise
Methods in io.netty.handler.traffic with parameters of type ChannelPromiseModifier and TypeMethodDescription(package private) abstract void
AbstractTrafficShapingHandler.submitWrite
(ChannelHandlerContext ctx, Object msg, long size, long delay, long now, ChannelPromise promise) protected void
AbstractTrafficShapingHandler.submitWrite
(ChannelHandlerContext ctx, Object msg, long delay, ChannelPromise promise) Deprecated.(package private) void
ChannelTrafficShapingHandler.submitWrite
(ChannelHandlerContext ctx, Object msg, long size, long delay, long now, ChannelPromise promise) protected void
GlobalChannelTrafficShapingHandler.submitWrite
(ChannelHandlerContext ctx, Object msg, long size, long writedelay, long now, ChannelPromise promise) (package private) void
GlobalTrafficShapingHandler.submitWrite
(ChannelHandlerContext ctx, Object msg, long size, long writedelay, long now, ChannelPromise promise) void
AbstractTrafficShapingHandler.write
(ChannelHandlerContext ctx, Object msg, ChannelPromise promise) void
GlobalChannelTrafficShapingHandler.write
(ChannelHandlerContext ctx, Object msg, ChannelPromise promise) Constructors in io.netty.handler.traffic with parameters of type ChannelPromiseModifierConstructorDescriptionprivate
ToSend
(long delay, Object toSend, ChannelPromise promise) private
ToSend
(long delay, Object toSend, long size, ChannelPromise promise) private
ToSend
(long delay, Object toSend, long size, ChannelPromise promise) -
Uses of ChannelPromise in io.netty.resolver.dns
Methods in io.netty.resolver.dns with parameters of type ChannelPromiseModifier and TypeMethodDescriptionprivate void
DnsQueryContext.writeQuery
(DnsQuery query, boolean flush, ChannelPromise promise)
ChannelFlushPromiseNotifier.add(ChannelPromise, long)