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

A

A - Static variable in class io.netty.handler.codec.dns.DnsRecordType
Address record RFC 1035 Returns a 32-bit IPv4 address, most commonly used to map hostnames to an IP address of the host, but also used for DNSBLs, storing subnet masks in RFC 1101, etc.
AAAA - Static variable in class io.netty.handler.codec.dns.DnsRecordType
IPv6 address record RFC 3596 Returns a 128-bit IPv6 address, most commonly used to map hostnames to an IP address of the host.
AbstractAddressResolver<T extends SocketAddress> - Class in io.netty.resolver
A skeletal AddressResolver implementation.
AbstractAddressResolver(EventExecutor) - Constructor for class io.netty.resolver.AbstractAddressResolver
 
AbstractAddressResolver(EventExecutor, Class<? extends T>) - Constructor for class io.netty.resolver.AbstractAddressResolver
 
AbstractBinaryMemcacheDecoder<M extends BinaryMemcacheMessage> - Class in io.netty.handler.codec.memcache.binary
AbstractBinaryMemcacheDecoder() - Constructor for class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheDecoder
Create a new AbstractBinaryMemcacheDecoder with default settings.
AbstractBinaryMemcacheDecoder(int) - Constructor for class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheDecoder
Create a new AbstractBinaryMemcacheDecoder with custom settings.
AbstractBinaryMemcacheEncoder<M extends BinaryMemcacheMessage> - Class in io.netty.handler.codec.memcache.binary
A MessageToByteEncoder that encodes binary memcache messages into bytes.
AbstractBinaryMemcacheEncoder() - Constructor for class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheEncoder
 
AbstractBinaryMemcacheMessage - Class in io.netty.handler.codec.memcache.binary
Default implementation of a BinaryMemcacheMessage.
AbstractBinaryMemcacheMessage(ByteBuf, ByteBuf) - Constructor for class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
Create a new instance with all properties set.
AbstractBootstrap<B extends AbstractBootstrap<B,C>,C extends Channel> - Class in io.netty.bootstrap
AbstractBootstrap is a helper class that makes it easy to bootstrap a Channel.
AbstractBootstrapConfig<B extends AbstractBootstrap<B,C>,C extends Channel> - Class in io.netty.bootstrap
Exposes the configuration of an AbstractBootstrap.
AbstractBootstrapConfig(B) - Constructor for class io.netty.bootstrap.AbstractBootstrapConfig
 
AbstractByteBuf - Class in io.netty.buffer
A skeletal implementation of a buffer.
AbstractByteBuf(int) - Constructor for class io.netty.buffer.AbstractByteBuf
 
AbstractByteBufAllocator - Class in io.netty.buffer
Skeletal ByteBufAllocator implementation to extend.
AbstractByteBufAllocator() - Constructor for class io.netty.buffer.AbstractByteBufAllocator
Instance use heap buffers by default
AbstractByteBufAllocator(boolean) - Constructor for class io.netty.buffer.AbstractByteBufAllocator
Create new instance
AbstractChannel - Class in io.netty.channel
A skeletal Channel implementation.
AbstractChannel(Channel) - Constructor for class io.netty.channel.AbstractChannel
Creates a new instance.
AbstractChannel(Channel, ChannelId) - Constructor for class io.netty.channel.AbstractChannel
Creates a new instance.
AbstractChannel.AbstractUnsafe - Class in io.netty.channel
Unsafe implementation which sub-classes must extend and use.
AbstractChannelPoolHandler - Class in io.netty.channel.pool
A skeletal ChannelPoolHandler implementation.
AbstractChannelPoolHandler() - Constructor for class io.netty.channel.pool.AbstractChannelPoolHandler
 
AbstractChannelPoolMap<K,P extends ChannelPool> - Class in io.netty.channel.pool
A skeletal ChannelPoolMap implementation.
AbstractChannelPoolMap() - Constructor for class io.netty.channel.pool.AbstractChannelPoolMap
 
AbstractConstant<T extends AbstractConstant<T>> - Class in io.netty.util
Base implementation of Constant.
AbstractConstant(int, String) - Constructor for class io.netty.util.AbstractConstant
Creates a new instance.
AbstractDerivedByteBuf - Class in io.netty.buffer
Deprecated.
Do not use.
AbstractDerivedByteBuf(int) - Constructor for class io.netty.buffer.AbstractDerivedByteBuf
Deprecated.
 
AbstractDnsMessage - Class in io.netty.handler.codec.dns
A skeletal implementation of DnsMessage.
AbstractDnsMessage(int) - Constructor for class io.netty.handler.codec.dns.AbstractDnsMessage
Creates a new instance with the specified id and DnsOpCode.QUERY opCode.
AbstractDnsMessage(int, DnsOpCode) - Constructor for class io.netty.handler.codec.dns.AbstractDnsMessage
Creates a new instance with the specified id and opCode.
AbstractDnsOptPseudoRrRecord - Class in io.netty.handler.codec.dns
An OPT RR record.
AbstractDnsOptPseudoRrRecord(int, int, int) - Constructor for class io.netty.handler.codec.dns.AbstractDnsOptPseudoRrRecord
 
AbstractDnsOptPseudoRrRecord(int) - Constructor for class io.netty.handler.codec.dns.AbstractDnsOptPseudoRrRecord
 
AbstractDnsRecord - Class in io.netty.handler.codec.dns
A skeletal implementation of DnsRecord.
AbstractDnsRecord(String, DnsRecordType, long) - Constructor for class io.netty.handler.codec.dns.AbstractDnsRecord
Creates a new IN-class record.
AbstractDnsRecord(String, DnsRecordType, int, long) - Constructor for class io.netty.handler.codec.dns.AbstractDnsRecord
Creates a new record.
AbstractEpollServerChannel - Class in io.netty.channel.epoll
 
AbstractEpollServerChannel(int) - Constructor for class io.netty.channel.epoll.AbstractEpollServerChannel
 
AbstractEpollStreamChannel - Class in io.netty.channel.epoll
 
AbstractEpollStreamChannel(Channel, int) - Constructor for class io.netty.channel.epoll.AbstractEpollStreamChannel
 
AbstractEpollStreamChannel(int) - Constructor for class io.netty.channel.epoll.AbstractEpollStreamChannel
 
AbstractEpollStreamChannel(LinuxSocket, boolean) - Constructor for class io.netty.channel.epoll.AbstractEpollStreamChannel
 
AbstractEpollStreamChannel.SpliceInTask - Class in io.netty.channel.epoll
 
AbstractEventExecutor - Class in io.netty.util.concurrent
Abstract base class for EventExecutor implementations.
AbstractEventExecutor() - Constructor for class io.netty.util.concurrent.AbstractEventExecutor
 
AbstractEventExecutor(EventExecutorGroup) - Constructor for class io.netty.util.concurrent.AbstractEventExecutor
 
AbstractEventExecutorGroup - Class in io.netty.util.concurrent
Abstract base class for EventExecutorGroup implementations.
AbstractEventExecutorGroup() - Constructor for class io.netty.util.concurrent.AbstractEventExecutorGroup
 
AbstractEventLoop - Class in io.netty.channel
Skeletal implementation of EventLoop.
AbstractEventLoop() - Constructor for class io.netty.channel.AbstractEventLoop
 
AbstractEventLoop(EventLoopGroup) - Constructor for class io.netty.channel.AbstractEventLoop
 
AbstractEventLoopGroup - Class in io.netty.channel
Skeletal implementation of EventLoopGroup.
AbstractEventLoopGroup() - Constructor for class io.netty.channel.AbstractEventLoopGroup
 
AbstractFuture<V> - Class in io.netty.util.concurrent
Abstract Future implementation which does not allow for cancellation.
AbstractFuture() - Constructor for class io.netty.util.concurrent.AbstractFuture
 
AbstractInternalLogger - Class in io.netty.util.internal.logging
A skeletal implementation of InternalLogger.
AbstractInternalLogger(String) - Constructor for class io.netty.util.internal.logging.AbstractInternalLogger
Creates a new instance.
AbstractKQueueServerChannel - Class in io.netty.channel.kqueue
 
AbstractKQueueStreamChannel - Class in io.netty.channel.kqueue
 
AbstractMemcacheObject - Class in io.netty.handler.codec.memcache
The default MemcacheObject implementation.
AbstractMemcacheObject() - Constructor for class io.netty.handler.codec.memcache.AbstractMemcacheObject
 
AbstractMemcacheObjectAggregator<H extends MemcacheMessage> - Class in io.netty.handler.codec.memcache
A ChannelHandler that aggregates an MemcacheMessage and its following MemcacheContents into a single MemcacheMessage with no following MemcacheContents.
AbstractMemcacheObjectAggregator(int) - Constructor for class io.netty.handler.codec.memcache.AbstractMemcacheObjectAggregator
 
AbstractMemcacheObjectDecoder - Class in io.netty.handler.codec.memcache
Abstract super class for both ascii and binary decoders.
AbstractMemcacheObjectDecoder() - Constructor for class io.netty.handler.codec.memcache.AbstractMemcacheObjectDecoder
 
AbstractMemcacheObjectEncoder<M extends MemcacheMessage> - Class in io.netty.handler.codec.memcache
A general purpose AbstractMemcacheObjectEncoder that encodes MemcacheMessages.
AbstractMemcacheObjectEncoder() - Constructor for class io.netty.handler.codec.memcache.AbstractMemcacheObjectEncoder
 
AbstractNioByteChannel - Class in io.netty.channel.nio
AbstractNioChannel base class for Channels that operate on bytes.
AbstractNioByteChannel(Channel, SelectableChannel) - Constructor for class io.netty.channel.nio.AbstractNioByteChannel
Create a new instance
AbstractNioByteChannel.NioByteUnsafe - Class in io.netty.channel.nio
 
AbstractNioChannel - Class in io.netty.channel.nio
Abstract base class for Channel implementations which use a Selector based approach.
AbstractNioChannel(Channel, SelectableChannel, int) - Constructor for class io.netty.channel.nio.AbstractNioChannel
Create a new instance
AbstractNioChannel.AbstractNioUnsafe - Class in io.netty.channel.nio
 
AbstractNioChannel.NioUnsafe - Interface in io.netty.channel.nio
Special Unsafe sub-type which allows to access the underlying SelectableChannel
AbstractNioMessageChannel - Class in io.netty.channel.nio
AbstractNioChannel base class for Channels that operate on messages.
AbstractNioMessageChannel(Channel, SelectableChannel, int) - Constructor for class io.netty.channel.nio.AbstractNioMessageChannel
 
AbstractNioUnsafe() - Constructor for class io.netty.channel.nio.AbstractNioChannel.AbstractNioUnsafe
 
AbstractOioByteChannel - Class in io.netty.channel.oio
Abstract base class for OIO which reads and writes bytes from/to a Socket
AbstractOioByteChannel(Channel) - Constructor for class io.netty.channel.oio.AbstractOioByteChannel
 
AbstractOioChannel - Class in io.netty.channel.oio
Abstract base class for Channel implementations that use Old-Blocking-IO
AbstractOioChannel(Channel) - Constructor for class io.netty.channel.oio.AbstractOioChannel
 
AbstractOioMessageChannel - Class in io.netty.channel.oio
Abstract base class for OIO which reads and writes objects from/to a Socket
AbstractOioMessageChannel(Channel) - Constructor for class io.netty.channel.oio.AbstractOioMessageChannel
 
AbstractReferenceCounted - Class in io.netty.util
Abstract base class for classes wants to implement ReferenceCounted.
AbstractReferenceCounted() - Constructor for class io.netty.util.AbstractReferenceCounted
 
AbstractReferenceCountedByteBuf - Class in io.netty.buffer
Abstract base class for ByteBuf implementations that count references.
AbstractReferenceCountedByteBuf(int) - Constructor for class io.netty.buffer.AbstractReferenceCountedByteBuf
 
AbstractRemoteAddressFilter<T extends SocketAddress> - Class in io.netty.handler.ipfilter
This class provides the functionality to either accept or reject new Channels based on their IP address.
AbstractRemoteAddressFilter() - Constructor for class io.netty.handler.ipfilter.AbstractRemoteAddressFilter
 
AbstractScheduledEventExecutor - Class in io.netty.util.concurrent
Abstract base class for EventExecutors that want to support scheduling.
AbstractScheduledEventExecutor() - Constructor for class io.netty.util.concurrent.AbstractScheduledEventExecutor
 
AbstractScheduledEventExecutor(EventExecutorGroup) - Constructor for class io.netty.util.concurrent.AbstractScheduledEventExecutor
 
AbstractServerChannel - Class in io.netty.channel
A skeletal server-side Channel implementation.
AbstractServerChannel() - Constructor for class io.netty.channel.AbstractServerChannel
Creates a new instance.
AbstractSniHandler<T> - Class in io.netty.handler.ssl
Enables SNI (Server Name Indication) extension for server side SSL.
AbstractSniHandler() - Constructor for class io.netty.handler.ssl.AbstractSniHandler
 
AbstractStringRedisMessage - Class in io.netty.handler.codec.redis
Abstract class for Simple Strings or Errors.
AbstractTrafficShapingHandler - Class in io.netty.handler.traffic
AbstractTrafficShapingHandler allows to limit the global bandwidth (see GlobalTrafficShapingHandler) or per session bandwidth (see ChannelTrafficShapingHandler), as traffic shaping.
AbstractTrafficShapingHandler(long, long, long, long) - Constructor for class io.netty.handler.traffic.AbstractTrafficShapingHandler
 
AbstractTrafficShapingHandler(long, long, long) - Constructor for class io.netty.handler.traffic.AbstractTrafficShapingHandler
Constructor using default max time as delay allowed value of 15000L ms.
AbstractTrafficShapingHandler(long, long) - Constructor for class io.netty.handler.traffic.AbstractTrafficShapingHandler
Constructor using default Check Interval value of 1000L ms and default max time as delay allowed value of 15000L ms.
AbstractTrafficShapingHandler() - Constructor for class io.netty.handler.traffic.AbstractTrafficShapingHandler
Constructor using NO LIMIT, default Check Interval value of 1000L ms and default max time as delay allowed value of 15000L ms.
AbstractTrafficShapingHandler(long) - Constructor for class io.netty.handler.traffic.AbstractTrafficShapingHandler
Constructor using NO LIMIT and default max time as delay allowed value of 15000L ms.
AbstractUnsafe() - Constructor for class io.netty.channel.AbstractChannel.AbstractUnsafe
 
accelerationFactor() - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
 
accept(byte[]) - Method in class io.netty.channel.unix.Socket
 
accept(ChannelHandlerContext, T) - Method in class io.netty.handler.ipfilter.AbstractRemoteAddressFilter
This method is called immediately after a Channel gets registered.
accept(ChannelHandlerContext, InetSocketAddress) - Method in class io.netty.handler.ipfilter.RuleBasedIpFilter
 
accept(ChannelHandlerContext, InetSocketAddress) - Method in class io.netty.handler.ipfilter.UniqueIpFilter
 
accept(ServerSocketChannel) - Static method in class io.netty.util.internal.SocketUtils
 
ACCEPT_VERSION - Static variable in interface io.netty.handler.codec.stomp.StompHeaders
 
AcceptFilter - Class in io.netty.channel.kqueue
 
AcceptFilter(String, String) - Constructor for class io.netty.channel.kqueue.AcceptFilter
 
acceptInboundMessage(Object) - Method in class io.netty.channel.SimpleChannelInboundHandler
Returns true if the given message should be handled.
acceptInboundMessage(Object) - Method in class io.netty.handler.codec.DatagramPacketDecoder
 
acceptInboundMessage(Object) - Method in class io.netty.handler.codec.MessageAggregator
 
acceptInboundMessage(Object) - Method in class io.netty.handler.codec.MessageToMessageCodec
Returns true if and only if the specified message can be decoded by this codec.
acceptInboundMessage(Object) - Method in class io.netty.handler.codec.MessageToMessageDecoder
Returns true if the given message should be handled.
acceptOutboundMessage(Object) - Method in class io.netty.handler.codec.ByteToMessageCodec
Returns true if and only if the specified message can be encoded by this codec.
acceptOutboundMessage(Object) - Method in class io.netty.handler.codec.DatagramPacketEncoder
 
acceptOutboundMessage(Object) - Method in class io.netty.handler.codec.memcache.AbstractMemcacheObjectEncoder
 
acceptOutboundMessage(Object) - Method in class io.netty.handler.codec.MessageToByteEncoder
Returns true if the given message should be handled.
acceptOutboundMessage(Object) - Method in class io.netty.handler.codec.MessageToMessageCodec
Returns true if and only if the specified message can be encoded by this codec.
acceptOutboundMessage(Object) - Method in class io.netty.handler.codec.MessageToMessageEncoder
Returns true if the given message should be handled.
acceptOutboundMessage(Object) - Method in class io.netty.handler.codec.smtp.SmtpRequestEncoder
 
ACK - Static variable in interface io.netty.handler.codec.stomp.StompHeaders
 
acquire() - Method in interface io.netty.channel.pool.ChannelPool
Acquire a Channel from this ChannelPool.
acquire(Promise<Channel>) - Method in interface io.netty.channel.pool.ChannelPool
Acquire a Channel from this ChannelPool.
acquire(Promise<Channel>) - Method in class io.netty.channel.pool.FixedChannelPool
 
acquire() - Method in class io.netty.channel.pool.SimpleChannelPool
 
acquire(Promise<Channel>) - Method in class io.netty.channel.pool.SimpleChannelPool
 
activate(InputStream, OutputStream) - Method in class io.netty.channel.oio.OioByteStreamChannel
Activate this instance.
ACTIVE - Static variable in interface io.netty.channel.pool.ChannelHealthChecker
ChannelHealthChecker implementation that checks if Channel.isActive() returns true.
actualReadableBytes() - Method in class io.netty.handler.codec.ByteToMessageDecoder
Returns the actual number of readable bytes in the internal cumulative buffer of this decoder.
AdaptiveRecvByteBufAllocator - Class in io.netty.channel
The RecvByteBufAllocator that automatically increases and decreases the predicted buffer size on feed back.
AdaptiveRecvByteBufAllocator() - Constructor for class io.netty.channel.AdaptiveRecvByteBufAllocator
Creates a new predictor with the default parameters.
AdaptiveRecvByteBufAllocator(int, int, int) - Constructor for class io.netty.channel.AdaptiveRecvByteBufAllocator
Creates a new predictor with the specified parameters.
add(ChannelPromise, int) - Method in class io.netty.channel.ChannelFlushPromiseNotifier
add(ChannelPromise, long) - Method in class io.netty.channel.ChannelFlushPromiseNotifier
Add a ChannelPromise to this ChannelFlushPromiseNotifier which will be notified after the given pendingDataSize was reached.
add(ByteBuf) - Method in class io.netty.channel.CoalescingBufferQueue
Add a buffer to the end of the queue.
add(ByteBuf, ChannelPromise) - Method in class io.netty.channel.CoalescingBufferQueue
Add a buffer to the end of the queue and associate a promise with it that should be completed when all the buffers bytes have been consumed from the queue and written.
add(ByteBuf, ChannelFutureListener) - Method in class io.netty.channel.CoalescingBufferQueue
Add a buffer to the end of the queue and associate a listener with it that should be completed when all the buffers bytes have been consumed from the queue and written.
add(Channel) - Method in class io.netty.channel.group.DefaultChannelGroup
 
add(Object, ChannelPromise) - Method in class io.netty.channel.PendingWriteQueue
Add the given msg and ChannelPromise.
add(ByteBuf) - Method in class io.netty.channel.unix.IovArray
Try to add the given ByteBuf.
add(K, V) - Method in class io.netty.handler.codec.DefaultHeaders
 
add(K, Iterable<? extends V>) - Method in class io.netty.handler.codec.DefaultHeaders
 
add(K, V...) - Method in class io.netty.handler.codec.DefaultHeaders
 
add(Headers<? extends K, ? extends V, ?>) - Method in class io.netty.handler.codec.DefaultHeaders
 
add(K, V) - Method in class io.netty.handler.codec.EmptyHeaders
 
add(K, Iterable<? extends V>) - Method in class io.netty.handler.codec.EmptyHeaders
 
add(K, V...) - Method in class io.netty.handler.codec.EmptyHeaders
 
add(Headers<? extends K, ? extends V, ?>) - Method in class io.netty.handler.codec.EmptyHeaders
 
add(K, V) - Method in interface io.netty.handler.codec.Headers
Adds a new header with the specified name and value.
add(K, Iterable<? extends V>) - Method in interface io.netty.handler.codec.Headers
Adds new headers with the specified name and values.
add(K, V...) - Method in interface io.netty.handler.codec.Headers
Adds new headers with the specified name and values.
add(Headers<? extends K, ? extends V, ?>) - Method in interface io.netty.handler.codec.Headers
Adds all header names and values of headers to this object.
ADD - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
add(Promise<V>...) - Method in class io.netty.util.concurrent.PromiseAggregator
Deprecated.
Add the given Promises to the aggregator.
add(Promise) - Method in class io.netty.util.concurrent.PromiseCombiner
Deprecated.
add(Future) - Method in class io.netty.util.concurrent.PromiseCombiner
Adds a new future to be combined.
add(String, V) - Method in class io.netty.util.DomainMappingBuilder
Deprecated.
Adds a mapping that maps the specified (optionally wildcard) host name to the specified output value.
add(String, V) - Method in class io.netty.util.DomainNameMapping
Deprecated.
use DomainNameMappingBuilder to create and fill the mapping instead
add(String, V) - Method in class io.netty.util.DomainNameMappingBuilder
Adds a mapping that maps the specified (optionally wildcard) host name to the specified output value.
add(E) - Method in class io.netty.util.internal.ConcurrentSet
 
add(T) - Method in class io.netty.util.internal.EmptyPriorityQueue
 
add(long) - Method in interface io.netty.util.internal.LongCounter
 
add(Object) - Method in class io.netty.util.internal.RecyclableArrayList
 
add(int, Object) - Method in class io.netty.util.internal.RecyclableArrayList
 
addAfter(String, String, ChannelHandler) - Method in interface io.netty.channel.ChannelPipeline
Inserts a ChannelHandler after an existing handler of this pipeline.
addAfter(EventExecutorGroup, String, String, ChannelHandler) - Method in interface io.netty.channel.ChannelPipeline
Inserts a ChannelHandler after an existing handler of this pipeline.
addAfter(String, String, ChannelHandler) - Method in class io.netty.channel.DefaultChannelPipeline
 
addAfter(EventExecutorGroup, String, String, ChannelHandler) - Method in class io.netty.channel.DefaultChannelPipeline
 
addAll(Promise...) - Method in class io.netty.util.concurrent.PromiseCombiner
Deprecated.
addAll(Future...) - Method in class io.netty.util.concurrent.PromiseCombiner
Adds new futures to be combined.
addAll(Collection<? extends T>) - Method in class io.netty.util.internal.EmptyPriorityQueue
 
addAll(Collection<?>) - Method in class io.netty.util.internal.RecyclableArrayList
 
addAll(int, Collection<?>) - Method in class io.netty.util.internal.RecyclableArrayList
 
addBefore(String, String, ChannelHandler) - Method in interface io.netty.channel.ChannelPipeline
Inserts a ChannelHandler before an existing handler of this pipeline.
addBefore(EventExecutorGroup, String, String, ChannelHandler) - Method in interface io.netty.channel.ChannelPipeline
Inserts a ChannelHandler before an existing handler of this pipeline.
addBefore(String, String, ChannelHandler) - Method in class io.netty.channel.DefaultChannelPipeline
 
addBefore(EventExecutorGroup, String, String, ChannelHandler) - Method in class io.netty.channel.DefaultChannelPipeline
 
addBoolean(K, boolean) - Method in class io.netty.handler.codec.DefaultHeaders
 
addBoolean(K, boolean) - Method in class io.netty.handler.codec.EmptyHeaders
 
addBoolean(K, boolean) - Method in interface io.netty.handler.codec.Headers
Adds a new header.
addByte(K, byte) - Method in class io.netty.handler.codec.DefaultHeaders
 
addByte(K, byte) - Method in class io.netty.handler.codec.EmptyHeaders
 
addByte(K, byte) - Method in interface io.netty.handler.codec.Headers
Adds a new header.
addChar(K, char) - Method in class io.netty.handler.codec.DefaultHeaders
 
addChar(K, char) - Method in class io.netty.handler.codec.EmptyHeaders
 
addChar(K, char) - Method in interface io.netty.handler.codec.Headers
Adds a new header.
addComponent(ByteBuf) - Method in class io.netty.buffer.CompositeByteBuf
Add the given ByteBuf.
addComponent(int, ByteBuf) - Method in class io.netty.buffer.CompositeByteBuf
Add the given ByteBuf on the specific index.
addComponent(boolean, ByteBuf) - Method in class io.netty.buffer.CompositeByteBuf
Add the given ByteBuf and increase the writerIndex if increaseWriterIndex is true.
addComponent(boolean, int, ByteBuf) - Method in class io.netty.buffer.CompositeByteBuf
Add the given ByteBuf on the specific index and increase the writerIndex if increaseWriterIndex is true.
addComponents(ByteBuf...) - Method in class io.netty.buffer.CompositeByteBuf
Add the given ByteBufs.
addComponents(Iterable<ByteBuf>) - Method in class io.netty.buffer.CompositeByteBuf
Add the given ByteBufs.
addComponents(boolean, ByteBuf...) - Method in class io.netty.buffer.CompositeByteBuf
Add the given ByteBufs and increase the writerIndex if increaseWriterIndex is true.
addComponents(boolean, Iterable<ByteBuf>) - Method in class io.netty.buffer.CompositeByteBuf
Add the given ByteBufs and increase the writerIndex if increaseWriterIndex is true.
addComponents(int, ByteBuf...) - Method in class io.netty.buffer.CompositeByteBuf
Add the given ByteBufs on the specific index
addComponents(int, Iterable<ByteBuf>) - Method in class io.netty.buffer.CompositeByteBuf
Add the given ByteBufs on the specific index Be aware that this method does not increase the writerIndex of the CompositeByteBuf.
addDouble(K, double) - Method in class io.netty.handler.codec.DefaultHeaders
 
addDouble(K, double) - Method in class io.netty.handler.codec.EmptyHeaders
 
addDouble(K, double) - Method in interface io.netty.handler.codec.Headers
Adds a new header.
addFirst(String, ChannelHandler) - Method in interface io.netty.channel.ChannelPipeline
Inserts a ChannelHandler at the first position of this pipeline.
addFirst(EventExecutorGroup, String, ChannelHandler) - Method in interface io.netty.channel.ChannelPipeline
Inserts a ChannelHandler at the first position of this pipeline.
addFirst(ChannelHandler...) - Method in interface io.netty.channel.ChannelPipeline
Inserts ChannelHandlers at the first position of this pipeline.
addFirst(EventExecutorGroup, ChannelHandler...) - Method in interface io.netty.channel.ChannelPipeline
Inserts ChannelHandlers at the first position of this pipeline.
addFirst(String, ChannelHandler) - Method in class io.netty.channel.DefaultChannelPipeline
 
addFirst(EventExecutorGroup, String, ChannelHandler) - Method in class io.netty.channel.DefaultChannelPipeline
 
addFirst(ChannelHandler...) - Method in class io.netty.channel.DefaultChannelPipeline
 
addFirst(EventExecutorGroup, ChannelHandler...) - Method in class io.netty.channel.DefaultChannelPipeline
 
addFloat(K, float) - Method in class io.netty.handler.codec.DefaultHeaders
 
addFloat(K, float) - Method in class io.netty.handler.codec.EmptyHeaders
 
addFloat(K, float) - Method in interface io.netty.handler.codec.Headers
Adds a new header.
addFlush() - Method in class io.netty.channel.ChannelOutboundBuffer
Add a flush to this ChannelOutboundBuffer.
addImpl(Headers<? extends K, ? extends V, ?>) - Method in class io.netty.handler.codec.DefaultHeaders
 
addInt(K, int) - Method in class io.netty.handler.codec.DefaultHeaders
 
addInt(K, int) - Method in class io.netty.handler.codec.EmptyHeaders
 
addInt(K, int) - Method in interface io.netty.handler.codec.Headers
Adds a new header.
addLast(String, ChannelHandler) - Method in interface io.netty.channel.ChannelPipeline
Appends a ChannelHandler at the last position of this pipeline.
addLast(EventExecutorGroup, String, ChannelHandler) - Method in interface io.netty.channel.ChannelPipeline
Appends a ChannelHandler at the last position of this pipeline.
addLast(ChannelHandler...) - Method in interface io.netty.channel.ChannelPipeline
Inserts ChannelHandlers at the last position of this pipeline.
addLast(EventExecutorGroup, ChannelHandler...) - Method in interface io.netty.channel.ChannelPipeline
Inserts ChannelHandlers at the last position of this pipeline.
addLast(String, ChannelHandler) - Method in class io.netty.channel.DefaultChannelPipeline
 
addLast(EventExecutorGroup, String, ChannelHandler) - Method in class io.netty.channel.DefaultChannelPipeline
 
addLast(ChannelHandler...) - Method in class io.netty.channel.DefaultChannelPipeline
 
addLast(EventExecutorGroup, ChannelHandler...) - Method in class io.netty.channel.DefaultChannelPipeline
 
addListener(GenericFutureListener<? extends Future<? super Void>>) - Method in interface io.netty.channel.ChannelFuture
 
addListener(GenericFutureListener<? extends Future<? super Void>>) - Method in interface io.netty.channel.ChannelProgressiveFuture
 
addListener(GenericFutureListener<? extends Future<? super Void>>) - Method in interface io.netty.channel.ChannelProgressivePromise
 
addListener(GenericFutureListener<? extends Future<? super Void>>) - Method in interface io.netty.channel.ChannelPromise
 
addListener(GenericFutureListener<? extends Future<? super Void>>) - Method in class io.netty.channel.DefaultChannelProgressivePromise
 
addListener(GenericFutureListener<? extends Future<? super Void>>) - Method in class io.netty.channel.DefaultChannelPromise
 
addListener(GenericFutureListener<? extends Future<? super Void>>) - Method in interface io.netty.channel.group.ChannelGroupFuture
 
addListener(GenericFutureListener<? extends Future<? super V>>) - Method in class io.netty.util.concurrent.CompleteFuture
 
addListener(GenericFutureListener<? extends Future<? super V>>) - Method in class io.netty.util.concurrent.DefaultProgressivePromise
 
addListener(GenericFutureListener<? extends Future<? super V>>) - Method in class io.netty.util.concurrent.DefaultPromise
 
addListener(GenericFutureListener<? extends Future<? super V>>) - Method in interface io.netty.util.concurrent.Future
Adds the specified listener to this future.
addListener(GenericFutureListener<? extends Future<? super V>>) - Method in interface io.netty.util.concurrent.ProgressiveFuture
 
addListener(GenericFutureListener<? extends Future<? super V>>) - Method in interface io.netty.util.concurrent.ProgressivePromise
 
addListener(GenericFutureListener<? extends Future<? super V>>) - Method in interface io.netty.util.concurrent.Promise
 
addListeners(GenericFutureListener<? extends Future<? super Void>>...) - Method in interface io.netty.channel.ChannelFuture
 
addListeners(GenericFutureListener<? extends Future<? super Void>>...) - Method in interface io.netty.channel.ChannelProgressiveFuture
 
addListeners(GenericFutureListener<? extends Future<? super Void>>...) - Method in interface io.netty.channel.ChannelProgressivePromise
 
addListeners(GenericFutureListener<? extends Future<? super Void>>...) - Method in interface io.netty.channel.ChannelPromise
 
addListeners(GenericFutureListener<? extends Future<? super Void>>...) - Method in class io.netty.channel.DefaultChannelProgressivePromise
 
addListeners(GenericFutureListener<? extends Future<? super Void>>...) - Method in class io.netty.channel.DefaultChannelPromise
 
addListeners(GenericFutureListener<? extends Future<? super Void>>...) - Method in interface io.netty.channel.group.ChannelGroupFuture
 
addListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in class io.netty.util.concurrent.CompleteFuture
 
addListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in class io.netty.util.concurrent.DefaultProgressivePromise
 
addListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in class io.netty.util.concurrent.DefaultPromise
 
addListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in interface io.netty.util.concurrent.Future
Adds the specified listeners to this future.
addListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in interface io.netty.util.concurrent.ProgressiveFuture
 
addListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in interface io.netty.util.concurrent.ProgressivePromise
 
addListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in interface io.netty.util.concurrent.Promise
 
addLong(K, long) - Method in class io.netty.handler.codec.DefaultHeaders
 
addLong(K, long) - Method in class io.netty.handler.codec.EmptyHeaders
 
addLong(K, long) - Method in interface io.netty.handler.codec.Headers
Adds a new header.
addMessage(Object, int, ChannelPromise) - Method in class io.netty.channel.ChannelOutboundBuffer
Add given message to this ChannelOutboundBuffer.
addObject(K, Object) - Method in class io.netty.handler.codec.DefaultHeaders
 
addObject(K, Iterable<?>) - Method in class io.netty.handler.codec.DefaultHeaders
 
addObject(K, Object...) - Method in class io.netty.handler.codec.DefaultHeaders
 
addObject(K, Object) - Method in class io.netty.handler.codec.EmptyHeaders
 
addObject(K, Iterable<?>) - Method in class io.netty.handler.codec.EmptyHeaders
 
addObject(K, Object...) - Method in class io.netty.handler.codec.EmptyHeaders
 
addObject(K, Object) - Method in interface io.netty.handler.codec.Headers
Adds a new header.
addObject(K, Iterable<?>) - Method in interface io.netty.handler.codec.Headers
Adds a new header with the specified name and values.
addObject(K, Object...) - Method in interface io.netty.handler.codec.Headers
Adds a new header with the specified name and values.
ADDQ - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
addRecord(DnsSection, DnsRecord) - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
 
addRecord(DnsSection, int, DnsRecord) - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
 
addRecord(DnsSection, DnsRecord) - Method in class io.netty.handler.codec.dns.DatagramDnsQuery
 
addRecord(DnsSection, int, DnsRecord) - Method in class io.netty.handler.codec.dns.DatagramDnsQuery
 
addRecord(DnsSection, DnsRecord) - Method in class io.netty.handler.codec.dns.DatagramDnsResponse
 
addRecord(DnsSection, int, DnsRecord) - Method in class io.netty.handler.codec.dns.DatagramDnsResponse
 
addRecord(DnsSection, DnsRecord) - Method in class io.netty.handler.codec.dns.DefaultDnsQuery
 
addRecord(DnsSection, int, DnsRecord) - Method in class io.netty.handler.codec.dns.DefaultDnsQuery
 
addRecord(DnsSection, DnsRecord) - Method in class io.netty.handler.codec.dns.DefaultDnsResponse
 
addRecord(DnsSection, int, DnsRecord) - Method in class io.netty.handler.codec.dns.DefaultDnsResponse
 
addRecord(DnsSection, DnsRecord) - Method in interface io.netty.handler.codec.dns.DnsMessage
Adds the specified record at the end of the specified section of this DNS message.
addRecord(DnsSection, int, DnsRecord) - Method in interface io.netty.handler.codec.dns.DnsMessage
Adds the specified record at the specified index of the specified section of this DNS message.
addRecord(DnsSection, DnsRecord) - Method in interface io.netty.handler.codec.dns.DnsQuery
 
addRecord(DnsSection, int, DnsRecord) - Method in interface io.netty.handler.codec.dns.DnsQuery
 
addRecord(DnsSection, DnsRecord) - Method in interface io.netty.handler.codec.dns.DnsResponse
 
addRecord(DnsSection, int, DnsRecord) - Method in interface io.netty.handler.codec.dns.DnsResponse
 
address() - Method in class io.netty.channel.unix.NativeInetAddress
 
address(byte[], int, int) - Static method in class io.netty.channel.unix.NativeInetAddress
 
address() - Method in class io.netty.handler.codec.dns.DefaultDnsOptEcsRecord
 
address() - Method in interface io.netty.handler.codec.dns.DnsOptEcsRecord
Returns the bytes of the InetAddress to use.
address(String, ResolvedAddressTypes) - Method in class io.netty.resolver.DefaultHostsFileEntriesResolver
 
address() - Method in class io.netty.resolver.dns.DnsCacheEntry
 
address(String, ResolvedAddressTypes) - Method in interface io.netty.resolver.HostsFileEntriesResolver
Resolve the address of a hostname against the entries in a hosts file, depending on some address types.
addressByName(String) - Static method in class io.netty.util.internal.SocketUtils
 
AddressedEnvelope<M,A extends SocketAddress> - Interface in io.netty.channel
A message that wraps another message with a sender address and a recipient address.
addressesFromNetworkInterface(NetworkInterface) - Static method in class io.netty.util.internal.SocketUtils
 
addressNumber() - Method in enum io.netty.channel.socket.InternetProtocolFamily
Returns the address number of the family.
AddressResolver<T extends SocketAddress> - Interface in io.netty.resolver
Resolves a possibility unresolved SocketAddress.
AddressResolverGroup<T extends SocketAddress> - Class in io.netty.resolver
Creates and manages NameResolvers so that each EventExecutor has its own resolver instance.
AddressResolverGroup() - Constructor for class io.netty.resolver.AddressResolverGroup
 
addressSize() - Static method in class io.netty.util.internal.PlatformDependent
Return the address size of the OS.
addressType() - Method in enum io.netty.channel.socket.InternetProtocolFamily
Returns the address type of this protocol family.
addShort(K, short) - Method in class io.netty.handler.codec.DefaultHeaders
 
addShort(K, short) - Method in class io.netty.handler.codec.EmptyHeaders
 
addShort(K, short) - Method in interface io.netty.handler.codec.Headers
Adds a new header.
addShutdownHook(Runnable) - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
Add a Runnable which will be executed on shutdown of this instance
addSubscription(MqttQoS, String) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.SubscribeBuilder
 
addTask(Runnable) - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
Add a task to the task queue, or throws a RejectedExecutionException if this instance was shutdown before.
addTimeMillis(K, long) - Method in class io.netty.handler.codec.DefaultHeaders
 
addTimeMillis(K, long) - Method in class io.netty.handler.codec.EmptyHeaders
 
addTimeMillis(K, long) - Method in interface io.netty.handler.codec.Headers
Adds a new header.
addTopicFilter(String) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.UnsubscribeBuilder
 
adjustMarkers(int) - Method in class io.netty.buffer.AbstractByteBuf
 
advmss() - Method in class io.netty.channel.epoll.EpollTcpInfo
 
AFSDB - Static variable in class io.netty.handler.codec.dns.DnsRecordType
AFS database record RFC 1183 Location of database servers of an AFS cell.
after - Variable in class io.netty.handler.codec.DefaultHeaders.HeaderEntry
Overall insertion order linked list
after() - Method in class io.netty.handler.codec.DefaultHeaders.HeaderEntry
 
afterRunningAllTasks() - Method in class io.netty.channel.SingleThreadEventLoop
 
afterRunningAllTasks() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
aggregate(O, C) - Method in class io.netty.handler.codec.MessageAggregator
Transfers the information provided by the specified content message to the specified aggregated message.
all() - Static method in class io.netty.channel.group.ChannelMatchers
Returns a ChannelMatcher that matches all Channels.
ALL_IDLE_STATE_EVENT - Static variable in class io.netty.handler.timeout.IdleStateEvent
 
allAddressesByName(String) - Static method in class io.netty.util.internal.SocketUtils
 
alloc() - Method in class io.netty.buffer.ByteBuf
Returns the ByteBufAllocator which created this buffer.
alloc() - Method in class io.netty.buffer.CompositeByteBuf
 
alloc() - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
alloc() - Method in class io.netty.buffer.EmptyByteBuf
 
alloc() - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
alloc() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
alloc() - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
alloc() - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
alloc() - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
alloc() - Method in class io.netty.channel.AbstractChannel
 
alloc() - Method in interface io.netty.channel.Channel
Return the assigned ByteBufAllocator which will be used to allocate ByteBufs.
alloc() - Method in interface io.netty.channel.ChannelHandlerContext
Return the assigned ByteBufAllocator which will be used to allocate ByteBufs.
alloc() - Method in class io.netty.channel.unix.SocketWritableByteChannel
 
allocate(ByteBufAllocator) - Method in class io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator.MaxMessageHandle
 
allocate(ByteBufAllocator) - Method in class io.netty.channel.RecvByteBufAllocator.DelegatingHandle
 
allocate(ByteBufAllocator) - Method in interface io.netty.channel.RecvByteBufAllocator.Handle
Deprecated.
Creates a new receive buffer whose capacity is probably large enough to read all inbound data and small enough not to waste its space.
allocateBuffer(ChannelHandlerContext, ByteBuf, boolean) - Method in class io.netty.handler.codec.compression.JdkZlibEncoder
 
allocateBuffer(ChannelHandlerContext, AddressedEnvelope<DnsQuery, InetSocketAddress>) - Method in class io.netty.handler.codec.dns.DatagramDnsQueryEncoder
Allocate a ByteBuf which will be used for constructing a datagram packet.
allocateBuffer(ChannelHandlerContext, AddressedEnvelope<DnsResponse, InetSocketAddress>) - Method in class io.netty.handler.codec.dns.DatagramDnsResponseEncoder
Allocate a ByteBuf which will be used for constructing a datagram packet.
allocateBuffer(ChannelHandlerContext, I, boolean) - Method in class io.netty.handler.codec.MessageToByteEncoder
Allocate a ByteBuf which will be used as argument of #encode(ChannelHandlerContext, I, ByteBuf).
allocateDirect(int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
Allocate a new direct ByteBuffer with the given initialCapacity.
allocateDirect(int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
Allocate a new direct ByteBuffer with the given initialCapacity.
allocateDirectNoCleaner(int) - Static method in class io.netty.util.internal.PlatformDependent
Allocate a new ByteBuffer with the given capacity.
allocateMemory(long) - Static method in class io.netty.util.internal.PlatformDependent
 
allocateUninitializedArray(int) - Static method in class io.netty.util.internal.PlatformDependent
 
ALLOCATOR - Static variable in class io.netty.channel.ChannelOption
 
ALLOW_HALF_CLOSURE - Static variable in class io.netty.channel.ChannelOption
 
annotateConnectException(Throwable, SocketAddress) - Method in class io.netty.channel.AbstractChannel.AbstractUnsafe
Appends the remote address to the message of the exceptions caused by connection attempt failure.
ANY - Static variable in class io.netty.channel.local.LocalAddress
 
ANY - Static variable in class io.netty.handler.codec.dns.DnsRecordType
All cached records RFC 1035 Returns all records of all types known to the name server.
APL - Static variable in class io.netty.handler.codec.dns.DnsRecordType
Address Prefix List record RFC 3123 Specify lists of address ranges, e.g.
append(Date, StringBuilder) - Static method in class io.netty.handler.codec.DateFormatter
Append a Date to a StringBuilder into RFC1123 format
APPEND - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
append(char) - Method in class io.netty.util.internal.AppendableCharSequence
 
append(CharSequence) - Method in class io.netty.util.internal.AppendableCharSequence
 
append(CharSequence, int, int) - Method in class io.netty.util.internal.AppendableCharSequence
 
AppendableCharSequence - Class in io.netty.util.internal
 
AppendableCharSequence(int) - Constructor for class io.netty.util.internal.AppendableCharSequence
 
appendPrettyHexDump(StringBuilder, ByteBuf) - Static method in class io.netty.buffer.ByteBufUtil
Appends the prettified multi-line hexadecimal dump of the specified ByteBuf to the specified StringBuilder that is easy to read by humans.
appendPrettyHexDump(StringBuilder, ByteBuf, int, int) - Static method in class io.netty.buffer.ByteBufUtil
Appends the prettified multi-line hexadecimal dump of the specified ByteBuf to the specified StringBuilder that is easy to read by humans, starting at the given offset using the given length.
APPENDQ - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
applicationProtocol() - Method in class io.netty.handler.ssl.SslHandler
Returns the name of the current application-level protocol.
ApplicationProtocolConfig - Class in io.netty.handler.ssl
Provides an SSLEngine agnostic way to configure a ApplicationProtocolNegotiator.
ApplicationProtocolConfig(ApplicationProtocolConfig.Protocol, ApplicationProtocolConfig.SelectorFailureBehavior, ApplicationProtocolConfig.SelectedListenerFailureBehavior, Iterable<String>) - Constructor for class io.netty.handler.ssl.ApplicationProtocolConfig
Create a new instance.
ApplicationProtocolConfig(ApplicationProtocolConfig.Protocol, ApplicationProtocolConfig.SelectorFailureBehavior, ApplicationProtocolConfig.SelectedListenerFailureBehavior, String...) - Constructor for class io.netty.handler.ssl.ApplicationProtocolConfig
Create a new instance.
applicationProtocolConfig(ApplicationProtocolConfig) - Method in class io.netty.handler.ssl.SslContextBuilder
Application protocol negotiation configuration.
ApplicationProtocolConfig.Protocol - Enum in io.netty.handler.ssl
Defines which application level protocol negotiation to use.
ApplicationProtocolConfig.SelectedListenerFailureBehavior - Enum in io.netty.handler.ssl
Defines the most common behaviors for the peer which is notified of the selected protocol.
ApplicationProtocolConfig.SelectorFailureBehavior - Enum in io.netty.handler.ssl
Defines the most common behaviors for the peer that selects the application protocol.
ApplicationProtocolNames - Class in io.netty.handler.ssl
Provides a set of protocol names used in ALPN and NPN.
ApplicationProtocolNegotiationHandler - Class in io.netty.handler.ssl
Configures a ChannelPipeline depending on the application-level protocol negotiation result of SslHandler.
ApplicationProtocolNegotiationHandler(String) - Constructor for class io.netty.handler.ssl.ApplicationProtocolNegotiationHandler
Creates a new instance with the specified fallback protocol name.
ApplicationProtocolNegotiator - Interface in io.netty.handler.ssl
Interface to support Application Protocol Negotiation.
applicationProtocolNegotiator() - Method in class io.netty.handler.ssl.DelegatingSslContext
 
applicationProtocolNegotiator() - Method in class io.netty.handler.ssl.JdkSslContext
 
applicationProtocolNegotiator() - Method in class io.netty.handler.ssl.SslContext
Returns the object responsible for negotiating application layer protocols for the TLS NPN/ALPN extensions.
array() - Method in class io.netty.buffer.ByteBuf
Returns the backing byte array of this buffer.
array() - Method in class io.netty.buffer.CompositeByteBuf
 
array() - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
array() - Method in class io.netty.buffer.EmptyByteBuf
 
array() - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
array() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
array() - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
array() - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
array() - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
array() - Method in class io.netty.util.AsciiString
This gives direct access to the underlying storage array.
arrayChanged() - Method in class io.netty.util.AsciiString
During normal use cases the AsciiString should be immutable, but if the underlying array is shared, and changes then this needs to be called.
ArrayHeaderRedisMessage - Class in io.netty.handler.codec.redis
Header of Redis Array Message.
ArrayHeaderRedisMessage(long) - Constructor for class io.netty.handler.codec.redis.ArrayHeaderRedisMessage
Creates a ArrayHeaderRedisMessage for the given length.
arrayList() - Method in class io.netty.util.internal.InternalThreadLocalMap
 
arrayList(int) - Method in class io.netty.util.internal.InternalThreadLocalMap
 
arrayOffset() - Method in class io.netty.buffer.ByteBuf
Returns the offset of the first byte within the backing byte array of this buffer.
arrayOffset() - Method in class io.netty.buffer.CompositeByteBuf
 
arrayOffset() - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
arrayOffset() - Method in class io.netty.buffer.EmptyByteBuf
 
arrayOffset() - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
arrayOffset() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
arrayOffset() - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
arrayOffset() - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
arrayOffset() - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
arrayOffset() - Method in class io.netty.util.AsciiString
The offset into AsciiString.array() for which data for this ByteString begins.
ArrayRedisMessage - Class in io.netty.handler.codec.redis
Arrays of RESP.
ArrayRedisMessage(List<RedisMessage>) - Constructor for class io.netty.handler.codec.redis.ArrayRedisMessage
Creates a ArrayRedisMessage for the given content.
artifactId() - Method in class io.netty.util.Version
 
artifactVersion() - Method in class io.netty.util.Version
 
asAddressResolver() - Method in class io.netty.resolver.InetNameResolver
Return a AddressResolver that will use this name resolver underneath.
AsciiHeadersEncoder - Class in io.netty.handler.codec
 
AsciiHeadersEncoder(ByteBuf) - Constructor for class io.netty.handler.codec.AsciiHeadersEncoder
 
AsciiHeadersEncoder(ByteBuf, AsciiHeadersEncoder.SeparatorType, AsciiHeadersEncoder.NewlineType) - Constructor for class io.netty.handler.codec.AsciiHeadersEncoder
 
AsciiHeadersEncoder.NewlineType - Enum in io.netty.handler.codec
The newline characters to insert between header entries.
AsciiHeadersEncoder.SeparatorType - Enum in io.netty.handler.codec
The separator characters to insert between a header name and a header value.
AsciiString - Class in io.netty.util
A string which has been encoded into a character encoding whose character always takes a single byte, similarly to ASCII.
AsciiString(byte[]) - Constructor for class io.netty.util.AsciiString
Initialize this byte string based upon a byte array.
AsciiString(byte[], boolean) - Constructor for class io.netty.util.AsciiString
Initialize this byte string based upon a byte array.
AsciiString(byte[], int, int, boolean) - Constructor for class io.netty.util.AsciiString
Construct a new instance from a byte[] array.
AsciiString(ByteBuffer) - Constructor for class io.netty.util.AsciiString
Create a copy of the underlying storage from value.
AsciiString(ByteBuffer, boolean) - Constructor for class io.netty.util.AsciiString
Initialize an instance based upon the underlying storage from value.
AsciiString(ByteBuffer, int, int, boolean) - Constructor for class io.netty.util.AsciiString
Initialize an AsciiString based upon the underlying storage from value.
AsciiString(char[]) - Constructor for class io.netty.util.AsciiString
Create a copy of value into this instance assuming ASCII encoding.
AsciiString(char[], int, int) - Constructor for class io.netty.util.AsciiString
Create a copy of value into this instance assuming ASCII encoding.
AsciiString(char[], Charset) - Constructor for class io.netty.util.AsciiString
Create a copy of value into this instance using the encoding type of charset.
AsciiString(char[], Charset, int, int) - Constructor for class io.netty.util.AsciiString
Create a copy of value into a this instance using the encoding type of charset.
AsciiString(CharSequence) - Constructor for class io.netty.util.AsciiString
Create a copy of value into this instance assuming ASCII encoding.
AsciiString(CharSequence, int, int) - Constructor for class io.netty.util.AsciiString
Create a copy of value into this instance assuming ASCII encoding.
AsciiString(CharSequence, Charset) - Constructor for class io.netty.util.AsciiString
Create a copy of value into this instance using the encoding type of charset.
AsciiString(CharSequence, Charset, int, int) - Constructor for class io.netty.util.AsciiString
Create a copy of value into this instance using the encoding type of charset.
asLongText() - Method in interface io.netty.channel.ChannelId
Returns the long yet globally unique string representation of the ChannelId.
asLongText() - Method in class io.netty.channel.DefaultChannelId
 
asMap() - Method in class io.netty.util.DomainNameMapping
Returns a read-only Map of the domain mapping patterns and their associated value objects.
asReadOnly() - Method in class io.netty.buffer.AbstractByteBuf
 
asReadOnly() - Method in class io.netty.buffer.ByteBuf
Returns a read-only version of this buffer.
asReadOnly() - Method in class io.netty.buffer.EmptyByteBuf
 
asReadOnly() - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
asReadOnly() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
asShortText() - Method in interface io.netty.channel.ChannelId
Returns the short but globally non-unique string representation of the ChannelId.
asShortText() - Method in class io.netty.channel.DefaultChannelId
 
AsyncMapping<IN,OUT> - Interface in io.netty.util
 
ato() - Method in class io.netty.channel.epoll.EpollTcpInfo
 
attemptedBytesRead() - Method in class io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator.MaxMessageHandle
 
attemptedBytesRead(int) - Method in class io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator.MaxMessageHandle
 
attemptedBytesRead() - Method in class io.netty.channel.RecvByteBufAllocator.DelegatingHandle
 
attemptedBytesRead(int) - Method in class io.netty.channel.RecvByteBufAllocator.DelegatingHandle
 
attemptedBytesRead(int) - Method in interface io.netty.channel.RecvByteBufAllocator.Handle
Deprecated.
Set how many bytes the read operation will (or did) attempt to read.
attemptedBytesRead() - Method in interface io.netty.channel.RecvByteBufAllocator.Handle
Deprecated.
Get how many bytes the read operation will (or did) attempt to read.
attr(AttributeKey<T>, T) - Method in class io.netty.bootstrap.AbstractBootstrap
Allow to specify an initial attribute of the newly created Channel.
attr(AttributeKey<T>) - Method in interface io.netty.channel.ChannelHandlerContext
attr(AttributeKey<T>) - Method in interface io.netty.util.AttributeMap
Get the Attribute for the given AttributeKey.
attr(AttributeKey<T>) - Method in class io.netty.util.DefaultAttributeMap
 
Attribute<T> - Interface in io.netty.util
An attribute which allows to store a value reference.
AttributeKey<T> - Class in io.netty.util
Key which can be used to access Attribute out of the AttributeMap.
AttributeMap - Interface in io.netty.util
Holds Attributes which can be accessed via AttributeKey.
attrs() - Method in class io.netty.bootstrap.AbstractBootstrapConfig
Returns a copy of the configured attributes.
AUTH_CONTINUE - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseStatus
 
AUTH_ERROR - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseStatus
 
authoritativeDnsServerCache() - Method in class io.netty.resolver.dns.DnsNameResolver
Returns the cache used for authoritative DNS servers for a domain.
authoritativeDnsServerCache(DnsCache) - Method in class io.netty.resolver.dns.DnsNameResolverBuilder
Sets the cache for authoritative NS servers
AUTO_CLOSE - Static variable in class io.netty.channel.ChannelOption
Deprecated.
Auto close will be removed in a future release. If true then the Channel is closed automatically and immediately on write failure. The default value is true.
AUTO_READ - Static variable in class io.netty.channel.ChannelOption
 
autoReadCleared() - Method in class io.netty.channel.DefaultChannelConfig
Is called once DefaultChannelConfig.setAutoRead(boolean) is called with false and DefaultChannelConfig.isAutoRead() was true before.
autoReadCleared() - Method in class io.netty.channel.epoll.EpollChannelConfig
 
autoReadCleared() - Method in class io.netty.channel.kqueue.KQueueChannelConfig
 
autoReadCleared() - Method in class io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig
 
autoReadCleared() - Method in class io.netty.channel.socket.oio.DefaultOioSocketChannelConfig
 
available() - Method in class io.netty.buffer.ByteBufInputStream
 
available() - Method in class io.netty.channel.oio.AbstractOioByteChannel
Return the number of bytes ready to read from the underlying Socket.
available() - Method in class io.netty.channel.oio.OioByteStreamChannel
 
available() - Method in class io.netty.handler.codec.serialization.ObjectDecoderInputStream
 
availableProcessors() - Static method in class io.netty.util.NettyRuntime
Get the configured number of available processors.
await() - Method in interface io.netty.channel.ChannelFuture
 
await() - Method in interface io.netty.channel.ChannelProgressiveFuture
 
await() - Method in interface io.netty.channel.ChannelProgressivePromise
 
await() - Method in interface io.netty.channel.ChannelPromise
 
await() - Method in class io.netty.channel.DefaultChannelProgressivePromise
 
await() - Method in class io.netty.channel.DefaultChannelPromise
 
await() - Method in interface io.netty.channel.group.ChannelGroupFuture
 
await() - Method in class io.netty.util.concurrent.CompleteFuture
 
await(long, TimeUnit) - Method in class io.netty.util.concurrent.CompleteFuture
 
await(long) - Method in class io.netty.util.concurrent.CompleteFuture
 
await() - Method in class io.netty.util.concurrent.DefaultProgressivePromise
 
await() - Method in class io.netty.util.concurrent.DefaultPromise
 
await(long, TimeUnit) - Method in class io.netty.util.concurrent.DefaultPromise
 
await(long) - Method in class io.netty.util.concurrent.DefaultPromise
 
await() - Method in interface io.netty.util.concurrent.Future
Waits for this future to be completed.
await(long, TimeUnit) - Method in interface io.netty.util.concurrent.Future
Waits for this future to be completed within the specified time limit.
await(long) - Method in interface io.netty.util.concurrent.Future
Waits for this future to be completed within the specified time limit.
await() - Method in interface io.netty.util.concurrent.ProgressiveFuture
 
await() - Method in interface io.netty.util.concurrent.ProgressivePromise
 
await() - Method in interface io.netty.util.concurrent.Promise
 
awaitInactivity(long, TimeUnit) - Method in class io.netty.util.concurrent.GlobalEventExecutor
Waits until the worker thread of this executor has no tasks left in its task queue and terminates itself.
awaitInactivity(long, TimeUnit) - Static method in class io.netty.util.ThreadDeathWatcher
Waits until the thread of this watcher has no threads to watch and terminates itself.
awaitTermination(long, TimeUnit) - Method in class io.netty.channel.ThreadPerChannelEventLoopGroup
 
awaitTermination(long, TimeUnit) - Method in class io.netty.util.concurrent.GlobalEventExecutor
 
awaitTermination(long, TimeUnit) - Method in class io.netty.util.concurrent.ImmediateEventExecutor
 
awaitTermination(long, TimeUnit) - Method in class io.netty.util.concurrent.MultithreadEventExecutorGroup
 
awaitTermination(long, TimeUnit) - Method in class io.netty.util.concurrent.NonStickyEventExecutorGroup
 
awaitTermination(long, TimeUnit) - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
 
awaitUninterruptibly() - Method in interface io.netty.channel.ChannelFuture
 
awaitUninterruptibly() - Method in interface io.netty.channel.ChannelProgressiveFuture
 
awaitUninterruptibly() - Method in interface io.netty.channel.ChannelProgressivePromise
 
awaitUninterruptibly() - Method in interface io.netty.channel.ChannelPromise
 
awaitUninterruptibly() - Method in class io.netty.channel.DefaultChannelProgressivePromise
 
awaitUninterruptibly() - Method in class io.netty.channel.DefaultChannelPromise
 
awaitUninterruptibly() - Method in interface io.netty.channel.group.ChannelGroupFuture
 
awaitUninterruptibly() - Method in class io.netty.util.concurrent.CompleteFuture
 
awaitUninterruptibly(long, TimeUnit) - Method in class io.netty.util.concurrent.CompleteFuture
 
awaitUninterruptibly(long) - Method in class io.netty.util.concurrent.CompleteFuture
 
awaitUninterruptibly() - Method in class io.netty.util.concurrent.DefaultProgressivePromise
 
awaitUninterruptibly() - Method in class io.netty.util.concurrent.DefaultPromise
 
awaitUninterruptibly(long, TimeUnit) - Method in class io.netty.util.concurrent.DefaultPromise
 
awaitUninterruptibly(long) - Method in class io.netty.util.concurrent.DefaultPromise
 
awaitUninterruptibly() - Method in interface io.netty.util.concurrent.Future
Waits for this future to be completed without interruption.
awaitUninterruptibly(long, TimeUnit) - Method in interface io.netty.util.concurrent.Future
Waits for this future to be completed within the specified time limit without interruption.
awaitUninterruptibly(long) - Method in interface io.netty.util.concurrent.Future
Waits for this future to be completed within the specified time limit without interruption.
awaitUninterruptibly() - Method in interface io.netty.util.concurrent.ProgressiveFuture
 
awaitUninterruptibly() - Method in interface io.netty.util.concurrent.ProgressivePromise
 
awaitUninterruptibly() - Method in interface io.netty.util.concurrent.Promise
 
AXFR - Static variable in class io.netty.handler.codec.dns.DnsRecordType
Authoritative Zone Transfer record RFC 1035 Transfer entire zone file from the master name server to secondary name servers.

B

b2c(byte) - Static method in class io.netty.util.AsciiString
 
backoff() - Method in class io.netty.channel.epoll.EpollTcpInfo
 
backoff(int, long, TimeUnit) - Static method in class io.netty.util.concurrent.RejectedExecutionHandlers
Tries to backoff when the task can not be added due restrictions for an configured amount of time.
BADALG - Static variable in class io.netty.handler.codec.dns.DnsResponseCode
The 'BADALG' DNS RCODE (21), as defined in RFC2930.
BADKEY - Static variable in class io.netty.handler.codec.dns.DnsResponseCode
The 'BADKEY' DNS RCODE (17), as defined in RFC2845.
BADMODE - Static variable in class io.netty.handler.codec.dns.DnsResponseCode
The 'BADMODE' DNS RCODE (19), as defined in RFC2930.
BADNAME - Static variable in class io.netty.handler.codec.dns.DnsResponseCode
The 'BADNAME' DNS RCODE (20), as defined in RFC2930.
BADTIME - Static variable in class io.netty.handler.codec.dns.DnsResponseCode
The 'BADTIME' DNS RCODE (18), as defined in RFC2845.
BADVERS_OR_BADSIG - Static variable in class io.netty.handler.codec.dns.DnsResponseCode
The 'BADVERS' or 'BADSIG' DNS RCODE (16), as defined in RFC2671 and RFC2845.
Base64 - Class in io.netty.handler.codec.base64
Utility class for ByteBuf that encodes and decodes to and from Base64 notation.
Base64Decoder - Class in io.netty.handler.codec.base64
Decodes a Base64-encoded ByteBuf or US-ASCII String into a ByteBuf.
Base64Decoder() - Constructor for class io.netty.handler.codec.base64.Base64Decoder
 
Base64Decoder(Base64Dialect) - Constructor for class io.netty.handler.codec.base64.Base64Decoder
 
Base64Dialect - Enum in io.netty.handler.codec.base64
Enumeration of supported Base64 dialects.
Base64Encoder - Class in io.netty.handler.codec.base64
Encodes a ByteBuf into a Base64-encoded ByteBuf.
Base64Encoder() - Constructor for class io.netty.handler.codec.base64.Base64Encoder
 
Base64Encoder(boolean) - Constructor for class io.netty.handler.codec.base64.Base64Encoder
 
Base64Encoder(boolean, Base64Dialect) - Constructor for class io.netty.handler.codec.base64.Base64Encoder
 
before - Variable in class io.netty.handler.codec.DefaultHeaders.HeaderEntry
Overall insertion order linked list
before() - Method in class io.netty.handler.codec.DefaultHeaders.HeaderEntry
 
beginAggregation(BinaryMemcacheMessage, ByteBuf) - Method in class io.netty.handler.codec.memcache.binary.BinaryMemcacheObjectAggregator
 
beginAggregation(S, ByteBuf) - Method in class io.netty.handler.codec.MessageAggregator
Creates a new aggregated message from the specified start message and the specified content.
beginAggregation(BulkStringHeaderRedisMessage, ByteBuf) - Method in class io.netty.handler.codec.redis.RedisBulkStringAggregator
 
beginAggregation(StompHeadersSubframe, ByteBuf) - Method in class io.netty.handler.codec.stomp.StompSubframeAggregator
 
beginRead() - Method in class io.netty.channel.AbstractChannel.AbstractUnsafe
 
beginRead() - Method in interface io.netty.channel.Channel.Unsafe
Schedules a read operation that fills the inbound buffer of the first ChannelInboundHandler in the ChannelPipeline.
bestAvailableMac() - Static method in class io.netty.util.internal.MacAddressUtil
Obtains the best MAC address found on local network interfaces.
BiDnsQueryLifecycleObserver - Class in io.netty.resolver.dns
BiDnsQueryLifecycleObserver(DnsQueryLifecycleObserver, DnsQueryLifecycleObserver) - Constructor for class io.netty.resolver.dns.BiDnsQueryLifecycleObserver
Create a new instance.
BiDnsQueryLifecycleObserverFactory - Class in io.netty.resolver.dns
BiDnsQueryLifecycleObserverFactory(DnsQueryLifecycleObserverFactory, DnsQueryLifecycleObserverFactory) - Constructor for class io.netty.resolver.dns.BiDnsQueryLifecycleObserverFactory
Create a new instance.
BIG_ENDIAN - Static variable in class io.netty.buffer.Unpooled
Big endian byte order.
BIG_ENDIAN_NATIVE_ORDER - Static variable in class io.netty.util.internal.PlatformDependent
 
BinaryMemcacheClientCodec - Class in io.netty.handler.codec.memcache.binary
The client codec that combines the proper encoder and decoder.
BinaryMemcacheClientCodec() - Constructor for class io.netty.handler.codec.memcache.binary.BinaryMemcacheClientCodec
Create a new BinaryMemcacheClientCodec with the default settings applied.
BinaryMemcacheClientCodec(int) - Constructor for class io.netty.handler.codec.memcache.binary.BinaryMemcacheClientCodec
Create a new BinaryMemcacheClientCodec and set a custom chunk size.
BinaryMemcacheClientCodec(int, boolean) - Constructor for class io.netty.handler.codec.memcache.binary.BinaryMemcacheClientCodec
Create a new BinaryMemcacheClientCodec with custom settings.
BinaryMemcacheMessage - Interface in io.netty.handler.codec.memcache.binary
An interface that defines a binary Memcache message, providing common properties for BinaryMemcacheRequest and BinaryMemcacheResponse.
BinaryMemcacheObjectAggregator - Class in io.netty.handler.codec.memcache.binary
An object aggregator for the memcache binary protocol.
BinaryMemcacheObjectAggregator(int) - Constructor for class io.netty.handler.codec.memcache.binary.BinaryMemcacheObjectAggregator
 
BinaryMemcacheOpcodes - Class in io.netty.handler.codec.memcache.binary
Represents all Opcodes that can occur in a BinaryMemcacheMessage.
BinaryMemcacheRequest - Interface in io.netty.handler.codec.memcache.binary
Represents a full BinaryMemcacheRequest, which contains the header and optional key and extras.
BinaryMemcacheRequestDecoder - Class in io.netty.handler.codec.memcache.binary
The decoder part which takes care of decoding the request-specific headers.
BinaryMemcacheRequestDecoder() - Constructor for class io.netty.handler.codec.memcache.binary.BinaryMemcacheRequestDecoder
 
BinaryMemcacheRequestDecoder(int) - Constructor for class io.netty.handler.codec.memcache.binary.BinaryMemcacheRequestDecoder
 
BinaryMemcacheRequestEncoder - Class in io.netty.handler.codec.memcache.binary
The encoder part which takes care of encoding the request headers.
BinaryMemcacheRequestEncoder() - Constructor for class io.netty.handler.codec.memcache.binary.BinaryMemcacheRequestEncoder
 
BinaryMemcacheResponse - Interface in io.netty.handler.codec.memcache.binary
Represents a full BinaryMemcacheResponse, which contains the header and optional key and extras.
BinaryMemcacheResponseDecoder - Class in io.netty.handler.codec.memcache.binary
The decoder which takes care of decoding the response headers.
BinaryMemcacheResponseDecoder() - Constructor for class io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseDecoder
 
BinaryMemcacheResponseDecoder(int) - Constructor for class io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseDecoder
 
BinaryMemcacheResponseEncoder - Class in io.netty.handler.codec.memcache.binary
The encoder which takes care of encoding the response headers.
BinaryMemcacheResponseEncoder() - Constructor for class io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseEncoder
 
BinaryMemcacheResponseStatus - Class in io.netty.handler.codec.memcache.binary
Contains all possible status values a BinaryMemcacheResponse can return.
BinaryMemcacheServerCodec - Class in io.netty.handler.codec.memcache.binary
The full server codec that combines the correct encoder and decoder.
BinaryMemcacheServerCodec() - Constructor for class io.netty.handler.codec.memcache.binary.BinaryMemcacheServerCodec
 
BinaryMemcacheServerCodec(int) - Constructor for class io.netty.handler.codec.memcache.binary.BinaryMemcacheServerCodec
 
bind() - Method in class io.netty.bootstrap.AbstractBootstrap
Create a new Channel and bind it.
bind(int) - Method in class io.netty.bootstrap.AbstractBootstrap
Create a new Channel and bind it.
bind(String, int) - Method in class io.netty.bootstrap.AbstractBootstrap
Create a new Channel and bind it.
bind(InetAddress, int) - Method in class io.netty.bootstrap.AbstractBootstrap
Create a new Channel and bind it.
bind(SocketAddress) - Method in class io.netty.bootstrap.AbstractBootstrap
Create a new Channel and bind it.
bind(SocketAddress, ChannelPromise) - Method in class io.netty.channel.AbstractChannel.AbstractUnsafe
 
bind(SocketAddress) - Method in class io.netty.channel.AbstractChannel
 
bind(SocketAddress, ChannelPromise) - Method in class io.netty.channel.AbstractChannel
 
bind(SocketAddress, ChannelPromise) - Method in interface io.netty.channel.Channel.Unsafe
Bind the SocketAddress to the Channel of the ChannelPromise and notify it once its done.
bind(ChannelHandlerContext, SocketAddress, ChannelPromise) - Method in class io.netty.channel.ChannelDuplexHandler
bind(ChannelHandlerContext, SocketAddress, ChannelPromise) - Method in interface io.netty.channel.ChannelOutboundHandler
Called once a bind operation is made.
bind(ChannelHandlerContext, SocketAddress, ChannelPromise) - Method in class io.netty.channel.ChannelOutboundHandlerAdapter
bind(SocketAddress) - Method in interface io.netty.channel.ChannelOutboundInvoker
Request to bind to the given SocketAddress and notify the ChannelFuture once the operation completes, either because the operation was successful or because of an error.
bind(SocketAddress, ChannelPromise) - Method in interface io.netty.channel.ChannelOutboundInvoker
Request to bind to the given SocketAddress and notify the ChannelFuture once the operation completes, either because the operation was successful or because of an error.
bind(ChannelHandlerContext, SocketAddress, ChannelPromise) - Method in class io.netty.channel.CombinedChannelDuplexHandler
 
bind(SocketAddress) - Method in class io.netty.channel.DefaultChannelPipeline
 
bind(SocketAddress, ChannelPromise) - Method in class io.netty.channel.DefaultChannelPipeline
 
bind(SocketAddress) - Method in class io.netty.channel.unix.Socket
 
bind(ChannelHandlerContext, SocketAddress, ChannelPromise) - Method in class io.netty.handler.codec.DatagramPacketEncoder
 
bind(ChannelHandlerContext, SocketAddress, ChannelPromise) - Method in class io.netty.handler.logging.LoggingHandler
 
bind(ChannelHandlerContext, SocketAddress, ChannelPromise) - Method in class io.netty.handler.ssl.AbstractSniHandler
 
bind(ChannelHandlerContext, SocketAddress, ChannelPromise) - Method in class io.netty.handler.ssl.SslHandler
 
bind(Socket, SocketAddress) - Static method in class io.netty.util.internal.SocketUtils
 
bind(SocketChannel, SocketAddress) - Static method in class io.netty.util.internal.SocketUtils
 
bind(DatagramChannel, SocketAddress) - Static method in class io.netty.util.internal.SocketUtils
 
bitMode() - Static method in class io.netty.util.internal.PlatformDependent
Returns the bit mode of the current VM (usually 32 or 64.)
block(InetAddress, NetworkInterface, InetAddress) - Method in class io.netty.channel.epoll.EpollDatagramChannel
 
block(InetAddress, NetworkInterface, InetAddress, ChannelPromise) - Method in class io.netty.channel.epoll.EpollDatagramChannel
 
block(InetAddress, InetAddress) - Method in class io.netty.channel.epoll.EpollDatagramChannel
 
block(InetAddress, InetAddress, ChannelPromise) - Method in class io.netty.channel.epoll.EpollDatagramChannel
 
block(InetAddress, NetworkInterface, InetAddress) - Method in class io.netty.channel.kqueue.KQueueDatagramChannel
 
block(InetAddress, NetworkInterface, InetAddress, ChannelPromise) - Method in class io.netty.channel.kqueue.KQueueDatagramChannel
 
block(InetAddress, InetAddress) - Method in class io.netty.channel.kqueue.KQueueDatagramChannel
 
block(InetAddress, InetAddress, ChannelPromise) - Method in class io.netty.channel.kqueue.KQueueDatagramChannel
 
block(InetAddress, NetworkInterface, InetAddress) - Method in interface io.netty.channel.socket.DatagramChannel
Block the given sourceToBlock address for the given multicastAddress on the given networkInterface and notifies the ChannelFuture once the operation completes.
block(InetAddress, NetworkInterface, InetAddress, ChannelPromise) - Method in interface io.netty.channel.socket.DatagramChannel
Block the given sourceToBlock address for the given multicastAddress on the given networkInterface and notifies the ChannelFuture once the operation completes.
block(InetAddress, InetAddress) - Method in interface io.netty.channel.socket.DatagramChannel
Block the given sourceToBlock address for the given multicastAddress and notifies the ChannelFuture once the operation completes.
block(InetAddress, InetAddress, ChannelPromise) - Method in interface io.netty.channel.socket.DatagramChannel
Block the given sourceToBlock address for the given multicastAddress and notifies the ChannelFuture once the operation completes.
block(InetAddress, NetworkInterface, InetAddress) - Method in class io.netty.channel.socket.nio.NioDatagramChannel
Block the given sourceToBlock address for the given multicastAddress on the given networkInterface
block(InetAddress, NetworkInterface, InetAddress, ChannelPromise) - Method in class io.netty.channel.socket.nio.NioDatagramChannel
Block the given sourceToBlock address for the given multicastAddress on the given networkInterface
block(InetAddress, InetAddress) - Method in class io.netty.channel.socket.nio.NioDatagramChannel
Block the given sourceToBlock address for the given multicastAddress
block(InetAddress, InetAddress, ChannelPromise) - Method in class io.netty.channel.socket.nio.NioDatagramChannel
Block the given sourceToBlock address for the given multicastAddress
block(InetAddress, NetworkInterface, InetAddress) - Method in class io.netty.channel.socket.oio.OioDatagramChannel
 
block(InetAddress, NetworkInterface, InetAddress, ChannelPromise) - Method in class io.netty.channel.socket.oio.OioDatagramChannel
 
block(InetAddress, InetAddress) - Method in class io.netty.channel.socket.oio.OioDatagramChannel
 
block(InetAddress, InetAddress, ChannelPromise) - Method in class io.netty.channel.socket.oio.OioDatagramChannel
 
BlockingOperationException - Exception in io.netty.util.concurrent
An IllegalStateException which is raised when a user performed a blocking operation when the user is in an event loop thread.
BlockingOperationException() - Constructor for exception io.netty.util.concurrent.BlockingOperationException
 
BlockingOperationException(String) - Constructor for exception io.netty.util.concurrent.BlockingOperationException
 
BlockingOperationException(Throwable) - Constructor for exception io.netty.util.concurrent.BlockingOperationException
 
BlockingOperationException(String, Throwable) - Constructor for exception io.netty.util.concurrent.BlockingOperationException
 
BooleanSupplier - Interface in io.netty.util
Represents a supplier of boolean-valued results.
bootstrap - Variable in class io.netty.bootstrap.AbstractBootstrapConfig
 
Bootstrap - Class in io.netty.bootstrap
A Bootstrap that makes it easy to bootstrap a Channel to use for clients.
Bootstrap() - Constructor for class io.netty.bootstrap.Bootstrap
 
bootstrap() - Method in class io.netty.channel.pool.SimpleChannelPool
Returns the Bootstrap this pool will use to open new connections.
BootstrapConfig - Class in io.netty.bootstrap
Exposes the configuration of a Bootstrap.
buffer() - Method in class io.netty.buffer.AbstractByteBufAllocator
 
buffer(int) - Method in class io.netty.buffer.AbstractByteBufAllocator
 
buffer(int, int) - Method in class io.netty.buffer.AbstractByteBufAllocator
 
buffer() - Method in interface io.netty.buffer.ByteBufAllocator
Allocate a ByteBuf.
buffer(int) - Method in interface io.netty.buffer.ByteBufAllocator
Allocate a ByteBuf with the given initial capacity.
buffer(int, int) - Method in interface io.netty.buffer.ByteBufAllocator
Allocate a ByteBuf with the given initial capacity and the given maximal capacity.
buffer() - Method in class io.netty.buffer.ByteBufOutputStream
Returns the buffer where this stream is writing data.
buffer() - Static method in class io.netty.buffer.Unpooled
Creates a new big-endian Java heap buffer with reasonably small initial capacity, which expands its capacity boundlessly on demand.
buffer(int) - Static method in class io.netty.buffer.Unpooled
Creates a new big-endian Java heap buffer with the specified capacity, which expands its capacity boundlessly on demand.
buffer(int, int) - Static method in class io.netty.buffer.Unpooled
Creates a new big-endian Java heap buffer with the specified initialCapacity, that may grow up to maxCapacity The new buffer's readerIndex and writerIndex are 0.
build() - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnAckBuilder
 
build() - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
 
build() - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.PublishBuilder
 
build() - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.SubscribeBuilder
 
build() - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.UnsubscribeBuilder
 
build() - Method in class io.netty.handler.ssl.SslContextBuilder
Create new SslContext instance with configured settings.
build() - Method in class io.netty.resolver.dns.DnsNameResolverBuilder
Returns a new DnsNameResolver instance.
build() - Method in class io.netty.util.DomainMappingBuilder
Deprecated.
Creates a new instance of immutable DomainNameMapping Attempts to add new mappings to the result object will cause UnsupportedOperationException to be thrown
build() - Method in class io.netty.util.DomainNameMappingBuilder
Creates a new instance of immutable DomainNameMapping Attempts to add new mappings to the result object will cause UnsupportedOperationException to be thrown
buildInvalidMessage() - Method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheDecoder
Helper method to create a upstream message when the incoming parsing did fail.
buildInvalidMessage() - Method in class io.netty.handler.codec.memcache.binary.BinaryMemcacheRequestDecoder
 
buildInvalidMessage() - Method in class io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseDecoder
 
buildKeyManagerFactory(File, File, String, KeyManagerFactory) - Static method in class io.netty.handler.ssl.JdkSslContext
Deprecated.
will be removed.
buildKeyManagerFactory(File, String, File, String, KeyManagerFactory) - Static method in class io.netty.handler.ssl.JdkSslContext
Deprecated.
will be removed.
buildTimeMillis() - Method in class io.netty.util.Version
 
buildTrustManagerFactory(File, TrustManagerFactory) - Static method in class io.netty.handler.ssl.SslContext
Deprecated.
BulkStringHeaderRedisMessage - Class in io.netty.handler.codec.redis
The header of Bulk Strings in RESP.
BulkStringHeaderRedisMessage(int) - Constructor for class io.netty.handler.codec.redis.BulkStringHeaderRedisMessage
bulkStringLength() - Method in class io.netty.handler.codec.redis.BulkStringHeaderRedisMessage
Return bulkStringLength for this content.
BulkStringRedisContent - Interface in io.netty.handler.codec.redis
A chunk of bulk strings which is used for Redis chunked transfer-encoding.
ByteArrayDecoder - Class in io.netty.handler.codec.bytes
Decodes a received ByteBuf into an array of bytes.
ByteArrayDecoder() - Constructor for class io.netty.handler.codec.bytes.ByteArrayDecoder
 
ByteArrayEncoder - Class in io.netty.handler.codec.bytes
Encodes the requested array of bytes into a ByteBuf.
ByteArrayEncoder() - Constructor for class io.netty.handler.codec.bytes.ByteArrayEncoder
 
byteAt(int) - Method in class io.netty.util.AsciiString
 
ByteBuf - Class in io.netty.buffer
A random and sequential accessible sequence of zero or more bytes (octets).
ByteBuf() - Constructor for class io.netty.buffer.ByteBuf
 
ByteBufAllocator - Interface in io.netty.buffer
Implementations are responsible to allocate buffers.
ByteBufAllocatorMetric - Interface in io.netty.buffer
 
ByteBufAllocatorMetricProvider - Interface in io.netty.buffer
 
ByteBufHolder - Interface in io.netty.buffer
A packet which is send or receive.
ByteBufInputStream - Class in io.netty.buffer
An InputStream which reads data from a ByteBuf.
ByteBufInputStream(ByteBuf) - Constructor for class io.netty.buffer.ByteBufInputStream
Creates a new stream which reads data from the specified buffer starting at the current readerIndex and ending at the current writerIndex.
ByteBufInputStream(ByteBuf, int) - Constructor for class io.netty.buffer.ByteBufInputStream
Creates a new stream which reads data from the specified buffer starting at the current readerIndex and ending at readerIndex + length.
ByteBufInputStream(ByteBuf, boolean) - Constructor for class io.netty.buffer.ByteBufInputStream
Creates a new stream which reads data from the specified buffer starting at the current readerIndex and ending at the current writerIndex.
ByteBufInputStream(ByteBuf, int, boolean) - Constructor for class io.netty.buffer.ByteBufInputStream
Creates a new stream which reads data from the specified buffer starting at the current readerIndex and ending at readerIndex + length.
ByteBufOutputStream - Class in io.netty.buffer
An OutputStream which writes data to a ByteBuf.
ByteBufOutputStream(ByteBuf) - Constructor for class io.netty.buffer.ByteBufOutputStream
Creates a new stream which writes data to the specified buffer.
ByteBufProcessor - Interface in io.netty.buffer
Deprecated.
ByteBufUtil - Class in io.netty.buffer
A collection of utility methods that is related with handling ByteBuf, such as the generation of hex dump and swapping an integer's byte order.
ByteCollections - Class in io.netty.util.collection
Utilities for byte-based primitive collections.
ByteObjectHashMap<V> - Class in io.netty.util.collection
A hash map implementation of ByteObjectMap that uses open addressing for keys.
ByteObjectHashMap() - Constructor for class io.netty.util.collection.ByteObjectHashMap
 
ByteObjectHashMap(int) - Constructor for class io.netty.util.collection.ByteObjectHashMap
 
ByteObjectHashMap(int, float) - Constructor for class io.netty.util.collection.ByteObjectHashMap
 
ByteObjectMap<V> - Interface in io.netty.util.collection
Interface for a primitive map that uses bytes as keys.
ByteObjectMap.PrimitiveEntry<V> - Interface in io.netty.util.collection
A primitive entry in the map, provided by the iterator from ByteObjectMap.entries()
ByteProcessor - Interface in io.netty.util
Provides a mechanism to iterate over a collection of bytes.
ByteProcessor.IndexNotOfProcessor - Class in io.netty.util
A ByteProcessor which finds the first appearance which is not of a specific byte.
ByteProcessor.IndexOfProcessor - Class in io.netty.util
A ByteProcessor which finds the first appearance of a specific byte.
bytes() - Method in class io.netty.channel.PendingWriteQueue
Returns the total number of bytes that are pending because of pending messages.
bytesBefore(byte) - Method in class io.netty.buffer.AbstractByteBuf
 
bytesBefore(int, byte) - Method in class io.netty.buffer.AbstractByteBuf
 
bytesBefore(int, int, byte) - Method in class io.netty.buffer.AbstractByteBuf
 
bytesBefore(byte) - Method in class io.netty.buffer.ByteBuf
Locates the first occurrence of the specified value in this buffer.
bytesBefore(int, byte) - Method in class io.netty.buffer.ByteBuf
Locates the first occurrence of the specified value in this buffer.
bytesBefore(int, int, byte) - Method in class io.netty.buffer.ByteBuf
Locates the first occurrence of the specified value in this buffer.
bytesBefore(byte) - Method in class io.netty.buffer.EmptyByteBuf
 
bytesBefore(int, byte) - Method in class io.netty.buffer.EmptyByteBuf
 
bytesBefore(int, int, byte) - Method in class io.netty.buffer.EmptyByteBuf
 
bytesBefore(byte) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
bytesBefore(int, byte) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
bytesBefore(int, int, byte) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
bytesBeforeUnwritable() - Method in class io.netty.channel.AbstractChannel
 
bytesBeforeUnwritable() - Method in interface io.netty.channel.Channel
Get how many bytes can be written until Channel.isWritable() returns false.
bytesBeforeUnwritable() - Method in class io.netty.channel.ChannelOutboundBuffer
Get how many bytes can be written until ChannelOutboundBuffer.isWritable() returns false.
bytesBeforeWritable() - Method in class io.netty.channel.AbstractChannel
 
bytesBeforeWritable() - Method in interface io.netty.channel.Channel
Get how many bytes must be drained from underlying buffers until Channel.isWritable() returns true.
bytesBeforeWritable() - Method in class io.netty.channel.ChannelOutboundBuffer
Get how many bytes must be drained from the underlying buffer until ChannelOutboundBuffer.isWritable() returns true.
bytesToIpAddress(byte[]) - Static method in class io.netty.util.NetUtil
Converts 4-byte or 16-byte data into an IPv4 or IPv6 string respectively.
bytesToIpAddress(byte[], int, int) - Static method in class io.netty.util.NetUtil
Converts 4-byte or 16-byte data into an IPv4 or IPv6 string respectively.
byteToHexString(int) - Static method in class io.netty.util.internal.StringUtil
Converts the specified byte value into a hexadecimal integer.
byteToHexString(T, int) - Static method in class io.netty.util.internal.StringUtil
Converts the specified byte value into a hexadecimal integer and appends it to the specified buffer.
byteToHexStringPadded(int) - Static method in class io.netty.util.internal.StringUtil
Converts the specified byte value into a 2-digit hexadecimal integer.
byteToHexStringPadded(T, int) - Static method in class io.netty.util.internal.StringUtil
Converts the specified byte value into a 2-digit hexadecimal integer and appends it to the specified buffer.
ByteToMessageCodec<I> - Class in io.netty.handler.codec
A Codec for on-the-fly encoding/decoding of bytes to messages and vise-versa.
ByteToMessageCodec() - Constructor for class io.netty.handler.codec.ByteToMessageCodec
see ByteToMessageCodec.ByteToMessageCodec(boolean) with true as boolean parameter.
ByteToMessageCodec(Class<? extends I>) - Constructor for class io.netty.handler.codec.ByteToMessageCodec
ByteToMessageCodec(boolean) - Constructor for class io.netty.handler.codec.ByteToMessageCodec
Create a new instance which will try to detect the types to match out of the type parameter of the class.
ByteToMessageCodec(Class<? extends I>, boolean) - Constructor for class io.netty.handler.codec.ByteToMessageCodec
Create a new instance
ByteToMessageDecoder - Class in io.netty.handler.codec
ChannelInboundHandlerAdapter which decodes bytes in a stream-like fashion from one ByteBuf to an other Message type.
ByteToMessageDecoder() - Constructor for class io.netty.handler.codec.ByteToMessageDecoder
 
ByteToMessageDecoder.Cumulator - Interface in io.netty.handler.codec
Cumulate ByteBufs.
byteValue() - Method in class io.netty.handler.codec.dns.DnsOpCode
 
byteValue() - Method in enum io.netty.handler.codec.mqtt.MqttConnectReturnCode
 
Bzip2Decoder - Class in io.netty.handler.codec.compression
Uncompresses a ByteBuf encoded with the Bzip2 format.
Bzip2Decoder() - Constructor for class io.netty.handler.codec.compression.Bzip2Decoder
 
Bzip2Encoder - Class in io.netty.handler.codec.compression
Compresses a ByteBuf using the Bzip2 algorithm.
Bzip2Encoder() - Constructor for class io.netty.handler.codec.compression.Bzip2Encoder
Creates a new bzip2 encoder with the maximum (900,000 byte) block size.
Bzip2Encoder(int) - Constructor for class io.netty.handler.codec.compression.Bzip2Encoder
Creates a new bzip2 encoder with the specified blockSizeMultiplier.

C

c2b(char) - Static method in class io.netty.util.AsciiString
 
CAA - Static variable in class io.netty.handler.codec.dns.DnsRecordType
Certification Authority Authorization record RFC 6844 CA pinning, constraining acceptable CAs for a host/domain.
cache(String, DnsRecord[], InetAddress, long, EventLoop) - Method in class io.netty.resolver.dns.DefaultDnsCache
 
cache(String, DnsRecord[], Throwable, EventLoop) - Method in class io.netty.resolver.dns.DefaultDnsCache
 
cache(String, DnsRecord[], InetAddress, long, EventLoop) - Method in interface io.netty.resolver.dns.DnsCache
Cache a resolved address for a given hostname.
cache(String, DnsRecord[], Throwable, EventLoop) - Method in interface io.netty.resolver.dns.DnsCache
Cache the resolution failure for a given hostname.
cache(String, DnsRecord[], InetAddress, long, EventLoop) - Method in class io.netty.resolver.dns.NoopDnsCache
 
cache(String, DnsRecord[], Throwable, EventLoop) - Method in class io.netty.resolver.dns.NoopDnsCache
 
cacheDisabled(ClassLoader) - Static method in class io.netty.handler.codec.serialization.ClassResolvers
cache disabled
calculateNewCapacity(int, int) - Method in class io.netty.buffer.AbstractByteBufAllocator
 
calculateNewCapacity(int, int) - Method in interface io.netty.buffer.ByteBufAllocator
Calculate the new capacity of a ByteBuf that is used when a ByteBuf needs to expand by the minNewCapacity with maxCapacity as upper-bound.
calculateSize(Object) - Method in class io.netty.handler.traffic.AbstractTrafficShapingHandler
Calculate the size of the given Object.
calculateStrategy(IntSupplier, boolean) - Method in interface io.netty.channel.SelectStrategy
The SelectStrategy can be used to steer the outcome of a potential select call.
callDecode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.ByteToMessageDecoder
Called once data should be decoded from the given ByteBuf.
callDecode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.ReplayingDecoder
 
cancel(boolean) - Method in class io.netty.util.concurrent.CompleteFuture
 
cancel(boolean) - Method in class io.netty.util.concurrent.DefaultPromise
 
cancel(boolean) - Method in interface io.netty.util.concurrent.Future
If the cancellation was successful it will fail the future with an CancellationException.
cancel() - Method in interface io.netty.util.Timeout
Attempts to cancel the TimerTask associated with this handle.
cancelScheduledTasks() - Method in class io.netty.util.concurrent.AbstractScheduledEventExecutor
Cancel all scheduled tasks.
canEnableTcpNoDelayByDefault() - Static method in class io.netty.util.internal.PlatformDependent
Returns true if and only if it is fine to enable TCP_NODELAY socket option by default.
capacity() - Method in class io.netty.buffer.ByteBuf
Returns the number of bytes (octets) this buffer can contain.
capacity(int) - Method in class io.netty.buffer.ByteBuf
Adjusts the capacity of this buffer.
capacity() - Method in class io.netty.buffer.CompositeByteBuf
 
capacity(int) - Method in class io.netty.buffer.CompositeByteBuf
 
capacity() - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
capacity(int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
capacity() - Method in class io.netty.buffer.EmptyByteBuf
 
capacity(int) - Method in class io.netty.buffer.EmptyByteBuf
 
capacity() - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
capacity(int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
capacity() - Method in class io.netty.buffer.SlicedByteBuf
Deprecated.
 
capacity() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
capacity(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
capacity() - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
capacity(int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
capacity() - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
capacity(int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
capacity() - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
capacity(int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
CARRIAGE_RETURN - Static variable in class io.netty.util.internal.StringUtil
 
cas() - Method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
cas() - Method in interface io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Returns the CAS identifier.
cascadeTo(Future<X>, Promise<? super X>) - Static method in class io.netty.util.concurrent.UnaryPromiseNotifier
 
CASE_INSENSITIVE_HASHER - Static variable in class io.netty.util.AsciiString
 
CASE_SENSITIVE_HASHER - Static variable in class io.netty.util.AsciiString
 
caState() - Method in class io.netty.channel.epoll.EpollTcpInfo
 
cause() - Method in interface io.netty.channel.group.ChannelGroupFuture
 
cause() - Method in class io.netty.handler.codec.DecoderResult
 
cause() - Method in class io.netty.handler.ssl.SslCompletionEvent
Return the Throwable if SslCompletionEvent.isSuccess() returns false and so the completion failed.
cause() - Method in class io.netty.resolver.dns.DnsCacheEntry
 
cause() - Method in class io.netty.util.concurrent.DefaultPromise
 
cause() - Method in class io.netty.util.concurrent.FailedFuture
 
cause() - Method in interface io.netty.util.concurrent.Future
Returns the cause of the failed I/O operation if the I/O operation has failed.
cause() - Method in class io.netty.util.concurrent.SucceededFuture
 
CERT - Static variable in class io.netty.handler.codec.dns.DnsRecordType
Certificate record RFC 4398 Stores PKIX, SPKI, PGP, etc.
cert() - Method in class io.netty.handler.ssl.util.SelfSignedCertificate
Returns the generated X.509 certificate.
certificate() - Method in class io.netty.handler.ssl.util.SelfSignedCertificate
Returns the generated X.509 certificate file in PEM format.
ch() - Method in class io.netty.channel.nio.AbstractNioChannel.AbstractNioUnsafe
 
ch() - Method in interface io.netty.channel.nio.AbstractNioChannel.NioUnsafe
Return underlying SelectableChannel
channel(Class<? extends C>) - Method in class io.netty.bootstrap.AbstractBootstrap
The Class which is used to create Channel instances from.
Channel - Interface in io.netty.channel
A nexus to a network socket or a component which is capable of I/O operations such as read, write, connect, and bind.
channel() - Method in interface io.netty.channel.ChannelFuture
Returns a channel where the I/O operation associated with this future takes place.
channel() - Method in interface io.netty.channel.ChannelHandlerContext
Return the Channel which is bound to the ChannelHandlerContext.
channel() - Method in interface io.netty.channel.ChannelPipeline
Returns the Channel that this pipeline is attached to.
channel() - Method in interface io.netty.channel.ChannelPromise
 
channel - Variable in class io.netty.channel.DefaultChannelConfig
 
channel() - Method in class io.netty.channel.DefaultChannelPipeline
 
channel() - Method in class io.netty.channel.DefaultChannelProgressivePromise
 
channel() - Method in class io.netty.channel.DefaultChannelPromise
 
channel - Variable in class io.netty.channel.epoll.EpollServerChannelConfig
 
channel - Variable in class io.netty.channel.kqueue.KQueueServerChannelConfig
 
Channel.Unsafe - Interface in io.netty.channel
Unsafe operations that should never be called from user-code.
channelAccepted(ChannelHandlerContext, T) - Method in class io.netty.handler.ipfilter.AbstractRemoteAddressFilter
This method is called if remoteAddress gets accepted by AbstractRemoteAddressFilter.accept(ChannelHandlerContext, SocketAddress).
channelAcquired(Channel) - Method in class io.netty.channel.pool.AbstractChannelPoolHandler
NOOP implementation, sub-classes may override this.
channelAcquired(Channel) - Method in interface io.netty.channel.pool.ChannelPoolHandler
Called once a Channel was acquired by calling ChannelPool.acquire() or ChannelPool.acquire(Promise).
channelActive(ChannelHandlerContext) - Method in interface io.netty.channel.ChannelInboundHandler
The Channel of the ChannelHandlerContext is now active
channelActive(ChannelHandlerContext) - Method in class io.netty.channel.ChannelInboundHandlerAdapter
channelActive(ChannelHandlerContext) - Method in class io.netty.channel.CombinedChannelDuplexHandler
 
channelActive(ChannelHandlerContext) - Method in class io.netty.handler.codec.DatagramPacketDecoder
 
channelActive(ChannelHandlerContext) - Method in class io.netty.handler.ipfilter.AbstractRemoteAddressFilter
 
channelActive(ChannelHandlerContext) - Method in class io.netty.handler.logging.LoggingHandler
 
channelActive(ChannelHandlerContext) - Method in class io.netty.handler.ssl.SslHandler
Issues an initial TLS handshake once connected when used in client-mode
channelActive(ChannelHandlerContext) - Method in class io.netty.handler.timeout.IdleStateHandler
 
ChannelConfig - Interface in io.netty.channel
A set of configuration properties of a Channel.
channelCreated(Channel) - Method in interface io.netty.channel.pool.ChannelPoolHandler
Called once a new Channel is created in the ChannelPool.
ChannelDuplexHandler - Class in io.netty.channel
ChannelHandler implementation which represents a combination out of a ChannelInboundHandler and the ChannelOutboundHandler.
ChannelDuplexHandler() - Constructor for class io.netty.channel.ChannelDuplexHandler
 
ChannelException - Exception in io.netty.channel
A RuntimeException which is thrown when an I/O operation fails.
ChannelException() - Constructor for exception io.netty.channel.ChannelException
Creates a new exception.
ChannelException(String, Throwable) - Constructor for exception io.netty.channel.ChannelException
Creates a new exception.
ChannelException(String) - Constructor for exception io.netty.channel.ChannelException
Creates a new exception.
ChannelException(Throwable) - Constructor for exception io.netty.channel.ChannelException
Creates a new exception.
channelFactory(ChannelFactory<? extends C>) - Method in class io.netty.bootstrap.AbstractBootstrap
channelFactory(ChannelFactory<? extends C>) - Method in class io.netty.bootstrap.AbstractBootstrap
ChannelFactory which is used to create Channel instances from when calling AbstractBootstrap.bind().
channelFactory() - Method in class io.netty.bootstrap.AbstractBootstrapConfig
Returns the configured ChannelFactory or null if non is configured yet.
ChannelFactory<T extends Channel> - Interface in io.netty.bootstrap
Deprecated.
Use ChannelFactory instead.
ChannelFactory<T extends Channel> - Interface in io.netty.channel
Creates a new Channel.
channelFactory(ChannelFactory<? extends DatagramChannel>) - Method in class io.netty.resolver.dns.DnsNameResolverBuilder
Sets the ChannelFactory that will create a DatagramChannel.
ChannelFlushPromiseNotifier - Class in io.netty.channel
This implementation allows to register ChannelFuture instances which will get notified once some amount of data was written and so a checkpoint was reached.
ChannelFlushPromiseNotifier(boolean) - Constructor for class io.netty.channel.ChannelFlushPromiseNotifier
Create a new instance
ChannelFlushPromiseNotifier() - Constructor for class io.netty.channel.ChannelFlushPromiseNotifier
Create a new instance which will use ChannelPromise.setSuccess() and ChannelPromise.setFailure(Throwable) to notify the ChannelPromises.
ChannelFuture - Interface in io.netty.channel
The result of an asynchronous Channel I/O operation.
ChannelFutureListener - Interface in io.netty.channel
Listens to the result of a ChannelFuture.
ChannelGroup - Interface in io.netty.channel.group
A thread-safe Set that contains open Channels and provides various bulk operations on them.
ChannelGroupException - Exception in io.netty.channel.group
ChannelException which holds ChannelFutures that failed because of an error.
ChannelGroupException(Collection<Map.Entry<Channel, Throwable>>) - Constructor for exception io.netty.channel.group.ChannelGroupException
 
ChannelGroupFuture - Interface in io.netty.channel.group
The result of an asynchronous ChannelGroup operation.
ChannelGroupFutureListener - Interface in io.netty.channel.group
Listens to the result of a ChannelGroupFuture.
ChannelHandler - Interface in io.netty.channel
Handles an I/O event or intercepts an I/O operation, and forwards it to its next handler in its ChannelPipeline.
ChannelHandler.Sharable - Annotation Type in io.netty.channel
Indicates that the same instance of the annotated ChannelHandler can be added to one or more ChannelPipelines multiple times without a race condition.
ChannelHandlerAdapter - Class in io.netty.channel
Skeleton implementation of a ChannelHandler.
ChannelHandlerAdapter() - Constructor for class io.netty.channel.ChannelHandlerAdapter
 
ChannelHandlerContext - Interface in io.netty.channel
Enables a ChannelHandler to interact with its ChannelPipeline and other handlers.
ChannelHealthChecker - Interface in io.netty.channel.pool
Called before a Channel will be returned via ChannelPool.acquire() or ChannelPool.acquire(Promise).
ChannelId - Interface in io.netty.channel
Represents the globally unique identifier of a Channel.
channelIdle(ChannelHandlerContext, IdleStateEvent) - Method in class io.netty.handler.timeout.IdleStateHandler
Is called when an IdleStateEvent should be fired.
channelIdle(ChannelHandlerContext, IdleStateEvent) - Method in class io.netty.handler.timeout.ReadTimeoutHandler
 
channelInactive(ChannelHandlerContext) - Method in interface io.netty.channel.ChannelInboundHandler
The Channel of the ChannelHandlerContext was registered is now inactive and reached its end of lifetime.
channelInactive(ChannelHandlerContext) - Method in class io.netty.channel.ChannelInboundHandlerAdapter
channelInactive(ChannelHandlerContext) - Method in class io.netty.channel.CombinedChannelDuplexHandler
 
channelInactive(ChannelHandlerContext) - Method in class io.netty.handler.codec.ByteToMessageCodec
 
channelInactive(ChannelHandlerContext) - Method in class io.netty.handler.codec.ByteToMessageDecoder
 
channelInactive(ChannelHandlerContext) - Method in class io.netty.handler.codec.DatagramPacketDecoder
 
channelInactive(ChannelHandlerContext) - Method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheDecoder
When the channel goes inactive, release all frames to prevent data leaks.
channelInactive(ChannelHandlerContext) - Method in class io.netty.handler.codec.MessageAggregator
 
channelInactive(ChannelHandlerContext) - Method in class io.netty.handler.flow.FlowControlHandler
 
channelInactive(ChannelHandlerContext) - Method in class io.netty.handler.logging.LoggingHandler
 
channelInactive(ChannelHandlerContext) - Method in class io.netty.handler.ssl.SslHandler
 
channelInactive(ChannelHandlerContext) - Method in class io.netty.handler.stream.ChunkedWriteHandler
 
channelInactive(ChannelHandlerContext) - Method in class io.netty.handler.timeout.IdleStateHandler
 
ChannelInboundHandler - Interface in io.netty.channel
ChannelHandler which adds callbacks for state changes.
ChannelInboundHandlerAdapter - Class in io.netty.channel
Abstract base class for ChannelInboundHandler implementations which provide implementations of all of their methods.
ChannelInboundHandlerAdapter() - Constructor for class io.netty.channel.ChannelInboundHandlerAdapter
 
ChannelInboundInvoker - Interface in io.netty.channel
 
ChannelInitializer<C extends Channel> - Class in io.netty.channel
A special ChannelInboundHandler which offers an easy way to initialize a Channel once it was registered to its EventLoop.
ChannelInitializer() - Constructor for class io.netty.channel.ChannelInitializer
 
ChannelInputShutdownEvent - Class in io.netty.channel.socket
Special event which will be fired and passed to the ChannelInboundHandler.userEventTriggered(ChannelHandlerContext, Object) methods once the input of a SocketChannel was shutdown and the SocketChannelConfig.isAllowHalfClosure() method returns true.
ChannelInputShutdownReadComplete - Class in io.netty.channel.socket
User event that signifies the channel's input side is shutdown, and we tried to shut it down again.
ChannelMatcher - Interface in io.netty.channel.group
Allows to only match some Channel's for operations in ChannelGroup.
ChannelMatchers - Class in io.netty.channel.group
Helper class which provides often used ChannelMatcher implementations.
ChannelMetadata - Class in io.netty.channel
Represents the properties of a Channel implementation.
ChannelMetadata(boolean) - Constructor for class io.netty.channel.ChannelMetadata
Create a new instance
ChannelMetadata(boolean, int) - Constructor for class io.netty.channel.ChannelMetadata
Create a new instance
ChannelOption<T> - Class in io.netty.channel
A ChannelOption allows to configure a ChannelConfig in a type-safe way.
ChannelOption(String) - Constructor for class io.netty.channel.ChannelOption
Deprecated.
ChannelOutboundBuffer - Class in io.netty.channel
(Transport implementors only) an internal data structure used by AbstractChannel to store its pending outbound write requests.
ChannelOutboundBuffer.MessageProcessor - Interface in io.netty.channel
 
ChannelOutboundHandler - Interface in io.netty.channel
ChannelHandler which will get notified for IO-outbound-operations.
ChannelOutboundHandlerAdapter - Class in io.netty.channel
Skeleton implementation of a ChannelOutboundHandler.
ChannelOutboundHandlerAdapter() - Constructor for class io.netty.channel.ChannelOutboundHandlerAdapter
 
ChannelOutboundInvoker - Interface in io.netty.channel
 
ChannelPipeline - Interface in io.netty.channel
A list of ChannelHandlers which handles or intercepts inbound events and outbound operations of a Channel.
ChannelPipelineException - Exception in io.netty.channel
A ChannelException which is thrown when a ChannelPipeline failed to execute an operation.
ChannelPipelineException() - Constructor for exception io.netty.channel.ChannelPipelineException
Creates a new instance.
ChannelPipelineException(String, Throwable) - Constructor for exception io.netty.channel.ChannelPipelineException
Creates a new instance.
ChannelPipelineException(String) - Constructor for exception io.netty.channel.ChannelPipelineException
Creates a new instance.
ChannelPipelineException(Throwable) - Constructor for exception io.netty.channel.ChannelPipelineException
Creates a new instance.
ChannelPool - Interface in io.netty.channel.pool
Allows to acquire and release Channel and so act as a pool of these.
ChannelPoolHandler - Interface in io.netty.channel.pool
Handler which is called for various actions done by the ChannelPool.
ChannelPoolMap<K,P extends ChannelPool> - Interface in io.netty.channel.pool
Allows to map ChannelPool implementations to a specific key.
ChannelProgressiveFuture - Interface in io.netty.channel
An special ChannelFuture which is used to indicate the FileRegion transfer progress
ChannelProgressiveFutureListener - Interface in io.netty.channel
An EventListener listener which will be called once the sending task associated with future is being transferred.
ChannelProgressivePromise - Interface in io.netty.channel
Special ChannelPromise which will be notified once the associated bytes is transferring.
ChannelPromise - Interface in io.netty.channel
Special ChannelFuture which is writable.
ChannelPromiseAggregator - Class in io.netty.channel
Deprecated.
Use PromiseCombiner Class which is used to consolidate multiple channel futures into one, by listening to the individual futures and producing an aggregated result (success/failure) when all futures have completed.
ChannelPromiseAggregator(ChannelPromise) - Constructor for class io.netty.channel.ChannelPromiseAggregator
Deprecated.
 
ChannelPromiseNotifier - Class in io.netty.channel
ChannelFutureListener implementation which takes other ChannelPromise(s) and notifies them on completion.
ChannelPromiseNotifier(ChannelPromise...) - Constructor for class io.netty.channel.ChannelPromiseNotifier
Create a new instance
ChannelPromiseNotifier(boolean, ChannelPromise...) - Constructor for class io.netty.channel.ChannelPromiseNotifier
Create a new instance
channelRead(ChannelHandlerContext, Object) - Method in interface io.netty.channel.ChannelInboundHandler
Invoked when the current Channel has read a message from the peer.
channelRead(ChannelHandlerContext, Object) - Method in class io.netty.channel.ChannelInboundHandlerAdapter
channelRead(ChannelHandlerContext, Object) - Method in class io.netty.channel.CombinedChannelDuplexHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class io.netty.channel.SimpleChannelInboundHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class io.netty.handler.codec.ByteToMessageCodec
 
channelRead(ChannelHandlerContext, Object) - Method in class io.netty.handler.codec.ByteToMessageDecoder
 
channelRead(ChannelHandlerContext, Object) - Method in class io.netty.handler.codec.MessageToMessageCodec
 
channelRead(ChannelHandlerContext, Object) - Method in class io.netty.handler.codec.MessageToMessageDecoder
 
channelRead(ChannelHandlerContext, Object) - Method in class io.netty.handler.flow.FlowControlHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class io.netty.handler.flush.FlushConsolidationHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class io.netty.handler.logging.LoggingHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class io.netty.handler.timeout.IdleStateHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class io.netty.handler.traffic.AbstractTrafficShapingHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
 
channelRead0(ChannelHandlerContext, I) - Method in class io.netty.channel.SimpleChannelInboundHandler
Please keep in mind that this method will be renamed to messageReceived(ChannelHandlerContext, I) in 5.0. Is called for each message of type I.
channelReadComplete(ChannelHandlerContext) - Method in interface io.netty.channel.ChannelInboundHandler
Invoked when the last message read by the current read operation has been consumed by ChannelInboundHandler.channelRead(ChannelHandlerContext, Object).
channelReadComplete(ChannelHandlerContext) - Method in class io.netty.channel.ChannelInboundHandlerAdapter
channelReadComplete(ChannelHandlerContext) - Method in class io.netty.channel.CombinedChannelDuplexHandler
 
channelReadComplete(ChannelHandlerContext) - Method in class io.netty.handler.codec.ByteToMessageCodec
 
channelReadComplete(ChannelHandlerContext) - Method in class io.netty.handler.codec.ByteToMessageDecoder
 
channelReadComplete(ChannelHandlerContext) - Method in class io.netty.handler.codec.DatagramPacketDecoder
 
channelReadComplete(ChannelHandlerContext) - Method in class io.netty.handler.codec.MessageAggregator
 
channelReadComplete(ChannelHandlerContext) - Method in class io.netty.handler.flow.FlowControlHandler
 
channelReadComplete(ChannelHandlerContext) - Method in class io.netty.handler.flush.FlushConsolidationHandler
 
channelReadComplete(ChannelHandlerContext) - Method in class io.netty.handler.logging.LoggingHandler
 
channelReadComplete(ChannelHandlerContext) - Method in class io.netty.handler.ssl.SslHandler
 
channelReadComplete(ChannelHandlerContext) - Method in class io.netty.handler.timeout.IdleStateHandler
 
channelReady(C, SelectionKey) - Method in interface io.netty.channel.nio.NioTask
Invoked when the SelectableChannel has been selected by the Selector.
channelRegistered(ChannelHandlerContext) - Method in interface io.netty.channel.ChannelInboundHandler
The Channel of the ChannelHandlerContext was registered with its EventLoop
channelRegistered(ChannelHandlerContext) - Method in class io.netty.channel.ChannelInboundHandlerAdapter
channelRegistered(ChannelHandlerContext) - Method in class io.netty.channel.ChannelInitializer
 
channelRegistered(ChannelHandlerContext) - Method in class io.netty.channel.CombinedChannelDuplexHandler
 
channelRegistered(ChannelHandlerContext) - Method in class io.netty.handler.codec.DatagramPacketDecoder
 
channelRegistered(ChannelHandlerContext) - Method in class io.netty.handler.ipfilter.AbstractRemoteAddressFilter
 
channelRegistered(ChannelHandlerContext) - Method in class io.netty.handler.logging.LoggingHandler
 
channelRegistered(ChannelHandlerContext) - Method in class io.netty.handler.timeout.IdleStateHandler
 
channelRegistered(ChannelHandlerContext) - Method in class io.netty.handler.traffic.AbstractTrafficShapingHandler
 
channelRejected(ChannelHandlerContext, T) - Method in class io.netty.handler.ipfilter.AbstractRemoteAddressFilter
This method is called if remoteAddress gets rejected by AbstractRemoteAddressFilter.accept(ChannelHandlerContext, SocketAddress).
channelReleased(Channel) - Method in class io.netty.channel.pool.AbstractChannelPoolHandler
NOOP implementation, sub-classes may override this.
channelReleased(Channel) - Method in interface io.netty.channel.pool.ChannelPoolHandler
channelTrafficCounters() - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
To allow for instance doAccounting to use the TrafficCounter per channel.
ChannelTrafficShapingHandler - Class in io.netty.handler.traffic
This implementation of the AbstractTrafficShapingHandler is for channel traffic shaping, that is to say a per channel limitation of the bandwidth.
ChannelTrafficShapingHandler(long, long, long, long) - Constructor for class io.netty.handler.traffic.ChannelTrafficShapingHandler
Create a new instance.
ChannelTrafficShapingHandler(long, long, long) - Constructor for class io.netty.handler.traffic.ChannelTrafficShapingHandler
Create a new instance using default max time as delay allowed value of 15000 ms.
ChannelTrafficShapingHandler(long, long) - Constructor for class io.netty.handler.traffic.ChannelTrafficShapingHandler
Create a new instance using default Check Interval value of 1000 ms and max time as delay allowed value of 15000 ms.
ChannelTrafficShapingHandler(long) - Constructor for class io.netty.handler.traffic.ChannelTrafficShapingHandler
Create a new instance using default max time as delay allowed value of 15000 ms and no limit.
channelType(Class<? extends DatagramChannel>) - Method in class io.netty.resolver.dns.DnsNameResolverBuilder
Sets the ChannelFactory as a ReflectiveChannelFactory of this type.
channelUnregistered(ChannelHandlerContext) - Method in interface io.netty.channel.ChannelInboundHandler
The Channel of the ChannelHandlerContext was unregistered from its EventLoop
channelUnregistered(ChannelHandlerContext) - Method in class io.netty.channel.ChannelInboundHandlerAdapter
channelUnregistered(ChannelHandlerContext) - Method in class io.netty.channel.CombinedChannelDuplexHandler
 
channelUnregistered(C, Throwable) - Method in interface io.netty.channel.nio.NioTask
Invoked when the SelectionKey of the specified SelectableChannel has been cancelled and thus this NioTask will not be notified anymore.
channelUnregistered(ChannelHandlerContext) - Method in class io.netty.handler.codec.DatagramPacketDecoder
 
channelUnregistered(ChannelHandlerContext) - Method in class io.netty.handler.logging.LoggingHandler
 
channelWritabilityChanged(ChannelHandlerContext) - Method in interface io.netty.channel.ChannelInboundHandler
Gets called once the writable state of a Channel changed.
channelWritabilityChanged(ChannelHandlerContext) - Method in class io.netty.channel.ChannelInboundHandlerAdapter
channelWritabilityChanged(ChannelHandlerContext) - Method in class io.netty.channel.CombinedChannelDuplexHandler
 
channelWritabilityChanged(ChannelHandlerContext) - Method in class io.netty.handler.codec.DatagramPacketDecoder
 
channelWritabilityChanged(ChannelHandlerContext) - Method in class io.netty.handler.flush.FlushConsolidationHandler
 
channelWritabilityChanged(ChannelHandlerContext) - Method in class io.netty.handler.logging.LoggingHandler
 
channelWritabilityChanged(ChannelHandlerContext) - Method in class io.netty.handler.stream.ChunkedWriteHandler
 
charAt(int) - Method in class io.netty.util.AsciiString
 
charAt(int) - Method in class io.netty.util.internal.AppendableCharSequence
 
charAtUnsafe(int) - Method in class io.netty.util.internal.AppendableCharSequence
Access a value in this CharSequence.
CharCollections - Class in io.netty.util.collection
Utilities for char-based primitive collections.
CharObjectHashMap<V> - Class in io.netty.util.collection
A hash map implementation of CharObjectMap that uses open addressing for keys.
CharObjectHashMap() - Constructor for class io.netty.util.collection.CharObjectHashMap
 
CharObjectHashMap(int) - Constructor for class io.netty.util.collection.CharObjectHashMap
 
CharObjectHashMap(int, float) - Constructor for class io.netty.util.collection.CharObjectHashMap
 
CharObjectMap<V> - Interface in io.netty.util.collection
Interface for a primitive map that uses chars as keys.
CharObjectMap.PrimitiveEntry<V> - Interface in io.netty.util.collection
A primitive entry in the map, provided by the iterator from CharObjectMap.entries()
CharSequenceValueConverter - Class in io.netty.handler.codec
Converts to/from native types, general Object, and CharSequences.
CharSequenceValueConverter() - Constructor for class io.netty.handler.codec.CharSequenceValueConverter
 
charsetDecoderCache() - Method in class io.netty.util.internal.InternalThreadLocalMap
 
charsetEncoderCache() - Method in class io.netty.util.internal.InternalThreadLocalMap
 
CharsetUtil - Class in io.netty.util
A utility class that provides various common operations and constants related with Charset and its relevant classes.
checkDeadLock() - Method in class io.netty.channel.DefaultChannelProgressivePromise
 
checkDeadLock() - Method in class io.netty.channel.DefaultChannelPromise
 
checkDeadLock() - Method in class io.netty.util.concurrent.DefaultPromise
 
checkDstIndex(int, int, int, int) - Method in class io.netty.buffer.AbstractByteBuf
 
checkException() - Method in class io.netty.channel.embedded.EmbeddedChannel
Check if there was any Throwable received and if so rethrow it.
checkIndex(int) - Method in class io.netty.buffer.AbstractByteBuf
 
checkIndex(int, int) - Method in class io.netty.buffer.AbstractByteBuf
 
checkInputShutdown() - Method in class io.netty.channel.socket.oio.OioSocketChannel
 
checkInterval - Variable in class io.netty.handler.traffic.AbstractTrafficShapingHandler
Delay between two performance snapshots
checkInterval() - Method in class io.netty.handler.traffic.TrafficCounter
 
checkNewCapacity(int) - Method in class io.netty.buffer.AbstractByteBuf
 
checkNonEmpty(T[], String) - Static method in class io.netty.util.internal.ObjectUtil
Checks that the given argument is neither null nor empty.
checkNotNull(T, String) - Static method in class io.netty.util.internal.ObjectUtil
Checks that the given argument is not null.
checkpoint() - Method in class io.netty.handler.codec.ReplayingDecoder
Stores the internal cumulative buffer's reader position.
checkpoint(S) - Method in class io.netty.handler.codec.ReplayingDecoder
Stores the internal cumulative buffer's reader position and updates the current decoder state.
checkPositive(int, String) - Static method in class io.netty.util.internal.ObjectUtil
Checks that the given argument is strictly positive.
checkPositive(long, String) - Static method in class io.netty.util.internal.ObjectUtil
Checks that the given argument is strictly positive.
checkPositiveOrZero(int, String) - Static method in class io.netty.util.internal.ObjectUtil
Checks that the given argument is positive or zero.
checkPositiveOrZero(long, String) - Static method in class io.netty.util.internal.ObjectUtil
Checks that the given argument is positive or zero.
checkReadableBytes(int) - Method in class io.netty.buffer.AbstractByteBuf
Throws an IndexOutOfBoundsException if the current readable bytes of this buffer is less than the specified value.
checkSrcIndex(int, int, int, int) - Method in class io.netty.buffer.AbstractByteBuf
 
checkValidity() - Method in class io.netty.handler.ssl.PemX509Certificate
 
checkValidity(Date) - Method in class io.netty.handler.ssl.PemX509Certificate
 
checkWaitReadTime(ChannelHandlerContext, long, long) - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
 
childAttr(AttributeKey<T>, T) - Method in class io.netty.bootstrap.ServerBootstrap
Set the specific AttributeKey with the given value on every child Channel.
childAttrs() - Method in class io.netty.bootstrap.ServerBootstrapConfig
Returns a copy of the configured attributes which will be used for the child channels.
childGroup() - Method in class io.netty.bootstrap.ServerBootstrap
Deprecated.
childGroup() - Method in class io.netty.bootstrap.ServerBootstrapConfig
Returns the configured EventLoopGroup which will be used for the child channels or null if non is configured yet.
childHandler(ChannelHandler) - Method in class io.netty.bootstrap.ServerBootstrap
Set the ChannelHandler which is used to serve the request for the Channel's.
childHandler() - Method in class io.netty.bootstrap.ServerBootstrapConfig
Returns the configured ChannelHandler be used for the child channels or null if non is configured yet.
childOption(ChannelOption<T>, T) - Method in class io.netty.bootstrap.ServerBootstrap
Allow to specify a ChannelOption which is used for the Channel instances once they get created (after the acceptor accepted the Channel).
childOptions() - Method in class io.netty.bootstrap.ServerBootstrapConfig
Returns a copy of the configured options which will be used for the child channels.
children() - Method in class io.netty.handler.codec.redis.ArrayRedisMessage
Get children of this Arrays.
ChunkedFile - Class in io.netty.handler.stream
A ChunkedInput that fetches data from a file chunk by chunk.
ChunkedFile(File) - Constructor for class io.netty.handler.stream.ChunkedFile
Creates a new instance that fetches data from the specified file.
ChunkedFile(File, int) - Constructor for class io.netty.handler.stream.ChunkedFile
Creates a new instance that fetches data from the specified file.
ChunkedFile(RandomAccessFile) - Constructor for class io.netty.handler.stream.ChunkedFile
Creates a new instance that fetches data from the specified file.
ChunkedFile(RandomAccessFile, int) - Constructor for class io.netty.handler.stream.ChunkedFile
Creates a new instance that fetches data from the specified file.
ChunkedFile(RandomAccessFile, long, long, int) - Constructor for class io.netty.handler.stream.ChunkedFile
Creates a new instance that fetches data from the specified file.
ChunkedInput<B> - Interface in io.netty.handler.stream
A data stream of indefinite length which is consumed by ChunkedWriteHandler.
ChunkedNioFile - Class in io.netty.handler.stream
A ChunkedInput that fetches data from a file chunk by chunk using NIO FileChannel.
ChunkedNioFile(File) - Constructor for class io.netty.handler.stream.ChunkedNioFile
Creates a new instance that fetches data from the specified file.
ChunkedNioFile(File, int) - Constructor for class io.netty.handler.stream.ChunkedNioFile
Creates a new instance that fetches data from the specified file.
ChunkedNioFile(FileChannel) - Constructor for class io.netty.handler.stream.ChunkedNioFile
Creates a new instance that fetches data from the specified file.
ChunkedNioFile(FileChannel, int) - Constructor for class io.netty.handler.stream.ChunkedNioFile
Creates a new instance that fetches data from the specified file.
ChunkedNioFile(FileChannel, long, long, int) - Constructor for class io.netty.handler.stream.ChunkedNioFile
Creates a new instance that fetches data from the specified file.
ChunkedNioStream - Class in io.netty.handler.stream
A ChunkedInput that fetches data from a ReadableByteChannel chunk by chunk.
ChunkedNioStream(ReadableByteChannel) - Constructor for class io.netty.handler.stream.ChunkedNioStream
Creates a new instance that fetches data from the specified channel.
ChunkedNioStream(ReadableByteChannel, int) - Constructor for class io.netty.handler.stream.ChunkedNioStream
Creates a new instance that fetches data from the specified channel.
ChunkedStream - Class in io.netty.handler.stream
A ChunkedInput that fetches data from an InputStream chunk by chunk.
ChunkedStream(InputStream) - Constructor for class io.netty.handler.stream.ChunkedStream
Creates a new instance that fetches data from the specified stream.
ChunkedStream(InputStream, int) - Constructor for class io.netty.handler.stream.ChunkedStream
Creates a new instance that fetches data from the specified stream.
ChunkedWriteHandler - Class in io.netty.handler.stream
A ChannelHandler that adds support for writing a large data stream asynchronously neither spending a lot of memory nor getting OutOfMemoryError.
ChunkedWriteHandler() - Constructor for class io.netty.handler.stream.ChunkedWriteHandler
 
ChunkedWriteHandler(int) - Constructor for class io.netty.handler.stream.ChunkedWriteHandler
chunkLists() - Method in interface io.netty.buffer.PoolArenaMetric
Returns an unmodifiable List which holds PoolChunkListMetrics.
chunkSize() - Method in interface io.netty.buffer.PoolChunkMetric
Return the size of the chunk in bytes, this is the maximum of bytes that can be served out of the chunk.
chunkSize() - Method in class io.netty.buffer.PooledByteBufAllocator
chunkSize() - Method in class io.netty.buffer.PooledByteBufAllocatorMetric
Return the chunk size for an arena.
ciphers(Iterable<String>) - Method in class io.netty.handler.ssl.SslContextBuilder
The cipher suites to enable, in the order of preference.
ciphers(Iterable<String>, CipherSuiteFilter) - Method in class io.netty.handler.ssl.SslContextBuilder
The cipher suites to enable, in the order of preference.
CipherSuiteFilter - Interface in io.netty.handler.ssl
Provides a means to filter the supplied cipher suite based upon the supported and default cipher suites.
cipherSuites() - Method in class io.netty.handler.ssl.DelegatingSslContext
 
cipherSuites() - Method in class io.netty.handler.ssl.JdkSslContext
 
cipherSuites() - Method in class io.netty.handler.ssl.SslContext
Returns the list of enabled cipher suites, in the order of preference.
CLASS_ANY - Static variable in interface io.netty.handler.codec.dns.DnsRecord
DNS resource record class: ANY
CLASS_CHAOS - Static variable in interface io.netty.handler.codec.dns.DnsRecord
DNS resource record class: CHAOS
CLASS_CSNET - Static variable in interface io.netty.handler.codec.dns.DnsRecord
DNS resource record class: CSNET
CLASS_HESIOD - Static variable in interface io.netty.handler.codec.dns.DnsRecord
DNS resource record class: HESIOD
CLASS_IN - Static variable in interface io.netty.handler.codec.dns.DnsRecord
DNS resource record class: IN
CLASS_NONE - Static variable in interface io.netty.handler.codec.dns.DnsRecord
DNS resource record class: NONE
ClassResolver - Interface in io.netty.handler.codec.serialization
please use ClassResolvers as instance factory
ClassResolvers - Class in io.netty.handler.codec.serialization
 
cleanSession(boolean) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
 
cleanup() - Method in class io.netty.channel.nio.NioEventLoop
 
cleanup() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
Do nothing, sub-classes may override
clear() - Method in class io.netty.buffer.AbstractByteBuf
 
clear() - Method in class io.netty.buffer.ByteBuf
Sets the readerIndex and writerIndex of this buffer to 0.
clear() - Method in class io.netty.buffer.CompositeByteBuf
 
clear() - Method in class io.netty.buffer.EmptyByteBuf
 
clear() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
clear() - Method in class io.netty.channel.group.DefaultChannelGroup
 
clear() - Method in class io.netty.channel.unix.IovArray
 
clear() - Method in class io.netty.handler.codec.DefaultHeaders
 
clear(DnsSection) - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
 
clear() - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
 
clear(DnsSection) - Method in class io.netty.handler.codec.dns.DatagramDnsQuery
 
clear() - Method in class io.netty.handler.codec.dns.DatagramDnsQuery
 
clear(DnsSection) - Method in class io.netty.handler.codec.dns.DatagramDnsResponse
 
clear() - Method in class io.netty.handler.codec.dns.DatagramDnsResponse
 
clear(DnsSection) - Method in class io.netty.handler.codec.dns.DefaultDnsQuery
 
clear() - Method in class io.netty.handler.codec.dns.DefaultDnsQuery
 
clear(DnsSection) - Method in class io.netty.handler.codec.dns.DefaultDnsResponse
 
clear() - Method in class io.netty.handler.codec.dns.DefaultDnsResponse
 
clear(DnsSection) - Method in interface io.netty.handler.codec.dns.DnsMessage
Removes all the records in the specified section of this DNS message.
clear() - Method in interface io.netty.handler.codec.dns.DnsMessage
Removes all the records in this DNS message.
clear(DnsSection) - Method in interface io.netty.handler.codec.dns.DnsQuery
 
clear() - Method in interface io.netty.handler.codec.dns.DnsQuery
 
clear(DnsSection) - Method in interface io.netty.handler.codec.dns.DnsResponse
 
clear() - Method in interface io.netty.handler.codec.dns.DnsResponse
 
clear() - Method in class io.netty.handler.codec.EmptyHeaders
 
clear() - Method in interface io.netty.handler.codec.Headers
Removes all headers.
clear() - Method in class io.netty.resolver.dns.DefaultDnsCache
 
clear(String) - Method in class io.netty.resolver.dns.DefaultDnsCache
 
clear() - Method in interface io.netty.resolver.dns.DnsCache
Clears all the resolved addresses cached by this resolver.
clear(String) - Method in interface io.netty.resolver.dns.DnsCache
Clears the resolved addresses of the specified host name from the cache of this resolver.
clear() - Method in class io.netty.resolver.dns.NoopDnsCache
 
clear(String) - Method in class io.netty.resolver.dns.NoopDnsCache
 
clear() - Method in class io.netty.util.collection.ByteObjectHashMap
 
clear() - Method in class io.netty.util.collection.CharObjectHashMap
 
clear() - Method in class io.netty.util.collection.IntObjectHashMap
 
clear() - Method in class io.netty.util.collection.LongObjectHashMap
 
clear() - Method in class io.netty.util.collection.ShortObjectHashMap
 
clear() - Method in class io.netty.util.internal.ConcurrentSet
 
clear() - Method in class io.netty.util.internal.DefaultPriorityQueue
 
clear() - Method in class io.netty.util.internal.EmptyPriorityQueue
 
clearOpWrite() - Method in class io.netty.channel.nio.AbstractNioByteChannel
 
clearReadPending() - Method in class io.netty.channel.nio.AbstractNioChannel
Set read pending to false.
clearReadPending() - Method in class io.netty.channel.oio.AbstractOioChannel
Set read pending to false.
ClientAuth - Enum in io.netty.handler.ssl
Indicates the state of the SSLEngine with respect to client authentication.
clientAuth(ClientAuth) - Method in class io.netty.handler.ssl.SslContextBuilder
Sets the client authentication mode.
clientId(String) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
 
clientIdentifier() - Method in class io.netty.handler.codec.mqtt.MqttConnectPayload
 
clone() - Method in class io.netty.bootstrap.AbstractBootstrap
Returns a deep clone of this bootstrap which has the identical configuration.
clone() - Method in class io.netty.bootstrap.Bootstrap
 
clone(EventLoopGroup) - Method in class io.netty.bootstrap.Bootstrap
Returns a deep clone of this bootstrap which has the identical configuration except that it uses the given EventLoopGroup.
clone() - Method in class io.netty.bootstrap.ServerBootstrap
 
close() - Method in class io.netty.buffer.ByteBufInputStream
 
close(ChannelPromise) - Method in class io.netty.channel.AbstractChannel.AbstractUnsafe
 
close() - Method in class io.netty.channel.AbstractChannel
 
close(ChannelPromise) - Method in class io.netty.channel.AbstractChannel
 
close(ChannelPromise) - Method in interface io.netty.channel.Channel.Unsafe
Close the Channel of the ChannelPromise and notify the ChannelPromise once the operation was complete.
close(ChannelHandlerContext, ChannelPromise) - Method in class io.netty.channel.ChannelDuplexHandler
CLOSE - Static variable in interface io.netty.channel.ChannelFutureListener
A ChannelFutureListener that closes the Channel which is associated with the specified ChannelFuture.
close(ChannelHandlerContext, ChannelPromise) - Method in interface io.netty.channel.ChannelOutboundHandler
Called once a close operation is made.
close(ChannelHandlerContext, ChannelPromise) - Method in class io.netty.channel.ChannelOutboundHandlerAdapter
close() - Method in interface io.netty.channel.ChannelOutboundInvoker
Request to close the Channel and notify the ChannelFuture once the operation completes, either because the operation was successful or because of an error.
close(ChannelPromise) - Method in interface io.netty.channel.ChannelOutboundInvoker
Request to close the Channel and notify the ChannelFuture once the operation completes, either because the operation was successful or because of an error.
close(ChannelHandlerContext, ChannelPromise) - Method in class io.netty.channel.CombinedChannelDuplexHandler
 
close() - Method in class io.netty.channel.DefaultChannelPipeline
 
close(ChannelPromise) - Method in class io.netty.channel.DefaultChannelPipeline
 
close() - Method in class io.netty.channel.embedded.EmbeddedChannel
 
close(ChannelPromise) - Method in class io.netty.channel.embedded.EmbeddedChannel
 
close() - Method in interface io.netty.channel.group.ChannelGroup
Closes all Channels in this group.
close(ChannelMatcher) - Method in interface io.netty.channel.group.ChannelGroup
Closes all Channels in this group that are matched by the given ChannelMatcher.
close() - Method in class io.netty.channel.group.DefaultChannelGroup
 
close(ChannelMatcher) - Method in class io.netty.channel.group.DefaultChannelGroup
 
close() - Method in class io.netty.channel.pool.AbstractChannelPoolMap
 
close() - Method in interface io.netty.channel.pool.ChannelPool
 
close() - Method in class io.netty.channel.pool.FixedChannelPool
 
close() - Method in class io.netty.channel.pool.SimpleChannelPool
 
close() - Method in class io.netty.channel.unix.FileDescriptor
Close the file descriptor.
close() - Method in class io.netty.channel.unix.SocketWritableByteChannel
 
close() - Method in class io.netty.handler.codec.compression.Bzip2Encoder
Close this Bzip2Encoder and so finish the encoding.
close(ChannelPromise) - Method in class io.netty.handler.codec.compression.Bzip2Encoder
Close this Bzip2Encoder and so finish the encoding.
close(ChannelHandlerContext, ChannelPromise) - Method in class io.netty.handler.codec.compression.Bzip2Encoder
 
close() - Method in class io.netty.handler.codec.compression.JdkZlibEncoder
 
close(ChannelPromise) - Method in class io.netty.handler.codec.compression.JdkZlibEncoder
 
close(ChannelHandlerContext, ChannelPromise) - Method in class io.netty.handler.codec.compression.JdkZlibEncoder
 
close() - Method in class io.netty.handler.codec.compression.JZlibEncoder
 
close(ChannelPromise) - Method in class io.netty.handler.codec.compression.JZlibEncoder
 
close(ChannelHandlerContext, ChannelPromise) - Method in class io.netty.handler.codec.compression.JZlibEncoder
 
close() - Method in class io.netty.handler.codec.compression.ZlibEncoder
Close this ZlibEncoder and so finish the encoding.
close(ChannelPromise) - Method in class io.netty.handler.codec.compression.ZlibEncoder
Close this ZlibEncoder and so finish the encoding.
close(ChannelHandlerContext, ChannelPromise) - Method in class io.netty.handler.codec.DatagramPacketEncoder
 
close() - Method in class io.netty.handler.codec.serialization.ObjectDecoderInputStream
 
close() - Method in class io.netty.handler.codec.serialization.ObjectEncoderOutputStream
 
close(ChannelHandlerContext, ChannelPromise) - Method in class io.netty.handler.flush.FlushConsolidationHandler
 
close(ChannelHandlerContext, ChannelPromise) - Method in class io.netty.handler.logging.LoggingHandler
 
close(ChannelHandlerContext, ChannelPromise) - Method in class io.netty.handler.ssl.AbstractSniHandler
 
close() - Method in class io.netty.handler.ssl.SslHandler
close(ChannelPromise) - Method in class io.netty.handler.ssl.SslHandler
close(ChannelHandlerContext, ChannelPromise) - Method in class io.netty.handler.ssl.SslHandler
 
close() - Method in class io.netty.handler.stream.ChunkedFile
 
close() - Method in interface io.netty.handler.stream.ChunkedInput
Releases the resources associated with the input.
close() - Method in class io.netty.handler.stream.ChunkedNioFile
 
close() - Method in class io.netty.handler.stream.ChunkedNioStream
 
close() - Method in class io.netty.handler.stream.ChunkedStream
 
close() - Method in class io.netty.resolver.AbstractAddressResolver
 
close() - Method in interface io.netty.resolver.AddressResolver
Closes all the resources allocated and used by this resolver.
close() - Method in class io.netty.resolver.AddressResolverGroup
Closes all NameResolvers created by this group.
close() - Method in class io.netty.resolver.dns.DnsNameResolver
Closes the internal datagram channel used for sending and receiving DNS messages, and clears all DNS resource records from the cache.
close() - Method in class io.netty.resolver.InetSocketAddressResolver
 
close() - Method in interface io.netty.resolver.NameResolver
Closes all the resources allocated and used by this resolver.
close() - Method in class io.netty.resolver.SimpleNameResolver
 
close() - Method in interface io.netty.util.ResourceLeak
Deprecated.
Close the leak so that ResourceLeakDetector does not warn about leaked resources.
close(T) - Method in interface io.netty.util.ResourceLeakTracker
Close the leak so that ResourceLeakTracker does not warn about leaked resources.
CLOSE_ON_FAILURE - Static variable in interface io.netty.channel.ChannelFutureListener
A ChannelFutureListener that closes the Channel when the operation ended up with a failure or cancellation rather than a success.
closeAfterContinueResponse(Object) - Method in class io.netty.handler.codec.memcache.AbstractMemcacheObjectAggregator
 
closeAfterContinueResponse(Object) - Method in class io.netty.handler.codec.MessageAggregator
Determine if the channel should be closed after the result of MessageAggregator.newContinueResponse(Object, int, ChannelPipeline) is written.
closeAfterContinueResponse(Object) - Method in class io.netty.handler.codec.redis.RedisBulkStringAggregator
 
closeAfterContinueResponse(Object) - Method in class io.netty.handler.codec.stomp.StompSubframeAggregator
 
closeForcibly() - Method in class io.netty.channel.AbstractChannel.AbstractUnsafe
 
closeForcibly() - Method in interface io.netty.channel.Channel.Unsafe
Closes the Channel immediately without firing any events.
closeFuture() - Method in class io.netty.channel.AbstractChannel
 
closeFuture() - Method in interface io.netty.channel.Channel
Returns the ChannelFuture which will be notified when this channel is closed.
closeIfClosed() - Method in class io.netty.channel.AbstractChannel.AbstractUnsafe
 
closeOnReadError(Throwable) - Method in class io.netty.channel.nio.AbstractNioMessageChannel
 
closeOnReadError(Throwable) - Method in class io.netty.channel.socket.nio.NioDatagramChannel
 
CNAME - Static variable in class io.netty.handler.codec.dns.DnsRecordType
Canonical name record RFC 1035 Alias of one name to another: the DNS lookup will continue by retrying the lookup with the new name.
CoalescingBufferQueue - Class in io.netty.channel
A FIFO queue of bytes where producers add bytes by repeatedly adding ByteBuf and consumers take bytes in arbitrary lengths.
CoalescingBufferQueue(Channel) - Constructor for class io.netty.channel.CoalescingBufferQueue
 
CoalescingBufferQueue(Channel, int) - Constructor for class io.netty.channel.CoalescingBufferQueue
 
code() - Method in class io.netty.handler.codec.dns.DefaultDnsResponse
 
code() - Method in interface io.netty.handler.codec.dns.DnsResponse
Returns the 4 bit return code.
code() - Method in class io.netty.handler.codec.smtp.DefaultSmtpResponse
 
code() - Method in interface io.netty.handler.codec.smtp.SmtpResponse
Returns the response code.
CodecException - Exception in io.netty.handler.codec
An Exception which is thrown by a codec.
CodecException() - Constructor for exception io.netty.handler.codec.CodecException
Creates a new instance.
CodecException(String, Throwable) - Constructor for exception io.netty.handler.codec.CodecException
Creates a new instance.
CodecException(String) - Constructor for exception io.netty.handler.codec.CodecException
Creates a new instance.
CodecException(Throwable) - Constructor for exception io.netty.handler.codec.CodecException
Creates a new instance.
CombinedChannelDuplexHandler<I extends ChannelInboundHandler,O extends ChannelOutboundHandler> - Class in io.netty.channel
CombinedChannelDuplexHandler() - Constructor for class io.netty.channel.CombinedChannelDuplexHandler
Creates a new uninitialized instance.
CombinedChannelDuplexHandler(I, O) - Constructor for class io.netty.channel.CombinedChannelDuplexHandler
Creates a new instance that combines the specified two handlers into one.
COMMA - Static variable in class io.netty.util.internal.StringUtil
 
command() - Method in class io.netty.handler.codec.smtp.DefaultSmtpRequest
 
command() - Method in interface io.netty.handler.codec.smtp.SmtpRequest
Returns the SmtpCommand that belongs to the request.
command - Variable in class io.netty.handler.codec.stomp.DefaultStompHeadersSubframe
 
command() - Method in class io.netty.handler.codec.stomp.DefaultStompHeadersSubframe
 
command() - Method in interface io.netty.handler.codec.stomp.StompHeadersSubframe
Returns command of this frame.
commitTimeMillis() - Method in class io.netty.util.Version
 
CommonsLoggerFactory - Class in io.netty.util.internal.logging
CommonsLoggerFactory() - Constructor for class io.netty.util.internal.logging.CommonsLoggerFactory
Deprecated.
commonSuffixOfLength(String, String, int) - Static method in class io.netty.util.internal.StringUtil
Checks if two strings have the same suffix of specified length
compare(ByteBuf, ByteBuf) - Static method in class io.netty.buffer.ByteBufUtil
Compares the two specified buffers as described in ByteBuf.compareTo(ByteBuf).
compare(int, int) - Static method in class io.netty.util.internal.MathUtil
Compares two int values.
compare(long, long) - Static method in class io.netty.util.internal.MathUtil
Compare two long values.
compareAndSet(T, T) - Method in interface io.netty.util.Attribute
Atomically sets the value to the given updated value if the current value == the expected value.
compareTo(ByteBuf) - Method in class io.netty.buffer.AbstractByteBuf
 
compareTo(ByteBuf) - Method in class io.netty.buffer.ByteBuf
Compares the content of the specified buffer to the content of this buffer.
compareTo(ByteBuf) - Method in class io.netty.buffer.EmptyByteBuf
 
compareTo(ByteBuf) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
compareTo(Channel) - Method in class io.netty.channel.AbstractChannel
 
compareTo(ChannelId) - Method in class io.netty.channel.DefaultChannelId
 
compareTo(ChannelGroup) - Method in class io.netty.channel.group.DefaultChannelGroup
 
compareTo(LocalAddress) - Method in class io.netty.channel.local.LocalAddress
 
compareTo(DnsOpCode) - Method in class io.netty.handler.codec.dns.DnsOpCode
 
compareTo(DnsRecordType) - Method in class io.netty.handler.codec.dns.DnsRecordType
 
compareTo(DnsResponseCode) - Method in class io.netty.handler.codec.dns.DnsResponseCode
 
compareTo(T) - Method in class io.netty.util.AbstractConstant
 
compareTo(CharSequence) - Method in class io.netty.util.AsciiString
Compares the specified string to this string using the ASCII values of the characters.
compareTo(Signal) - Method in error io.netty.util.Signal
 
CompatibleObjectEncoder - Class in io.netty.handler.codec.serialization
An encoder which serializes a Java object into a ByteBuf (interoperability version).
CompatibleObjectEncoder() - Constructor for class io.netty.handler.codec.serialization.CompatibleObjectEncoder
Creates a new instance with the reset interval of 16.
CompatibleObjectEncoder(int) - Constructor for class io.netty.handler.codec.serialization.CompatibleObjectEncoder
Creates a new instance.
CompleteFuture<V> - Class in io.netty.util.concurrent
A skeletal Future implementation which represents a Future which has been completed already.
CompleteFuture(EventExecutor) - Constructor for class io.netty.util.concurrent.CompleteFuture
Creates a new instance.
component(int) - Method in class io.netty.buffer.CompositeByteBuf
Return the ByteBuf on the specified index
componentAtOffset(int) - Method in class io.netty.buffer.CompositeByteBuf
Return the ByteBuf on the specified index
compose(ChannelMatcher...) - Static method in class io.netty.channel.group.ChannelMatchers
Return a composite of the given ChannelMatchers.
COMPOSITE_CUMULATOR - Static variable in class io.netty.handler.codec.ByteToMessageDecoder
Cumulate ByteBufs by add them to a CompositeByteBuf and so do no memory copy whenever possible.
compositeBuffer() - Method in class io.netty.buffer.AbstractByteBufAllocator
 
compositeBuffer(int) - Method in class io.netty.buffer.AbstractByteBufAllocator
 
compositeBuffer() - Method in interface io.netty.buffer.ByteBufAllocator
Allocate a CompositeByteBuf.
compositeBuffer(int) - Method in interface io.netty.buffer.ByteBufAllocator
Allocate a CompositeByteBuf with the given maximum number of components that can be stored in it.
compositeBuffer() - Static method in class io.netty.buffer.Unpooled
Returns a new big-endian composite buffer with no components.
compositeBuffer(int) - Static method in class io.netty.buffer.Unpooled
Returns a new big-endian composite buffer with no components.
CompositeByteBuf - Class in io.netty.buffer
A virtual buffer which shows multiple buffers as a single merged buffer.
CompositeByteBuf(ByteBufAllocator, boolean, int) - Constructor for class io.netty.buffer.CompositeByteBuf
 
CompositeByteBuf(ByteBufAllocator, boolean, int, ByteBuf...) - Constructor for class io.netty.buffer.CompositeByteBuf
 
CompositeByteBuf(ByteBufAllocator, boolean, int, Iterable<ByteBuf>) - Constructor for class io.netty.buffer.CompositeByteBuf
 
compositeDirectBuffer() - Method in class io.netty.buffer.AbstractByteBufAllocator
 
compositeDirectBuffer(int) - Method in class io.netty.buffer.AbstractByteBufAllocator
 
compositeDirectBuffer() - Method in interface io.netty.buffer.ByteBufAllocator
Allocate a direct CompositeByteBuf.
compositeDirectBuffer(int) - Method in interface io.netty.buffer.ByteBufAllocator
Allocate a direct CompositeByteBuf with the given maximum number of components that can be stored in it.
compositeDirectBuffer(int) - Method in class io.netty.buffer.UnpooledByteBufAllocator
 
compositeHeapBuffer() - Method in class io.netty.buffer.AbstractByteBufAllocator
 
compositeHeapBuffer(int) - Method in class io.netty.buffer.AbstractByteBufAllocator
 
compositeHeapBuffer() - Method in interface io.netty.buffer.ByteBufAllocator
Allocate a heap CompositeByteBuf.
compositeHeapBuffer(int) - Method in interface io.netty.buffer.ByteBufAllocator
Allocate a heap CompositeByteBuf with the given maximum number of components that can be stored in it.
compositeHeapBuffer(int) - Method in class io.netty.buffer.UnpooledByteBufAllocator
 
CompositeNameResolver<T> - Class in io.netty.resolver
A composite SimpleNameResolver that resolves a host name against a sequence of NameResolvers.
CompositeNameResolver(EventExecutor, NameResolver<T>...) - Constructor for class io.netty.resolver.CompositeNameResolver
 
CompressionException - Exception in io.netty.handler.codec.compression
An EncoderException that is raised when compression failed.
CompressionException() - Constructor for exception io.netty.handler.codec.compression.CompressionException
Creates a new instance.
CompressionException(String, Throwable) - Constructor for exception io.netty.handler.codec.compression.CompressionException
Creates a new instance.
CompressionException(String) - Constructor for exception io.netty.handler.codec.compression.CompressionException
Creates a new instance.
CompressionException(Throwable) - Constructor for exception io.netty.handler.codec.compression.CompressionException
Creates a new instance.
computeResolvedAddressTypes(InternetProtocolFamily...) - Static method in class io.netty.resolver.dns.DnsNameResolverBuilder
concat(CharSequence) - Method in class io.netty.util.AsciiString
Concatenates this string and the specified string.
ConcurrentSet<E> - Class in io.netty.util.internal
 
ConcurrentSet() - Constructor for class io.netty.util.internal.ConcurrentSet
Creates a new instance which wraps the specified map.
config() - Method in class io.netty.bootstrap.AbstractBootstrap
Returns the AbstractBootstrapConfig object that can be used to obtain the current config of the bootstrap.
config() - Method in class io.netty.bootstrap.Bootstrap
 
config() - Method in class io.netty.bootstrap.ServerBootstrap
 
config() - Method in interface io.netty.channel.Channel
Returns the configuration of this channel.
config() - Method in class io.netty.channel.embedded.EmbeddedChannel
 
config() - Method in class io.netty.channel.epoll.EpollDatagramChannel
 
config() - Method in class io.netty.channel.epoll.EpollDomainSocketChannel
 
config() - Method in class io.netty.channel.epoll.EpollServerDomainSocketChannel
 
config() - Method in class io.netty.channel.epoll.EpollServerSocketChannel
 
config() - Method in class io.netty.channel.epoll.EpollSocketChannel
 
config() - Method in class io.netty.channel.kqueue.KQueueDatagramChannel
 
config() - Method in class io.netty.channel.kqueue.KQueueDomainSocketChannel
 
config() - Method in class io.netty.channel.kqueue.KQueueServerDomainSocketChannel
 
config() - Method in class io.netty.channel.kqueue.KQueueServerSocketChannel
 
config() - Method in class io.netty.channel.kqueue.KQueueSocketChannel
 
config() - Method in class io.netty.channel.local.LocalChannel
 
config() - Method in class io.netty.channel.local.LocalServerChannel
 
config() - Method in interface io.netty.channel.socket.DatagramChannel
 
config() - Method in class io.netty.channel.socket.nio.NioDatagramChannel
 
config() - Method in class io.netty.channel.socket.nio.NioServerSocketChannel
 
config() - Method in class io.netty.channel.socket.nio.NioSocketChannel
 
config() - Method in class io.netty.channel.socket.oio.OioDatagramChannel
 
config() - Method in class io.netty.channel.socket.oio.OioServerSocketChannel
 
config() - Method in class io.netty.channel.socket.oio.OioSocketChannel
 
config() - Method in interface io.netty.channel.socket.ServerSocketChannel
 
config() - Method in interface io.netty.channel.socket.SocketChannel
 
config() - Method in interface io.netty.channel.unix.DomainSocketChannel
 
configure(long, long, long) - Method in class io.netty.handler.traffic.AbstractTrafficShapingHandler
Change the underlying limitations and check interval.
configure(long, long) - Method in class io.netty.handler.traffic.AbstractTrafficShapingHandler
Change the underlying limitations.
configure(long) - Method in class io.netty.handler.traffic.AbstractTrafficShapingHandler
Change the check interval.
configure(long) - Method in class io.netty.handler.traffic.TrafficCounter
Change checkInterval between two computations in millisecond.
configureChannel(long, long) - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
 
configurePipeline(ChannelHandlerContext, String) - Method in class io.netty.handler.ssl.ApplicationProtocolNegotiationHandler
Invoked on successful initial SSL/TLS handshake.
confirmShutdown() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
Confirm that the shutdown if the instance should be done now!
connAck() - Static method in class io.netty.handler.codec.mqtt.MqttMessageBuilders
 
connect() - Method in class io.netty.bootstrap.Bootstrap
Connect a Channel to the remote peer.
connect(String, int) - Method in class io.netty.bootstrap.Bootstrap
Connect a Channel to the remote peer.
connect(InetAddress, int) - Method in class io.netty.bootstrap.Bootstrap
Connect a Channel to the remote peer.
connect(SocketAddress) - Method in class io.netty.bootstrap.Bootstrap
Connect a Channel to the remote peer.
connect(SocketAddress, SocketAddress) - Method in class io.netty.bootstrap.Bootstrap
Connect a Channel to the remote peer.
connect(SocketAddress) - Method in class io.netty.channel.AbstractChannel
 
connect(SocketAddress, SocketAddress) - Method in class io.netty.channel.AbstractChannel
 
connect(SocketAddress, ChannelPromise) - Method in class io.netty.channel.AbstractChannel
 
connect(SocketAddress, SocketAddress, ChannelPromise) - Method in class io.netty.channel.AbstractChannel
 
connect(SocketAddress, SocketAddress, ChannelPromise) - Method in interface io.netty.channel.Channel.Unsafe
Connect the Channel of the given ChannelFuture with the given remote SocketAddress.
connect(ChannelHandlerContext, SocketAddress, SocketAddress, ChannelPromise) - Method in class io.netty.channel.ChannelDuplexHandler
connect(ChannelHandlerContext, SocketAddress, SocketAddress, ChannelPromise) - Method in interface io.netty.channel.ChannelOutboundHandler
Called once a connect operation is made.
connect(ChannelHandlerContext, SocketAddress, SocketAddress, ChannelPromise) - Method in class io.netty.channel.ChannelOutboundHandlerAdapter
connect(SocketAddress) - Method in interface io.netty.channel.ChannelOutboundInvoker
Request to connect to the given SocketAddress and notify the ChannelFuture once the operation completes, either because the operation was successful or because of an error.
connect(SocketAddress, SocketAddress) - Method in interface io.netty.channel.ChannelOutboundInvoker
Request to connect to the given SocketAddress while bind to the localAddress and notify the ChannelFuture once the operation completes, either because the operation was successful or because of an error.
connect(SocketAddress, ChannelPromise) - Method in interface io.netty.channel.ChannelOutboundInvoker
Request to connect to the given SocketAddress and notify the ChannelFuture once the operation completes, either because the operation was successful or because of an error.
connect(SocketAddress, SocketAddress, ChannelPromise) - Method in interface io.netty.channel.ChannelOutboundInvoker
Request to connect to the given SocketAddress while bind to the localAddress and notify the ChannelFuture once the operation completes, either because the operation was successful or because of an error.
connect(ChannelHandlerContext, SocketAddress, SocketAddress, ChannelPromise) - Method in class io.netty.channel.CombinedChannelDuplexHandler
 
connect(SocketAddress) - Method in class io.netty.channel.DefaultChannelPipeline
 
connect(SocketAddress, SocketAddress) - Method in class io.netty.channel.DefaultChannelPipeline
 
connect(SocketAddress, ChannelPromise) - Method in class io.netty.channel.DefaultChannelPipeline
 
connect(SocketAddress, SocketAddress, ChannelPromise) - Method in class io.netty.channel.DefaultChannelPipeline
 
connect(SocketAddress, SocketAddress, ChannelPromise) - Method in class io.netty.channel.nio.AbstractNioChannel.AbstractNioUnsafe
 
connect(SocketAddress) - Method in class io.netty.channel.unix.Socket
 
connect(ChannelHandlerContext, SocketAddress, SocketAddress, ChannelPromise) - Method in class io.netty.handler.codec.DatagramPacketEncoder
 
connect() - Static method in class io.netty.handler.codec.mqtt.MqttMessageBuilders
 
connect(ChannelHandlerContext, SocketAddress, SocketAddress, ChannelPromise) - Method in class io.netty.handler.logging.LoggingHandler
 
connect(ChannelHandlerContext, SocketAddress, SocketAddress, ChannelPromise) - Method in class io.netty.handler.ssl.AbstractSniHandler
 
connect(ChannelHandlerContext, SocketAddress, SocketAddress, ChannelPromise) - Method in class io.netty.handler.ssl.SslHandler
 
connect(Socket, SocketAddress, int) - Static method in class io.netty.util.internal.SocketUtils
 
connect(SocketChannel, SocketAddress) - Static method in class io.netty.util.internal.SocketUtils
 
CONNECT_TIMEOUT_MILLIS - Static variable in class io.netty.channel.ChannelOption
 
connectChannel(Bootstrap) - Method in class io.netty.channel.pool.SimpleChannelPool
Bootstrap a new Channel.
connectReturnCode() - Method in class io.netty.handler.codec.mqtt.MqttConnAckVariableHeader
 
ConnectTimeoutException - Exception in io.netty.channel
ConnectException which will be thrown if a connection could not be established because of a connection timeout.
ConnectTimeoutException(String) - Constructor for exception io.netty.channel.ConnectTimeoutException
 
ConnectTimeoutException() - Constructor for exception io.netty.channel.ConnectTimeoutException
 
consolidate() - Method in class io.netty.buffer.CompositeByteBuf
Consolidate the composed ByteBufs
consolidate(int, int) - Method in class io.netty.buffer.CompositeByteBuf
Consolidate the composed ByteBufs
Constant<T extends Constant<T>> - Interface in io.netty.util
A singleton which is safe to compare via the == operator.
ConstantPool<T extends Constant<T>> - Class in io.netty.util
A pool of Constants.
ConstantPool() - Constructor for class io.netty.util.ConstantPool
 
ConstantTimeUtils - Class in io.netty.util.internal
 
contains(Object) - Method in class io.netty.channel.group.DefaultChannelGroup
 
contains(K) - Method in class io.netty.channel.pool.AbstractChannelPoolMap
 
contains(K) - Method in interface io.netty.channel.pool.ChannelPoolMap
Returns true if a ChannelPool exists for the given key.
contains(K) - Method in class io.netty.handler.codec.DefaultHeaders
 
contains(K, V) - Method in class io.netty.handler.codec.DefaultHeaders
 
contains(K, V, HashingStrategy<? super V>) - Method in class io.netty.handler.codec.DefaultHeaders
 
contains(K) - Method in class io.netty.handler.codec.EmptyHeaders
 
contains(K, V) - Method in class io.netty.handler.codec.EmptyHeaders
 
contains(K) - Method in interface io.netty.handler.codec.Headers
Returns true if a header with the name exists, false otherwise.
contains(K, V) - Method in interface io.netty.handler.codec.Headers
Returns true if a header with the name and value exists, false otherwise.
contains(CharSequence, CharSequence) - Method in class io.netty.handler.codec.stomp.DefaultStompHeaders
 
contains(CharSequence, CharSequence, boolean) - Method in class io.netty.handler.codec.stomp.DefaultStompHeaders
 
contains(CharSequence, CharSequence, boolean) - Method in interface io.netty.handler.codec.stomp.StompHeaders
Returns true if a header with the name and value exists, false otherwise.
contains(CharSequence) - Method in class io.netty.util.AsciiString
Determines if this String contains the sequence of characters in the CharSequence passed.
contains(CharSequence, CharSequence) - Static method in class io.netty.util.AsciiString
Determine if a contains b in a case sensitive manner.
contains(Object) - Method in class io.netty.util.internal.ConcurrentSet
 
contains(Object) - Method in class io.netty.util.internal.DefaultPriorityQueue
 
contains(Object) - Method in class io.netty.util.internal.EmptyPriorityQueue
 
contains(String) - Static method in class io.netty.util.internal.SystemPropertyUtil
Returns true if and only if the system property with the specified key exists.
containsAll(Collection<?>) - Method in class io.netty.util.internal.EmptyPriorityQueue
 
containsAllContentEqualsIgnoreCase(Collection<CharSequence>, Collection<CharSequence>) - Static method in class io.netty.util.AsciiString
Determine if a contains all of the values in b using AsciiString.contentEqualsIgnoreCase(CharSequence, CharSequence) to compare values.
containsBoolean(K, boolean) - Method in class io.netty.handler.codec.DefaultHeaders
 
containsBoolean(K, boolean) - Method in class io.netty.handler.codec.EmptyHeaders
 
containsBoolean(K, boolean) - Method in interface io.netty.handler.codec.Headers
Returns true if a header with the name and value exists.
containsByte(K, byte) - Method in class io.netty.handler.codec.DefaultHeaders
 
containsByte(K, byte) - Method in class io.netty.handler.codec.EmptyHeaders
 
containsByte(K, byte) - Method in interface io.netty.handler.codec.Headers
Returns true if a header with the name and value exists.
containsChar(K, char) - Method in class io.netty.handler.codec.DefaultHeaders
 
containsChar(K, char) - Method in class io.netty.handler.codec.EmptyHeaders
 
containsChar(K, char) - Method in interface io.netty.handler.codec.Headers
Returns true if a header with the name and value exists.
containsContentEqualsIgnoreCase(Collection<CharSequence>, CharSequence) - Static method in class io.netty.util.AsciiString
Determine if collection contains value and using AsciiString.contentEqualsIgnoreCase(CharSequence, CharSequence) to compare values.
containsDouble(K, double) - Method in class io.netty.handler.codec.DefaultHeaders
 
containsDouble(K, double) - Method in class io.netty.handler.codec.EmptyHeaders
 
containsDouble(K, double) - Method in interface io.netty.handler.codec.Headers
Returns true if a header with the name and value exists.
containsFloat(K, float) - Method in class io.netty.handler.codec.DefaultHeaders
 
containsFloat(K, float) - Method in class io.netty.handler.codec.EmptyHeaders
 
containsFloat(K, float) - Method in interface io.netty.handler.codec.Headers
Returns true if a header with the name and value exists.
containsIgnoreCase(CharSequence, CharSequence) - Static method in class io.netty.util.AsciiString
Determine if a contains b in a case insensitive manner.
containsInt(K, int) - Method in class io.netty.handler.codec.DefaultHeaders
 
containsInt(K, int) - Method in class io.netty.handler.codec.EmptyHeaders
 
containsInt(K, int) - Method in interface io.netty.handler.codec.Headers
Returns true if a header with the name and value exists.
containsKey(byte) - Method in class io.netty.util.collection.ByteObjectHashMap
 
containsKey(Object) - Method in class io.netty.util.collection.ByteObjectHashMap
 
containsKey(byte) - Method in interface io.netty.util.collection.ByteObjectMap
Indicates whether or not this map contains a value for the specified key.
containsKey(char) - Method in class io.netty.util.collection.CharObjectHashMap
 
containsKey(Object) - Method in class io.netty.util.collection.CharObjectHashMap
 
containsKey(char) - Method in interface io.netty.util.collection.CharObjectMap
Indicates whether or not this map contains a value for the specified key.
containsKey(int) - Method in class io.netty.util.collection.IntObjectHashMap
 
containsKey(Object) - Method in class io.netty.util.collection.IntObjectHashMap
 
containsKey(int) - Method in interface io.netty.util.collection.IntObjectMap
Indicates whether or not this map contains a value for the specified key.
containsKey(long) - Method in class io.netty.util.collection.LongObjectHashMap
 
containsKey(Object) - Method in class io.netty.util.collection.LongObjectHashMap
 
containsKey(long) - Method in interface io.netty.util.collection.LongObjectMap
Indicates whether or not this map contains a value for the specified key.
containsKey(short) - Method in class io.netty.util.collection.ShortObjectHashMap
 
containsKey(Object) - Method in class io.netty.util.collection.ShortObjectHashMap
 
containsKey(short) - Method in interface io.netty.util.collection.ShortObjectMap
Indicates whether or not this map contains a value for the specified key.
containsLong(K, long) - Method in class io.netty.handler.codec.DefaultHeaders
 
containsLong(K, long) - Method in class io.netty.handler.codec.EmptyHeaders
 
containsLong(K, long) - Method in interface io.netty.handler.codec.Headers
Returns true if a header with the name and value exists.
containsObject(K, Object) - Method in class io.netty.handler.codec.DefaultHeaders
 
containsObject(K, Object) - Method in class io.netty.handler.codec.EmptyHeaders
 
containsObject(K, Object) - Method in interface io.netty.handler.codec.Headers
Returns true if a header with the name and value exists.
containsShort(K, short) - Method in class io.netty.handler.codec.DefaultHeaders
 
containsShort(K, short) - Method in class io.netty.handler.codec.EmptyHeaders
 
containsShort(K, short) - Method in interface io.netty.handler.codec.Headers
Returns true if a header with the name and value exists.
containsTimeMillis(K, long) - Method in class io.netty.handler.codec.DefaultHeaders
 
containsTimeMillis(K, long) - Method in class io.netty.handler.codec.EmptyHeaders
 
containsTimeMillis(K, long) - Method in interface io.netty.handler.codec.Headers
Returns true if a header with the name and value exists.
containsTyped(T) - Method in class io.netty.util.internal.DefaultPriorityQueue
 
containsTyped(T) - Method in class io.netty.util.internal.EmptyPriorityQueue
 
containsTyped(T) - Method in interface io.netty.util.internal.PriorityQueue
Same as Collection.contains(Object) but typed using generics.
containsValue(Object) - Method in class io.netty.util.collection.ByteObjectHashMap
 
containsValue(Object) - Method in class io.netty.util.collection.CharObjectHashMap
 
containsValue(Object) - Method in class io.netty.util.collection.IntObjectHashMap
 
containsValue(Object) - Method in class io.netty.util.collection.LongObjectHashMap
 
containsValue(Object) - Method in class io.netty.util.collection.ShortObjectHashMap
 
content() - Method in interface io.netty.buffer.ByteBufHolder
Return the data which is held by this ByteBufHolder.
content() - Method in class io.netty.buffer.DefaultByteBufHolder
 
content() - Method in interface io.netty.channel.AddressedEnvelope
Returns the message wrapped by this envelope message.
content() - Method in class io.netty.channel.DefaultAddressedEnvelope
 
content() - Method in class io.netty.handler.codec.dns.DatagramDnsQuery
 
content() - Method in class io.netty.handler.codec.dns.DatagramDnsResponse
 
content() - Method in class io.netty.handler.codec.dns.DefaultDnsRawRecord
 
content() - Method in class io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheRequest
 
content() - Method in class io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheResponse
 
content() - Method in class io.netty.handler.codec.memcache.DefaultMemcacheContent
 
content() - Method in class io.netty.handler.codec.mqtt.MqttPublishMessage
 
content() - Method in class io.netty.handler.codec.redis.AbstractStringRedisMessage
Get string content of this AbstractStringRedisMessage.
content() - Method in class io.netty.handler.codec.stomp.DefaultStompFrame
 
content() - Method in class io.netty.handler.ssl.PemPrivateKey
 
content() - Method in class io.netty.handler.ssl.PemX509Certificate
 
CONTENT_LENGTH - Static variable in interface io.netty.handler.codec.stomp.StompHeaders
 
CONTENT_TYPE - Static variable in interface io.netty.handler.codec.stomp.StompHeaders
 
contentEquals(CharSequence) - Method in class io.netty.util.AsciiString
Compares a CharSequence to this String to determine if their contents are equal.
contentEquals(CharSequence, CharSequence) - Static method in class io.netty.util.AsciiString
Returns true if the content of both CharSequence's are equals.
contentEqualsIgnoreCase(CharSequence) - Method in class io.netty.util.AsciiString
Compares the specified string to this string ignoring the case of the characters and returns true if they are equal.
contentEqualsIgnoreCase(CharSequence, CharSequence) - Static method in class io.netty.util.AsciiString
Returns true if both CharSequence's are equals when ignore the case.
contentToString() - Method in class io.netty.buffer.DefaultByteBufHolder
Return ByteBuf.toString() without checking the reference count first.
context(ChannelHandler) - Method in interface io.netty.channel.ChannelPipeline
Returns the context object of the specified ChannelHandler in this pipeline.
context(String) - Method in interface io.netty.channel.ChannelPipeline
Returns the context object of the ChannelHandler with the specified name in this pipeline.
context(Class<? extends ChannelHandler>) - Method in interface io.netty.channel.ChannelPipeline
Returns the context object of the ChannelHandler of the specified type in this pipeline.
context(String) - Method in class io.netty.channel.DefaultChannelPipeline
 
context(ChannelHandler) - Method in class io.netty.channel.DefaultChannelPipeline
 
context(Class<? extends ChannelHandler>) - Method in class io.netty.channel.DefaultChannelPipeline
 
context() - Method in class io.netty.handler.ssl.JdkSslContext
Returns the JDK SSLContext object held by this context.
CONTINUE - Static variable in interface io.netty.channel.SelectStrategy
Indicates the IO loop should be retried, no blocking select to follow directly.
continueOnWriteError() - Method in class io.netty.channel.nio.AbstractNioMessageChannel
Returns true if we should continue the write loop on a write error.
continueOnWriteError() - Method in class io.netty.channel.socket.nio.NioDatagramChannel
 
continueReading() - Method in class io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator.MaxMessageHandle
 
continueReading(UncheckedBooleanSupplier) - Method in class io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator.MaxMessageHandle
 
continueReading() - Method in class io.netty.channel.RecvByteBufAllocator.DelegatingHandle
 
continueReading(UncheckedBooleanSupplier) - Method in interface io.netty.channel.RecvByteBufAllocator.ExtendedHandle
Same as RecvByteBufAllocator.Handle.continueReading() except "more data" is determined by the supplier parameter.
continueReading() - Method in interface io.netty.channel.RecvByteBufAllocator.Handle
Deprecated.
Determine if the current read loop should should continue.
convertBoolean(boolean) - Method in class io.netty.handler.codec.CharSequenceValueConverter
 
convertBoolean(boolean) - Method in class io.netty.handler.codec.UnsupportedValueConverter
 
convertBoolean(boolean) - Method in interface io.netty.handler.codec.ValueConverter
 
convertByte(byte) - Method in class io.netty.handler.codec.CharSequenceValueConverter
 
convertByte(byte) - Method in class io.netty.handler.codec.UnsupportedValueConverter
 
convertByte(byte) - Method in interface io.netty.handler.codec.ValueConverter
 
convertChar(char) - Method in class io.netty.handler.codec.CharSequenceValueConverter
 
convertChar(char) - Method in class io.netty.handler.codec.UnsupportedValueConverter
 
convertChar(char) - Method in interface io.netty.handler.codec.ValueConverter
 
convertDouble(double) - Method in class io.netty.handler.codec.CharSequenceValueConverter
 
convertDouble(double) - Method in class io.netty.handler.codec.UnsupportedValueConverter
 
convertDouble(double) - Method in interface io.netty.handler.codec.ValueConverter
 
convertFloat(float) - Method in class io.netty.handler.codec.CharSequenceValueConverter
 
convertFloat(float) - Method in class io.netty.handler.codec.UnsupportedValueConverter
 
convertFloat(float) - Method in interface io.netty.handler.codec.ValueConverter
 
convertInt(int) - Method in class io.netty.handler.codec.CharSequenceValueConverter
 
convertInt(int) - Method in class io.netty.handler.codec.UnsupportedValueConverter
 
convertInt(int) - Method in interface io.netty.handler.codec.ValueConverter
 
convertLong(long) - Method in class io.netty.handler.codec.CharSequenceValueConverter
 
convertLong(long) - Method in class io.netty.handler.codec.UnsupportedValueConverter
 
convertLong(long) - Method in interface io.netty.handler.codec.ValueConverter
 
convertObject(Object) - Method in class io.netty.handler.codec.CharSequenceValueConverter
 
convertObject(Object) - Method in class io.netty.handler.codec.UnsupportedValueConverter
 
convertObject(Object) - Method in interface io.netty.handler.codec.ValueConverter
 
convertShort(short) - Method in class io.netty.handler.codec.CharSequenceValueConverter
 
convertShort(short) - Method in class io.netty.handler.codec.UnsupportedValueConverter
 
convertShort(short) - Method in interface io.netty.handler.codec.ValueConverter
 
convertTimeMillis(long) - Method in class io.netty.handler.codec.CharSequenceValueConverter
 
convertTimeMillis(long) - Method in class io.netty.handler.codec.UnsupportedValueConverter
 
convertTimeMillis(long) - Method in interface io.netty.handler.codec.ValueConverter
 
convertToBoolean(CharSequence) - Method in class io.netty.handler.codec.CharSequenceValueConverter
 
convertToBoolean(V) - Method in class io.netty.handler.codec.UnsupportedValueConverter
 
convertToBoolean(T) - Method in interface io.netty.handler.codec.ValueConverter
 
convertToByte(CharSequence) - Method in class io.netty.handler.codec.CharSequenceValueConverter
 
convertToByte(V) - Method in class io.netty.handler.codec.UnsupportedValueConverter
 
convertToByte(T) - Method in interface io.netty.handler.codec.ValueConverter
 
convertToChar(CharSequence) - Method in class io.netty.handler.codec.CharSequenceValueConverter
 
convertToChar(V) - Method in class io.netty.handler.codec.UnsupportedValueConverter
 
convertToChar(T) - Method in interface io.netty.handler.codec.ValueConverter
 
convertToDouble(CharSequence) - Method in class io.netty.handler.codec.CharSequenceValueConverter
 
convertToDouble(V) - Method in class io.netty.handler.codec.UnsupportedValueConverter
 
convertToDouble(T) - Method in interface io.netty.handler.codec.ValueConverter
 
convertToFloat(CharSequence) - Method in class io.netty.handler.codec.CharSequenceValueConverter
 
convertToFloat(V) - Method in class io.netty.handler.codec.UnsupportedValueConverter
 
convertToFloat(T) - Method in interface io.netty.handler.codec.ValueConverter
 
convertToInt(CharSequence) - Method in class io.netty.handler.codec.CharSequenceValueConverter
 
convertToInt(V) - Method in class io.netty.handler.codec.UnsupportedValueConverter
 
convertToInt(T) - Method in interface io.netty.handler.codec.ValueConverter
 
convertToLong(CharSequence) - Method in class io.netty.handler.codec.CharSequenceValueConverter
 
convertToLong(V) - Method in class io.netty.handler.codec.UnsupportedValueConverter
 
convertToLong(T) - Method in interface io.netty.handler.codec.ValueConverter
 
convertToShort(CharSequence) - Method in class io.netty.handler.codec.CharSequenceValueConverter
 
convertToShort(V) - Method in class io.netty.handler.codec.UnsupportedValueConverter
 
convertToShort(T) - Method in interface io.netty.handler.codec.ValueConverter
 
convertToTimeMillis(CharSequence) - Method in class io.netty.handler.codec.CharSequenceValueConverter
 
convertToTimeMillis(V) - Method in class io.netty.handler.codec.UnsupportedValueConverter
 
convertToTimeMillis(T) - Method in interface io.netty.handler.codec.ValueConverter
 
copiedBuffer(byte[]) - Static method in class io.netty.buffer.Unpooled
Creates a new big-endian buffer whose content is a copy of the specified array.
copiedBuffer(byte[], int, int) - Static method in class io.netty.buffer.Unpooled
Creates a new big-endian buffer whose content is a copy of the specified array's sub-region.
copiedBuffer(ByteBuffer) - Static method in class io.netty.buffer.Unpooled
Creates a new buffer whose content is a copy of the specified buffer's current slice.
copiedBuffer(ByteBuf) - Static method in class io.netty.buffer.Unpooled
Creates a new buffer whose content is a copy of the specified buffer's readable bytes.
copiedBuffer(byte[]...) - Static method in class io.netty.buffer.Unpooled
Creates a new big-endian buffer whose content is a merged copy of the specified arrays.
copiedBuffer(ByteBuf...) - Static method in class io.netty.buffer.Unpooled
Creates a new buffer whose content is a merged copy of the specified buffers' readable bytes.
copiedBuffer(ByteBuffer...) - Static method in class io.netty.buffer.Unpooled
Creates a new buffer whose content is a merged copy of the specified buffers' slices.
copiedBuffer(CharSequence, Charset) - Static method in class io.netty.buffer.Unpooled
Creates a new big-endian buffer whose content is the specified string encoded in the specified charset.
copiedBuffer(CharSequence, int, int, Charset) - Static method in class io.netty.buffer.Unpooled
Creates a new big-endian buffer whose content is a subregion of the specified string encoded in the specified charset.
copiedBuffer(char[], Charset) - Static method in class io.netty.buffer.Unpooled
Creates a new big-endian buffer whose content is the specified array encoded in the specified charset.
copiedBuffer(char[], int, int, Charset) - Static method in class io.netty.buffer.Unpooled
Creates a new big-endian buffer whose content is a subregion of the specified array encoded in the specified charset.
copy() - Method in class io.netty.buffer.AbstractByteBuf
 
copy() - Method in class io.netty.buffer.ByteBuf
Returns a copy of this buffer's readable bytes.
copy(int, int) - Method in class io.netty.buffer.ByteBuf
Returns a copy of this buffer's sub-region.
copy() - Method in interface io.netty.buffer.ByteBufHolder
Creates a deep copy of this ByteBufHolder.
copy(AsciiString, ByteBuf) - Static method in class io.netty.buffer.ByteBufUtil
Copies the all content of src to a ByteBuf using ByteBuf.writeBytes(byte[], int, int).
copy(AsciiString, int, ByteBuf, int, int) - Static method in class io.netty.buffer.ByteBufUtil
Copies the content of src to a ByteBuf using ByteBuf.writeBytes(byte[], int, int).
copy(AsciiString, int, ByteBuf, int) - Static method in class io.netty.buffer.ByteBufUtil
Copies the content of src to a ByteBuf using ByteBuf.writeBytes(byte[], int, int).
copy(int, int) - Method in class io.netty.buffer.CompositeByteBuf
 
copy() - Method in class io.netty.buffer.DefaultByteBufHolder
Creates a deep copy of this ByteBufHolder.
copy(int, int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
copy() - Method in class io.netty.buffer.EmptyByteBuf
 
copy(int, int) - Method in class io.netty.buffer.EmptyByteBuf
 
copy(int, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
copy() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
copy(int, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
copy(int, int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
copy(int, int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
copy(int, int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
copy() - Method in class io.netty.channel.socket.DatagramPacket
 
copy() - Method in class io.netty.handler.codec.dns.DefaultDnsRawRecord
 
copy() - Method in interface io.netty.handler.codec.dns.DnsRawRecord
 
copy() - Method in class io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheRequest
 
copy() - Method in class io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheResponse
 
copy() - Method in interface io.netty.handler.codec.memcache.binary.FullBinaryMemcacheRequest
 
copy() - Method in interface io.netty.handler.codec.memcache.binary.FullBinaryMemcacheResponse
 
copy() - Method in class io.netty.handler.codec.memcache.DefaultLastMemcacheContent
 
copy() - Method in class io.netty.handler.codec.memcache.DefaultMemcacheContent
 
copy() - Method in interface io.netty.handler.codec.memcache.FullMemcacheMessage
 
copy() - Method in interface io.netty.handler.codec.memcache.LastMemcacheContent
 
copy() - Method in interface io.netty.handler.codec.memcache.MemcacheContent
 
copy() - Method in class io.netty.handler.codec.mqtt.MqttPublishMessage
 
copy() - Method in interface io.netty.handler.codec.redis.BulkStringRedisContent
 
copy() - Method in class io.netty.handler.codec.redis.DefaultBulkStringRedisContent
 
copy() - Method in class io.netty.handler.codec.redis.DefaultLastBulkStringRedisContent
 
copy() - Method in class io.netty.handler.codec.redis.FullBulkStringRedisMessage
 
copy() - Method in interface io.netty.handler.codec.redis.LastBulkStringRedisContent
 
copy() - Method in class io.netty.handler.codec.smtp.DefaultLastSmtpContent
 
copy() - Method in class io.netty.handler.codec.smtp.DefaultSmtpContent
 
copy() - Method in interface io.netty.handler.codec.smtp.LastSmtpContent
 
copy() - Method in interface io.netty.handler.codec.smtp.SmtpContent
 
copy() - Method in class io.netty.handler.codec.stomp.DefaultLastStompContentSubframe
 
copy() - Method in class io.netty.handler.codec.stomp.DefaultStompContentSubframe
 
copy() - Method in class io.netty.handler.codec.stomp.DefaultStompFrame
 
copy() - Method in interface io.netty.handler.codec.stomp.LastStompContentSubframe
 
copy() - Method in interface io.netty.handler.codec.stomp.StompContentSubframe
 
copy() - Method in interface io.netty.handler.codec.stomp.StompFrame
 
copy() - Method in class io.netty.handler.ssl.PemPrivateKey
 
copy() - Method in class io.netty.handler.ssl.PemX509Certificate
 
copy(int, byte[], int, int) - Method in class io.netty.util.AsciiString
Copies the content of this string to a byte array.
copy(int, char[], int, int) - Method in class io.netty.util.AsciiString
Copied the content of this string to a character array.
copyBoolean(boolean) - Static method in class io.netty.buffer.Unpooled
Creates a new single-byte big-endian buffer that holds the specified boolean value.
copyBoolean(boolean...) - Static method in class io.netty.buffer.Unpooled
Create a new big-endian buffer that holds a sequence of the specified boolean values.
copyDouble(double) - Static method in class io.netty.buffer.Unpooled
Creates a new 8-byte big-endian buffer that holds the specified 64-bit floating point number.
copyDouble(double...) - Static method in class io.netty.buffer.Unpooled
Create a new big-endian buffer that holds a sequence of the specified 64-bit floating point numbers.
copyFloat(float) - Static method in class io.netty.buffer.Unpooled
Creates a new 4-byte big-endian buffer that holds the specified 32-bit floating point number.
copyFloat(float...) - Static method in class io.netty.buffer.Unpooled
Create a new big-endian buffer that holds a sequence of the specified 32-bit floating point numbers.
copyInt(int) - Static method in class io.netty.buffer.Unpooled
Creates a new 4-byte big-endian buffer that holds the specified 32-bit integer.
copyInt(int...) - Static method in class io.netty.buffer.Unpooled
Create a big-endian buffer that holds a sequence of the specified 32-bit integers.
copyLong(long) - Static method in class io.netty.buffer.Unpooled
Creates a new 8-byte big-endian buffer that holds the specified 64-bit integer.
copyLong(long...) - Static method in class io.netty.buffer.Unpooled
Create a new big-endian buffer that holds a sequence of the specified 64-bit integers.
copyMedium(int) - Static method in class io.netty.buffer.Unpooled
Creates a new 3-byte big-endian buffer that holds the specified 24-bit integer.
copyMedium(int...) - Static method in class io.netty.buffer.Unpooled
Create a new big-endian buffer that holds a sequence of the specified 24-bit integers.
copyMemory(long, long, long) - Static method in class io.netty.util.internal.PlatformDependent
 
copyMemory(byte[], int, long, long) - Static method in class io.netty.util.internal.PlatformDependent
 
copyMemory(long, byte[], int, long) - Static method in class io.netty.util.internal.PlatformDependent
 
copyShort(int) - Static method in class io.netty.buffer.Unpooled
Creates a new 2-byte big-endian buffer that holds the specified 16-bit integer.
copyShort(short...) - Static method in class io.netty.buffer.Unpooled
Create a new big-endian buffer that holds a sequence of the specified 16-bit integers.
copyShort(int...) - Static method in class io.netty.buffer.Unpooled
Create a new big-endian buffer that holds a sequence of the specified 16-bit integers.
copyTo(CoalescingBufferQueue) - Method in class io.netty.channel.CoalescingBufferQueue
Copy all pending entries in this queue into the destination queue.
CorruptedFrameException - Exception in io.netty.handler.codec
An DecoderException which is thrown when the received frame data could not be decoded by an inbound handler.
CorruptedFrameException() - Constructor for exception io.netty.handler.codec.CorruptedFrameException
Creates a new instance.
CorruptedFrameException(String, Throwable) - Constructor for exception io.netty.handler.codec.CorruptedFrameException
Creates a new instance.
CorruptedFrameException(String) - Constructor for exception io.netty.handler.codec.CorruptedFrameException
Creates a new instance.
CorruptedFrameException(Throwable) - Constructor for exception io.netty.handler.codec.CorruptedFrameException
Creates a new instance.
count() - Method in class io.netty.channel.DefaultFileRegion
 
count() - Method in interface io.netty.channel.FileRegion
Returns the number of bytes to transfer.
count() - Method in class io.netty.channel.unix.IovArray
Returns the number if iov entries.
count(DnsSection) - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
 
count() - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
 
count(DnsSection) - Method in interface io.netty.handler.codec.dns.DnsMessage
Returns the number of records in the specified section of this DNS message.
count() - Method in interface io.netty.handler.codec.dns.DnsMessage
Returns the number of records in this DNS message.
counterHashCode() - Method in class io.netty.util.internal.InternalThreadLocalMap
 
createByteArrayFromIpAddressString(String) - Static method in class io.netty.util.NetUtil
Creates an byte[] based on an ipAddressString.
ctx() - Method in class io.netty.handler.codec.MessageAggregator
 
cumulate(ByteBufAllocator, ByteBuf, ByteBuf) - Method in interface io.netty.handler.codec.ByteToMessageDecoder.Cumulator
Cumulate the given ByteBufs and return the ByteBuf that holds the cumulated bytes.
cumulativeReadBytes() - Method in class io.netty.handler.traffic.TrafficCounter
 
cumulativeWrittenBytes() - Method in class io.netty.handler.traffic.TrafficCounter
 
current() - Method in class io.netty.channel.ChannelOutboundBuffer
Return the current message to write or null if nothing was flushed before and so is ready to be written.
current() - Method in class io.netty.channel.PendingWriteQueue
Return the current message or null if empty.
current() - Static method in class io.netty.util.internal.ThreadLocalRandom
Returns the current thread's ThreadLocalRandom.
currentOffset() - Method in class io.netty.handler.stream.ChunkedFile
Returns the offset in the file where the transfer is happening currently.
currentOffset() - Method in class io.netty.handler.stream.ChunkedNioFile
Returns the offset in the file where the transfer is happening currently.
currentReadBytes() - Method in class io.netty.handler.traffic.TrafficCounter
 
currentWrittenBytes() - Method in class io.netty.handler.traffic.TrafficCounter
 

D

DATA - Static variable in class io.netty.handler.codec.smtp.SmtpCommand
 
data() - Static method in class io.netty.handler.codec.smtp.SmtpRequests
Creates a DATA request.
DATAGRAM_CHANNEL_ACTIVE_ON_REGISTRATION - Static variable in class io.netty.channel.ChannelOption
Deprecated.
DatagramChannel - Interface in io.netty.channel.socket
A UDP/IP Channel.
DatagramChannelConfig - Interface in io.netty.channel.socket
DatagramDnsQuery - Class in io.netty.handler.codec.dns
A DnsQuery implementation for UDP/IP.
DatagramDnsQuery(InetSocketAddress, InetSocketAddress, int) - Constructor for class io.netty.handler.codec.dns.DatagramDnsQuery
Creates a new instance with the DnsOpCode.QUERY opCode.
DatagramDnsQuery(InetSocketAddress, InetSocketAddress, int, DnsOpCode) - Constructor for class io.netty.handler.codec.dns.DatagramDnsQuery
Creates a new instance.
DatagramDnsQueryDecoder - Class in io.netty.handler.codec.dns
DatagramDnsQueryDecoder() - Constructor for class io.netty.handler.codec.dns.DatagramDnsQueryDecoder
Creates a new decoder with the default record decoder.
DatagramDnsQueryDecoder(DnsRecordDecoder) - Constructor for class io.netty.handler.codec.dns.DatagramDnsQueryDecoder
Creates a new decoder with the specified recordDecoder.
DatagramDnsQueryEncoder - Class in io.netty.handler.codec.dns
DatagramDnsQueryEncoder() - Constructor for class io.netty.handler.codec.dns.DatagramDnsQueryEncoder
Creates a new encoder with the default record encoder.
DatagramDnsQueryEncoder(DnsRecordEncoder) - Constructor for class io.netty.handler.codec.dns.DatagramDnsQueryEncoder
Creates a new encoder with the specified recordEncoder.
DatagramDnsResponse - Class in io.netty.handler.codec.dns
A DnsResponse implementation for UDP/IP.
DatagramDnsResponse(InetSocketAddress, InetSocketAddress, int) - Constructor for class io.netty.handler.codec.dns.DatagramDnsResponse
Creates a new instance with the DnsOpCode.QUERY opCode and the DnsResponseCode.NOERROR RCODE.
DatagramDnsResponse(InetSocketAddress, InetSocketAddress, int, DnsOpCode) - Constructor for class io.netty.handler.codec.dns.DatagramDnsResponse
Creates a new instance with the DnsResponseCode.NOERROR responseCode.
DatagramDnsResponse(InetSocketAddress, InetSocketAddress, int, DnsOpCode, DnsResponseCode) - Constructor for class io.netty.handler.codec.dns.DatagramDnsResponse
Creates a new instance.
DatagramDnsResponseDecoder - Class in io.netty.handler.codec.dns
DatagramDnsResponseDecoder() - Constructor for class io.netty.handler.codec.dns.DatagramDnsResponseDecoder
Creates a new decoder with the default record decoder.
DatagramDnsResponseDecoder(DnsRecordDecoder) - Constructor for class io.netty.handler.codec.dns.DatagramDnsResponseDecoder
Creates a new decoder with the specified recordDecoder.
DatagramDnsResponseEncoder - Class in io.netty.handler.codec.dns
DatagramDnsResponseEncoder() - Constructor for class io.netty.handler.codec.dns.DatagramDnsResponseEncoder
Creates a new encoder with the default record encoder.
DatagramDnsResponseEncoder(DnsRecordEncoder) - Constructor for class io.netty.handler.codec.dns.DatagramDnsResponseEncoder
Creates a new encoder with the specified recordEncoder.
DatagramPacket - Class in io.netty.channel.socket
The message container that is used for DatagramChannel to communicate with the remote peer.
DatagramPacket(ByteBuf, InetSocketAddress) - Constructor for class io.netty.channel.socket.DatagramPacket
Create a new instance with the specified packet data and recipient address.
DatagramPacket(ByteBuf, InetSocketAddress, InetSocketAddress) - Constructor for class io.netty.channel.socket.DatagramPacket
Create a new instance with the specified packet data, recipient address, and sender address.
DatagramPacketDecoder - Class in io.netty.handler.codec
A decoder that decodes the content of the received DatagramPacket using the specified ByteBuf decoder.
DatagramPacketDecoder(MessageToMessageDecoder<ByteBuf>) - Constructor for class io.netty.handler.codec.DatagramPacketDecoder
Create a DatagramPacket decoder using the specified ByteBuf decoder.
DatagramPacketEncoder<M> - Class in io.netty.handler.codec
An encoder that encodes the content in AddressedEnvelope to DatagramPacket using the specified message encoder.
DatagramPacketEncoder(MessageToMessageEncoder<? super M>) - Constructor for class io.netty.handler.codec.DatagramPacketEncoder
Create an encoder that encodes the content in AddressedEnvelope to DatagramPacket using the specified message encoder.
DatagramSocketAddress - Class in io.netty.channel.unix
Act as special InetSocketAddress to be able to easily pass all needed data from JNI without the need to create more objects then needed.
dataType() - Method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
dataType() - Method in interface io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Returns the data type of the message.
DateFormatter - Class in io.netty.handler.codec
A formatter for HTTP header dates, such as "Expires" and "Date" headers, or "expires" field in "Set-Cookie".
deallocate() - Method in class io.netty.buffer.AbstractReferenceCountedByteBuf
deallocate() - Method in class io.netty.buffer.CompositeByteBuf
 
deallocate() - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
deallocate() - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
deallocate() - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
deallocate() - Method in class io.netty.channel.DefaultFileRegion
 
deallocate() - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
 
deallocate() - Method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
deallocate() - Method in class io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheRequest
 
deallocate() - Method in class io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheResponse
 
deallocate() - Method in class io.netty.handler.codec.memcache.DefaultMemcacheContent
 
deallocate() - Method in class io.netty.handler.codec.redis.ArrayRedisMessage
 
deallocate() - Method in class io.netty.handler.ssl.PemPrivateKey
 
deallocate() - Method in class io.netty.util.AbstractReferenceCounted
Called once AbstractReferenceCounted.refCnt() is equals 0.
debug(Throwable) - Method in class io.netty.util.internal.logging.AbstractInternalLogger
 
debug(String) - Method in interface io.netty.util.internal.logging.InternalLogger
Log a message at the DEBUG level.
debug(String, Object) - Method in interface io.netty.util.internal.logging.InternalLogger
Log a message at the DEBUG level according to the specified format and argument.
debug(String, Object, Object) - Method in interface io.netty.util.internal.logging.InternalLogger
Log a message at the DEBUG level according to the specified format and arguments.
debug(String, Object...) - Method in interface io.netty.util.internal.logging.InternalLogger
Log a message at the DEBUG level according to the specified format and arguments.
debug(String, Throwable) - Method in interface io.netty.util.internal.logging.InternalLogger
Log an exception (throwable) at the DEBUG level with an accompanying message.
debug(Throwable) - Method in interface io.netty.util.internal.logging.InternalLogger
Log an exception (throwable) at the DEBUG level.
decode(ByteBuf) - Static method in class io.netty.handler.codec.base64.Base64
 
decode(ByteBuf, Base64Dialect) - Static method in class io.netty.handler.codec.base64.Base64
 
decode(ByteBuf, int, int) - Static method in class io.netty.handler.codec.base64.Base64
 
decode(ByteBuf, int, int, Base64Dialect) - Static method in class io.netty.handler.codec.base64.Base64
 
decode(ByteBuf, int, int, Base64Dialect, ByteBufAllocator) - Static method in class io.netty.handler.codec.base64.Base64
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.base64.Base64Decoder
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.bytes.ByteArrayDecoder
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.ByteToMessageCodec
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.ByteToMessageDecoder
Decode the from one ByteBuf to an other.
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.compression.Bzip2Decoder
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.compression.FastLzFrameDecoder
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.compression.JdkZlibDecoder
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.compression.JZlibDecoder
 
decode(ByteBuf, ByteBuf) - Method in class io.netty.handler.codec.compression.Snappy
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.compression.SnappyFrameDecoder
 
decode(ChannelHandlerContext, DatagramPacket, List<Object>) - Method in class io.netty.handler.codec.DatagramPacketDecoder
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.DelimiterBasedFrameDecoder
 
decode(ChannelHandlerContext, ByteBuf) - Method in class io.netty.handler.codec.DelimiterBasedFrameDecoder
Create a frame out of the ByteBuf and return it.
decode(ChannelHandlerContext, DatagramPacket, List<Object>) - Method in class io.netty.handler.codec.dns.DatagramDnsQueryDecoder
 
decode(ChannelHandlerContext, DatagramPacket, List<Object>) - Method in class io.netty.handler.codec.dns.DatagramDnsResponseDecoder
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.FixedLengthFrameDecoder
 
decode(ChannelHandlerContext, ByteBuf) - Method in class io.netty.handler.codec.FixedLengthFrameDecoder
Create a frame out of the ByteBuf and return it.
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.json.JsonObjectDecoder
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.LengthFieldBasedFrameDecoder
 
decode(ChannelHandlerContext, ByteBuf) - Method in class io.netty.handler.codec.LengthFieldBasedFrameDecoder
Create a frame out of the ByteBuf and return it.
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.LineBasedFrameDecoder
 
decode(ChannelHandlerContext, ByteBuf) - Method in class io.netty.handler.codec.LineBasedFrameDecoder
Create a frame out of the ByteBuf and return it.
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheDecoder
 
decode(ChannelHandlerContext, I, List<Object>) - Method in class io.netty.handler.codec.MessageAggregator
 
decode(ChannelHandlerContext, INBOUND_IN, List<Object>) - Method in class io.netty.handler.codec.MessageToMessageCodec
 
decode(ChannelHandlerContext, I, List<Object>) - Method in class io.netty.handler.codec.MessageToMessageDecoder
Decode from one message to an other.
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.mqtt.MqttDecoder
 
decode(ChannelHandlerContext, RedisMessage, List<Object>) - Method in class io.netty.handler.codec.redis.RedisArrayAggregator
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.redis.RedisDecoder
 
decode(ChannelHandlerContext, ByteBuf) - Method in class io.netty.handler.codec.serialization.ObjectDecoder
 
decode(ChannelHandlerContext, ByteBuf) - Method in class io.netty.handler.codec.smtp.SmtpResponseDecoder
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.stomp.StompSubframeDecoder
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.string.StringDecoder
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.xml.XmlFrameDecoder
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.ssl.AbstractSniHandler
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.ssl.OptionalSslHandler
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.ssl.SslHandler
 
decodeHeader(ByteBuf) - Method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheDecoder
Decode and return the parsed BinaryMemcacheMessage.
decodeHeader(ByteBuf) - Method in class io.netty.handler.codec.memcache.binary.BinaryMemcacheRequestDecoder
 
decodeHeader(ByteBuf) - Method in class io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseDecoder
 
decodeHexByte(CharSequence, int) - Static method in class io.netty.buffer.ByteBufUtil
Decode a 2-digit hex byte from within a string.
decodeHexByte(CharSequence, int) - Static method in class io.netty.util.internal.StringUtil
Decode a 2-digit hex byte from within a string.
decodeHexDump(CharSequence) - Static method in class io.netty.buffer.ByteBufUtil
Decodes a string generated by ByteBufUtil.hexDump(byte[])
decodeHexDump(CharSequence, int, int) - Static method in class io.netty.buffer.ByteBufUtil
Decodes part of a string generated by ByteBufUtil.hexDump(byte[])
decodeHexDump(CharSequence, int, int) - Static method in class io.netty.util.internal.StringUtil
Decodes part of a string with hex dump
decodeHexDump(CharSequence) - Static method in class io.netty.util.internal.StringUtil
Decodes a hex dump
decodeHexNibble(char) - Static method in class io.netty.util.internal.StringUtil
Helper to decode half of a hexadecimal number from a string.
decodeIdn(boolean) - Method in class io.netty.resolver.dns.DnsNameResolverBuilder
Set if domain / host names should be decoded to unicode when received.
decodeLast(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.ByteToMessageCodec
 
decodeLast(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.ByteToMessageDecoder
Is called one last time when the ChannelHandlerContext goes in-active.
decodeName(ByteBuf) - Static method in class io.netty.handler.codec.dns.DefaultDnsRecordDecoder
Retrieves a domain name given a buffer containing a DNS packet.
decodeName0(ByteBuf) - Method in class io.netty.handler.codec.dns.DefaultDnsRecordDecoder
Retrieves a domain name given a buffer containing a DNS packet.
decodeQuestion(ByteBuf) - Method in class io.netty.handler.codec.dns.DefaultDnsRecordDecoder
 
decodeQuestion(ByteBuf) - Method in interface io.netty.handler.codec.dns.DnsRecordDecoder
Decodes a DNS question into its object representation.
decoder(Charset, CodingErrorAction, CodingErrorAction) - Static method in class io.netty.util.CharsetUtil
Returns a new CharsetDecoder for the Charset with specified error actions.
decoder(Charset, CodingErrorAction) - Static method in class io.netty.util.CharsetUtil
Returns a new CharsetDecoder for the Charset with the specified error action.
decoder(Charset) - Static method in class io.netty.util.CharsetUtil
Returns a cached thread-local CharsetDecoder for the specified Charset.
decodeRecord(ByteBuf) - Method in class io.netty.handler.codec.dns.DefaultDnsRecordDecoder
 
decodeRecord(String, DnsRecordType, int, long, ByteBuf, int, int) - Method in class io.netty.handler.codec.dns.DefaultDnsRecordDecoder
Decodes a record from the information decoded so far by DefaultDnsRecordDecoder.decodeRecord(ByteBuf).
decodeRecord(ByteBuf) - Method in interface io.netty.handler.codec.dns.DnsRecordDecoder
Decodes a DNS record into its object representation.
DecoderException - Exception in io.netty.handler.codec
An CodecException which is thrown by a decoder.
DecoderException() - Constructor for exception io.netty.handler.codec.DecoderException
Creates a new instance.
DecoderException(String, Throwable) - Constructor for exception io.netty.handler.codec.DecoderException
Creates a new instance.
DecoderException(String) - Constructor for exception io.netty.handler.codec.DecoderException
Creates a new instance.
DecoderException(Throwable) - Constructor for exception io.netty.handler.codec.DecoderException
Creates a new instance.
DecoderResult - Class in io.netty.handler.codec
 
DecoderResult(Throwable) - Constructor for class io.netty.handler.codec.DecoderResult
 
decoderResult() - Method in interface io.netty.handler.codec.DecoderResultProvider
Returns the result of decoding this object.
decoderResult() - Method in class io.netty.handler.codec.memcache.AbstractMemcacheObject
 
decoderResult() - Method in class io.netty.handler.codec.mqtt.MqttMessage
 
decoderResult() - Method in class io.netty.handler.codec.stomp.DefaultStompContentSubframe
 
decoderResult - Variable in class io.netty.handler.codec.stomp.DefaultStompHeadersSubframe
 
decoderResult() - Method in class io.netty.handler.codec.stomp.DefaultStompHeadersSubframe
 
DecoderResultProvider - Interface in io.netty.handler.codec
Provides the accessor methods for the DecoderResult property of a decoded message.
decompose(int, int) - Method in class io.netty.buffer.CompositeByteBuf
Same with AbstractByteBuf.slice(int, int) except that this method returns a list.
DecompressionException - Exception in io.netty.handler.codec.compression
A DecoderException that is raised when decompression failed.
DecompressionException() - Constructor for exception io.netty.handler.codec.compression.DecompressionException
Creates a new instance.
DecompressionException(String, Throwable) - Constructor for exception io.netty.handler.codec.compression.DecompressionException
Creates a new instance.
DecompressionException(String) - Constructor for exception io.netty.handler.codec.compression.DecompressionException
Creates a new instance.
DecompressionException(Throwable) - Constructor for exception io.netty.handler.codec.compression.DecompressionException
Creates a new instance.
decorateTask(Runnable, RunnableScheduledFuture<V>) - Method in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor
 
decorateTask(Callable<V>, RunnableScheduledFuture<V>) - Method in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor
 
DECREMENT - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
decrement() - Method in interface io.netty.util.internal.LongCounter
 
DECREMENTQ - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
DEFAULT - Static variable in interface io.netty.buffer.ByteBufAllocator
 
DEFAULT - Static variable in class io.netty.buffer.PooledByteBufAllocator
 
DEFAULT - Static variable in class io.netty.buffer.UnpooledByteBufAllocator
Default instance which uses leak-detection for direct buffers.
DEFAULT - Static variable in class io.netty.channel.AdaptiveRecvByteBufAllocator
Deprecated.
There is state for DefaultMaxMessagesRecvByteBufAllocator.maxMessagesPerRead() which is typically based upon channel type.
DEFAULT - Static variable in class io.netty.channel.DefaultMessageSizeEstimator
Return the default implementation which returns 8 for unknown messages.
DEFAULT - Static variable in class io.netty.channel.WriteBufferWaterMark
 
DEFAULT - Static variable in interface io.netty.handler.codec.dns.DnsRecordDecoder
 
DEFAULT - Static variable in interface io.netty.handler.codec.dns.DnsRecordEncoder
 
DEFAULT - Static variable in class io.netty.handler.codec.string.LineSeparator
The default line separator in the current system.
DEFAULT - Static variable in interface io.netty.resolver.HostsFileEntriesResolver
Default instance: a DefaultHostsFileEntriesResolver.
DEFAULT_CAPACITY - Static variable in class io.netty.util.collection.ByteObjectHashMap
Default initial capacity.
DEFAULT_CAPACITY - Static variable in class io.netty.util.collection.CharObjectHashMap
Default initial capacity.
DEFAULT_CAPACITY - Static variable in class io.netty.util.collection.IntObjectHashMap
Default initial capacity.
DEFAULT_CAPACITY - Static variable in class io.netty.util.collection.LongObjectHashMap
Default initial capacity.
DEFAULT_CAPACITY - Static variable in class io.netty.util.collection.ShortObjectHashMap
Default initial capacity.
DEFAULT_CHECK_INTERVAL - Static variable in class io.netty.handler.traffic.AbstractTrafficShapingHandler
Default delay between two checks: 1s
DEFAULT_LOAD_FACTOR - Static variable in class io.netty.util.collection.ByteObjectHashMap
Default load factor.
DEFAULT_LOAD_FACTOR - Static variable in class io.netty.util.collection.CharObjectHashMap
Default load factor.
DEFAULT_LOAD_FACTOR - Static variable in class io.netty.util.collection.IntObjectHashMap
Default load factor.
DEFAULT_LOAD_FACTOR - Static variable in class io.netty.util.collection.LongObjectHashMap
Default load factor.
DEFAULT_LOAD_FACTOR - Static variable in class io.netty.util.collection.ShortObjectHashMap
Default load factor.
DEFAULT_MAX_CHUNK_SIZE - Static variable in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheDecoder
 
DEFAULT_MAX_PENDING_TASKS - Static variable in class io.netty.channel.SingleThreadEventLoop
 
DEFAULT_MAX_TIME - Static variable in class io.netty.handler.traffic.AbstractTrafficShapingHandler
Default max delay in case of traffic shaping (during which no communication will occur).
DefaultAddressedEnvelope<M,A extends SocketAddress> - Class in io.netty.channel
The default AddressedEnvelope implementation.
DefaultAddressedEnvelope(M, A, A) - Constructor for class io.netty.channel.DefaultAddressedEnvelope
Creates a new instance with the specified message, recipient address, and sender address.
DefaultAddressedEnvelope(M, A) - Constructor for class io.netty.channel.DefaultAddressedEnvelope
Creates a new instance with the specified message and recipient address.
defaultAddresses() - Static method in class io.netty.resolver.dns.DefaultDnsServerAddressStreamProvider
Returns the DnsServerAddresses that yields the system DNS server addresses sequentially.
defaultAddresses() - Static method in class io.netty.resolver.dns.DnsServerAddresses
Deprecated.
Use DefaultDnsServerAddressStreamProvider.defaultAddresses().

Returns the DnsServerAddresses that yields the system DNS server addresses sequentially. If it failed to retrieve the list of the system DNS server addresses from the environment, it will use "8.8.8.8" and "8.8.4.4", the addresses of the Google public DNS servers.

This method has the same effect with the following code:

 DnsServerAddresses.sequential(DnsServerAddresses.defaultAddressList());
 

defaultAddressList() - Static method in class io.netty.resolver.dns.DefaultDnsServerAddressStreamProvider
Returns the list of the system DNS server addresses.
defaultAddressList() - Static method in class io.netty.resolver.dns.DnsServerAddresses
Deprecated.
Use DefaultDnsServerAddressStreamProvider.defaultAddressList().

Returns the list of the system DNS server addresses. If it failed to retrieve the list of the system DNS server addresses from the environment, it will return "8.8.8.8" and "8.8.4.4", the addresses of the Google public DNS servers.

DefaultAddressResolverGroup - Class in io.netty.resolver
DefaultAttributeMap - Class in io.netty.util
Default AttributeMap implementation which use simple synchronization per bucket to keep the memory overhead as low as possible.
DefaultAttributeMap() - Constructor for class io.netty.util.DefaultAttributeMap
 
DefaultBinaryMemcacheRequest - Class in io.netty.handler.codec.memcache.binary
The default implementation of the BinaryMemcacheRequest.
DefaultBinaryMemcacheRequest() - Constructor for class io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheRequest
Create a new DefaultBinaryMemcacheRequest with the header only.
DefaultBinaryMemcacheRequest(ByteBuf) - Constructor for class io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheRequest
Create a new DefaultBinaryMemcacheRequest with the header and key.
DefaultBinaryMemcacheRequest(ByteBuf, ByteBuf) - Constructor for class io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheRequest
Create a new DefaultBinaryMemcacheRequest with the header only.
DefaultBinaryMemcacheResponse - Class in io.netty.handler.codec.memcache.binary
The default implementation of the BinaryMemcacheResponse.
DefaultBinaryMemcacheResponse() - Constructor for class io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheResponse
Create a new DefaultBinaryMemcacheResponse with the header only.
DefaultBinaryMemcacheResponse(ByteBuf) - Constructor for class io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheResponse
Create a new DefaultBinaryMemcacheResponse with the header and key.
DefaultBinaryMemcacheResponse(ByteBuf, ByteBuf) - Constructor for class io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheResponse
Create a new DefaultBinaryMemcacheResponse with the header, key and extras.
DefaultBulkStringRedisContent - Class in io.netty.handler.codec.redis
A default implementation of BulkStringRedisContent.
DefaultBulkStringRedisContent(ByteBuf) - Constructor for class io.netty.handler.codec.redis.DefaultBulkStringRedisContent
Creates a DefaultBulkStringRedisContent for the given content.
DefaultByteBufHolder - Class in io.netty.buffer
Default implementation of a ByteBufHolder that holds it's data in a ByteBuf.
DefaultByteBufHolder(ByteBuf) - Constructor for class io.netty.buffer.DefaultByteBufHolder
 
DefaultChannelConfig - Class in io.netty.channel
The default ChannelConfig implementation.
DefaultChannelConfig(Channel) - Constructor for class io.netty.channel.DefaultChannelConfig
 
DefaultChannelConfig(Channel, RecvByteBufAllocator) - Constructor for class io.netty.channel.DefaultChannelConfig
 
DefaultChannelGroup - Class in io.netty.channel.group
The default ChannelGroup implementation.
DefaultChannelGroup(EventExecutor) - Constructor for class io.netty.channel.group.DefaultChannelGroup
Creates a new group with a generated name and the provided EventExecutor to notify the ChannelGroupFutures.
DefaultChannelGroup(String, EventExecutor) - Constructor for class io.netty.channel.group.DefaultChannelGroup
Creates a new group with the specified name and EventExecutor to notify the ChannelGroupFutures.
DefaultChannelGroup(EventExecutor, boolean) - Constructor for class io.netty.channel.group.DefaultChannelGroup
Creates a new group with a generated name and the provided EventExecutor to notify the ChannelGroupFutures.
DefaultChannelGroup(String, EventExecutor, boolean) - Constructor for class io.netty.channel.group.DefaultChannelGroup
Creates a new group with the specified name and EventExecutor to notify the ChannelGroupFutures.
DefaultChannelId - Class in io.netty.channel
The default ChannelId implementation.
DefaultChannelPipeline - Class in io.netty.channel
The default ChannelPipeline implementation.
DefaultChannelPipeline(Channel) - Constructor for class io.netty.channel.DefaultChannelPipeline
 
DefaultChannelProgressivePromise - Class in io.netty.channel
The default ChannelProgressivePromise implementation.
DefaultChannelProgressivePromise(Channel) - Constructor for class io.netty.channel.DefaultChannelProgressivePromise
Creates a new instance.
DefaultChannelProgressivePromise(Channel, EventExecutor) - Constructor for class io.netty.channel.DefaultChannelProgressivePromise
Creates a new instance.
DefaultChannelPromise - Class in io.netty.channel
The default ChannelPromise implementation.
DefaultChannelPromise(Channel) - Constructor for class io.netty.channel.DefaultChannelPromise
Creates a new instance.
DefaultChannelPromise(Channel, EventExecutor) - Constructor for class io.netty.channel.DefaultChannelPromise
Creates a new instance.
defaultClientProvider() - Static method in class io.netty.handler.ssl.SslContext
Returns the default client-side implementation provider currently in use.
DefaultDatagramChannelConfig - Class in io.netty.channel.socket
The default DatagramChannelConfig implementation.
DefaultDatagramChannelConfig(DatagramChannel, DatagramSocket) - Constructor for class io.netty.channel.socket.DefaultDatagramChannelConfig
Creates a new instance.
DefaultDnsCache - Class in io.netty.resolver.dns
Default implementation of DnsCache, backed by a ConcurrentMap.
DefaultDnsCache() - Constructor for class io.netty.resolver.dns.DefaultDnsCache
Create a cache that respects the TTL returned by the DNS server and doesn't cache negative responses.
DefaultDnsCache(int, int, int) - Constructor for class io.netty.resolver.dns.DefaultDnsCache
Create a cache.
DefaultDnsOptEcsRecord - Class in io.netty.handler.codec.dns
Default DnsOptEcsRecord implementation.
DefaultDnsOptEcsRecord(int, int, int, int, byte[]) - Constructor for class io.netty.handler.codec.dns.DefaultDnsOptEcsRecord
Creates a new instance.
DefaultDnsOptEcsRecord(int, int, byte[]) - Constructor for class io.netty.handler.codec.dns.DefaultDnsOptEcsRecord
Creates a new instance.
DefaultDnsOptEcsRecord(int, InternetProtocolFamily) - Constructor for class io.netty.handler.codec.dns.DefaultDnsOptEcsRecord
Creates a new instance.
DefaultDnsPtrRecord - Class in io.netty.handler.codec.dns
 
DefaultDnsPtrRecord(String, int, long, String) - Constructor for class io.netty.handler.codec.dns.DefaultDnsPtrRecord
Creates a new PTR record.
DefaultDnsQuery - Class in io.netty.handler.codec.dns
The default DnsQuery implementation.
DefaultDnsQuery(int) - Constructor for class io.netty.handler.codec.dns.DefaultDnsQuery
Creates a new instance with the DnsOpCode.QUERY opCode.
DefaultDnsQuery(int, DnsOpCode) - Constructor for class io.netty.handler.codec.dns.DefaultDnsQuery
Creates a new instance.
DefaultDnsQuestion - Class in io.netty.handler.codec.dns
The default DnsQuestion implementation.
DefaultDnsQuestion(String, DnsRecordType) - Constructor for class io.netty.handler.codec.dns.DefaultDnsQuestion
Creates a new IN-class question.
DefaultDnsQuestion(String, DnsRecordType, int) - Constructor for class io.netty.handler.codec.dns.DefaultDnsQuestion
Creates a new question.
DefaultDnsRawRecord - Class in io.netty.handler.codec.dns
The default DnsRawRecord implementation.
DefaultDnsRawRecord(String, DnsRecordType, long, ByteBuf) - Constructor for class io.netty.handler.codec.dns.DefaultDnsRawRecord
Creates a new IN-class record.
DefaultDnsRawRecord(String, DnsRecordType, int, long, ByteBuf) - Constructor for class io.netty.handler.codec.dns.DefaultDnsRawRecord
Creates a new record.
DefaultDnsRecordDecoder - Class in io.netty.handler.codec.dns
The default DnsRecordDecoder implementation.
DefaultDnsRecordDecoder() - Constructor for class io.netty.handler.codec.dns.DefaultDnsRecordDecoder
Creates a new instance.
DefaultDnsRecordEncoder - Class in io.netty.handler.codec.dns
The default DnsRecordEncoder implementation.
DefaultDnsRecordEncoder() - Constructor for class io.netty.handler.codec.dns.DefaultDnsRecordEncoder
Creates a new instance.
DefaultDnsResponse - Class in io.netty.handler.codec.dns
The default DnsResponse implementation.
DefaultDnsResponse(int) - Constructor for class io.netty.handler.codec.dns.DefaultDnsResponse
Creates a new instance with the DnsOpCode.QUERY opCode and the DnsResponseCode.NOERROR RCODE.
DefaultDnsResponse(int, DnsOpCode) - Constructor for class io.netty.handler.codec.dns.DefaultDnsResponse
Creates a new instance with the DnsResponseCode.NOERROR RCODE.
DefaultDnsResponse(int, DnsOpCode, DnsResponseCode) - Constructor for class io.netty.handler.codec.dns.DefaultDnsResponse
Creates a new instance.
DefaultDnsServerAddressStreamProvider - Class in io.netty.resolver.dns
A DnsServerAddressStreamProvider which will use predefined default DNS servers to use for DNS resolution.
DefaultEventExecutor - Class in io.netty.util.concurrent
Default SingleThreadEventExecutor implementation which just execute all submitted task in a serial fashion.
DefaultEventExecutor() - Constructor for class io.netty.util.concurrent.DefaultEventExecutor
 
DefaultEventExecutor(ThreadFactory) - Constructor for class io.netty.util.concurrent.DefaultEventExecutor
 
DefaultEventExecutor(Executor) - Constructor for class io.netty.util.concurrent.DefaultEventExecutor
 
DefaultEventExecutor(EventExecutorGroup) - Constructor for class io.netty.util.concurrent.DefaultEventExecutor
 
DefaultEventExecutor(EventExecutorGroup, ThreadFactory) - Constructor for class io.netty.util.concurrent.DefaultEventExecutor
 
DefaultEventExecutor(EventExecutorGroup, Executor) - Constructor for class io.netty.util.concurrent.DefaultEventExecutor
 
DefaultEventExecutor(EventExecutorGroup, ThreadFactory, int, RejectedExecutionHandler) - Constructor for class io.netty.util.concurrent.DefaultEventExecutor
 
DefaultEventExecutor(EventExecutorGroup, Executor, int, RejectedExecutionHandler) - Constructor for class io.netty.util.concurrent.DefaultEventExecutor
 
DefaultEventExecutorChooserFactory - Class in io.netty.util.concurrent
Default implementation which uses simple round-robin to choose next EventExecutor.
DefaultEventExecutorGroup - Class in io.netty.util.concurrent
Default implementation of MultithreadEventExecutorGroup which will use DefaultEventExecutor instances to handle the tasks.
DefaultEventExecutorGroup(int) - Constructor for class io.netty.util.concurrent.DefaultEventExecutorGroup
 
DefaultEventExecutorGroup(int, ThreadFactory) - Constructor for class io.netty.util.concurrent.DefaultEventExecutorGroup
Create a new instance.
DefaultEventExecutorGroup(int, ThreadFactory, int, RejectedExecutionHandler) - Constructor for class io.netty.util.concurrent.DefaultEventExecutorGroup
Create a new instance.
DefaultEventLoop - Class in io.netty.channel
 
DefaultEventLoop() - Constructor for class io.netty.channel.DefaultEventLoop
 
DefaultEventLoop(ThreadFactory) - Constructor for class io.netty.channel.DefaultEventLoop
 
DefaultEventLoop(Executor) - Constructor for class io.netty.channel.DefaultEventLoop
 
DefaultEventLoop(EventLoopGroup) - Constructor for class io.netty.channel.DefaultEventLoop
 
DefaultEventLoop(EventLoopGroup, ThreadFactory) - Constructor for class io.netty.channel.DefaultEventLoop
 
DefaultEventLoop(EventLoopGroup, Executor) - Constructor for class io.netty.channel.DefaultEventLoop
 
DefaultEventLoopGroup - Class in io.netty.channel
MultithreadEventLoopGroup which must be used for the local transport.
DefaultEventLoopGroup() - Constructor for class io.netty.channel.DefaultEventLoopGroup
Create a new instance with the default number of threads.
DefaultEventLoopGroup(int) - Constructor for class io.netty.channel.DefaultEventLoopGroup
Create a new instance
DefaultEventLoopGroup(int, ThreadFactory) - Constructor for class io.netty.channel.DefaultEventLoopGroup
Create a new instance
DefaultEventLoopGroup(int, Executor) - Constructor for class io.netty.channel.DefaultEventLoopGroup
Create a new instance
DefaultFileRegion - Class in io.netty.channel
Default FileRegion implementation which transfer data from a FileChannel or File.
DefaultFileRegion(FileChannel, long, long) - Constructor for class io.netty.channel.DefaultFileRegion
Create a new instance
DefaultFileRegion(File, long, long) - Constructor for class io.netty.channel.DefaultFileRegion
Create a new instance using the given File.
DefaultFullBinaryMemcacheRequest - Class in io.netty.handler.codec.memcache.binary
The default implementation of a FullBinaryMemcacheRequest.
DefaultFullBinaryMemcacheRequest(ByteBuf, ByteBuf) - Constructor for class io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheRequest
Create a new DefaultBinaryMemcacheRequest with the header, key and extras.
DefaultFullBinaryMemcacheRequest(ByteBuf, ByteBuf, ByteBuf) - Constructor for class io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheRequest
Create a new DefaultBinaryMemcacheRequest with the header, key, extras and content.
DefaultFullBinaryMemcacheResponse - Class in io.netty.handler.codec.memcache.binary
The default implementation of a FullBinaryMemcacheResponse.
DefaultFullBinaryMemcacheResponse(ByteBuf, ByteBuf) - Constructor for class io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheResponse
Create a new DefaultFullBinaryMemcacheResponse with the header, key and extras.
DefaultFullBinaryMemcacheResponse(ByteBuf, ByteBuf, ByteBuf) - Constructor for class io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheResponse
Create a new DefaultFullBinaryMemcacheResponse with the header, key, extras and content.
DefaultHeaders<K,V,T extends Headers<K,V,T>> - Class in io.netty.handler.codec
Default implementation of Headers;
DefaultHeaders(ValueConverter<V>) - Constructor for class io.netty.handler.codec.DefaultHeaders
 
DefaultHeaders(ValueConverter<V>, DefaultHeaders.NameValidator<K>) - Constructor for class io.netty.handler.codec.DefaultHeaders
 
DefaultHeaders(HashingStrategy<K>, ValueConverter<V>) - Constructor for class io.netty.handler.codec.DefaultHeaders
 
DefaultHeaders(HashingStrategy<K>, ValueConverter<V>, DefaultHeaders.NameValidator<K>) - Constructor for class io.netty.handler.codec.DefaultHeaders
 
DefaultHeaders(HashingStrategy<K>, ValueConverter<V>, DefaultHeaders.NameValidator<K>, int) - Constructor for class io.netty.handler.codec.DefaultHeaders
Create a new instance.
DefaultHeaders.HeaderEntry<K,V> - Class in io.netty.handler.codec
 
DefaultHeaders.NameValidator<K> - Interface in io.netty.handler.codec
 
DefaultHeadersImpl<K,V> - Class in io.netty.handler.codec
A concrete implementation of DefaultHeaders that allows for direct instantiation.
DefaultHeadersImpl(HashingStrategy<K>, ValueConverter<V>, DefaultHeaders.NameValidator<K>) - Constructor for class io.netty.handler.codec.DefaultHeadersImpl
 
DefaultHostsFileEntriesResolver - Class in io.netty.resolver
Default HostsFileEntriesResolver that resolves hosts file entries only once.
DefaultHostsFileEntriesResolver() - Constructor for class io.netty.resolver.DefaultHostsFileEntriesResolver
 
DefaultLastBulkStringRedisContent - Class in io.netty.handler.codec.redis
A default implementation for LastBulkStringRedisContent.
DefaultLastBulkStringRedisContent(ByteBuf) - Constructor for class io.netty.handler.codec.redis.DefaultLastBulkStringRedisContent
Creates a DefaultLastBulkStringRedisContent for the given content.
DefaultLastMemcacheContent - Class in io.netty.handler.codec.memcache
The default implementation for the LastMemcacheContent.
DefaultLastMemcacheContent() - Constructor for class io.netty.handler.codec.memcache.DefaultLastMemcacheContent
 
DefaultLastMemcacheContent(ByteBuf) - Constructor for class io.netty.handler.codec.memcache.DefaultLastMemcacheContent
 
DefaultLastSmtpContent - Class in io.netty.handler.codec.smtp
Default implementation of LastSmtpContent that does no validation of the raw data passed in.
DefaultLastSmtpContent(ByteBuf) - Constructor for class io.netty.handler.codec.smtp.DefaultLastSmtpContent
Creates a new instance using the given data.
DefaultLastStompContentSubframe - Class in io.netty.handler.codec.stomp
The default implementation for the LastStompContentSubframe.
DefaultLastStompContentSubframe(ByteBuf) - Constructor for class io.netty.handler.codec.stomp.DefaultLastStompContentSubframe
 
defaultMachineId() - Static method in class io.netty.util.internal.MacAddressUtil
Returns the result of MacAddressUtil.bestAvailableMac() if non-null otherwise returns a random EUI-64 MAC address.
DefaultMaxBytesRecvByteBufAllocator - Class in io.netty.channel
The RecvByteBufAllocator that yields a buffer size prediction based upon decrementing the value from the max bytes per read.
DefaultMaxBytesRecvByteBufAllocator() - Constructor for class io.netty.channel.DefaultMaxBytesRecvByteBufAllocator
 
DefaultMaxBytesRecvByteBufAllocator(int, int) - Constructor for class io.netty.channel.DefaultMaxBytesRecvByteBufAllocator
 
defaultMaxMessagesPerRead() - Method in class io.netty.channel.ChannelMetadata
DefaultMaxMessagesRecvByteBufAllocator - Class in io.netty.channel
Default implementation of MaxMessagesRecvByteBufAllocator which respects ChannelConfig.isAutoRead() and also prevents overflow.
DefaultMaxMessagesRecvByteBufAllocator() - Constructor for class io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator
 
DefaultMaxMessagesRecvByteBufAllocator(int) - Constructor for class io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator
 
DefaultMaxMessagesRecvByteBufAllocator.MaxMessageHandle - Class in io.netty.channel
Focuses on enforcing the maximum messages per read condition for DefaultMaxMessagesRecvByteBufAllocator.MaxMessageHandle.continueReading().
defaultMaxOrder() - Static method in class io.netty.buffer.PooledByteBufAllocator
Default maximum order - System Property: io.netty.allocator.maxOrder - default 11
DefaultMemcacheContent - Class in io.netty.handler.codec.memcache
The default MemcacheContent implementation.
DefaultMemcacheContent(ByteBuf) - Constructor for class io.netty.handler.codec.memcache.DefaultMemcacheContent
Creates a new instance with the specified content.
DefaultMessageSizeEstimator - Class in io.netty.channel
Default MessageSizeEstimator implementation which supports the estimation of the size of ByteBuf, ByteBufHolder and FileRegion.
DefaultMessageSizeEstimator(int) - Constructor for class io.netty.channel.DefaultMessageSizeEstimator
Create a new instance
DefaultNameResolver - Class in io.netty.resolver
A InetNameResolver that resolves using JDK's built-in domain name lookup mechanism.
DefaultNameResolver(EventExecutor) - Constructor for class io.netty.resolver.DefaultNameResolver
 
defaultNormalCacheSize() - Static method in class io.netty.buffer.PooledByteBufAllocator
Default normal cache size - System Property: io.netty.allocator.normalCacheSize - default 64
defaultNumDirectArena() - Static method in class io.netty.buffer.PooledByteBufAllocator
Default number of direct arenas - System Property: io.netty.allocator.numDirectArenas - default 2 * cores
defaultNumHeapArena() - Static method in class io.netty.buffer.PooledByteBufAllocator
Default number of heap arenas - System Property: io.netty.allocator.numHeapArenas - default 2 * cores
DefaultOioServerSocketChannelConfig - Class in io.netty.channel.socket.oio
Default OioServerSocketChannelConfig implementation
DefaultOioServerSocketChannelConfig(ServerSocketChannel, ServerSocket) - Constructor for class io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig
Deprecated.
DefaultOioSocketChannelConfig - Class in io.netty.channel.socket.oio
Default OioSocketChannelConfig implementation
DefaultOioSocketChannelConfig(SocketChannel, Socket) - Constructor for class io.netty.channel.socket.oio.DefaultOioSocketChannelConfig
Deprecated.
defaultPageSize() - Static method in class io.netty.buffer.PooledByteBufAllocator
Default buffer page size - System Property: io.netty.allocator.pageSize - default 8192
DefaultPriorityQueue<T extends PriorityQueueNode> - Class in io.netty.util.internal
A priority queue which uses natural ordering of elements.
DefaultPriorityQueue(Comparator<T>, int) - Constructor for class io.netty.util.internal.DefaultPriorityQueue
 
DefaultProgressivePromise<V> - Class in io.netty.util.concurrent
 
DefaultProgressivePromise(EventExecutor) - Constructor for class io.netty.util.concurrent.DefaultProgressivePromise
Creates a new instance.
DefaultProgressivePromise() - Constructor for class io.netty.util.concurrent.DefaultProgressivePromise
 
DefaultPromise<V> - Class in io.netty.util.concurrent
 
DefaultPromise(EventExecutor) - Constructor for class io.netty.util.concurrent.DefaultPromise
Creates a new instance.
DefaultPromise() - Constructor for class io.netty.util.concurrent.DefaultPromise
See DefaultPromise.executor() for expectations of the executor.
DefaultSelectStrategyFactory - Class in io.netty.channel
Factory which uses the default select strategy.
defaultServerProvider() - Static method in class io.netty.handler.ssl.SslContext
Returns the default server-side implementation provider currently in use.
DefaultServerSocketChannelConfig - Class in io.netty.channel.socket
The default ServerSocketChannelConfig implementation.
DefaultServerSocketChannelConfig(ServerSocketChannel, ServerSocket) - Constructor for class io.netty.channel.socket.DefaultServerSocketChannelConfig
Creates a new instance.
defaultSmallCacheSize() - Static method in class io.netty.buffer.PooledByteBufAllocator
Default small cache size - System Property: io.netty.allocator.smallCacheSize - default 256
DefaultSmtpContent - Class in io.netty.handler.codec.smtp
Default implementation of SmtpContent that does no validation of the raw data passed in.
DefaultSmtpContent(ByteBuf) - Constructor for class io.netty.handler.codec.smtp.DefaultSmtpContent
Creates a new instance using the given data.
DefaultSmtpRequest - Class in io.netty.handler.codec.smtp
Default SmtpRequest implementation.
DefaultSmtpRequest(SmtpCommand) - Constructor for class io.netty.handler.codec.smtp.DefaultSmtpRequest
Creates a new instance with the given command and no parameters.
DefaultSmtpRequest(SmtpCommand, CharSequence...) - Constructor for class io.netty.handler.codec.smtp.DefaultSmtpRequest
Creates a new instance with the given command and parameters.
DefaultSmtpRequest(CharSequence, CharSequence...) - Constructor for class io.netty.handler.codec.smtp.DefaultSmtpRequest
Creates a new instance with the given command and parameters.
DefaultSmtpResponse - Class in io.netty.handler.codec.smtp
Default SmtpResponse implementation.
DefaultSmtpResponse(int) - Constructor for class io.netty.handler.codec.smtp.DefaultSmtpResponse
Creates a new instance with the given smtp code and no details.
DefaultSmtpResponse(int, CharSequence...) - Constructor for class io.netty.handler.codec.smtp.DefaultSmtpResponse
Creates a new instance with the given smtp code and details.
DefaultSocketChannelConfig - Class in io.netty.channel.socket
The default SocketChannelConfig implementation.
DefaultSocketChannelConfig(SocketChannel, Socket) - Constructor for class io.netty.channel.socket.DefaultSocketChannelConfig
Creates a new instance.
DefaultStompContentSubframe - Class in io.netty.handler.codec.stomp
The default StompContentSubframe implementation.
DefaultStompContentSubframe(ByteBuf) - Constructor for class io.netty.handler.codec.stomp.DefaultStompContentSubframe
 
DefaultStompFrame - Class in io.netty.handler.codec.stomp
Default implementation of StompFrame.
DefaultStompFrame(StompCommand) - Constructor for class io.netty.handler.codec.stomp.DefaultStompFrame
 
DefaultStompFrame(StompCommand, ByteBuf) - Constructor for class io.netty.handler.codec.stomp.DefaultStompFrame
 
DefaultStompHeaders - Class in io.netty.handler.codec.stomp
 
DefaultStompHeaders() - Constructor for class io.netty.handler.codec.stomp.DefaultStompHeaders
 
DefaultStompHeadersSubframe - Class in io.netty.handler.codec.stomp
Default implementation of StompHeadersSubframe.
DefaultStompHeadersSubframe(StompCommand) - Constructor for class io.netty.handler.codec.stomp.DefaultStompHeadersSubframe
 
DefaultThreadFactory - Class in io.netty.util.concurrent
A ThreadFactory implementation with a simple naming rule.
DefaultThreadFactory(Class<?>) - Constructor for class io.netty.util.concurrent.DefaultThreadFactory
 
DefaultThreadFactory(String) - Constructor for class io.netty.util.concurrent.DefaultThreadFactory
 
DefaultThreadFactory(Class<?>, boolean) - Constructor for class io.netty.util.concurrent.DefaultThreadFactory
 
DefaultThreadFactory(String, boolean) - Constructor for class io.netty.util.concurrent.DefaultThreadFactory
 
DefaultThreadFactory(Class<?>, int) - Constructor for class io.netty.util.concurrent.DefaultThreadFactory
 
DefaultThreadFactory(String, int) - Constructor for class io.netty.util.concurrent.DefaultThreadFactory
 
DefaultThreadFactory(Class<?>, boolean, int) - Constructor for class io.netty.util.concurrent.DefaultThreadFactory
 
DefaultThreadFactory(String, boolean, int, ThreadGroup) - Constructor for class io.netty.util.concurrent.DefaultThreadFactory
 
DefaultThreadFactory(String, boolean, int) - Constructor for class io.netty.util.concurrent.DefaultThreadFactory
 
defaultTinyCacheSize() - Static method in class io.netty.buffer.PooledByteBufAllocator
Default tiny cache size - System Property: io.netty.allocator.tinyCacheSize - default 512
delayNanos(long) - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
Returns the amount of time left until the scheduled task with the closest dead line is executed.
delegate() - Method in class io.netty.channel.RecvByteBufAllocator.DelegatingHandle
Get the RecvByteBufAllocator.Handle which all methods will be delegated to.
DelegatingHandle(RecvByteBufAllocator.Handle) - Constructor for class io.netty.channel.RecvByteBufAllocator.DelegatingHandle
 
DelegatingSslContext - Class in io.netty.handler.ssl
Adapter class which allows to wrap another SslContext and init SSLEngine instances.
DelegatingSslContext(SslContext) - Constructor for class io.netty.handler.ssl.DelegatingSslContext
 
DELETE - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
delete() - Method in class io.netty.handler.ssl.util.SelfSignedCertificate
Deletes the generated X.509 certificate file and RSA private key file.
DELETEQ - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
DelimiterBasedFrameDecoder - Class in io.netty.handler.codec
A decoder that splits the received ByteBufs by one or more delimiters.
DelimiterBasedFrameDecoder(int, ByteBuf) - Constructor for class io.netty.handler.codec.DelimiterBasedFrameDecoder
Creates a new instance.
DelimiterBasedFrameDecoder(int, boolean, ByteBuf) - Constructor for class io.netty.handler.codec.DelimiterBasedFrameDecoder
Creates a new instance.
DelimiterBasedFrameDecoder(int, boolean, boolean, ByteBuf) - Constructor for class io.netty.handler.codec.DelimiterBasedFrameDecoder
Creates a new instance.
DelimiterBasedFrameDecoder(int, ByteBuf...) - Constructor for class io.netty.handler.codec.DelimiterBasedFrameDecoder
Creates a new instance.
DelimiterBasedFrameDecoder(int, boolean, ByteBuf...) - Constructor for class io.netty.handler.codec.DelimiterBasedFrameDecoder
Creates a new instance.
DelimiterBasedFrameDecoder(int, boolean, boolean, ByteBuf...) - Constructor for class io.netty.handler.codec.DelimiterBasedFrameDecoder
Creates a new instance.
Delimiters - Class in io.netty.handler.codec
A set of commonly used delimiters for DelimiterBasedFrameDecoder.
DELTA_BADVAL - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseStatus
 
deregister(ChannelPromise) - Method in class io.netty.channel.AbstractChannel.AbstractUnsafe
 
deregister() - Method in class io.netty.channel.AbstractChannel
 
deregister(ChannelPromise) - Method in class io.netty.channel.AbstractChannel
 
deregister(ChannelPromise) - Method in interface io.netty.channel.Channel.Unsafe
Deregister the Channel of the ChannelPromise from EventLoop and notify the ChannelPromise once the operation was complete.
deregister(ChannelHandlerContext, ChannelPromise) - Method in class io.netty.channel.ChannelDuplexHandler
deregister(ChannelHandlerContext, ChannelPromise) - Method in interface io.netty.channel.ChannelOutboundHandler
Called once a deregister operation is made from the current registered EventLoop.
deregister(ChannelHandlerContext, ChannelPromise) - Method in class io.netty.channel.ChannelOutboundHandlerAdapter
deregister() - Method in interface io.netty.channel.ChannelOutboundInvoker
Request to deregister from the previous assigned EventExecutor and notify the ChannelFuture once the operation completes, either because the operation was successful or because of an error.
deregister(ChannelPromise) - Method in interface io.netty.channel.ChannelOutboundInvoker
Request to deregister from the previous assigned EventExecutor and notify the ChannelFuture once the operation completes, either because the operation was successful or because of an error.
deregister(ChannelHandlerContext, ChannelPromise) - Method in class io.netty.channel.CombinedChannelDuplexHandler
 
deregister() - Method in class io.netty.channel.DefaultChannelPipeline
 
deregister(ChannelPromise) - Method in class io.netty.channel.DefaultChannelPipeline
 
deregister() - Method in interface io.netty.channel.group.ChannelGroup
Deprecated.
This method will be removed in the next major feature release. Deregister all Channels in this group from their EventLoop. Please note that this operation is asynchronous as ChannelOutboundInvoker.deregister() is.
deregister(ChannelMatcher) - Method in interface io.netty.channel.group.ChannelGroup
Deprecated.
This method will be removed in the next major feature release. Deregister all Channels in this group from their EventLoop that are matched by the given ChannelMatcher. Please note that this operation is asynchronous as ChannelOutboundInvoker.deregister() is.
deregister() - Method in class io.netty.channel.group.DefaultChannelGroup
 
deregister(ChannelMatcher) - Method in class io.netty.channel.group.DefaultChannelGroup
 
deregister() - Method in class io.netty.channel.ThreadPerChannelEventLoop
 
deregister(ChannelHandlerContext, ChannelPromise) - Method in class io.netty.handler.codec.DatagramPacketEncoder
 
deregister(ChannelHandlerContext, ChannelPromise) - Method in class io.netty.handler.logging.LoggingHandler
 
deregister(ChannelHandlerContext, ChannelPromise) - Method in class io.netty.handler.ssl.AbstractSniHandler
 
deregister(ChannelHandlerContext, ChannelPromise) - Method in class io.netty.handler.ssl.SslHandler
 
DESTINATION - Static variable in interface io.netty.handler.codec.stomp.StompHeaders
 
destroy() - Method in class io.netty.handler.ssl.PemPrivateKey
NOTE: This is a JDK8 interface/method.
destroy() - Static method in class io.netty.util.concurrent.FastThreadLocal
Destroys the data structure that keeps all FastThreadLocal variables accessed from non-FastThreadLocalThreads.
destroy() - Static method in class io.netty.util.internal.InternalThreadLocalMap
 
details() - Method in class io.netty.handler.codec.smtp.DefaultSmtpResponse
 
details() - Method in interface io.netty.handler.codec.smtp.SmtpResponse
Returns the details if any.
detected(T) - Static method in class io.netty.handler.codec.ProtocolDetectionResult
Returns a ProtocolDetectionResult which holds the detected protocol.
detectedProtocol() - Method in class io.netty.handler.codec.ProtocolDetectionResult
Returns the protocol if ProtocolDetectionResult.state() returns ProtocolDetectionState.DETECTED, otherwise null.
DHCID - Static variable in class io.netty.handler.codec.dns.DnsRecordType
DHCP identifier record RFC 4701 Used in conjunction with the FQDN option to DHCP.
directArenas() - Method in class io.netty.buffer.PooledByteBufAllocator
directArenas() - Method in class io.netty.buffer.PooledByteBufAllocatorMetric
Return a List of all direct PoolArenaMetrics that are provided by this pool.
directBuffer() - Method in class io.netty.buffer.AbstractByteBufAllocator
 
directBuffer(int) - Method in class io.netty.buffer.AbstractByteBufAllocator
 
directBuffer(int, int) - Method in class io.netty.buffer.AbstractByteBufAllocator
 
directBuffer() - Method in interface io.netty.buffer.ByteBufAllocator
Allocate a direct ByteBuf.
directBuffer(int) - Method in interface io.netty.buffer.ByteBufAllocator
Allocate a direct ByteBuf with the given initial capacity.
directBuffer(int, int) - Method in interface io.netty.buffer.ByteBufAllocator
Allocate a direct ByteBuf with the given initial capacity and the given maximal capacity.
directBuffer() - Static method in class io.netty.buffer.Unpooled
Creates a new big-endian direct buffer with reasonably small initial capacity, which expands its capacity boundlessly on demand.
directBuffer(int) - Static method in class io.netty.buffer.Unpooled
Creates a new big-endian direct buffer with the specified capacity, which expands its capacity boundlessly on demand.
directBuffer(int, int) - Static method in class io.netty.buffer.Unpooled
Creates a new big-endian direct buffer with the specified initialCapacity, that may grow up to maxCapacity.
directBuffer(long, int) - Static method in class io.netty.util.internal.PlatformDependent
 
directBufferAddress(ByteBuffer) - Static method in class io.netty.util.internal.PlatformDependent
 
directBufferPreferred() - Static method in class io.netty.util.internal.PlatformDependent
Returns true if the platform has reliable low-level direct buffer access API and a user has not specified -Dio.netty.noPreferDirect option.
DISABLED - Static variable in class io.netty.handler.ssl.ApplicationProtocolConfig
The configuration that disables application protocol negotiation.
discardReadBytes() - Method in class io.netty.buffer.AbstractByteBuf
 
discardReadBytes() - Method in class io.netty.buffer.ByteBuf
Discards the bytes between the 0th index and readerIndex.
discardReadBytes() - Method in class io.netty.buffer.CompositeByteBuf
 
discardReadBytes() - Method in class io.netty.buffer.EmptyByteBuf
 
discardReadBytes() - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
discardReadBytes() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
discardReadComponents() - Method in class io.netty.buffer.CompositeByteBuf
Discard all ByteBufs which are read.
discardSomeReadBytes() - Method in class io.netty.buffer.AbstractByteBuf
 
discardSomeReadBytes() - Method in class io.netty.buffer.ByteBuf
Similar to ByteBuf.discardReadBytes() except that this method might discard some, all, or none of read bytes depending on its internal implementation to reduce overall memory bandwidth consumption at the cost of potentially additional memory consumption.
discardSomeReadBytes() - Method in class io.netty.buffer.CompositeByteBuf
 
discardSomeReadBytes() - Method in class io.netty.buffer.EmptyByteBuf
 
discardSomeReadBytes() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
discardSomeReadBytes() - Method in class io.netty.handler.codec.ByteToMessageDecoder
 
disconnect(ChannelPromise) - Method in class io.netty.channel.AbstractChannel.AbstractUnsafe
 
disconnect() - Method in class io.netty.channel.AbstractChannel
 
disconnect(ChannelPromise) - Method in class io.netty.channel.AbstractChannel
 
disconnect(ChannelPromise) - Method in interface io.netty.channel.Channel.Unsafe
Disconnect the Channel of the ChannelFuture and notify the ChannelPromise once the operation was complete.
disconnect(ChannelHandlerContext, ChannelPromise) - Method in class io.netty.channel.ChannelDuplexHandler
disconnect(ChannelHandlerContext, ChannelPromise) - Method in interface io.netty.channel.ChannelOutboundHandler
Called once a disconnect operation is made.
disconnect(ChannelHandlerContext, ChannelPromise) - Method in class io.netty.channel.ChannelOutboundHandlerAdapter
disconnect() - Method in interface io.netty.channel.ChannelOutboundInvoker
Request to disconnect from the remote peer and notify the ChannelFuture once the operation completes, either because the operation was successful or because of an error.
disconnect(ChannelPromise) - Method in interface io.netty.channel.ChannelOutboundInvoker
Request to disconnect from the remote peer and notify the ChannelFuture once the operation completes, either because the operation was successful or because of an error.
disconnect(ChannelHandlerContext, ChannelPromise) - Method in class io.netty.channel.CombinedChannelDuplexHandler
 
disconnect() - Method in class io.netty.channel.DefaultChannelPipeline
 
disconnect(ChannelPromise) - Method in class io.netty.channel.DefaultChannelPipeline
 
disconnect() - Method in class io.netty.channel.embedded.EmbeddedChannel
 
disconnect(ChannelPromise) - Method in class io.netty.channel.embedded.EmbeddedChannel
 
disconnect() - Method in interface io.netty.channel.group.ChannelGroup
Disconnects all Channels in this group from their remote peers.
disconnect(ChannelMatcher) - Method in interface io.netty.channel.group.ChannelGroup
Disconnects all Channels in this group from their remote peers, that are matched by the given ChannelMatcher.
disconnect() - Method in class io.netty.channel.group.DefaultChannelGroup
 
disconnect(ChannelMatcher) - Method in class io.netty.channel.group.DefaultChannelGroup
 
disconnect(ChannelHandlerContext, ChannelPromise) - Method in class io.netty.handler.codec.DatagramPacketEncoder
 
disconnect(ChannelHandlerContext, ChannelPromise) - Method in class io.netty.handler.flush.FlushConsolidationHandler
 
disconnect(ChannelHandlerContext, ChannelPromise) - Method in class io.netty.handler.logging.LoggingHandler
 
disconnect(ChannelHandlerContext, ChannelPromise) - Method in class io.netty.handler.ssl.AbstractSniHandler
 
disconnect(ChannelHandlerContext, ChannelPromise) - Method in class io.netty.handler.ssl.SslHandler
 
DLV - Static variable in class io.netty.handler.codec.dns.DnsRecordType
DNSSEC Lookaside Validation record RFC 4431 For publishing DNSSEC trust anchors outside of the DNS delegation chain.
DNAME - Static variable in class io.netty.handler.codec.dns.DnsRecordType
Delegation name record RFC 2672 DNAME creates an alias for a name and all its subnames, unlike CNAME, which aliases only the exact name in its label.
DnsAddressResolverGroup - Class in io.netty.resolver.dns
DnsAddressResolverGroup(Class<? extends DatagramChannel>, DnsServerAddressStreamProvider) - Constructor for class io.netty.resolver.dns.DnsAddressResolverGroup
 
DnsAddressResolverGroup(ChannelFactory<? extends DatagramChannel>, DnsServerAddressStreamProvider) - Constructor for class io.netty.resolver.dns.DnsAddressResolverGroup
 
DnsCache - Interface in io.netty.resolver.dns
A cache for DNS resolution entries.
DnsCacheEntry - Class in io.netty.resolver.dns
Entry in DnsCache.
DnsCacheEntry(String, InetAddress) - Constructor for class io.netty.resolver.dns.DnsCacheEntry
 
DnsCacheEntry(String, Throwable) - Constructor for class io.netty.resolver.dns.DnsCacheEntry
 
dnsClass() - Method in class io.netty.handler.codec.dns.AbstractDnsRecord
 
dnsClass() - Method in interface io.netty.handler.codec.dns.DnsRecord
Returns the class of this resource record.
DNSKEY - Static variable in class io.netty.handler.codec.dns.DnsRecordType
DNS Key record RFC 4034 The key record used in DNSSEC.
DnsMessage - Interface in io.netty.handler.codec.dns
The superclass which contains core information concerning a DnsQuery and a DnsResponse.
DnsNameResolver - Class in io.netty.resolver.dns
A DNS-based InetNameResolver.
DnsNameResolver(EventLoop, ChannelFactory<? extends DatagramChannel>, DnsCache, DnsCache, DnsQueryLifecycleObserverFactory, long, ResolvedAddressTypes, boolean, int, boolean, int, boolean, HostsFileEntriesResolver, DnsServerAddressStreamProvider, String[], int, boolean) - Constructor for class io.netty.resolver.dns.DnsNameResolver
Creates a new DNS-based name resolver that communicates with the specified list of DNS servers.
DnsNameResolverBuilder - Class in io.netty.resolver.dns
A DnsNameResolver builder.
DnsNameResolverBuilder(EventLoop) - Constructor for class io.netty.resolver.dns.DnsNameResolverBuilder
Creates a new builder.
DnsNameResolverException - Exception in io.netty.resolver.dns
A RuntimeException raised when DnsNameResolver failed to perform a successful query.
DnsNameResolverException(InetSocketAddress, DnsQuestion, String) - Constructor for exception io.netty.resolver.dns.DnsNameResolverException
 
DnsNameResolverException(InetSocketAddress, DnsQuestion, String, Throwable) - Constructor for exception io.netty.resolver.dns.DnsNameResolverException
 
DnsOpCode - Class in io.netty.handler.codec.dns
The DNS OpCode as defined in RFC2929.
DnsOpCode(int, String) - Constructor for class io.netty.handler.codec.dns.DnsOpCode
 
DnsOptEcsRecord - Interface in io.netty.handler.codec.dns
An ECS record as defined in Client Subnet in DNS Queries.
DnsOptPseudoRecord - Interface in io.netty.handler.codec.dns
An OPT RR record.
DnsPtrRecord - Interface in io.netty.handler.codec.dns
 
DnsQuery - Interface in io.netty.handler.codec.dns
A DNS query message.
DnsQueryLifecycleObserver - Interface in io.netty.resolver.dns
This interface provides visibility into individual DNS queries.
dnsQueryLifecycleObserverFactory(DnsQueryLifecycleObserverFactory) - Method in class io.netty.resolver.dns.DnsNameResolverBuilder
Set the factory used to generate objects which can observe individual DNS queries.
DnsQueryLifecycleObserverFactory - Interface in io.netty.resolver.dns
Used to generate new instances of DnsQueryLifecycleObserver.
DnsQuestion - Interface in io.netty.handler.codec.dns
A DNS question.
DnsRawRecord - Interface in io.netty.handler.codec.dns
A generic DnsRecord that contains an undecoded RDATA.
DnsRecord - Interface in io.netty.handler.codec.dns
A DNS resource record.
DnsRecordDecoder - Interface in io.netty.handler.codec.dns
Decodes a DNS record into its object representation.
DnsRecordEncoder - Interface in io.netty.handler.codec.dns
Encodes a DnsRecord into binary representation.
DnsRecordType - Class in io.netty.handler.codec.dns
Represents a DNS record type.
DnsRecordType(int, String) - Constructor for class io.netty.handler.codec.dns.DnsRecordType
 
DnsResponse - Interface in io.netty.handler.codec.dns
A DNS response message.
DnsResponseCode - Class in io.netty.handler.codec.dns
The DNS RCODE, as defined in RFC2929.
DnsResponseCode(int, String) - Constructor for class io.netty.handler.codec.dns.DnsResponseCode
 
DnsSection - Enum in io.netty.handler.codec.dns
Represents a section of a DnsMessage.
DnsServerAddresses - Class in io.netty.resolver.dns
Provides an infinite sequence of DNS server addresses to DnsNameResolver.
DnsServerAddresses() - Constructor for class io.netty.resolver.dns.DnsServerAddresses
 
DnsServerAddressStream - Interface in io.netty.resolver.dns
An infinite stream of DNS server addresses.
DnsServerAddressStreamProvider - Interface in io.netty.resolver.dns
Provides an opportunity to override which DnsServerAddressStream is used to resolve a specific hostname.
DnsServerAddressStreamProviders - Class in io.netty.resolver.dns
Utility methods related to DnsServerAddressStreamProvider.
doAccounting(TrafficCounter) - Method in class io.netty.handler.traffic.AbstractTrafficShapingHandler
Called each time the accounting is computed from the TrafficCounters.
doAccounting(TrafficCounter) - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
 
doBeginRead() - Method in class io.netty.channel.AbstractChannel
Schedule a read operation.
doBeginRead() - Method in class io.netty.channel.embedded.EmbeddedChannel
 
doBeginRead() - Method in class io.netty.channel.local.LocalChannel
 
doBeginRead() - Method in class io.netty.channel.local.LocalServerChannel
 
doBeginRead() - Method in class io.netty.channel.nio.AbstractNioChannel
 
doBeginRead() - Method in class io.netty.channel.nio.AbstractNioMessageChannel
 
doBeginRead() - Method in class io.netty.channel.oio.AbstractOioChannel
 
doBind(SocketAddress) - Method in class io.netty.channel.AbstractChannel
Bind the Channel to the SocketAddress
doBind(SocketAddress) - Method in class io.netty.channel.embedded.EmbeddedChannel
 
doBind(SocketAddress) - Method in class io.netty.channel.epoll.EpollDatagramChannel
 
doBind(SocketAddress) - Method in class io.netty.channel.epoll.EpollDomainSocketChannel
 
doBind(SocketAddress) - Method in class io.netty.channel.epoll.EpollServerDomainSocketChannel
 
doBind(SocketAddress) - Method in class io.netty.channel.epoll.EpollServerSocketChannel
 
doBind(SocketAddress) - Method in class io.netty.channel.epoll.EpollSocketChannel
 
doBind(SocketAddress) - Method in class io.netty.channel.kqueue.KQueueDatagramChannel
 
doBind(SocketAddress) - Method in class io.netty.channel.kqueue.KQueueDomainSocketChannel
 
doBind(SocketAddress) - Method in class io.netty.channel.kqueue.KQueueServerDomainSocketChannel
 
doBind(SocketAddress) - Method in class io.netty.channel.kqueue.KQueueServerSocketChannel
 
doBind(SocketAddress) - Method in class io.netty.channel.kqueue.KQueueSocketChannel
 
doBind(SocketAddress) - Method in class io.netty.channel.local.LocalChannel
 
doBind(SocketAddress) - Method in class io.netty.channel.local.LocalServerChannel
 
doBind(SocketAddress) - Method in class io.netty.channel.socket.nio.NioDatagramChannel
 
doBind(SocketAddress) - Method in class io.netty.channel.socket.nio.NioServerSocketChannel
 
doBind(SocketAddress) - Method in class io.netty.channel.socket.nio.NioSocketChannel
 
doBind(SocketAddress) - Method in class io.netty.channel.socket.oio.OioDatagramChannel
 
doBind(SocketAddress) - Method in class io.netty.channel.socket.oio.OioServerSocketChannel
 
doBind(SocketAddress) - Method in class io.netty.channel.socket.oio.OioSocketChannel
 
doClose() - Method in class io.netty.channel.AbstractChannel
Close the Channel
doClose() - Method in class io.netty.channel.embedded.EmbeddedChannel
 
doClose() - Method in class io.netty.channel.epoll.AbstractEpollStreamChannel
 
doClose() - Method in class io.netty.channel.epoll.EpollServerDomainSocketChannel
 
doClose() - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel
 
doClose() - Method in class io.netty.channel.kqueue.KQueueServerDomainSocketChannel
 
doClose() - Method in class io.netty.channel.local.LocalChannel
 
doClose() - Method in class io.netty.channel.local.LocalServerChannel
 
doClose() - Method in class io.netty.channel.nio.AbstractNioChannel
 
doClose() - Method in class io.netty.channel.oio.OioByteStreamChannel
 
doClose() - Method in class io.netty.channel.socket.nio.NioDatagramChannel
 
doClose() - Method in class io.netty.channel.socket.nio.NioServerSocketChannel
 
doClose() - Method in class io.netty.channel.socket.nio.NioSocketChannel
 
doClose() - Method in class io.netty.channel.socket.oio.OioDatagramChannel
 
doClose() - Method in class io.netty.channel.socket.oio.OioServerSocketChannel
 
doClose() - Method in class io.netty.channel.socket.oio.OioSocketChannel
 
doConnect(SocketAddress, SocketAddress) - Method in class io.netty.channel.epoll.AbstractEpollStreamChannel
Connect to the remote peer
doConnect(SocketAddress, SocketAddress) - Method in class io.netty.channel.epoll.EpollDomainSocketChannel
 
doConnect(SocketAddress, SocketAddress) - Method in class io.netty.channel.epoll.EpollSocketChannel
 
doConnect(SocketAddress, SocketAddress) - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel
Connect to the remote peer
doConnect(SocketAddress, SocketAddress) - Method in class io.netty.channel.kqueue.KQueueDomainSocketChannel
 
doConnect(SocketAddress, SocketAddress) - Method in class io.netty.channel.kqueue.KQueueSocketChannel
 
doConnect(SocketAddress, SocketAddress) - Method in class io.netty.channel.nio.AbstractNioChannel
Connect to the remote peer
doConnect(SocketAddress, SocketAddress) - Method in class io.netty.channel.oio.AbstractOioChannel
Connect to the remote peer using the given localAddress if one is specified or null otherwise.
doConnect(SocketAddress, SocketAddress) - Method in class io.netty.channel.socket.nio.NioDatagramChannel
 
doConnect(SocketAddress, SocketAddress) - Method in class io.netty.channel.socket.nio.NioServerSocketChannel
 
doConnect(SocketAddress, SocketAddress) - Method in class io.netty.channel.socket.nio.NioSocketChannel
 
doConnect(SocketAddress, SocketAddress) - Method in class io.netty.channel.socket.oio.OioDatagramChannel
 
doConnect(SocketAddress, SocketAddress) - Method in class io.netty.channel.socket.oio.OioServerSocketChannel
 
doConnect(SocketAddress, SocketAddress) - Method in class io.netty.channel.socket.oio.OioSocketChannel
 
doDeregister() - Method in class io.netty.channel.AbstractChannel
Deregister the Channel from its EventLoop.
doDeregister() - Method in class io.netty.channel.local.LocalChannel
 
doDeregister() - Method in class io.netty.channel.local.LocalServerChannel
 
doDeregister() - Method in class io.netty.channel.nio.AbstractNioChannel
 
doDisconnect() - Method in class io.netty.channel.AbstractChannel
Disconnect this Channel from its remote peer
doDisconnect() - Method in class io.netty.channel.AbstractServerChannel
 
doDisconnect() - Method in class io.netty.channel.embedded.EmbeddedChannel
 
doDisconnect() - Method in class io.netty.channel.epoll.EpollDatagramChannel
 
doDisconnect() - Method in class io.netty.channel.kqueue.KQueueDatagramChannel
 
doDisconnect() - Method in class io.netty.channel.local.LocalChannel
 
doDisconnect() - Method in class io.netty.channel.socket.nio.NioDatagramChannel
 
doDisconnect() - Method in class io.netty.channel.socket.nio.NioServerSocketChannel
 
doDisconnect() - Method in class io.netty.channel.socket.nio.NioSocketChannel
 
doDisconnect() - Method in class io.netty.channel.socket.oio.OioDatagramChannel
 
doDisconnect() - Method in class io.netty.channel.socket.oio.OioServerSocketChannel
 
doDisconnect() - Method in class io.netty.channel.socket.oio.OioSocketChannel
 
doFinishConnect() - Method in class io.netty.channel.nio.AbstractNioChannel
Finish the connect
doFinishConnect() - Method in class io.netty.channel.socket.nio.NioDatagramChannel
 
doFinishConnect() - Method in class io.netty.channel.socket.nio.NioServerSocketChannel
 
doFinishConnect() - Method in class io.netty.channel.socket.nio.NioSocketChannel
 
doIsResolved(T) - Method in class io.netty.resolver.AbstractAddressResolver
Invoked by AbstractAddressResolver.isResolved(SocketAddress) to check if the specified address has been resolved already.
doIsResolved(InetSocketAddress) - Method in class io.netty.resolver.InetSocketAddressResolver
 
doIsResolved(SocketAddress) - Method in class io.netty.resolver.NoopAddressResolver
 
DOMAIN_SOCKET_READ_MODE - Static variable in class io.netty.channel.unix.UnixChannelOption
 
DomainMappingBuilder<V> - Class in io.netty.util
Deprecated.
DomainMappingBuilder(V) - Constructor for class io.netty.util.DomainMappingBuilder
Deprecated.
Constructor with default initial capacity of the map holding the mappings
DomainMappingBuilder(int, V) - Constructor for class io.netty.util.DomainMappingBuilder
Deprecated.
Constructor with initial capacity of the map holding the mappings
DomainNameMapping<V> - Class in io.netty.util
Maps a domain name to its associated value object.
DomainNameMapping(V) - Constructor for class io.netty.util.DomainNameMapping
Deprecated.
use DomainNameMappingBuilder to create and fill the mapping instead
DomainNameMapping(int, V) - Constructor for class io.netty.util.DomainNameMapping
Deprecated.
use DomainNameMappingBuilder to create and fill the mapping instead
DomainNameMappingBuilder<V> - Class in io.netty.util
Builder for immutable DomainNameMapping instances.
DomainNameMappingBuilder(V) - Constructor for class io.netty.util.DomainNameMappingBuilder
Constructor with default initial capacity of the map holding the mappings
DomainNameMappingBuilder(int, V) - Constructor for class io.netty.util.DomainNameMappingBuilder
Constructor with initial capacity of the map holding the mappings
DomainSocketAddress - Class in io.netty.channel.unix
A address for a Unix Domain Socket.
DomainSocketAddress(String) - Constructor for class io.netty.channel.unix.DomainSocketAddress
 
DomainSocketAddress(File) - Constructor for class io.netty.channel.unix.DomainSocketAddress
 
DomainSocketChannel - Interface in io.netty.channel.unix
A UnixChannel that supports communication via Unix Domain Socket.
DomainSocketChannelConfig - Interface in io.netty.channel.unix
DomainSocketReadMode - Enum in io.netty.channel.unix
Different modes of reading from a DomainSocketChannel.
doRead() - Method in class io.netty.channel.oio.AbstractOioByteChannel
 
doRead() - Method in class io.netty.channel.oio.AbstractOioChannel
 
doRead() - Method in class io.netty.channel.oio.AbstractOioMessageChannel
 
doReadBytes(ByteBuf) - Method in class io.netty.channel.nio.AbstractNioByteChannel
Read bytes into the given ByteBuf and return the amount.
doReadBytes(ByteBuf) - Method in class io.netty.channel.oio.AbstractOioByteChannel
Read bytes from the underlying Socket.
doReadBytes(ByteBuf) - Method in class io.netty.channel.oio.OioByteStreamChannel
 
doReadBytes(ByteBuf) - Method in class io.netty.channel.socket.nio.NioSocketChannel
 
doReadBytes(ByteBuf) - Method in class io.netty.channel.socket.oio.OioSocketChannel
 
doReadMessages(List<Object>) - Method in class io.netty.channel.nio.AbstractNioMessageChannel
Read messages into the given array and return the amount which was read.
doReadMessages(List<Object>) - Method in class io.netty.channel.oio.AbstractOioMessageChannel
Read messages into the given array and return the amount which was read.
doReadMessages(List<Object>) - Method in class io.netty.channel.socket.nio.NioDatagramChannel
 
doReadMessages(List<Object>) - Method in class io.netty.channel.socket.nio.NioServerSocketChannel
 
doReadMessages(List<Object>) - Method in class io.netty.channel.socket.oio.OioDatagramChannel
 
doReadMessages(List<Object>) - Method in class io.netty.channel.socket.oio.OioServerSocketChannel
 
doRegister() - Method in class io.netty.channel.AbstractChannel
Is called after the Channel is registered with its EventLoop as part of the register process.
doRegister() - Method in class io.netty.channel.embedded.EmbeddedChannel
 
doRegister() - Method in class io.netty.channel.local.LocalChannel
 
doRegister() - Method in class io.netty.channel.local.LocalServerChannel
 
doRegister() - Method in class io.netty.channel.nio.AbstractNioChannel
 
doResolve(T, Promise<T>) - Method in class io.netty.resolver.AbstractAddressResolver
Invoked by AbstractAddressResolver.resolve(SocketAddress) to perform the actual name resolution.
doResolve(String, Promise<T>) - Method in class io.netty.resolver.CompositeNameResolver
 
doResolve(String, Promise<InetAddress>) - Method in class io.netty.resolver.DefaultNameResolver
 
doResolve(String, Promise<InetAddress>) - Method in class io.netty.resolver.dns.DnsNameResolver
 
doResolve(String, DnsRecord[], Promise<InetAddress>, DnsCache) - Method in class io.netty.resolver.dns.DnsNameResolver
Hook designed for extensibility so one can pass a different cache on each resolution attempt instead of using the global one.
doResolve(InetSocketAddress, Promise<InetSocketAddress>) - Method in class io.netty.resolver.InetSocketAddressResolver
 
doResolve(SocketAddress, Promise<SocketAddress>) - Method in class io.netty.resolver.NoopAddressResolver
 
doResolve(String, Promise<InetAddress>) - Method in class io.netty.resolver.RoundRobinInetAddressResolver
 
doResolve(String, Promise<T>) - Method in class io.netty.resolver.SimpleNameResolver
Invoked by SimpleNameResolver.resolve(String) to perform the actual name resolution.
doResolveAll(T, Promise<List<T>>) - Method in class io.netty.resolver.AbstractAddressResolver
Invoked by AbstractAddressResolver.resolveAll(SocketAddress) to perform the actual name resolution.
doResolveAll(String, Promise<List<T>>) - Method in class io.netty.resolver.CompositeNameResolver
 
doResolveAll(String, Promise<List<InetAddress>>) - Method in class io.netty.resolver.DefaultNameResolver
 
doResolveAll(String, Promise<List<InetAddress>>) - Method in class io.netty.resolver.dns.DnsNameResolver
 
doResolveAll(String, DnsRecord[], Promise<List<InetAddress>>, DnsCache) - Method in class io.netty.resolver.dns.DnsNameResolver
Hook designed for extensibility so one can pass a different cache on each resolution attempt instead of using the global one.
doResolveAll(InetSocketAddress, Promise<List<InetSocketAddress>>) - Method in class io.netty.resolver.InetSocketAddressResolver
 
doResolveAll(SocketAddress, Promise<List<SocketAddress>>) - Method in class io.netty.resolver.NoopAddressResolver
 
doResolveAll(String, Promise<List<InetAddress>>) - Method in class io.netty.resolver.RoundRobinInetAddressResolver
 
doResolveAll(String, Promise<List<T>>) - Method in class io.netty.resolver.SimpleNameResolver
Invoked by SimpleNameResolver.resolveAll(String) to perform the actual name resolution.
DOUBLE_QUOTE - Static variable in class io.netty.util.internal.StringUtil
 
doWrite(ChannelOutboundBuffer) - Method in class io.netty.channel.AbstractChannel
Flush the content of the given buffer to the remote peer.
doWrite(ChannelOutboundBuffer) - Method in class io.netty.channel.AbstractServerChannel
 
doWrite(ChannelOutboundBuffer) - Method in class io.netty.channel.embedded.EmbeddedChannel
 
doWrite(ChannelOutboundBuffer) - Method in class io.netty.channel.epoll.AbstractEpollServerChannel
 
doWrite(ChannelOutboundBuffer) - Method in class io.netty.channel.epoll.AbstractEpollStreamChannel
 
doWrite(ChannelOutboundBuffer) - Method in class io.netty.channel.epoll.EpollDatagramChannel
 
doWrite(ChannelOutboundBuffer) - Method in class io.netty.channel.kqueue.AbstractKQueueServerChannel
 
doWrite(ChannelOutboundBuffer) - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel
 
doWrite(ChannelOutboundBuffer) - Method in class io.netty.channel.kqueue.KQueueDatagramChannel
 
doWrite(ChannelOutboundBuffer) - Method in class io.netty.channel.local.LocalChannel
 
doWrite(ChannelOutboundBuffer) - Method in class io.netty.channel.nio.AbstractNioByteChannel
 
doWrite(ChannelOutboundBuffer) - Method in class io.netty.channel.nio.AbstractNioMessageChannel
 
doWrite(ChannelOutboundBuffer) - Method in class io.netty.channel.oio.AbstractOioByteChannel
 
doWrite(ChannelOutboundBuffer) - Method in class io.netty.channel.socket.nio.NioSocketChannel
 
doWrite(ChannelOutboundBuffer) - Method in class io.netty.channel.socket.oio.OioDatagramChannel
 
doWrite(ChannelOutboundBuffer) - Method in class io.netty.channel.socket.oio.OioServerSocketChannel
 
doWriteBytes(ByteBuf) - Method in class io.netty.channel.nio.AbstractNioByteChannel
Write bytes form the given ByteBuf to the underlying Channel.
doWriteBytes(ByteBuf) - Method in class io.netty.channel.oio.AbstractOioByteChannel
Write the data which is hold by the ByteBuf to the underlying Socket.
doWriteBytes(ByteBuf) - Method in class io.netty.channel.oio.OioByteStreamChannel
 
doWriteBytes(ByteBuf) - Method in class io.netty.channel.socket.nio.NioSocketChannel
 
doWriteFileRegion(FileRegion) - Method in class io.netty.channel.nio.AbstractNioByteChannel
Write a FileRegion
doWriteFileRegion(FileRegion) - Method in class io.netty.channel.oio.AbstractOioByteChannel
Write the data which is hold by the FileRegion to the underlying Socket.
doWriteFileRegion(FileRegion) - Method in class io.netty.channel.oio.OioByteStreamChannel
 
doWriteFileRegion(FileRegion) - Method in class io.netty.channel.socket.nio.NioSocketChannel
 
doWriteMessage(Object, ChannelOutboundBuffer) - Method in class io.netty.channel.nio.AbstractNioMessageChannel
Write a message to the underlying Channel.
doWriteMessage(Object, ChannelOutboundBuffer) - Method in class io.netty.channel.socket.nio.NioDatagramChannel
 
doWriteMessage(Object, ChannelOutboundBuffer) - Method in class io.netty.channel.socket.nio.NioServerSocketChannel
 
doWriteSingle(ChannelOutboundBuffer, int) - Method in class io.netty.channel.epoll.AbstractEpollStreamChannel
 
doWriteSingle(ChannelOutboundBuffer, int) - Method in class io.netty.channel.epoll.EpollDomainSocketChannel
 
doWriteSingle(ChannelOutboundBuffer, int) - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel
 
doWriteSingle(ChannelOutboundBuffer, int) - Method in class io.netty.channel.kqueue.KQueueDomainSocketChannel
 
DS - Static variable in class io.netty.handler.codec.dns.DnsRecordType
Delegation signer record RFC 4034 The record used to identify the DNSSEC signing key of a delegated zone.
dumpStats() - Method in class io.netty.buffer.PooledByteBufAllocator
Returns the status of the allocator (which contains all metrics) as string.
DuplexChannel - Interface in io.netty.channel.socket
A duplex Channel that has two sides that can be shutdown independently.
duplicate() - Method in class io.netty.buffer.AbstractByteBuf
 
duplicate() - Method in class io.netty.buffer.ByteBuf
Returns a buffer which shares the whole region of this buffer.
duplicate() - Method in interface io.netty.buffer.ByteBufHolder
Duplicates this ByteBufHolder.
duplicate() - Method in class io.netty.buffer.DefaultByteBufHolder
Duplicates this ByteBufHolder.
duplicate() - Method in class io.netty.buffer.EmptyByteBuf
 
duplicate() - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
duplicate() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
duplicate() - Method in class io.netty.channel.socket.DatagramPacket
 
duplicate() - Method in class io.netty.handler.codec.dns.DefaultDnsRawRecord
 
duplicate() - Method in interface io.netty.handler.codec.dns.DnsRawRecord
 
duplicate() - Method in class io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheRequest
 
duplicate() - Method in class io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheResponse
 
duplicate() - Method in interface io.netty.handler.codec.memcache.binary.FullBinaryMemcacheRequest
 
duplicate() - Method in interface io.netty.handler.codec.memcache.binary.FullBinaryMemcacheResponse
 
duplicate() - Method in class io.netty.handler.codec.memcache.DefaultLastMemcacheContent
 
duplicate() - Method in class io.netty.handler.codec.memcache.DefaultMemcacheContent
 
duplicate() - Method in interface io.netty.handler.codec.memcache.FullMemcacheMessage
 
duplicate() - Method in interface io.netty.handler.codec.memcache.LastMemcacheContent
 
duplicate() - Method in interface io.netty.handler.codec.memcache.MemcacheContent
 
duplicate() - Method in class io.netty.handler.codec.mqtt.MqttPublishMessage
 
duplicate() - Method in interface io.netty.handler.codec.redis.BulkStringRedisContent
 
duplicate() - Method in class io.netty.handler.codec.redis.DefaultBulkStringRedisContent
 
duplicate() - Method in class io.netty.handler.codec.redis.DefaultLastBulkStringRedisContent
 
duplicate() - Method in class io.netty.handler.codec.redis.FullBulkStringRedisMessage
 
duplicate() - Method in interface io.netty.handler.codec.redis.LastBulkStringRedisContent
 
duplicate() - Method in class io.netty.handler.codec.smtp.DefaultLastSmtpContent
 
duplicate() - Method in class io.netty.handler.codec.smtp.DefaultSmtpContent
 
duplicate() - Method in interface io.netty.handler.codec.smtp.LastSmtpContent
 
duplicate() - Method in interface io.netty.handler.codec.smtp.SmtpContent
 
duplicate() - Method in class io.netty.handler.codec.stomp.DefaultLastStompContentSubframe
 
duplicate() - Method in class io.netty.handler.codec.stomp.DefaultStompContentSubframe
 
duplicate() - Method in class io.netty.handler.codec.stomp.DefaultStompFrame
 
duplicate() - Method in interface io.netty.handler.codec.stomp.LastStompContentSubframe
 
duplicate() - Method in interface io.netty.handler.codec.stomp.StompContentSubframe
 
duplicate() - Method in interface io.netty.handler.codec.stomp.StompFrame
 
duplicate() - Method in class io.netty.handler.ssl.PemPrivateKey
 
duplicate() - Method in class io.netty.handler.ssl.PemX509Certificate
 
duplicate() - Method in interface io.netty.resolver.dns.DnsServerAddressStream
Duplicate this object.
DuplicatedByteBuf - Class in io.netty.buffer
Deprecated.
Do not use.
DuplicatedByteBuf(ByteBuf) - Constructor for class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 

E

E2BIG - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseStatus
 
EHLO - Static variable in class io.netty.handler.codec.smtp.SmtpCommand
 
ehlo(CharSequence) - Static method in class io.netty.handler.codec.smtp.SmtpRequests
Creates a EHLO request.
EINVA - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseStatus
 
element() - Method in class io.netty.util.internal.EmptyPriorityQueue
 
elementSize() - Method in interface io.netty.buffer.PoolSubpageMetric
Return the size (in bytes) of the elements that will be allocated.
EmbeddedChannel - Class in io.netty.channel.embedded
Base class for Channel implementations that are used in an embedded fashion.
EmbeddedChannel() - Constructor for class io.netty.channel.embedded.EmbeddedChannel
Create a new instance with an EmbeddedChannelId and an empty pipeline.
EmbeddedChannel(ChannelId) - Constructor for class io.netty.channel.embedded.EmbeddedChannel
Create a new instance with the specified ID and an empty pipeline.
EmbeddedChannel(ChannelHandler...) - Constructor for class io.netty.channel.embedded.EmbeddedChannel
Create a new instance with the pipeline initialized with the specified handlers.
EmbeddedChannel(boolean, ChannelHandler...) - Constructor for class io.netty.channel.embedded.EmbeddedChannel
Create a new instance with the pipeline initialized with the specified handlers.
EmbeddedChannel(ChannelId, ChannelHandler...) - Constructor for class io.netty.channel.embedded.EmbeddedChannel
Create a new instance with the channel ID set to the given ID and the pipeline initialized with the specified handlers.
EmbeddedChannel(ChannelId, boolean, ChannelHandler...) - Constructor for class io.netty.channel.embedded.EmbeddedChannel
Create a new instance with the channel ID set to the given ID and the pipeline initialized with the specified handlers.
EmbeddedChannel(ChannelId, boolean, ChannelConfig, ChannelHandler...) - Constructor for class io.netty.channel.embedded.EmbeddedChannel
Create a new instance with the channel ID set to the given ID and the pipeline initialized with the specified handlers.
EMPTY_ASCII_STRINGS - Static variable in class io.netty.util.internal.EmptyArrays
 
EMPTY_BUFFER - Static variable in class io.netty.buffer.Unpooled
A buffer whose capacity is 0.
EMPTY_BYTE_BUFFERS - Static variable in class io.netty.util.internal.EmptyArrays
 
EMPTY_BYTES - Static variable in class io.netty.util.internal.EmptyArrays
 
EMPTY_CERTIFICATES - Static variable in class io.netty.util.internal.EmptyArrays
 
EMPTY_CHARS - Static variable in class io.netty.util.internal.EmptyArrays
 
EMPTY_CLASSES - Static variable in class io.netty.util.internal.EmptyArrays
 
EMPTY_INSTANCE - Static variable in class io.netty.handler.codec.redis.ArrayRedisMessage
A predefined empty array instance for ArrayRedisMessage.
EMPTY_INSTANCE - Static variable in class io.netty.handler.codec.redis.FullBulkStringRedisMessage
A predefined empty instance of FullBulkStringRedisMessage.
EMPTY_INTS - Static variable in class io.netty.util.internal.EmptyArrays
 
EMPTY_JAVAX_X509_CERTIFICATES - Static variable in class io.netty.util.internal.EmptyArrays
 
EMPTY_LAST_CONTENT - Static variable in interface io.netty.handler.codec.memcache.LastMemcacheContent
 
EMPTY_LAST_CONTENT - Static variable in interface io.netty.handler.codec.redis.LastBulkStringRedisContent
The 'end of content' marker in chunked encoding.
EMPTY_LAST_CONTENT - Static variable in interface io.netty.handler.codec.smtp.LastSmtpContent
EMPTY_LAST_CONTENT - Static variable in interface io.netty.handler.codec.stomp.LastStompContentSubframe
 
EMPTY_OBJECTS - Static variable in class io.netty.util.internal.EmptyArrays
 
EMPTY_STACK_TRACE - Static variable in class io.netty.util.internal.EmptyArrays
 
EMPTY_STRING - Static variable in class io.netty.util.AsciiString
 
EMPTY_STRING - Static variable in class io.netty.util.internal.StringUtil
 
EMPTY_STRINGS - Static variable in class io.netty.util.internal.EmptyArrays
 
EMPTY_X509_CERTIFICATES - Static variable in class io.netty.util.internal.EmptyArrays
 
EmptyArrays - Class in io.netty.util.internal
 
EmptyByteBuf - Class in io.netty.buffer
An empty ByteBuf whose capacity and maximum capacity are all 0.
EmptyByteBuf(ByteBufAllocator) - Constructor for class io.netty.buffer.EmptyByteBuf
 
EmptyHeaders<K,V,T extends Headers<K,V,T>> - Class in io.netty.handler.codec
 
EmptyHeaders() - Constructor for class io.netty.handler.codec.EmptyHeaders
 
emptyMap() - Static method in class io.netty.util.collection.ByteCollections
Returns an unmodifiable empty ByteObjectMap.
emptyMap() - Static method in class io.netty.util.collection.CharCollections
Returns an unmodifiable empty CharObjectMap.
emptyMap() - Static method in class io.netty.util.collection.IntCollections
Returns an unmodifiable empty IntObjectMap.
emptyMap() - Static method in class io.netty.util.collection.LongCollections
Returns an unmodifiable empty LongObjectMap.
emptyMap() - Static method in class io.netty.util.collection.ShortCollections
Returns an unmodifiable empty ShortObjectMap.
EmptyPriorityQueue<T> - Class in io.netty.util.internal
 
enableOcsp(boolean) - Method in class io.netty.handler.ssl.SslContextBuilder
Enables OCSP stapling.
encode(Map.Entry<CharSequence, CharSequence>) - Method in class io.netty.handler.codec.AsciiHeadersEncoder
 
encode(ByteBuf) - Static method in class io.netty.handler.codec.base64.Base64
 
encode(ByteBuf, Base64Dialect) - Static method in class io.netty.handler.codec.base64.Base64
 
encode(ByteBuf, boolean) - Static method in class io.netty.handler.codec.base64.Base64
 
encode(ByteBuf, boolean, Base64Dialect) - Static method in class io.netty.handler.codec.base64.Base64
 
encode(ByteBuf, int, int) - Static method in class io.netty.handler.codec.base64.Base64
 
encode(ByteBuf, int, int, Base64Dialect) - Static method in class io.netty.handler.codec.base64.Base64
 
encode(ByteBuf, int, int, boolean) - Static method in class io.netty.handler.codec.base64.Base64
 
encode(ByteBuf, int, int, boolean, Base64Dialect) - Static method in class io.netty.handler.codec.base64.Base64
 
encode(ByteBuf, int, int, boolean, Base64Dialect, ByteBufAllocator) - Static method in class io.netty.handler.codec.base64.Base64
 
encode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.base64.Base64Encoder
 
encode(ChannelHandlerContext, byte[], List<Object>) - Method in class io.netty.handler.codec.bytes.ByteArrayEncoder
 
encode(ChannelHandlerContext, I, ByteBuf) - Method in class io.netty.handler.codec.ByteToMessageCodec
 
encode(ChannelHandlerContext, ByteBuf, ByteBuf) - Method in class io.netty.handler.codec.compression.Bzip2Encoder
 
encode(ChannelHandlerContext, ByteBuf, ByteBuf) - Method in class io.netty.handler.codec.compression.FastLzFrameEncoder
 
encode(ChannelHandlerContext, ByteBuf, ByteBuf) - Method in class io.netty.handler.codec.compression.JdkZlibEncoder
 
encode(ChannelHandlerContext, ByteBuf, ByteBuf) - Method in class io.netty.handler.codec.compression.JZlibEncoder
 
encode(ByteBuf, ByteBuf, int) - Method in class io.netty.handler.codec.compression.Snappy
 
encode(ChannelHandlerContext, ByteBuf, ByteBuf) - Method in class io.netty.handler.codec.compression.SnappyFrameEncoder
 
encode(ChannelHandlerContext, AddressedEnvelope<M, InetSocketAddress>, List<Object>) - Method in class io.netty.handler.codec.DatagramPacketEncoder
 
encode(ChannelHandlerContext, AddressedEnvelope<DnsQuery, InetSocketAddress>, List<Object>) - Method in class io.netty.handler.codec.dns.DatagramDnsQueryEncoder
 
encode(ChannelHandlerContext, AddressedEnvelope<DnsResponse, InetSocketAddress>, List<Object>) - Method in class io.netty.handler.codec.dns.DatagramDnsResponseEncoder
 
encode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.LengthFieldPrepender
 
encode(ChannelHandlerContext, Object, List<Object>) - Method in class io.netty.handler.codec.memcache.AbstractMemcacheObjectEncoder
 
encode(ChannelHandlerContext, I, ByteBuf) - Method in class io.netty.handler.codec.MessageToByteEncoder
Encode a message into a ByteBuf.
encode(ChannelHandlerContext, OUTBOUND_IN, List<Object>) - Method in class io.netty.handler.codec.MessageToMessageCodec
 
encode(ChannelHandlerContext, I, List<Object>) - Method in class io.netty.handler.codec.MessageToMessageEncoder
Encode from one message to an other.
encode(ChannelHandlerContext, MqttMessage, List<Object>) - Method in class io.netty.handler.codec.mqtt.MqttEncoder
 
encode(ChannelHandlerContext, RedisMessage, List<Object>) - Method in class io.netty.handler.codec.redis.RedisEncoder
 
encode(ChannelHandlerContext, Serializable, ByteBuf) - Method in class io.netty.handler.codec.serialization.CompatibleObjectEncoder
 
encode(ChannelHandlerContext, Serializable, ByteBuf) - Method in class io.netty.handler.codec.serialization.ObjectEncoder
 
encode(ChannelHandlerContext, Object, List<Object>) - Method in class io.netty.handler.codec.smtp.SmtpRequestEncoder
 
encode(ChannelHandlerContext, StompSubframe, List<Object>) - Method in class io.netty.handler.codec.stomp.StompSubframeEncoder
 
encode(ChannelHandlerContext, CharSequence, List<Object>) - Method in class io.netty.handler.codec.string.LineEncoder
 
encode(ChannelHandlerContext, CharSequence, List<Object>) - Method in class io.netty.handler.codec.string.StringEncoder
 
encodeHeader(ByteBuf, M) - Method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheEncoder
Encode the header.
encodeHeader(ByteBuf, BinaryMemcacheRequest) - Method in class io.netty.handler.codec.memcache.binary.BinaryMemcacheRequestEncoder
 
encodeHeader(ByteBuf, BinaryMemcacheResponse) - Method in class io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseEncoder
 
encodeMessage(ChannelHandlerContext, M) - Method in class io.netty.handler.codec.memcache.AbstractMemcacheObjectEncoder
Take the given MemcacheMessage and encode it into a writable ByteBuf.
encodeMessage(ChannelHandlerContext, M) - Method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheEncoder
 
encodeName(String, ByteBuf) - Method in class io.netty.handler.codec.dns.DefaultDnsRecordEncoder
 
encodeQuestion(DnsQuestion, ByteBuf) - Method in class io.netty.handler.codec.dns.DefaultDnsRecordEncoder
 
encodeQuestion(DnsQuestion, ByteBuf) - Method in interface io.netty.handler.codec.dns.DnsRecordEncoder
Encodes a DnsQuestion.
encoder(Charset, CodingErrorAction, CodingErrorAction) - Static method in class io.netty.util.CharsetUtil
Returns a new CharsetEncoder for the Charset with specified error actions.
encoder(Charset, CodingErrorAction) - Static method in class io.netty.util.CharsetUtil
Returns a new CharsetEncoder for the Charset with the specified error action.
encoder(Charset) - Static method in class io.netty.util.CharsetUtil
Returns a cached thread-local CharsetEncoder for the specified Charset.
encodeRecord(DnsRecord, ByteBuf) - Method in class io.netty.handler.codec.dns.DefaultDnsRecordEncoder
 
encodeRecord(DnsRecord, ByteBuf) - Method in interface io.netty.handler.codec.dns.DnsRecordEncoder
Encodes a DnsRecord.
EncoderException - Exception in io.netty.handler.codec
An CodecException which is thrown by an encoder.
EncoderException() - Constructor for exception io.netty.handler.codec.EncoderException
Creates a new instance.
EncoderException(String, Throwable) - Constructor for exception io.netty.handler.codec.EncoderException
Creates a new instance.
EncoderException(String) - Constructor for exception io.netty.handler.codec.EncoderException
Creates a new instance.
EncoderException(Throwable) - Constructor for exception io.netty.handler.codec.EncoderException
Creates a new instance.
encodeString(ByteBufAllocator, CharBuffer, Charset) - Static method in class io.netty.buffer.ByteBufUtil
Encode the given CharBuffer using the given Charset into a new ByteBuf which is allocated via the ByteBufAllocator.
encodeString(ByteBufAllocator, CharBuffer, Charset, int) - Static method in class io.netty.buffer.ByteBufUtil
Encode the given CharBuffer using the given Charset into a new ByteBuf which is allocated via the ByteBufAllocator.
endOffset() - Method in class io.netty.handler.stream.ChunkedFile
Returns the offset in the file where the transfer will end.
endOffset() - Method in class io.netty.handler.stream.ChunkedNioFile
Returns the offset in the file where the transfer will end.
endsWith(CharSequence) - Method in class io.netty.util.AsciiString
Compares the specified string to this string to determine if the specified string is a suffix.
endsWith(CharSequence, char) - Static method in class io.netty.util.internal.StringUtil
Determine if the string s ends with the char c.
engine() - Method in class io.netty.handler.ssl.SslHandler
Returns the SSLEngine which is used by this handler.
engineGetTrustManagers() - Method in class io.netty.handler.ssl.util.FingerprintTrustManagerFactory
 
engineGetTrustManagers() - Method in class io.netty.handler.ssl.util.InsecureTrustManagerFactory
 
engineGetTrustManagers() - Method in class io.netty.handler.ssl.util.SimpleTrustManagerFactory
Returns one trust manager for each type of trust material.
engineInit(KeyStore) - Method in class io.netty.handler.ssl.util.FingerprintTrustManagerFactory
 
engineInit(ManagerFactoryParameters) - Method in class io.netty.handler.ssl.util.FingerprintTrustManagerFactory
 
engineInit(KeyStore) - Method in class io.netty.handler.ssl.util.InsecureTrustManagerFactory
 
engineInit(ManagerFactoryParameters) - Method in class io.netty.handler.ssl.util.InsecureTrustManagerFactory
 
engineInit(KeyStore) - Method in class io.netty.handler.ssl.util.SimpleTrustManagerFactory
Initializes this factory with a source of certificate authorities and related trust material.
engineInit(ManagerFactoryParameters) - Method in class io.netty.handler.ssl.util.SimpleTrustManagerFactory
Initializes this factory with a source of provider-specific key material.
ENOMEM - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseStatus
 
ensureAccessible() - Method in class io.netty.buffer.AbstractByteBuf
Should be called by every method that tries to access the buffers content to check if the buffer was released before.
ensureAvailability() - Static method in class io.netty.channel.epoll.Epoll
Ensure that netty-transport-native-epoll is available.
ensureAvailability() - Static method in class io.netty.channel.kqueue.KQueue
Ensure that netty-transport-native-kqueue is available.
ensureNotSharable() - Method in class io.netty.channel.ChannelHandlerAdapter
ensureOpen(ChannelPromise) - Method in class io.netty.channel.AbstractChannel.AbstractUnsafe
 
ensureOpen() - Method in class io.netty.channel.embedded.EmbeddedChannel
Ensure the Channel is open and if not throw an exception.
ensureWritable(int) - Method in class io.netty.buffer.AbstractByteBuf
 
ensureWritable(int, boolean) - Method in class io.netty.buffer.AbstractByteBuf
 
ensureWritable(int) - Method in class io.netty.buffer.ByteBuf
Makes sure the number of the writable bytes is equal to or greater than the specified value.
ensureWritable(int, boolean) - Method in class io.netty.buffer.ByteBuf
Tries to make sure the number of the writable bytes is equal to or greater than the specified value.
ensureWritable(int) - Method in class io.netty.buffer.CompositeByteBuf
 
ensureWritable(int) - Method in class io.netty.buffer.EmptyByteBuf
 
ensureWritable(int, boolean) - Method in class io.netty.buffer.EmptyByteBuf
 
ensureWritable(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
ensureWritable(int, boolean) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
entries() - Method in class io.netty.util.collection.ByteObjectHashMap
 
entries() - Method in interface io.netty.util.collection.ByteObjectMap
Gets an iterable to traverse over the primitive entries contained in this map.
entries() - Method in class io.netty.util.collection.CharObjectHashMap
 
entries() - Method in interface io.netty.util.collection.CharObjectMap
Gets an iterable to traverse over the primitive entries contained in this map.
entries() - Method in class io.netty.util.collection.IntObjectHashMap
 
entries() - Method in interface io.netty.util.collection.IntObjectMap
Gets an iterable to traverse over the primitive entries contained in this map.
entries() - Method in class io.netty.util.collection.LongObjectHashMap
 
entries() - Method in interface io.netty.util.collection.LongObjectMap
Gets an iterable to traverse over the primitive entries contained in this map.
entries() - Method in class io.netty.util.collection.ShortObjectHashMap
 
entries() - Method in interface io.netty.util.collection.ShortObjectMap
Gets an iterable to traverse over the primitive entries contained in this map.
entrySet() - Method in class io.netty.util.collection.ByteObjectHashMap
 
entrySet() - Method in class io.netty.util.collection.CharObjectHashMap
 
entrySet() - Method in class io.netty.util.collection.IntObjectHashMap
 
entrySet() - Method in class io.netty.util.collection.LongObjectHashMap
 
entrySet() - Method in class io.netty.util.collection.ShortObjectHashMap
 
Epoll - Class in io.netty.channel.epoll
Tells if netty-transport-native-epoll is supported.
EPOLL_MODE - Static variable in class io.netty.channel.epoll.EpollChannelOption
 
EpollChannelConfig - Class in io.netty.channel.epoll
 
EpollChannelOption<T> - Class in io.netty.channel.epoll
 
epollCtlAdd(int, int, int) - Static method in class io.netty.channel.epoll.Native
 
epollCtlDel(int, int) - Static method in class io.netty.channel.epoll.Native
 
epollCtlMod(int, int, int) - Static method in class io.netty.channel.epoll.Native
 
EpollDatagramChannel - Class in io.netty.channel.epoll
DatagramChannel implementation that uses linux EPOLL Edge-Triggered Mode for maximal performance.
EpollDatagramChannel() - Constructor for class io.netty.channel.epoll.EpollDatagramChannel
 
EpollDatagramChannel(int) - Constructor for class io.netty.channel.epoll.EpollDatagramChannel
 
EpollDatagramChannelConfig - Class in io.netty.channel.epoll
 
EpollDomainSocketChannel - Class in io.netty.channel.epoll
 
EpollDomainSocketChannel() - Constructor for class io.netty.channel.epoll.EpollDomainSocketChannel
 
EpollDomainSocketChannel(int) - Constructor for class io.netty.channel.epoll.EpollDomainSocketChannel
 
EpollDomainSocketChannel(Channel, LinuxSocket) - Constructor for class io.netty.channel.epoll.EpollDomainSocketChannel
 
EpollDomainSocketChannel(int, boolean) - Constructor for class io.netty.channel.epoll.EpollDomainSocketChannel
 
EpollDomainSocketChannelConfig - Class in io.netty.channel.epoll
 
EPOLLERR - Static variable in class io.netty.channel.epoll.Native
 
EPOLLET - Static variable in class io.netty.channel.epoll.Native
 
EpollEventLoopGroup - Class in io.netty.channel.epoll
EventLoopGroup which uses epoll under the covers.
EpollEventLoopGroup() - Constructor for class io.netty.channel.epoll.EpollEventLoopGroup
Create a new instance using the default number of threads and the default ThreadFactory.
EpollEventLoopGroup(int) - Constructor for class io.netty.channel.epoll.EpollEventLoopGroup
Create a new instance using the specified number of threads and the default ThreadFactory.
EpollEventLoopGroup(int, SelectStrategyFactory) - Constructor for class io.netty.channel.epoll.EpollEventLoopGroup
Create a new instance using the specified number of threads and the default ThreadFactory.
EpollEventLoopGroup(int, ThreadFactory) - Constructor for class io.netty.channel.epoll.EpollEventLoopGroup
Create a new instance using the specified number of threads and the given ThreadFactory.
EpollEventLoopGroup(int, Executor) - Constructor for class io.netty.channel.epoll.EpollEventLoopGroup
 
EpollEventLoopGroup(int, ThreadFactory, SelectStrategyFactory) - Constructor for class io.netty.channel.epoll.EpollEventLoopGroup
Create a new instance using the specified number of threads and the given ThreadFactory.
EpollEventLoopGroup(int, ThreadFactory, int) - Constructor for class io.netty.channel.epoll.EpollEventLoopGroup
EpollEventLoopGroup(int, ThreadFactory, int, SelectStrategyFactory) - Constructor for class io.netty.channel.epoll.EpollEventLoopGroup
EpollEventLoopGroup(int, Executor, SelectStrategyFactory) - Constructor for class io.netty.channel.epoll.EpollEventLoopGroup
 
EpollEventLoopGroup(int, Executor, EventExecutorChooserFactory, SelectStrategyFactory) - Constructor for class io.netty.channel.epoll.EpollEventLoopGroup
 
EpollEventLoopGroup(int, Executor, EventExecutorChooserFactory, SelectStrategyFactory, RejectedExecutionHandler) - Constructor for class io.netty.channel.epoll.EpollEventLoopGroup
 
EPOLLIN - Static variable in class io.netty.channel.epoll.Native
 
EpollMode - Enum in io.netty.channel.epoll
The epoll mode to use.
EPOLLOUT - Static variable in class io.netty.channel.epoll.Native
 
EPOLLRDHUP - Static variable in class io.netty.channel.epoll.Native
 
EpollServerChannelConfig - Class in io.netty.channel.epoll
 
EpollServerDomainSocketChannel - Class in io.netty.channel.epoll
 
EpollServerDomainSocketChannel() - Constructor for class io.netty.channel.epoll.EpollServerDomainSocketChannel
 
EpollServerDomainSocketChannel(int) - Constructor for class io.netty.channel.epoll.EpollServerDomainSocketChannel
 
EpollServerSocketChannel - Class in io.netty.channel.epoll
ServerSocketChannel implementation that uses linux EPOLL Edge-Triggered Mode for maximal performance.
EpollServerSocketChannel() - Constructor for class io.netty.channel.epoll.EpollServerSocketChannel
 
EpollServerSocketChannel(int) - Constructor for class io.netty.channel.epoll.EpollServerSocketChannel
 
EpollServerSocketChannelConfig - Class in io.netty.channel.epoll
 
EpollSocketChannel - Class in io.netty.channel.epoll
SocketChannel implementation that uses linux EPOLL Edge-Triggered Mode for maximal performance.
EpollSocketChannel() - Constructor for class io.netty.channel.epoll.EpollSocketChannel
 
EpollSocketChannel(int) - Constructor for class io.netty.channel.epoll.EpollSocketChannel
 
EpollSocketChannelConfig - Class in io.netty.channel.epoll
 
EpollTcpInfo - Class in io.netty.channel.epoll
struct tcp_info { __u8 tcpi_state; __u8 tcpi_ca_state; __u8 tcpi_retransmits; __u8 tcpi_probes; __u8 tcpi_backoff; __u8 tcpi_options; __u8 tcpi_snd_wscale : 4, tcpi_rcv_wscale : 4; __u32 tcpi_rto; __u32 tcpi_ato; __u32 tcpi_snd_mss; __u32 tcpi_rcv_mss; __u32 tcpi_unacked; __u32 tcpi_sacked; __u32 tcpi_lost; __u32 tcpi_retrans; __u32 tcpi_fackets; __u32 tcpi_last_data_sent; __u32 tcpi_last_ack_sent; __u32 tcpi_last_data_recv; __u32 tcpi_last_ack_recv; __u32 tcpi_pmtu; __u32 tcpi_rcv_ssthresh; __u32 tcpi_rtt; __u32 tcpi_rttvar; __u32 tcpi_snd_ssthresh; __u32 tcpi_snd_cwnd; __u32 tcpi_advmss; __u32 tcpi_reordering; __u32 tcpi_rcv_rtt; __u32 tcpi_rcv_space; __u32 tcpi_total_retrans; };
EpollTcpInfo() - Constructor for class io.netty.channel.epoll.EpollTcpInfo
 
epollWait(int, EpollEventArray, int) - Static method in class io.netty.channel.epoll.Native
 
equals(Object) - Method in class io.netty.buffer.AbstractByteBuf
 
equals(Object) - Method in class io.netty.buffer.ByteBuf
Determines if the content of the specified buffer is identical to the content of this array.
equals(ByteBuf, int, ByteBuf, int, int) - Static method in class io.netty.buffer.ByteBufUtil
Returns true if and only if the two specified buffers are identical to each other for length bytes starting at aStartIndex index for the a buffer and bStartIndex index for the b buffer.
equals(ByteBuf, ByteBuf) - Static method in class io.netty.buffer.ByteBufUtil
Returns true if and only if the two specified buffers are identical to each other as described in ByteBuf.equals(Object).
equals(Object) - Method in class io.netty.buffer.DefaultByteBufHolder
 
equals(Object) - Method in class io.netty.buffer.EmptyByteBuf
 
equals(Object) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
equals(Object) - Method in class io.netty.channel.AbstractChannel
Returns true if and only if the specified object is identical with this channel (i.e: this == o).
equals(Object) - Method in class io.netty.channel.DefaultChannelId
 
equals(Object) - Method in class io.netty.channel.group.DefaultChannelGroup
 
equals(Object) - Method in class io.netty.channel.kqueue.AcceptFilter
 
equals(Object) - Method in class io.netty.channel.local.LocalAddress
 
equals(Object) - Method in class io.netty.channel.unix.DomainSocketAddress
 
equals(Object) - Method in class io.netty.channel.unix.FileDescriptor
 
equals(Object) - Method in class io.netty.handler.codec.DefaultHeaders
 
equals(Headers<K, V, ?>, HashingStrategy<V>) - Method in class io.netty.handler.codec.DefaultHeaders
Test this object for equality against h2.
equals(Object) - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
 
equals(Object) - Method in class io.netty.handler.codec.dns.AbstractDnsRecord
 
equals(Object) - Method in class io.netty.handler.codec.dns.DatagramDnsQuery
 
equals(Object) - Method in class io.netty.handler.codec.dns.DatagramDnsResponse
 
equals(Object) - Method in class io.netty.handler.codec.dns.DnsOpCode
 
equals(Object) - Method in class io.netty.handler.codec.dns.DnsRecordType
 
equals(Object) - Method in class io.netty.handler.codec.dns.DnsResponseCode
Equality of DnsResponseCode only depends on DnsResponseCode.intValue().
equals(Object) - Method in class io.netty.handler.codec.EmptyHeaders
 
equals(Object) - Method in class io.netty.handler.codec.smtp.DefaultSmtpRequest
 
equals(Object) - Method in class io.netty.handler.codec.smtp.DefaultSmtpResponse
 
equals(Object) - Method in class io.netty.handler.codec.smtp.SmtpCommand
 
equals(Object) - Method in class io.netty.handler.codec.string.LineSeparator
 
equals(Object) - Method in class io.netty.handler.ssl.PemX509Certificate
 
equals(Object) - Method in class io.netty.util.AbstractConstant
 
equals(Object) - Method in class io.netty.util.AsciiString
 
equals(Object) - Method in class io.netty.util.collection.ByteObjectHashMap
 
equals(Object) - Method in class io.netty.util.collection.CharObjectHashMap
 
equals(Object) - Method in class io.netty.util.collection.IntObjectHashMap
 
equals(Object) - Method in class io.netty.util.collection.LongObjectHashMap
 
equals(Object) - Method in class io.netty.util.collection.ShortObjectHashMap
 
equals(T, T) - Method in interface io.netty.util.HashingStrategy
Returns true if the arguments are equal to each other and false otherwise.
equals(Object) - Method in class io.netty.util.internal.EmptyPriorityQueue
 
equals(byte[], int, byte[], int, int) - Static method in class io.netty.util.internal.PlatformDependent
Compare two byte arrays for equality.
equals(Object) - Method in exception io.netty.util.ResourceLeakException
Deprecated.
 
equals(Object) - Method in error io.netty.util.Signal
 
equalsConstantTime(int, int) - Static method in class io.netty.util.internal.ConstantTimeUtils
Compare two ints without leaking timing information.
equalsConstantTime(long, long) - Static method in class io.netty.util.internal.ConstantTimeUtils
Compare two longss without leaking timing information.
equalsConstantTime(byte[], int, byte[], int, int) - Static method in class io.netty.util.internal.ConstantTimeUtils
Compare two byte arrays for equality without leaking timing information.
equalsConstantTime(CharSequence, CharSequence) - Static method in class io.netty.util.internal.ConstantTimeUtils
Compare two CharSequence objects without leaking timing information.
equalsConstantTime(byte[], int, byte[], int, int) - Static method in class io.netty.util.internal.PlatformDependent
Compare two byte arrays for equality without leaking timing information.
ERRNO_EAGAIN_NEGATIVE - Static variable in class io.netty.channel.unix.Errors
 
ERRNO_EBADF_NEGATIVE - Static variable in class io.netty.channel.unix.Errors
 
ERRNO_ECONNRESET_NEGATIVE - Static variable in class io.netty.channel.unix.Errors
 
ERRNO_EINPROGRESS_NEGATIVE - Static variable in class io.netty.channel.unix.Errors
 
ERRNO_ENOTCONN_NEGATIVE - Static variable in class io.netty.channel.unix.Errors
 
ERRNO_EPIPE_NEGATIVE - Static variable in class io.netty.channel.unix.Errors
 
ERRNO_EWOULDBLOCK_NEGATIVE - Static variable in class io.netty.channel.unix.Errors
 
error(Throwable) - Method in class io.netty.util.internal.logging.AbstractInternalLogger
 
error(String) - Method in interface io.netty.util.internal.logging.InternalLogger
Log a message at the ERROR level.
error(String, Object) - Method in interface io.netty.util.internal.logging.InternalLogger
Log a message at the ERROR level according to the specified format and argument.
error(String, Object, Object) - Method in interface io.netty.util.internal.logging.InternalLogger
Log a message at the ERROR level according to the specified format and arguments.
error(String, Object...) - Method in interface io.netty.util.internal.logging.InternalLogger
Log a message at the ERROR level according to the specified format and arguments.
error(String, Throwable) - Method in interface io.netty.util.internal.logging.InternalLogger
Log an exception (throwable) at the ERROR level with an accompanying message.
error(Throwable) - Method in interface io.netty.util.internal.logging.InternalLogger
Log an exception (throwable) at the ERROR level.
ERROR_EALREADY_NEGATIVE - Static variable in class io.netty.channel.unix.Errors
 
ERROR_ECONNREFUSED_NEGATIVE - Static variable in class io.netty.channel.unix.Errors
 
ERROR_EISCONN_NEGATIVE - Static variable in class io.netty.channel.unix.Errors
 
ERROR_ENETUNREACH_NEGATIVE - Static variable in class io.netty.channel.unix.Errors
 
ErrorRedisMessage - Class in io.netty.handler.codec.redis
Errors of RESP.
ErrorRedisMessage(String) - Constructor for class io.netty.handler.codec.redis.ErrorRedisMessage
Creates a ErrorRedisMessage from content.
Errors - Class in io.netty.channel.unix
Internal usage only!
Errors.NativeIoException - Exception in io.netty.channel.unix
Internal usage only!
escapeCsv(CharSequence) - Static method in class io.netty.util.internal.StringUtil
Escapes the specified value, if necessary according to RFC-4180.
escapeCsv(CharSequence, boolean) - Static method in class io.netty.util.internal.StringUtil
Escapes the specified value, if necessary according to RFC-4180.
EventExecutor - Interface in io.netty.util.concurrent
The EventExecutor is a special EventExecutorGroup which comes with some handy methods to see if a Thread is executed in a event loop.
EventExecutorChooserFactory - Interface in io.netty.util.concurrent
EventExecutorChooserFactory.EventExecutorChooser - Interface in io.netty.util.concurrent
Chooses the next EventExecutor to use.
EventExecutorGroup - Interface in io.netty.util.concurrent
The EventExecutorGroup is responsible for providing the EventExecutor's to use via its EventExecutorGroup.next() method.
eventFdRead(int) - Static method in class io.netty.channel.epoll.Native
 
eventFdWrite(int, long) - Static method in class io.netty.channel.epoll.Native
 
eventLoop() - Method in class io.netty.channel.AbstractChannel
 
eventLoop() - Method in interface io.netty.channel.Channel
Return the EventLoop this Channel was registered to.
EventLoop - Interface in io.netty.channel
Will handle all the I/O operations for a Channel once registered.
eventLoop() - Method in class io.netty.channel.nio.AbstractNioChannel
 
EventLoopException - Exception in io.netty.channel
Special ChannelException which will be thrown by EventLoop and EventLoopGroup implementations when an error occurs.
EventLoopException() - Constructor for exception io.netty.channel.EventLoopException
 
EventLoopException(String, Throwable) - Constructor for exception io.netty.channel.EventLoopException
 
EventLoopException(String) - Constructor for exception io.netty.channel.EventLoopException
 
EventLoopException(Throwable) - Constructor for exception io.netty.channel.EventLoopException
 
EventLoopGroup - Interface in io.netty.channel
Special EventExecutorGroup which allows registering Channels that get processed for later selection during the event loop.
exceptionCaught(ChannelHandlerContext, Throwable) - Method in interface io.netty.channel.ChannelHandler
Deprecated.
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class io.netty.channel.ChannelHandlerAdapter
exceptionCaught(ChannelHandlerContext, Throwable) - Method in interface io.netty.channel.ChannelInboundHandler
Gets called if a Throwable was thrown.
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class io.netty.channel.ChannelInboundHandlerAdapter
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class io.netty.channel.ChannelInitializer
Handle the Throwable by logging and closing the Channel.
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class io.netty.channel.CombinedChannelDuplexHandler
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class io.netty.handler.codec.DatagramPacketDecoder
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class io.netty.handler.codec.DatagramPacketEncoder
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class io.netty.handler.flush.FlushConsolidationHandler
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class io.netty.handler.logging.LoggingHandler
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class io.netty.handler.ssl.ApplicationProtocolNegotiationHandler
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class io.netty.handler.ssl.SslHandler
 
execute(Runnable) - Method in class io.netty.util.concurrent.AbstractEventExecutorGroup
 
execute(Runnable) - Method in class io.netty.util.concurrent.GlobalEventExecutor
 
execute(Runnable) - Method in class io.netty.util.concurrent.ImmediateEventExecutor
 
execute(Runnable) - Method in class io.netty.util.concurrent.ImmediateExecutor
 
execute(Runnable) - Method in class io.netty.util.concurrent.NonStickyEventExecutorGroup
 
execute(Runnable) - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
 
execute(Runnable) - Method in class io.netty.util.concurrent.ThreadPerTaskExecutor
 
execute(Runnable) - Method in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor
 
executeAfterEventLoopIteration(Runnable) - Method in class io.netty.channel.SingleThreadEventLoop
Adds a task to be run once at the end of next (or current) eventloop iteration.
executor() - Method in interface io.netty.channel.ChannelHandlerContext
Returns the EventExecutor which is used to execute an arbitrary task.
executor() - Method in class io.netty.channel.DefaultChannelProgressivePromise
 
executor() - Method in class io.netty.channel.DefaultChannelPromise
 
executor() - Method in class io.netty.resolver.AbstractAddressResolver
Returns the EventExecutor which is used to notify the listeners of the Future returned by AbstractAddressResolver.resolve(SocketAddress).
executor() - Method in class io.netty.resolver.dns.DnsNameResolver
 
executor() - Method in class io.netty.resolver.SimpleNameResolver
Returns the EventExecutor which is used to notify the listeners of the Future returned by SimpleNameResolver.resolve(String).
executor() - Method in class io.netty.util.concurrent.CompleteFuture
Return the EventExecutor which is used by this CompleteFuture.
executor() - Method in class io.netty.util.concurrent.DefaultPromise
Get the executor used to notify listeners when this promise is complete.
executorCount() - Method in class io.netty.util.concurrent.MultithreadEventExecutorGroup
Return the number of EventExecutor this implementation uses.
exists(String) - Static method in class io.netty.channel.ChannelOption
Returns true if a ChannelOption exists for the given name.
exists(String) - Static method in class io.netty.util.AttributeKey
Returns true if a AttributeKey exists for the given name.
exists(String) - Method in class io.netty.util.ConstantPool
Returns true if a AttributeKey exists for the given name.
expect(Signal) - Method in error io.netty.util.Signal
Check if the given Signal is the same as this instance.
expectedErr() - Method in exception io.netty.channel.unix.Errors.NativeIoException
 
EXPN - Static variable in class io.netty.handler.codec.smtp.SmtpCommand
 
expn(CharSequence) - Static method in class io.netty.handler.codec.smtp.SmtpRequests
Creates a EXPN request.
extendedRcode() - Method in class io.netty.handler.codec.dns.AbstractDnsOptPseudoRrRecord
 
extendedRcode() - Method in interface io.netty.handler.codec.dns.DnsOptPseudoRecord
Returns the EXTENDED-RCODE which is encoded into DnsRecord.timeToLive().
extractFrame(ChannelHandlerContext, ByteBuf, int, int) - Method in class io.netty.handler.codec.LengthFieldBasedFrameDecoder
Extract the sub-region of the specified buffer.
extractObject(ChannelHandlerContext, ByteBuf, int, int) - Method in class io.netty.handler.codec.json.JsonObjectDecoder
Override this method if you want to filter the json objects/arrays that get passed through the pipeline.
extras() - Method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
extras() - Method in interface io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Returns a ByteBuf representation of the optional extras.
extrasLength() - Method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
extrasLength() - Method in interface io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Return the extras length of the message.

F

fackets() - Method in class io.netty.channel.epoll.EpollTcpInfo
 
failAndRecycle(Throwable) - Method in class io.netty.util.internal.PendingWrite
Fails the underlying Promise with the given cause and recycle this instance.
FailedFuture<V> - Class in io.netty.util.concurrent
The CompleteFuture which is failed already.
FailedFuture(EventExecutor, Throwable) - Constructor for class io.netty.util.concurrent.FailedFuture
Creates a new instance.
failure(Throwable) - Static method in class io.netty.handler.codec.DecoderResult
 
FALSE_SUPPLIER - Static variable in interface io.netty.util.BooleanSupplier
A supplier which always returns false and never throws.
FALSE_SUPPLIER - Static variable in interface io.netty.util.UncheckedBooleanSupplier
A supplier which always returns false and never throws.
FastLzFrameDecoder - Class in io.netty.handler.codec.compression
Uncompresses a ByteBuf encoded by FastLzFrameEncoder using the FastLZ algorithm.
FastLzFrameDecoder() - Constructor for class io.netty.handler.codec.compression.FastLzFrameDecoder
Creates the fastest FastLZ decoder without checksum calculation.
FastLzFrameDecoder(boolean) - Constructor for class io.netty.handler.codec.compression.FastLzFrameDecoder
Creates a FastLZ decoder with calculation of checksums as specified.
FastLzFrameDecoder(Checksum) - Constructor for class io.netty.handler.codec.compression.FastLzFrameDecoder
Creates a FastLZ decoder with specified checksum calculator.
FastLzFrameEncoder - Class in io.netty.handler.codec.compression
Compresses a ByteBuf using the FastLZ algorithm.
FastLzFrameEncoder() - Constructor for class io.netty.handler.codec.compression.FastLzFrameEncoder
Creates a FastLZ encoder without checksum calculator and with auto detection of compression level.
FastLzFrameEncoder(int) - Constructor for class io.netty.handler.codec.compression.FastLzFrameEncoder
Creates a FastLZ encoder with specified compression level and without checksum calculator.
FastLzFrameEncoder(boolean) - Constructor for class io.netty.handler.codec.compression.FastLzFrameEncoder
Creates a FastLZ encoder with auto detection of compression level and calculation of checksums as specified.
FastLzFrameEncoder(int, Checksum) - Constructor for class io.netty.handler.codec.compression.FastLzFrameEncoder
Creates a FastLZ encoder with specified compression level and checksum calculator.
FastThreadLocal<V> - Class in io.netty.util.concurrent
A special variant of ThreadLocal that yields higher access performance when accessed from a FastThreadLocalThread.
FastThreadLocal() - Constructor for class io.netty.util.concurrent.FastThreadLocal
 
FastThreadLocalThread - Class in io.netty.util.concurrent
A special Thread that provides fast access to FastThreadLocal variables.
FastThreadLocalThread() - Constructor for class io.netty.util.concurrent.FastThreadLocalThread
 
FastThreadLocalThread(Runnable) - Constructor for class io.netty.util.concurrent.FastThreadLocalThread
 
FastThreadLocalThread(ThreadGroup, Runnable) - Constructor for class io.netty.util.concurrent.FastThreadLocalThread
 
FastThreadLocalThread(String) - Constructor for class io.netty.util.concurrent.FastThreadLocalThread
 
FastThreadLocalThread(ThreadGroup, String) - Constructor for class io.netty.util.concurrent.FastThreadLocalThread
 
FastThreadLocalThread(Runnable, String) - Constructor for class io.netty.util.concurrent.FastThreadLocalThread
 
FastThreadLocalThread(ThreadGroup, Runnable, String) - Constructor for class io.netty.util.concurrent.FastThreadLocalThread
 
FastThreadLocalThread(ThreadGroup, Runnable, String, long) - Constructor for class io.netty.util.concurrent.FastThreadLocalThread
 
fd() - Method in interface io.netty.channel.unix.UnixChannel
Returns the FileDescriptor that is used by this Channel.
FileDescriptor - Class in io.netty.channel.unix
Native FileDescriptor implementation which allows to wrap an int and provide a FileDescriptor for it.
FileDescriptor(int) - Constructor for class io.netty.channel.unix.FileDescriptor
 
FileRegion - Interface in io.netty.channel
A region of a file that is sent via a Channel which supports zero-copy file transfer.
fillInStackTrace() - Method in exception io.netty.handler.timeout.TimeoutException
 
fillInStackTrace() - Method in exception io.netty.resolver.dns.DnsNameResolverException
 
fillInStackTrace() - Method in error io.netty.util.Signal
 
filterArgs() - Method in class io.netty.channel.kqueue.AcceptFilter
 
filterCipherSuites(Iterable<String>, List<String>, Set<String>) - Method in interface io.netty.handler.ssl.CipherSuiteFilter
Filter the requested ciphers based upon other cipher characteristics.
filterCipherSuites(Iterable<String>, List<String>, Set<String>) - Method in class io.netty.handler.ssl.IdentityCipherSuiteFilter
 
filterCipherSuites(Iterable<String>, List<String>, Set<String>) - Method in class io.netty.handler.ssl.SupportedCipherSuiteFilter
 
filterName() - Method in class io.netty.channel.kqueue.AcceptFilter
 
filterOutboundMessage(Object) - Method in class io.netty.channel.AbstractChannel
Invoked when a new message is added to a ChannelOutboundBuffer of this AbstractChannel, so that the Channel implementation converts the message to another.
filterOutboundMessage(Object) - Method in class io.netty.channel.AbstractServerChannel
 
filterOutboundMessage(Object) - Method in class io.netty.channel.epoll.AbstractEpollServerChannel
 
filterOutboundMessage(Object) - Method in class io.netty.channel.epoll.AbstractEpollStreamChannel
 
filterOutboundMessage(Object) - Method in class io.netty.channel.epoll.EpollDatagramChannel
 
filterOutboundMessage(Object) - Method in class io.netty.channel.epoll.EpollDomainSocketChannel
 
filterOutboundMessage(Object) - Method in class io.netty.channel.kqueue.AbstractKQueueServerChannel
 
filterOutboundMessage(Object) - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel
 
filterOutboundMessage(Object) - Method in class io.netty.channel.kqueue.KQueueDatagramChannel
 
filterOutboundMessage(Object) - Method in class io.netty.channel.kqueue.KQueueDomainSocketChannel
 
filterOutboundMessage(Object) - Method in class io.netty.channel.nio.AbstractNioByteChannel
 
filterOutboundMessage(Object) - Method in class io.netty.channel.oio.AbstractOioByteChannel
 
filterOutboundMessage(Object) - Method in class io.netty.channel.socket.nio.NioDatagramChannel
 
filterOutboundMessage(Object) - Method in class io.netty.channel.socket.nio.NioServerSocketChannel
 
filterOutboundMessage(Object) - Method in class io.netty.channel.socket.oio.OioDatagramChannel
 
filterOutboundMessage(Object) - Method in class io.netty.channel.socket.oio.OioServerSocketChannel
 
finalize() - Method in class io.netty.util.HashedWheelTimer
 
find(ChannelId) - Method in interface io.netty.channel.group.ChannelGroup
Returns the Channel which has the specified ChannelId.
find(Channel) - Method in interface io.netty.channel.group.ChannelGroupFuture
Returns the ChannelFuture of the individual I/O operation which is associated with the specified Channel.
find(ChannelId) - Method in class io.netty.channel.group.DefaultChannelGroup
 
find(Object, Class<?>, String) - Static method in class io.netty.util.internal.TypeParameterMatcher
 
FIND_CR - Static variable in interface io.netty.buffer.ByteBufProcessor
Deprecated.
FIND_CR - Static variable in interface io.netty.util.ByteProcessor
Aborts on a CR ('\r').
FIND_CRLF - Static variable in interface io.netty.buffer.ByteBufProcessor
Deprecated.
FIND_CRLF - Static variable in interface io.netty.util.ByteProcessor
Aborts on a CR ('\r') or a LF ('\n').
FIND_LF - Static variable in interface io.netty.buffer.ByteBufProcessor
Deprecated.
FIND_LF - Static variable in interface io.netty.util.ByteProcessor
Aborts on a LF ('\n').
FIND_LINEAR_WHITESPACE - Static variable in interface io.netty.buffer.ByteBufProcessor
FIND_LINEAR_WHITESPACE - Static variable in interface io.netty.util.ByteProcessor
Aborts on a linear whitespace (a (' ' or a '\t').
FIND_NON_CR - Static variable in interface io.netty.buffer.ByteBufProcessor
Deprecated.
FIND_NON_CR - Static variable in interface io.netty.util.ByteProcessor
Aborts on a non-CR ('\r').
FIND_NON_CRLF - Static variable in interface io.netty.buffer.ByteBufProcessor
Deprecated.
FIND_NON_CRLF - Static variable in interface io.netty.util.ByteProcessor
Aborts on a byte which is neither a CR ('\r') nor a LF ('\n').
FIND_NON_LF - Static variable in interface io.netty.buffer.ByteBufProcessor
Deprecated.
FIND_NON_LF - Static variable in interface io.netty.util.ByteProcessor
Aborts on a non-LF ('\n').
FIND_NON_LINEAR_WHITESPACE - Static variable in interface io.netty.buffer.ByteBufProcessor
FIND_NON_LINEAR_WHITESPACE - Static variable in interface io.netty.util.ByteProcessor
Aborts on a byte which is not a linear whitespace (neither ' ' nor '\t').
FIND_NON_NUL - Static variable in interface io.netty.buffer.ByteBufProcessor
Deprecated.
FIND_NON_NUL - Static variable in interface io.netty.util.ByteProcessor
Aborts on a non-NUL (0x00).
FIND_NUL - Static variable in interface io.netty.buffer.ByteBufProcessor
Deprecated.
FIND_NUL - Static variable in interface io.netty.util.ByteProcessor
Aborts on a NUL (0x00).
FIND_SEMI_COLON - Static variable in interface io.netty.util.ByteProcessor
Aborts on a CR (';').
findNextPositivePowerOfTwo(int) - Static method in class io.netty.util.internal.MathUtil
Fast method of finding the next power of 2 greater than or equal to the supplied value.
FingerprintTrustManagerFactory - Class in io.netty.handler.ssl.util
An TrustManagerFactory that trusts an X.509 certificate whose SHA1 checksum matches.
FingerprintTrustManagerFactory(Iterable<String>) - Constructor for class io.netty.handler.ssl.util.FingerprintTrustManagerFactory
Creates a new instance.
FingerprintTrustManagerFactory(String...) - Constructor for class io.netty.handler.ssl.util.FingerprintTrustManagerFactory
Creates a new instance.
FingerprintTrustManagerFactory(byte[]...) - Constructor for class io.netty.handler.ssl.util.FingerprintTrustManagerFactory
Creates a new instance.
finish() - Method in class io.netty.channel.embedded.EmbeddedChannel
Mark this Channel as finished.
finish(Promise<Void>) - Method in class io.netty.util.concurrent.PromiseCombiner
Sets the promise to be notified when all combined futures have finished.
finishAggregation(O) - Method in class io.netty.handler.codec.MessageAggregator
Invoked when the specified aggregated message is about to be passed to the next handler in the pipeline.
finishAndReleaseAll() - Method in class io.netty.channel.embedded.EmbeddedChannel
Mark this Channel as finished and release all pending message in the inbound and outbound buffer.
finishConnect() - Method in class io.netty.channel.nio.AbstractNioChannel.AbstractNioUnsafe
 
finishConnect() - Method in interface io.netty.channel.nio.AbstractNioChannel.NioUnsafe
Finish connect
finishConnect() - Method in class io.netty.channel.unix.Socket
 
FIRE_EXCEPTION_ON_FAILURE - Static variable in interface io.netty.channel.ChannelFutureListener
A ChannelFutureListener that forwards the Throwable of the ChannelFuture into the ChannelPipeline.
fireChannelActive() - Method in interface io.netty.channel.ChannelHandlerContext
 
fireChannelActive() - Method in interface io.netty.channel.ChannelInboundInvoker
A Channel is active now, which means it is connected.
fireChannelActive() - Method in interface io.netty.channel.ChannelPipeline
 
fireChannelActive() - Method in class io.netty.channel.DefaultChannelPipeline
 
fireChannelInactive() - Method in interface io.netty.channel.ChannelHandlerContext
 
fireChannelInactive() - Method in interface io.netty.channel.ChannelInboundInvoker
A Channel is inactive now, which means it is closed.
fireChannelInactive() - Method in interface io.netty.channel.ChannelPipeline
 
fireChannelInactive() - Method in class io.netty.channel.DefaultChannelPipeline
 
fireChannelRead(Object) - Method in interface io.netty.channel.ChannelHandlerContext
 
fireChannelRead(Object) - Method in interface io.netty.channel.ChannelInboundInvoker
A Channel received a message.
fireChannelRead(Object) - Method in interface io.netty.channel.ChannelPipeline
 
fireChannelRead(Object) - Method in class io.netty.channel.DefaultChannelPipeline
 
fireChannelReadComplete() - Method in interface io.netty.channel.ChannelHandlerContext
 
fireChannelReadComplete() - Method in interface io.netty.channel.ChannelInboundInvoker
fireChannelReadComplete() - Method in interface io.netty.channel.ChannelPipeline
 
fireChannelReadComplete() - Method in class io.netty.channel.DefaultChannelPipeline
 
fireChannelRegistered() - Method in interface io.netty.channel.ChannelHandlerContext
 
fireChannelRegistered() - Method in interface io.netty.channel.ChannelInboundInvoker
A Channel was registered to its EventLoop.
fireChannelRegistered() - Method in interface io.netty.channel.ChannelPipeline
 
fireChannelRegistered() - Method in class io.netty.channel.DefaultChannelPipeline
 
fireChannelUnregistered() - Method in interface io.netty.channel.ChannelHandlerContext
 
fireChannelUnregistered() - Method in interface io.netty.channel.ChannelInboundInvoker
A Channel was unregistered from its EventLoop.
fireChannelUnregistered() - Method in interface io.netty.channel.ChannelPipeline
 
fireChannelUnregistered() - Method in class io.netty.channel.DefaultChannelPipeline
 
fireChannelWritabilityChanged() - Method in interface io.netty.channel.ChannelHandlerContext
 
fireChannelWritabilityChanged() - Method in interface io.netty.channel.ChannelInboundInvoker
fireChannelWritabilityChanged() - Method in interface io.netty.channel.ChannelPipeline
 
fireChannelWritabilityChanged() - Method in class io.netty.channel.DefaultChannelPipeline
 
fireExceptionCaught(Throwable) - Method in interface io.netty.channel.ChannelHandlerContext
 
fireExceptionCaught(Throwable) - Method in interface io.netty.channel.ChannelInboundInvoker
A Channel received an Throwable in one of its inbound operations.
fireExceptionCaught(Throwable) - Method in interface io.netty.channel.ChannelPipeline
 
fireExceptionCaught(Throwable) - Method in class io.netty.channel.DefaultChannelPipeline
 
fireUserEventTriggered(Object) - Method in interface io.netty.channel.ChannelHandlerContext
 
fireUserEventTriggered(Object) - Method in interface io.netty.channel.ChannelInboundInvoker
A Channel received an user defined event.
fireUserEventTriggered(Object) - Method in interface io.netty.channel.ChannelPipeline
 
fireUserEventTriggered(Object) - Method in class io.netty.channel.DefaultChannelPipeline
 
first() - Method in interface io.netty.channel.ChannelPipeline
Returns the first ChannelHandler in this pipeline.
first() - Method in class io.netty.channel.DefaultChannelPipeline
 
FIRST_ALL_IDLE_STATE_EVENT - Static variable in class io.netty.handler.timeout.IdleStateEvent
 
FIRST_READER_IDLE_STATE_EVENT - Static variable in class io.netty.handler.timeout.IdleStateEvent
 
FIRST_WRITER_IDLE_STATE_EVENT - Static variable in class io.netty.handler.timeout.IdleStateEvent
 
firstContext() - Method in interface io.netty.channel.ChannelPipeline
Returns the context of the first ChannelHandler in this pipeline.
firstContext() - Method in class io.netty.channel.DefaultChannelPipeline
 
FixedChannelPool - Class in io.netty.channel.pool
ChannelPool implementation that takes another ChannelPool implementation and enforce a maximum number of concurrent connections.
FixedChannelPool(Bootstrap, ChannelPoolHandler, int) - Constructor for class io.netty.channel.pool.FixedChannelPool
Creates a new instance using the ChannelHealthChecker.ACTIVE.
FixedChannelPool(Bootstrap, ChannelPoolHandler, int, int) - Constructor for class io.netty.channel.pool.FixedChannelPool
Creates a new instance using the ChannelHealthChecker.ACTIVE.
FixedChannelPool(Bootstrap, ChannelPoolHandler, ChannelHealthChecker, FixedChannelPool.AcquireTimeoutAction, long, int, int) - Constructor for class io.netty.channel.pool.FixedChannelPool
Creates a new instance.
FixedChannelPool(Bootstrap, ChannelPoolHandler, ChannelHealthChecker, FixedChannelPool.AcquireTimeoutAction, long, int, int, boolean) - Constructor for class io.netty.channel.pool.FixedChannelPool
Creates a new instance.
FixedChannelPool.AcquireTimeoutAction - Enum in io.netty.channel.pool
 
fixedHeader() - Method in class io.netty.handler.codec.mqtt.MqttMessage
 
FixedLengthFrameDecoder - Class in io.netty.handler.codec
A decoder that splits the received ByteBufs by the fixed number of bytes.
FixedLengthFrameDecoder(int) - Constructor for class io.netty.handler.codec.FixedLengthFrameDecoder
Creates a new instance.
FixedRecvByteBufAllocator - Class in io.netty.channel
The RecvByteBufAllocator that always yields the same buffer size prediction.
FixedRecvByteBufAllocator(int) - Constructor for class io.netty.channel.FixedRecvByteBufAllocator
Creates a new predictor that always returns the same prediction of the specified buffer size.
FixedRedisMessagePool - Class in io.netty.handler.codec.redis
A default fixed redis message pool.
flags() - Method in class io.netty.handler.codec.dns.AbstractDnsOptPseudoRrRecord
 
flags() - Method in interface io.netty.handler.codec.dns.DnsOptPseudoRecord
Returns the flags which includes DO and Z which is encoded into DnsRecord.timeToLive().
FlowControlHandler - Class in io.netty.handler.flow
The FlowControlHandler ensures that only one message per read() is sent downstream.
FlowControlHandler() - Constructor for class io.netty.handler.flow.FlowControlHandler
 
FlowControlHandler(boolean) - Constructor for class io.netty.handler.flow.FlowControlHandler
 
flush() - Method in class io.netty.channel.AbstractChannel.AbstractUnsafe
 
flush() - Method in class io.netty.channel.AbstractChannel
 
flush() - Method in interface io.netty.channel.Channel
 
flush() - Method in interface io.netty.channel.Channel.Unsafe
Flush out all write operations scheduled via Channel.Unsafe.write(Object, ChannelPromise).
flush(ChannelHandlerContext) - Method in class io.netty.channel.ChannelDuplexHandler
flush() - Method in interface io.netty.channel.ChannelHandlerContext
 
flush(ChannelHandlerContext) - Method in interface io.netty.channel.ChannelOutboundHandler
Called once a flush operation is made.
flush(ChannelHandlerContext) - Method in class io.netty.channel.ChannelOutboundHandlerAdapter
flush() - Method in interface io.netty.channel.ChannelOutboundInvoker
Request to flush all pending messages via this ChannelOutboundInvoker.
flush() - Method in interface io.netty.channel.ChannelPipeline
 
flush(ChannelHandlerContext) - Method in class io.netty.channel.CombinedChannelDuplexHandler
 
flush() - Method in class io.netty.channel.DefaultChannelPipeline
 
flush() - Method in interface io.netty.channel.group.ChannelGroup
Flush all Channels in this group.
flush(ChannelMatcher) - Method in interface io.netty.channel.group.ChannelGroup
Flush all Channels in this group that are matched by the given ChannelMatcher.
flush() - Method in class io.netty.channel.group.DefaultChannelGroup
 
flush(ChannelMatcher) - Method in class io.netty.channel.group.DefaultChannelGroup
 
flush(ChannelHandlerContext) - Method in class io.netty.handler.codec.DatagramPacketEncoder
 
FLUSH - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
flush() - Method in class io.netty.handler.codec.serialization.ObjectEncoderOutputStream
 
flush(ChannelHandlerContext) - Method in class io.netty.handler.flush.FlushConsolidationHandler
 
flush(ChannelHandlerContext) - Method in class io.netty.handler.logging.LoggingHandler
 
flush(ChannelHandlerContext) - Method in class io.netty.handler.ssl.AbstractSniHandler
 
flush(ChannelHandlerContext) - Method in class io.netty.handler.ssl.SslHandler
 
flush(ChannelHandlerContext) - Method in class io.netty.handler.stream.ChunkedWriteHandler
 
flush0() - Method in class io.netty.channel.AbstractChannel.AbstractUnsafe
 
flush0() - Method in class io.netty.channel.nio.AbstractNioChannel.AbstractNioUnsafe
 
flushAndWrite(Object) - Method in interface io.netty.channel.group.ChannelGroup
Deprecated.
flushAndWrite(Object, ChannelMatcher) - Method in interface io.netty.channel.group.ChannelGroup
flushAndWrite(Object) - Method in class io.netty.channel.group.DefaultChannelGroup
 
flushAndWrite(Object, ChannelMatcher) - Method in class io.netty.channel.group.DefaultChannelGroup
 
flushCheckpoint() - Method in class io.netty.channel.DefaultChannelProgressivePromise
 
flushCheckpoint(long) - Method in class io.netty.channel.DefaultChannelProgressivePromise
 
flushCheckpoint() - Method in class io.netty.channel.DefaultChannelPromise
 
flushCheckpoint(long) - Method in class io.netty.channel.DefaultChannelPromise
 
FlushConsolidationHandler - Class in io.netty.handler.flush
FlushConsolidationHandler() - Constructor for class io.netty.handler.flush.FlushConsolidationHandler
Create new instance which explicit flush after 256 pending flush operations latest.
FlushConsolidationHandler(int) - Constructor for class io.netty.handler.flush.FlushConsolidationHandler
Create new instance which doesn't consolidate flushes when no read is in progress.
FlushConsolidationHandler(int, boolean) - Constructor for class io.netty.handler.flush.FlushConsolidationHandler
Create new instance.
flushInbound() - Method in class io.netty.channel.embedded.EmbeddedChannel
Flushes the inbound of this Channel.
flushOutbound() - Method in class io.netty.channel.embedded.EmbeddedChannel
Flushes the outbound of this Channel.
FLUSHQ - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
forceFlush() - Method in class io.netty.channel.nio.AbstractNioChannel.AbstractNioUnsafe
 
forceFlush() - Method in interface io.netty.channel.nio.AbstractNioChannel.NioUnsafe
 
forClient() - Static method in class io.netty.handler.ssl.SslContextBuilder
Creates a builder for new client-side SslContext.
forEachByte(ByteProcessor) - Method in class io.netty.buffer.AbstractByteBuf
 
forEachByte(int, int, ByteProcessor) - Method in class io.netty.buffer.AbstractByteBuf
 
forEachByte(ByteProcessor) - Method in class io.netty.buffer.ByteBuf
Iterates over the readable bytes of this buffer with the specified processor in ascending order.
forEachByte(int, int, ByteProcessor) - Method in class io.netty.buffer.ByteBuf
Iterates over the specified area of this buffer with the specified processor in ascending order.
forEachByte(int, int, ByteProcessor) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
forEachByte(ByteProcessor) - Method in class io.netty.buffer.EmptyByteBuf
 
forEachByte(int, int, ByteProcessor) - Method in class io.netty.buffer.EmptyByteBuf
 
forEachByte(int, int, ByteProcessor) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
forEachByte(ByteProcessor) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
forEachByte(int, int, ByteProcessor) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
forEachByte(ByteProcessor) - Method in class io.netty.util.AsciiString
Iterates over the readable bytes of this buffer with the specified processor in ascending order.
forEachByte(int, int, ByteProcessor) - Method in class io.netty.util.AsciiString
Iterates over the specified area of this buffer with the specified processor in ascending order.
forEachByteDesc(ByteProcessor) - Method in class io.netty.buffer.AbstractByteBuf
 
forEachByteDesc(int, int, ByteProcessor) - Method in class io.netty.buffer.AbstractByteBuf
 
forEachByteDesc(ByteProcessor) - Method in class io.netty.buffer.ByteBuf
Iterates over the readable bytes of this buffer with the specified processor in descending order.
forEachByteDesc(int, int, ByteProcessor) - Method in class io.netty.buffer.ByteBuf
Iterates over the specified area of this buffer with the specified processor in descending order.
forEachByteDesc(int, int, ByteProcessor) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
forEachByteDesc(ByteProcessor) - Method in class io.netty.buffer.EmptyByteBuf
 
forEachByteDesc(int, int, ByteProcessor) - Method in class io.netty.buffer.EmptyByteBuf
 
forEachByteDesc(int, int, ByteProcessor) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
forEachByteDesc(ByteProcessor) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
forEachByteDesc(int, int, ByteProcessor) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
forEachByteDesc(ByteProcessor) - Method in class io.netty.util.AsciiString
Iterates over the readable bytes of this buffer with the specified processor in descending order.
forEachByteDesc(int, int, ByteProcessor) - Method in class io.netty.util.AsciiString
Iterates over the specified area of this buffer with the specified processor in descending order.
forEachFlushedMessage(ChannelOutboundBuffer.MessageProcessor) - Method in class io.netty.channel.ChannelOutboundBuffer
Call ChannelOutboundBuffer.MessageProcessor.processMessage(Object) for each flushed message in this ChannelOutboundBuffer until ChannelOutboundBuffer.MessageProcessor.processMessage(Object) returns false or there are no more flushed messages to process.
format(Date) - Static method in class io.netty.handler.codec.DateFormatter
Format a Date into RFC1123 format
format(ChannelHandlerContext, String) - Method in class io.netty.handler.logging.LoggingHandler
Formats an event and returns the formatted message.
format(ChannelHandlerContext, String, Object) - Method in class io.netty.handler.logging.LoggingHandler
Formats an event and returns the formatted message.
format(ChannelHandlerContext, String, Object, Object) - Method in class io.netty.handler.logging.LoggingHandler
Formats an event and returns the formatted message.
formatAddress(byte[]) - Static method in class io.netty.util.internal.MacAddressUtil
 
FORMERR - Static variable in class io.netty.handler.codec.dns.DnsResponseCode
The 'FormErr' DNS RCODE (1), as defined in RFC1035.
forServer(File, File) - Static method in class io.netty.handler.ssl.SslContextBuilder
Creates a builder for new server-side SslContext.
forServer(InputStream, InputStream) - Static method in class io.netty.handler.ssl.SslContextBuilder
Creates a builder for new server-side SslContext.
forServer(PrivateKey, X509Certificate...) - Static method in class io.netty.handler.ssl.SslContextBuilder
Creates a builder for new server-side SslContext.
forServer(File, File, String) - Static method in class io.netty.handler.ssl.SslContextBuilder
Creates a builder for new server-side SslContext.
forServer(InputStream, InputStream, String) - Static method in class io.netty.handler.ssl.SslContextBuilder
Creates a builder for new server-side SslContext.
forServer(PrivateKey, String, X509Certificate...) - Static method in class io.netty.handler.ssl.SslContextBuilder
Creates a builder for new server-side SslContext.
forServer(KeyManagerFactory) - Static method in class io.netty.handler.ssl.SslContextBuilder
Creates a builder for new server-side SslContext.
freeBytes() - Method in interface io.netty.buffer.PoolChunkMetric
Return the number of free bytes in the chunk.
freeDirect(ByteBuffer) - Method in class io.netty.buffer.UnpooledDirectByteBuf
Free a direct ByteBuffer
freeDirect(ByteBuffer) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
Free a direct ByteBuffer
freeDirectBuffer(ByteBuffer) - Static method in class io.netty.util.internal.PlatformDependent
Try to deallocate the specified direct ByteBuffer.
freeDirectNoCleaner(ByteBuffer) - Static method in class io.netty.util.internal.PlatformDependent
This method MUST only be called for ByteBuffers that were allocated via PlatformDependent.allocateDirectNoCleaner(int).
freeMemory(long) - Static method in class io.netty.util.internal.PlatformDependent
 
freeThreadLocalCache() - Method in class io.netty.buffer.PooledByteBufAllocator
Deprecated.
from(String) - Static method in class io.netty.channel.unix.FileDescriptor
Open a new FileDescriptor for the given path.
from(File) - Static method in class io.netty.channel.unix.FileDescriptor
Open a new FileDescriptor for the given File.
from(int) - Static method in class io.netty.handler.codec.mqtt.MqttMessageIdVariableHeader
 
fromProtocolNameAndLevel(String, byte) - Static method in enum io.netty.handler.codec.mqtt.MqttVersion
 
FullBinaryMemcacheRequest - Interface in io.netty.handler.codec.memcache.binary
A BinaryMemcacheRequest that also includes the content.
FullBinaryMemcacheResponse - Interface in io.netty.handler.codec.memcache.binary
A BinaryMemcacheResponse that also includes the content.
FullBulkStringRedisMessage - Class in io.netty.handler.codec.redis
An aggregated bulk string of RESP.
FullBulkStringRedisMessage(ByteBuf) - Constructor for class io.netty.handler.codec.redis.FullBulkStringRedisMessage
Creates a FullBulkStringRedisMessage for the given content.
FullMemcacheMessage - Interface in io.netty.handler.codec.memcache
Combines MemcacheMessage and LastMemcacheContent into one message.
Future<V> - Interface in io.netty.util.concurrent
The result of an asynchronous operation.
FutureListener<V> - Interface in io.netty.util.concurrent
A subtype of GenericFutureListener that hides type parameter for convenience.
futureListenerStackDepth() - Method in class io.netty.util.internal.InternalThreadLocalMap
 

G

GAT - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
GATK - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
GATKQ - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
GATQ - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
generateKeySpec(char[], byte[]) - Static method in class io.netty.handler.ssl.SslContext
Generates a key specification for an (encrypted) private key.
GenericFutureListener<F extends Future<?>> - Interface in io.netty.util.concurrent
Listens to the result of a Future.
GenericProgressiveFutureListener<F extends ProgressiveFuture<?>> - Interface in io.netty.util.concurrent
 
get(String) - Method in interface io.netty.channel.ChannelPipeline
Returns the ChannelHandler with the specified name in this pipeline.
get(Class<T>) - Method in interface io.netty.channel.ChannelPipeline
Returns the ChannelHandler of the specified type in this pipeline.
get(String) - Method in class io.netty.channel.DefaultChannelPipeline
 
get(Class<T>) - Method in class io.netty.channel.DefaultChannelPipeline
 
get(K) - Method in class io.netty.channel.pool.AbstractChannelPoolMap
 
get(K) - Method in interface io.netty.channel.pool.ChannelPoolMap
Return the ChannelPool for the code.
get(K) - Method in class io.netty.handler.codec.DefaultHeaders
 
get(K, V) - Method in class io.netty.handler.codec.DefaultHeaders
 
get(K) - Method in class io.netty.handler.codec.EmptyHeaders
 
get(K, V) - Method in class io.netty.handler.codec.EmptyHeaders
 
get(K) - Method in interface io.netty.handler.codec.Headers
Returns the value of a header with the specified name.
get(K, V) - Method in interface io.netty.handler.codec.Headers
Returns the value of a header with the specified name.
GET - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
get(String, DnsRecord[]) - Method in class io.netty.resolver.dns.DefaultDnsCache
 
get(String, DnsRecord[]) - Method in interface io.netty.resolver.dns.DnsCache
Return the cached entries for the given hostname.
get(String, DnsRecord[]) - Method in class io.netty.resolver.dns.NoopDnsCache
 
get() - Method in interface io.netty.util.Attribute
Returns the current value, which may be null
get() - Method in interface io.netty.util.BooleanSupplier
Gets a boolean value.
get(byte) - Method in class io.netty.util.collection.ByteObjectHashMap
 
get(Object) - Method in class io.netty.util.collection.ByteObjectHashMap
 
get(byte) - Method in interface io.netty.util.collection.ByteObjectMap
Gets the value in the map with the specified key.
get(char) - Method in class io.netty.util.collection.CharObjectHashMap
 
get(Object) - Method in class io.netty.util.collection.CharObjectHashMap
 
get(char) - Method in interface io.netty.util.collection.CharObjectMap
Gets the value in the map with the specified key.
get(int) - Method in class io.netty.util.collection.IntObjectHashMap
 
get(Object) - Method in class io.netty.util.collection.IntObjectHashMap
 
get(int) - Method in interface io.netty.util.collection.IntObjectMap
Gets the value in the map with the specified key.
get(long) - Method in class io.netty.util.collection.LongObjectHashMap
 
get(Object) - Method in class io.netty.util.collection.LongObjectHashMap
 
get(long) - Method in interface io.netty.util.collection.LongObjectMap
Gets the value in the map with the specified key.
get(short) - Method in class io.netty.util.collection.ShortObjectHashMap
 
get(Object) - Method in class io.netty.util.collection.ShortObjectHashMap
 
get(short) - Method in interface io.netty.util.collection.ShortObjectMap
Gets the value in the map with the specified key.
get() - Method in class io.netty.util.concurrent.AbstractFuture
 
get(long, TimeUnit) - Method in class io.netty.util.concurrent.AbstractFuture
 
get() - Method in class io.netty.util.concurrent.FastThreadLocal
Returns the current value for the current thread
get(InternalThreadLocalMap) - Method in class io.netty.util.concurrent.FastThreadLocal
Returns the current value for the specified thread local map.
get() - Static method in class io.netty.util.internal.InternalThreadLocalMap
 
get(String) - Static method in class io.netty.util.internal.SystemPropertyUtil
Returns the value of the Java system property with the specified key, while falling back to null if the property access fails.
get(String, String) - Static method in class io.netty.util.internal.SystemPropertyUtil
Returns the value of the Java system property with the specified key, while falling back to the specified default value if the property access fails.
get(Class<?>) - Static method in class io.netty.util.internal.TypeParameterMatcher
 
get() - Method in interface io.netty.util.IntSupplier
Gets a result.
get() - Method in class io.netty.util.Recycler
 
get() - Method in interface io.netty.util.UncheckedBooleanSupplier
Gets a boolean value.
getAcceptFilter() - Method in class io.netty.channel.kqueue.KQueueServerSocketChannelConfig
 
getAlgorithm() - Method in class io.netty.handler.ssl.PemPrivateKey
 
getAll(K) - Method in class io.netty.handler.codec.DefaultHeaders
 
getAll(K) - Method in class io.netty.handler.codec.EmptyHeaders
 
getAll(K) - Method in interface io.netty.handler.codec.Headers
Returns all values for the header with the specified name.
getAllAndRemove(K) - Method in class io.netty.handler.codec.DefaultHeaders
 
getAllAndRemove(K) - Method in class io.netty.handler.codec.EmptyHeaders
 
getAllAndRemove(K) - Method in interface io.netty.handler.codec.Headers
Returns all values for the header with the specified name and removes them from this object.
getAllAsString(Headers<K, V, ?>, K) - Static method in class io.netty.handler.codec.HeadersUtils
Headers.get(Object) and convert each element of List to a String.
getAllAsString(CharSequence) - Method in class io.netty.handler.codec.stomp.DefaultStompHeaders
 
getAllAsString(CharSequence) - Method in interface io.netty.handler.codec.stomp.StompHeaders
Headers.getAll(Object) and convert each element of List to a String.
getAllIdleTimeInMillis() - Method in class io.netty.handler.timeout.IdleStateHandler
Return the allIdleTime that was given when instance this class in milliseconds.
getAllocator() - Method in interface io.netty.channel.ChannelConfig
Returns ByteBufAllocator which is used for the channel to allocate buffers.
getAllocator() - Method in class io.netty.channel.DefaultChannelConfig
 
getAndRemove(K) - Method in class io.netty.handler.codec.DefaultHeaders
 
getAndRemove(K, V) - Method in class io.netty.handler.codec.DefaultHeaders
 
getAndRemove(K) - Method in class io.netty.handler.codec.EmptyHeaders
 
getAndRemove(K, V) - Method in class io.netty.handler.codec.EmptyHeaders
 
getAndRemove(K) - Method in interface io.netty.handler.codec.Headers
Returns the value of a header with the specified name and removes it from this object.
getAndRemove(K, V) - Method in interface io.netty.handler.codec.Headers
Returns the value of a header with the specified name and removes it from this object.
getAndRemove() - Method in interface io.netty.util.Attribute
Deprecated.
please consider using Attribute.getAndSet(Object) (with value of null).
getAndSet(T) - Method in interface io.netty.util.Attribute
Atomically sets to the given value and returns the old value which may be null if non was set before.
getAsString(Headers<K, V, ?>, K) - Static method in class io.netty.handler.codec.HeadersUtils
Headers.get(Object) and convert the result to a String.
getAsString(CharSequence) - Method in class io.netty.handler.codec.stomp.DefaultStompHeaders
 
getAsString(CharSequence) - Method in interface io.netty.handler.codec.stomp.StompHeaders
Headers.get(Object) and convert the result to a String.
getBacklog() - Method in class io.netty.channel.epoll.EpollServerChannelConfig
 
getBacklog() - Method in class io.netty.channel.kqueue.KQueueServerChannelConfig
 
getBacklog() - Method in class io.netty.channel.socket.DefaultServerSocketChannelConfig
 
getBacklog() - Method in interface io.netty.channel.socket.ServerSocketChannelConfig
Gets the backlog value to specify when the channel binds to a local address.
getBasicConstraints() - Method in class io.netty.handler.ssl.PemX509Certificate
 
getBoolean(int) - Method in class io.netty.buffer.AbstractByteBuf
 
getBoolean(int) - Method in class io.netty.buffer.ByteBuf
Gets a boolean at the specified absolute (@code index) in this buffer.
getBoolean(int) - Method in class io.netty.buffer.EmptyByteBuf
 
getBoolean(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
getBoolean(K) - Method in class io.netty.handler.codec.DefaultHeaders
 
getBoolean(K, boolean) - Method in class io.netty.handler.codec.DefaultHeaders
 
getBoolean(K) - Method in class io.netty.handler.codec.EmptyHeaders
 
getBoolean(K, boolean) - Method in class io.netty.handler.codec.EmptyHeaders
 
getBoolean(K) - Method in interface io.netty.handler.codec.Headers
Returns the boolean value of a header with the specified name.
getBoolean(K, boolean) - Method in interface io.netty.handler.codec.Headers
Returns the boolean value of a header with the specified name.
getBoolean(String, boolean) - Static method in class io.netty.util.internal.SystemPropertyUtil
Returns the value of the Java system property with the specified key, while falling back to the specified default value if the property access fails.
getBooleanAndRemove(K) - Method in class io.netty.handler.codec.DefaultHeaders
 
getBooleanAndRemove(K, boolean) - Method in class io.netty.handler.codec.DefaultHeaders
 
getBooleanAndRemove(K) - Method in class io.netty.handler.codec.EmptyHeaders
 
getBooleanAndRemove(K, boolean) - Method in class io.netty.handler.codec.EmptyHeaders
 
getBooleanAndRemove(K) - Method in interface io.netty.handler.codec.Headers
Returns the boolean value of a header with the specified name and removes the header from this object.
getBooleanAndRemove(K, boolean) - Method in interface io.netty.handler.codec.Headers
Returns the boolean value of a header with the specified name and removes the header from this object.
getByName(CharSequence) - Static method in class io.netty.util.NetUtil
Returns the Inet6Address representation of a CharSequence IP address.
getByName(CharSequence, boolean) - Static method in class io.netty.util.NetUtil
Returns the Inet6Address representation of a CharSequence IP address.
getByte(int) - Method in class io.netty.buffer.AbstractByteBuf
 
getByte(int) - Method in class io.netty.buffer.ByteBuf
Gets a byte at the specified absolute index in this buffer.
getByte(int) - Method in class io.netty.buffer.CompositeByteBuf
 
getByte(int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
getByte(int) - Method in class io.netty.buffer.EmptyByteBuf
 
getByte(int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
getByte(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
getByte(int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
getByte(int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
getByte(K) - Method in class io.netty.handler.codec.DefaultHeaders
 
getByte(K, byte) - Method in class io.netty.handler.codec.DefaultHeaders
 
getByte(K) - Method in class io.netty.handler.codec.EmptyHeaders
 
getByte(K, byte) - Method in class io.netty.handler.codec.EmptyHeaders
 
getByte(K) - Method in interface io.netty.handler.codec.Headers
Returns the byte value of a header with the specified name.
getByte(K, byte) - Method in interface io.netty.handler.codec.Headers
Returns the byte value of a header with the specified name.
getByte(long) - Static method in class io.netty.util.internal.PlatformDependent
 
getByte(byte[], int) - Static method in class io.netty.util.internal.PlatformDependent
 
getByteAndRemove(K) - Method in class io.netty.handler.codec.DefaultHeaders
 
getByteAndRemove(K, byte) - Method in class io.netty.handler.codec.DefaultHeaders
 
getByteAndRemove(K) - Method in class io.netty.handler.codec.EmptyHeaders
 
getByteAndRemove(K, byte) - Method in class io.netty.handler.codec.EmptyHeaders
 
getByteAndRemove(K) - Method in interface io.netty.handler.codec.Headers
Returns the byte value of a header with the specified name and removes the header from this object.
getByteAndRemove(K, byte) - Method in interface io.netty.handler.codec.Headers
Returns the byte value of a header with the specified name and removes the header from this object.
getByteBufOfInteger(long) - Method in class io.netty.handler.codec.redis.FixedRedisMessagePool
 
getByteBufOfInteger(long) - Method in interface io.netty.handler.codec.redis.RedisMessagePool
Returns byte[] for given msg.
getBytes(int, byte[]) - Method in class io.netty.buffer.AbstractByteBuf
 
getBytes(int, ByteBuf) - Method in class io.netty.buffer.AbstractByteBuf
 
getBytes(int, ByteBuf, int) - Method in class io.netty.buffer.AbstractByteBuf
 
getBytes(int, ByteBuf) - Method in class io.netty.buffer.ByteBuf
Transfers this buffer's data to the specified destination starting at the specified absolute index until the destination becomes non-writable.
getBytes(int, ByteBuf, int) - Method in class io.netty.buffer.ByteBuf
Transfers this buffer's data to the specified destination starting at the specified absolute index.
getBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.ByteBuf
Transfers this buffer's data to the specified destination starting at the specified absolute index.
getBytes(int, byte[]) - Method in class io.netty.buffer.ByteBuf
Transfers this buffer's data to the specified destination starting at the specified absolute index.
getBytes(int, byte[], int, int) - Method in class io.netty.buffer.ByteBuf
Transfers this buffer's data to the specified destination starting at the specified absolute index.
getBytes(int, ByteBuffer) - Method in class io.netty.buffer.ByteBuf
Transfers this buffer's data to the specified destination starting at the specified absolute index until the destination's position reaches its limit.
getBytes(int, OutputStream, int) - Method in class io.netty.buffer.ByteBuf
Transfers this buffer's data to the specified stream starting at the specified absolute index.
getBytes(int, GatheringByteChannel, int) - Method in class io.netty.buffer.ByteBuf
Transfers this buffer's data to the specified channel starting at the specified absolute index.
getBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.ByteBuf
Transfers this buffer's data starting at the specified absolute index to the specified channel starting at the given file position.
getBytes(ByteBuf) - Static method in class io.netty.buffer.ByteBufUtil
Create a copy of the underlying storage from buf into a byte array.
getBytes(ByteBuf, int, int) - Static method in class io.netty.buffer.ByteBufUtil
Create a copy of the underlying storage from buf into a byte array.
getBytes(ByteBuf, int, int, boolean) - Static method in class io.netty.buffer.ByteBufUtil
Return an array of the underlying storage from buf into a byte array.
getBytes(int, byte[], int, int) - Method in class io.netty.buffer.CompositeByteBuf
 
getBytes(int, ByteBuffer) - Method in class io.netty.buffer.CompositeByteBuf
 
getBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.CompositeByteBuf
 
getBytes(int, GatheringByteChannel, int) - Method in class io.netty.buffer.CompositeByteBuf
 
getBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.CompositeByteBuf
 
getBytes(int, OutputStream, int) - Method in class io.netty.buffer.CompositeByteBuf
 
getBytes(int, ByteBuf) - Method in class io.netty.buffer.CompositeByteBuf
 
getBytes(int, ByteBuf, int) - Method in class io.netty.buffer.CompositeByteBuf
 
getBytes(int, byte[]) - Method in class io.netty.buffer.CompositeByteBuf
 
getBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
getBytes(int, byte[], int, int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
getBytes(int, ByteBuffer) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
getBytes(int, OutputStream, int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
getBytes(int, GatheringByteChannel, int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
getBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
getBytes(int, ByteBuf) - Method in class io.netty.buffer.EmptyByteBuf
 
getBytes(int, ByteBuf, int) - Method in class io.netty.buffer.EmptyByteBuf
 
getBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.EmptyByteBuf
 
getBytes(int, byte[]) - Method in class io.netty.buffer.EmptyByteBuf
 
getBytes(int, byte[], int, int) - Method in class io.netty.buffer.EmptyByteBuf
 
getBytes(int, ByteBuffer) - Method in class io.netty.buffer.EmptyByteBuf
 
getBytes(int, OutputStream, int) - Method in class io.netty.buffer.EmptyByteBuf
 
getBytes(int, GatheringByteChannel, int) - Method in class io.netty.buffer.EmptyByteBuf
 
getBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.EmptyByteBuf
 
getBytes(int, GatheringByteChannel, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
getBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
getBytes(int, OutputStream, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
getBytes(int, byte[], int, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
getBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
getBytes(int, ByteBuffer) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
getBytes(int, ByteBuf) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
getBytes(int, ByteBuf, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
getBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
getBytes(int, byte[]) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
getBytes(int, byte[], int, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
getBytes(int, ByteBuffer) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
getBytes(int, OutputStream, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
getBytes(int, GatheringByteChannel, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
getBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
getBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
getBytes(int, byte[], int, int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
getBytes(int, ByteBuffer) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
getBytes(int, OutputStream, int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
getBytes(int, GatheringByteChannel, int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
getBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
getBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
getBytes(int, byte[], int, int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
getBytes(int, ByteBuffer) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
getBytes(int, OutputStream, int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
getBytes(int, GatheringByteChannel, int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
getBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
getBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
getBytes(int, byte[], int, int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
getBytes(int, ByteBuffer) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
getBytes(int, OutputStream, int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
getBytes(int, GatheringByteChannel, int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
getBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
getChar(int) - Method in class io.netty.buffer.AbstractByteBuf
 
getChar(int) - Method in class io.netty.buffer.ByteBuf
Gets a 2-byte UTF-16 character at the specified absolute index in this buffer.
getChar(int) - Method in class io.netty.buffer.EmptyByteBuf
 
getChar(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
getChar(K) - Method in class io.netty.handler.codec.DefaultHeaders
 
getChar(K, char) - Method in class io.netty.handler.codec.DefaultHeaders
 
getChar(K) - Method in class io.netty.handler.codec.EmptyHeaders
 
getChar(K, char) - Method in class io.netty.handler.codec.EmptyHeaders
 
getChar(K) - Method in interface io.netty.handler.codec.Headers
Returns the char value of a header with the specified name.
getChar(K, char) - Method in interface io.netty.handler.codec.Headers
Returns the char value of a header with the specified name.
getCharAndRemove(K) - Method in class io.netty.handler.codec.DefaultHeaders
 
getCharAndRemove(K, char) - Method in class io.netty.handler.codec.DefaultHeaders
 
getCharAndRemove(K) - Method in class io.netty.handler.codec.EmptyHeaders
 
getCharAndRemove(K, char) - Method in class io.netty.handler.codec.EmptyHeaders
 
getCharAndRemove(K) - Method in interface io.netty.handler.codec.Headers
Returns the char value of a header with the specified name and removes the header from this object.
getCharAndRemove(K, char) - Method in interface io.netty.handler.codec.Headers
Returns the char value of a header with the specified name and removes the header from this object.
getCharSequence(int, int, Charset) - Method in class io.netty.buffer.AbstractByteBuf
 
getCharSequence(int, int, Charset) - Method in class io.netty.buffer.ByteBuf
Gets a CharSequence with the given length at the given index.
getCharSequence(int, int, Charset) - Method in class io.netty.buffer.EmptyByteBuf
 
getCharSequence(int, int, Charset) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
getCheckInterval() - Method in class io.netty.handler.traffic.AbstractTrafficShapingHandler
 
getClassLoader(Class<?>) - Static method in class io.netty.util.internal.PlatformDependent
Return the ClassLoader for the given Class.
getCloseNotifyFlushTimeoutMillis() - Method in class io.netty.handler.ssl.SslHandler
Gets the timeout for flushing the close_notify that was triggered by closing the Channel.
getCloseNotifyReadTimeoutMillis() - Method in class io.netty.handler.ssl.SslHandler
Gets the timeout (in ms) for receiving the response for the close_notify that was triggered by closing the Channel.
getCloseNotifyTimeoutMillis() - Method in class io.netty.handler.ssl.SslHandler
getConnectTimeoutMillis() - Method in interface io.netty.channel.ChannelConfig
Returns the connect timeout of the channel in milliseconds.
getConnectTimeoutMillis() - Method in class io.netty.channel.DefaultChannelConfig
 
getContextClassLoader() - Static method in class io.netty.util.internal.PlatformDependent
Return the context ClassLoader for the current Thread.
getCriticalExtensionOIDs() - Method in class io.netty.handler.ssl.PemX509Certificate
 
getDecoder(Charset) - Static method in class io.netty.util.CharsetUtil
getDefaultFactory() - Static method in class io.netty.util.internal.logging.InternalLoggerFactory
Returns the default factory.
getDouble(int) - Method in class io.netty.buffer.AbstractByteBuf
 
getDouble(int) - Method in class io.netty.buffer.ByteBuf
Gets a 64-bit floating point number at the specified absolute index in this buffer.
getDouble(int) - Method in class io.netty.buffer.EmptyByteBuf
 
getDouble(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
getDouble(K) - Method in class io.netty.handler.codec.DefaultHeaders
 
getDouble(K, double) - Method in class io.netty.handler.codec.DefaultHeaders
 
getDouble(K) - Method in class io.netty.handler.codec.EmptyHeaders
 
getDouble(K, double) - Method in class io.netty.handler.codec.EmptyHeaders
 
getDouble(K) - Method in interface io.netty.handler.codec.Headers
Returns the double value of a header with the specified name.
getDouble(K, double) - Method in interface io.netty.handler.codec.Headers
Returns the double value of a header with the specified name.
getDoubleAndRemove(K) - Method in class io.netty.handler.codec.DefaultHeaders
 
getDoubleAndRemove(K, double) - Method in class io.netty.handler.codec.DefaultHeaders
 
getDoubleAndRemove(K) - Method in class io.netty.handler.codec.EmptyHeaders
 
getDoubleAndRemove(K, double) - Method in class io.netty.handler.codec.EmptyHeaders
 
getDoubleAndRemove(K) - Method in interface io.netty.handler.codec.Headers
Returns the double value of a header with the specified name and removes the header from this object.
getDoubleAndRemove(K, double) - Method in interface io.netty.handler.codec.Headers
Returns the double value of a header with the specified name and removes the header from this object.
getEncoded() - Method in class io.netty.handler.ssl.PemPrivateKey
 
getEncoded() - Method in class io.netty.handler.ssl.PemX509Certificate
 
getEncoder(Charset) - Static method in class io.netty.util.CharsetUtil
getEpollMode() - Method in class io.netty.channel.epoll.EpollChannelConfig
Return the EpollMode used.
getError(String) - Method in class io.netty.handler.codec.redis.FixedRedisMessagePool
 
getError(ByteBuf) - Method in class io.netty.handler.codec.redis.FixedRedisMessagePool
 
getError(String) - Method in interface io.netty.handler.codec.redis.RedisMessagePool
Returns ErrorRedisMessage for given content.
getError(ByteBuf) - Method in interface io.netty.handler.codec.redis.RedisMessagePool
Returns ErrorRedisMessage for given content.
getExtensionValue(String) - Method in class io.netty.handler.ssl.PemX509Certificate
 
getFloat(int) - Method in class io.netty.buffer.AbstractByteBuf
 
getFloat(int) - Method in class io.netty.buffer.ByteBuf
Gets a 32-bit floating point number at the specified absolute index in this buffer.
getFloat(int) - Method in class io.netty.buffer.EmptyByteBuf
 
getFloat(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
getFloat(K) - Method in class io.netty.handler.codec.DefaultHeaders
 
getFloat(K, float) - Method in class io.netty.handler.codec.DefaultHeaders
 
getFloat(K) - Method in class io.netty.handler.codec.EmptyHeaders
 
getFloat(K, float) - Method in class io.netty.handler.codec.EmptyHeaders
 
getFloat(K) - Method in interface io.netty.handler.codec.Headers
Returns the float value of a header with the specified name.
getFloat(K, float) - Method in interface io.netty.handler.codec.Headers
Returns the float value of a header with the specified name.
getFloatAndRemove(K) - Method in class io.netty.handler.codec.DefaultHeaders
 
getFloatAndRemove(K, float) - Method in class io.netty.handler.codec.DefaultHeaders
 
getFloatAndRemove(K) - Method in class io.netty.handler.codec.EmptyHeaders
 
getFloatAndRemove(K, float) - Method in class io.netty.handler.codec.EmptyHeaders
 
getFloatAndRemove(K) - Method in interface io.netty.handler.codec.Headers
Returns the float value of a header with the specified name and removes the header from this object.
getFloatAndRemove(K, float) - Method in interface io.netty.handler.codec.Headers
Returns the float value of a header with the specified name and removes the header from this object.
getFormat() - Method in class io.netty.handler.ssl.PemPrivateKey
 
getHandshakeTimeoutMillis() - Method in class io.netty.handler.ssl.SslHandler
 
getIfSet() - Static method in class io.netty.util.internal.InternalThreadLocalMap
 
getInitialSeedUniquifier() - Static method in class io.netty.util.internal.ThreadLocalRandom
 
getInstance(Class<?>) - Static method in class io.netty.util.internal.logging.InternalLoggerFactory
Creates a new logger instance with the name of the specified class.
getInstance(String) - Static method in class io.netty.util.internal.logging.InternalLoggerFactory
Creates a new logger instance with the specified name.
getInt(int) - Method in class io.netty.buffer.AbstractByteBuf
 
getInt(int) - Method in class io.netty.buffer.ByteBuf
Gets a 32-bit integer at the specified absolute index in this buffer.
getInt(int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
getInt(int) - Method in class io.netty.buffer.EmptyByteBuf
 
getInt(int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
getInt(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
getInt(int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
getInt(int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
getInt(K) - Method in class io.netty.handler.codec.DefaultHeaders
 
getInt(K, int) - Method in class io.netty.handler.codec.DefaultHeaders
 
getInt(K) - Method in class io.netty.handler.codec.EmptyHeaders
 
getInt(K, int) - Method in class io.netty.handler.codec.EmptyHeaders
 
getInt(K) - Method in interface io.netty.handler.codec.Headers
Returns the int value of a header with the specified name.
getInt(K, int) - Method in interface io.netty.handler.codec.Headers
Returns the int value of a header with the specified name.
getInt(Object, long) - Static method in class io.netty.util.internal.PlatformDependent
 
getInt(long) - Static method in class io.netty.util.internal.PlatformDependent
 
getInt(byte[], int) - Static method in class io.netty.util.internal.PlatformDependent
 
getInt(String, int) - Static method in class io.netty.util.internal.SystemPropertyUtil
Returns the value of the Java system property with the specified key, while falling back to the specified default value if the property access fails.
getIntAndRemove(K) - Method in class io.netty.handler.codec.DefaultHeaders
 
getIntAndRemove(K, int) - Method in class io.netty.handler.codec.DefaultHeaders
 
getIntAndRemove(K) - Method in class io.netty.handler.codec.EmptyHeaders
 
getIntAndRemove(K, int) - Method in class io.netty.handler.codec.EmptyHeaders
 
getIntAndRemove(K) - Method in interface io.netty.handler.codec.Headers
Returns the int value of a header with the specified name and removes the header from this object.
getIntAndRemove(K, int) - Method in interface io.netty.handler.codec.Headers
Returns the int value of a header with the specified name and removes the header from this object.
getInteger(long) - Method in class io.netty.handler.codec.redis.FixedRedisMessagePool
 
getInteger(ByteBuf) - Method in class io.netty.handler.codec.redis.FixedRedisMessagePool
 
getInteger(long) - Method in interface io.netty.handler.codec.redis.RedisMessagePool
Returns IntegerRedisMessage for given value.
getInteger(ByteBuf) - Method in interface io.netty.handler.codec.redis.RedisMessagePool
Returns IntegerRedisMessage for given content.
getInterface() - Method in class io.netty.channel.epoll.EpollDatagramChannelConfig
 
getInterface() - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
 
getInterface() - Method in interface io.netty.channel.socket.DatagramChannelConfig
Gets the address of the network interface used for multicast packets.
getInterface() - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
 
getIntLE(int) - Method in class io.netty.buffer.AbstractByteBuf
 
getIntLE(int) - Method in class io.netty.buffer.ByteBuf
Gets a 32-bit integer at the specified absolute index in this buffer with Little Endian Byte Order.
getIntLE(int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
getIntLE(int) - Method in class io.netty.buffer.EmptyByteBuf
 
getIntLE(int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
getIntLE(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
getIntLE(int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
getIoRatio() - Method in class io.netty.channel.nio.NioEventLoop
Returns the percentage of the desired amount of time spent for I/O in the event loop.
getIssuerDN() - Method in class io.netty.handler.ssl.PemX509Certificate
 
getIssuerUniqueID() - Method in class io.netty.handler.ssl.PemX509Certificate
 
GETK - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
getKey() - Method in class io.netty.handler.codec.DefaultHeaders.HeaderEntry
 
getKeyUsage() - Method in class io.netty.handler.ssl.PemX509Certificate
 
GETKQ - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
getLevel() - Static method in class io.netty.util.ResourceLeakDetector
Returns the current resource leak detection level.
getLong(int) - Method in class io.netty.buffer.AbstractByteBuf
 
getLong(int) - Method in class io.netty.buffer.ByteBuf
Gets a 64-bit long integer at the specified absolute index in this buffer.
getLong(int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
getLong(int) - Method in class io.netty.buffer.EmptyByteBuf
 
getLong(int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
getLong(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
getLong(int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
getLong(int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
getLong(K) - Method in class io.netty.handler.codec.DefaultHeaders
 
getLong(K, long) - Method in class io.netty.handler.codec.DefaultHeaders
 
getLong(K) - Method in class io.netty.handler.codec.EmptyHeaders
 
getLong(K, long) - Method in class io.netty.handler.codec.EmptyHeaders
 
getLong(K) - Method in interface io.netty.handler.codec.Headers
Returns the long value of a header with the specified name.
getLong(K, long) - Method in interface io.netty.handler.codec.Headers
Returns the long value of a header with the specified name.
getLong(long) - Static method in class io.netty.util.internal.PlatformDependent
 
getLong(byte[], int) - Static method in class io.netty.util.internal.PlatformDependent
 
getLong(String, long) - Static method in class io.netty.util.internal.SystemPropertyUtil
Returns the value of the Java system property with the specified key, while falling back to the specified default value if the property access fails.
getLongAndRemove(K) - Method in class io.netty.handler.codec.DefaultHeaders
 
getLongAndRemove(K, long) - Method in class io.netty.handler.codec.DefaultHeaders
 
getLongAndRemove(K) - Method in class io.netty.handler.codec.EmptyHeaders
 
getLongAndRemove(K, long) - Method in class io.netty.handler.codec.EmptyHeaders
 
getLongAndRemove(K) - Method in interface io.netty.handler.codec.Headers
Returns the long value of a header with the specified name and removes the header from this object.
getLongAndRemove(K, long) - Method in interface io.netty.handler.codec.Headers
Returns the long value of a header with the specified name and removes the header from this object.
getLongLE(int) - Method in class io.netty.buffer.AbstractByteBuf
 
getLongLE(int) - Method in class io.netty.buffer.ByteBuf
Gets a 64-bit long integer at the specified absolute index in this buffer in Little Endian Byte Order.
getLongLE(int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
getLongLE(int) - Method in class io.netty.buffer.EmptyByteBuf
 
getLongLE(int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
getLongLE(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
getLongLE(int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
getMaxGlobalWriteSize() - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
 
getMaxGlobalWriteSize() - Method in class io.netty.handler.traffic.GlobalTrafficShapingHandler
 
getMaxMessagesPerRead() - Method in interface io.netty.channel.ChannelConfig
Deprecated.
Use MaxMessagesRecvByteBufAllocator

Returns the maximum number of messages to read per read loop. a channelRead() event. If this value is greater than 1, an event loop might attempt to read multiple times to procure multiple messages.

getMaxMessagesPerRead() - Method in class io.netty.channel.DefaultChannelConfig
Deprecated.
getMaxTimeWait() - Method in class io.netty.handler.traffic.AbstractTrafficShapingHandler
 
getMaxWriteDelay() - Method in class io.netty.handler.traffic.AbstractTrafficShapingHandler
 
getMaxWriteSize() - Method in class io.netty.handler.traffic.AbstractTrafficShapingHandler
 
getMedium(int) - Method in class io.netty.buffer.AbstractByteBuf
 
getMedium(int) - Method in class io.netty.buffer.ByteBuf
Gets a 24-bit medium integer at the specified absolute index in this buffer.
getMedium(int) - Method in class io.netty.buffer.EmptyByteBuf
 
getMedium(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
getMediumLE(int) - Method in class io.netty.buffer.AbstractByteBuf
 
getMediumLE(int) - Method in class io.netty.buffer.ByteBuf
Gets a 24-bit medium integer at the specified absolute index in this buffer in the Little Endian Byte Order.
getMediumLE(int) - Method in class io.netty.buffer.EmptyByteBuf
 
getMediumLE(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
getMessageSizeEstimator() - Method in interface io.netty.channel.ChannelConfig
Returns MessageSizeEstimator which is used for the channel to detect the size of a message.
getMessageSizeEstimator() - Method in class io.netty.channel.DefaultChannelConfig
 
getNetworkInterface() - Method in class io.netty.channel.epoll.EpollDatagramChannelConfig
 
getNetworkInterface() - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
 
getNetworkInterface() - Method in interface io.netty.channel.socket.DatagramChannelConfig
getNetworkInterface() - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
 
getNonCriticalExtensionOIDs() - Method in class io.netty.handler.ssl.PemX509Certificate
 
getNotAfter() - Method in class io.netty.handler.ssl.PemX509Certificate
 
getNotBefore() - Method in class io.netty.handler.ssl.PemX509Certificate
 
getNow() - Method in class io.netty.util.concurrent.DefaultPromise
 
getNow() - Method in class io.netty.util.concurrent.FailedFuture
 
getNow() - Method in interface io.netty.util.concurrent.Future
Return the result without blocking.
getNow() - Method in class io.netty.util.concurrent.SucceededFuture
 
getOption(ChannelOption<T>) - Method in interface io.netty.channel.ChannelConfig
Return the value of the given ChannelOption
getOption(ChannelOption<T>) - Method in class io.netty.channel.DefaultChannelConfig
 
getOption(ChannelOption<T>) - Method in class io.netty.channel.epoll.EpollChannelConfig
 
getOption(ChannelOption<T>) - Method in class io.netty.channel.epoll.EpollDatagramChannelConfig
 
getOption(ChannelOption<T>) - Method in class io.netty.channel.epoll.EpollDomainSocketChannelConfig
 
getOption(ChannelOption<T>) - Method in class io.netty.channel.epoll.EpollServerChannelConfig
 
getOption(ChannelOption<T>) - Method in class io.netty.channel.epoll.EpollServerSocketChannelConfig
 
getOption(ChannelOption<T>) - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
 
getOption(ChannelOption<T>) - Method in class io.netty.channel.kqueue.KQueueChannelConfig
 
getOption(ChannelOption<T>) - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
 
getOption(ChannelOption<T>) - Method in class io.netty.channel.kqueue.KQueueDomainSocketChannelConfig
 
getOption(ChannelOption<T>) - Method in class io.netty.channel.kqueue.KQueueServerChannelConfig
 
getOption(ChannelOption<T>) - Method in class io.netty.channel.kqueue.KQueueServerSocketChannelConfig
 
getOption(ChannelOption<T>) - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
 
getOption(ChannelOption<T>) - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
 
getOption(ChannelOption<T>) - Method in class io.netty.channel.socket.DefaultServerSocketChannelConfig
 
getOption(ChannelOption<T>) - Method in class io.netty.channel.socket.DefaultSocketChannelConfig
 
getOption(ChannelOption<T>) - Method in class io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig
 
getOption(ChannelOption<T>) - Method in class io.netty.channel.socket.oio.DefaultOioSocketChannelConfig
 
getOptions() - Method in interface io.netty.channel.ChannelConfig
Return all set ChannelOption's.
getOptions() - Method in class io.netty.channel.DefaultChannelConfig
 
getOptions(Map<ChannelOption<?>, Object>, ChannelOption<?>...) - Method in class io.netty.channel.DefaultChannelConfig
 
getOptions() - Method in class io.netty.channel.epoll.EpollChannelConfig
 
getOptions() - Method in class io.netty.channel.epoll.EpollDatagramChannelConfig
 
getOptions() - Method in class io.netty.channel.epoll.EpollDomainSocketChannelConfig
 
getOptions() - Method in class io.netty.channel.epoll.EpollServerChannelConfig
 
getOptions() - Method in class io.netty.channel.epoll.EpollServerSocketChannelConfig
 
getOptions() - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
 
getOptions() - Method in class io.netty.channel.kqueue.KQueueChannelConfig
 
getOptions() - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
 
getOptions() - Method in class io.netty.channel.kqueue.KQueueDomainSocketChannelConfig
 
getOptions() - Method in class io.netty.channel.kqueue.KQueueServerChannelConfig
 
getOptions() - Method in class io.netty.channel.kqueue.KQueueServerSocketChannelConfig
 
getOptions() - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
 
getOptions() - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
 
getOptions() - Method in class io.netty.channel.socket.DefaultServerSocketChannelConfig
 
getOptions() - Method in class io.netty.channel.socket.DefaultSocketChannelConfig
 
getOptions() - Method in class io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig
 
getOptions() - Method in class io.netty.channel.socket.oio.DefaultOioSocketChannelConfig
 
getPublicKey() - Method in class io.netty.handler.ssl.PemX509Certificate
 
GETQ - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
getRcvAllocTransportProvidesGuess() - Method in class io.netty.channel.kqueue.KQueueChannelConfig
If this is true then the RecvByteBufAllocator.Handle#guess() will be overriden to always attempt to read as many bytes as kqueue says are available.
getReadChannelLimit() - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
 
getReaderIdleTimeInMillis() - Method in class io.netty.handler.timeout.IdleStateHandler
Return the readerIdleTime that was given when instance this class in milliseconds.
getReadLimit() - Method in class io.netty.handler.traffic.AbstractTrafficShapingHandler
 
getReadMode() - Method in class io.netty.channel.epoll.EpollDomainSocketChannelConfig
 
getReadMode() - Method in class io.netty.channel.kqueue.KQueueDomainSocketChannelConfig
 
getReadMode() - Method in interface io.netty.channel.unix.DomainSocketChannelConfig
Return the DomainSocketReadMode for the channel.
getRealWriteThroughput() - Method in class io.netty.handler.traffic.TrafficCounter
 
getRealWrittenBytes() - Method in class io.netty.handler.traffic.TrafficCounter
 
getReceiveBufferSize() - Method in class io.netty.channel.epoll.EpollDatagramChannelConfig
 
getReceiveBufferSize() - Method in class io.netty.channel.epoll.EpollServerChannelConfig
 
getReceiveBufferSize() - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
 
getReceiveBufferSize() - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
 
getReceiveBufferSize() - Method in class io.netty.channel.kqueue.KQueueServerChannelConfig
 
getReceiveBufferSize() - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
 
getReceiveBufferSize() - Method in interface io.netty.channel.socket.DatagramChannelConfig
getReceiveBufferSize() - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
 
getReceiveBufferSize() - Method in class io.netty.channel.socket.DefaultServerSocketChannelConfig
 
getReceiveBufferSize() - Method in class io.netty.channel.socket.DefaultSocketChannelConfig
 
getReceiveBufferSize() - Method in interface io.netty.channel.socket.ServerSocketChannelConfig
getReceiveBufferSize() - Method in interface io.netty.channel.socket.SocketChannelConfig
getReceiveBufferSize() - Method in class io.netty.channel.unix.Socket
 
getRecvByteBufAllocator() - Method in interface io.netty.channel.ChannelConfig
Returns RecvByteBufAllocator which is used for the channel to allocate receive buffers.
getRecvByteBufAllocator() - Method in class io.netty.channel.DefaultChannelConfig
 
getResolver(EventExecutor) - Method in class io.netty.resolver.AddressResolverGroup
Returns the AddressResolver associated with the specified EventExecutor.
getSendBufferSize() - Method in class io.netty.channel.epoll.EpollDatagramChannelConfig
 
getSendBufferSize() - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
 
getSendBufferSize() - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
 
getSendBufferSize() - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
 
getSendBufferSize() - Method in interface io.netty.channel.socket.DatagramChannelConfig
getSendBufferSize() - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
 
getSendBufferSize() - Method in class io.netty.channel.socket.DefaultSocketChannelConfig
 
getSendBufferSize() - Method in interface io.netty.channel.socket.SocketChannelConfig
getSendBufferSize() - Method in class io.netty.channel.unix.Socket
 
getSerialNumber() - Method in class io.netty.handler.ssl.PemX509Certificate
 
getShort(int) - Method in class io.netty.buffer.AbstractByteBuf
 
getShort(int) - Method in class io.netty.buffer.ByteBuf
Gets a 16-bit short integer at the specified absolute index in this buffer.
getShort(int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
getShort(int) - Method in class io.netty.buffer.EmptyByteBuf
 
getShort(int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
getShort(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
getShort(int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
getShort(int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
getShort(K) - Method in class io.netty.handler.codec.DefaultHeaders
 
getShort(K, short) - Method in class io.netty.handler.codec.DefaultHeaders
 
getShort(K) - Method in class io.netty.handler.codec.EmptyHeaders
 
getShort(K, short) - Method in class io.netty.handler.codec.EmptyHeaders
 
getShort(K) - Method in interface io.netty.handler.codec.Headers
Returns the short value of a header with the specified name.
getShort(K, short) - Method in interface io.netty.handler.codec.Headers
Returns the short value of a header with the specified name.
getShort(long) - Static method in class io.netty.util.internal.PlatformDependent
 
getShort(byte[], int) - Static method in class io.netty.util.internal.PlatformDependent
 
getShortAndRemove(K) - Method in class io.netty.handler.codec.DefaultHeaders
 
getShortAndRemove(K, short) - Method in class io.netty.handler.codec.DefaultHeaders
 
getShortAndRemove(K) - Method in class io.netty.handler.codec.EmptyHeaders
 
getShortAndRemove(K, short) - Method in class io.netty.handler.codec.EmptyHeaders
 
getShortAndRemove(K) - Method in interface io.netty.handler.codec.Headers
Returns the short value of a header with the specified name and removes the header from this object.
getShortAndRemove(K, short) - Method in interface io.netty.handler.codec.Headers
Returns the short value of a header with the specified name and removes the header from this object.
getShortLE(int) - Method in class io.netty.buffer.AbstractByteBuf
 
getShortLE(int) - Method in class io.netty.buffer.ByteBuf
Gets a 16-bit short integer at the specified absolute index in this buffer in Little Endian Byte Order.
getShortLE(int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
getShortLE(int) - Method in class io.netty.buffer.EmptyByteBuf
 
getShortLE(int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
getShortLE(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
getShortLE(int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
getSigAlgName() - Method in class io.netty.handler.ssl.PemX509Certificate
 
getSigAlgOID() - Method in class io.netty.handler.ssl.PemX509Certificate
 
getSigAlgParams() - Method in class io.netty.handler.ssl.PemX509Certificate
 
getSignature() - Method in class io.netty.handler.ssl.PemX509Certificate
 
getSimpleString(String) - Method in class io.netty.handler.codec.redis.FixedRedisMessagePool
 
getSimpleString(ByteBuf) - Method in class io.netty.handler.codec.redis.FixedRedisMessagePool
 
getSimpleString(String) - Method in interface io.netty.handler.codec.redis.RedisMessagePool
Returns SimpleStringRedisMessage for given content.
getSimpleString(ByteBuf) - Method in interface io.netty.handler.codec.redis.RedisMessagePool
Returns SimpleStringRedisMessage for given content.
getSndLowAt() - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
 
getSoError() - Method in class io.netty.channel.unix.Socket
 
getSoLinger() - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
 
getSoLinger() - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
 
getSoLinger() - Method in class io.netty.channel.socket.DefaultSocketChannelConfig
 
getSoLinger() - Method in interface io.netty.channel.socket.SocketChannelConfig
getSoLinger() - Method in class io.netty.channel.unix.Socket
 
getSoTimeout() - Method in class io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig
 
getSoTimeout() - Method in class io.netty.channel.socket.oio.DefaultOioSocketChannelConfig
 
getSoTimeout() - Method in interface io.netty.channel.socket.oio.OioServerSocketChannelConfig
Returns the maximal time a operation on the underlying socket may block.
getSoTimeout() - Method in interface io.netty.channel.socket.oio.OioSocketChannelConfig
Returns the maximal time a operation on the underlying socket may block.
getSubjectDN() - Method in class io.netty.handler.ssl.PemX509Certificate
 
getSubjectUniqueID() - Method in class io.netty.handler.ssl.PemX509Certificate
 
getSystemClassLoader() - Static method in class io.netty.util.internal.PlatformDependent
Return the system ClassLoader.
getTBSCertificate() - Method in class io.netty.handler.ssl.PemX509Certificate
 
getTcpDeferAccept() - Method in class io.netty.channel.epoll.EpollServerSocketChannelConfig
Returns a positive value if TCP_DEFER_ACCEPT is enabled.
getTcpFastopen() - Method in class io.netty.channel.epoll.EpollServerChannelConfig
Returns threshold value of number of pending for fast open connect.
getTcpKeepCnt() - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
Get the TCP_KEEPCNT option on the socket.
getTcpKeepIdle() - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
Get the TCP_KEEPIDLE option on the socket.
getTcpKeepIntvl() - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
Get the TCP_KEEPINTVL option on the socket.
getTcpNotSentLowAt() - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
Get the TCP_NOTSENT_LOWAT option on the socket.
getTcpUserTimeout() - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
Get the TCP_USER_TIMEOUT option on the socket.
getTimeMillis(K) - Method in class io.netty.handler.codec.DefaultHeaders
 
getTimeMillis(K, long) - Method in class io.netty.handler.codec.DefaultHeaders
 
getTimeMillis(K) - Method in class io.netty.handler.codec.EmptyHeaders
 
getTimeMillis(K, long) - Method in class io.netty.handler.codec.EmptyHeaders
 
getTimeMillis(K) - Method in interface io.netty.handler.codec.Headers
Returns the value of a header with the specified name in milliseconds.
getTimeMillis(K, long) - Method in interface io.netty.handler.codec.Headers
Returns the value of a header with the specified name in milliseconds.
getTimeMillisAndRemove(K) - Method in class io.netty.handler.codec.DefaultHeaders
 
getTimeMillisAndRemove(K, long) - Method in class io.netty.handler.codec.DefaultHeaders
 
getTimeMillisAndRemove(K) - Method in class io.netty.handler.codec.EmptyHeaders
 
getTimeMillisAndRemove(K, long) - Method in class io.netty.handler.codec.EmptyHeaders
 
getTimeMillisAndRemove(K) - Method in interface io.netty.handler.codec.Headers
Returns the value of a header with the specified name in milliseconds and removes the header from this object.
getTimeMillisAndRemove(K, long) - Method in interface io.netty.handler.codec.Headers
Returns the value of a header with the specified name in milliseconds and removes the header from this object.
getTimeToLive() - Method in class io.netty.channel.epoll.EpollDatagramChannelConfig
 
getTimeToLive() - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
 
getTimeToLive() - Method in interface io.netty.channel.socket.DatagramChannelConfig
getTimeToLive() - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
 
getTrafficClass() - Method in class io.netty.channel.epoll.EpollDatagramChannelConfig
 
getTrafficClass() - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
 
getTrafficClass() - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
 
getTrafficClass() - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
 
getTrafficClass() - Method in interface io.netty.channel.socket.DatagramChannelConfig
getTrafficClass() - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
 
getTrafficClass() - Method in class io.netty.channel.socket.DefaultSocketChannelConfig
 
getTrafficClass() - Method in interface io.netty.channel.socket.SocketChannelConfig
getTrafficClass() - Method in class io.netty.channel.unix.Socket
 
getUnadjustedFrameLength(ByteBuf, int, int, ByteOrder) - Method in class io.netty.handler.codec.LengthFieldBasedFrameDecoder
Decodes the specified region of the buffer into an unadjusted frame length.
getUnsignedByte(int) - Method in class io.netty.buffer.AbstractByteBuf
 
getUnsignedByte(int) - Method in class io.netty.buffer.ByteBuf
Gets an unsigned byte at the specified absolute index in this buffer.
getUnsignedByte(int) - Method in class io.netty.buffer.EmptyByteBuf
 
getUnsignedByte(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
getUnsignedInt(int) - Method in class io.netty.buffer.AbstractByteBuf
 
getUnsignedInt(int) - Method in class io.netty.buffer.ByteBuf
Gets an unsigned 32-bit integer at the specified absolute index in this buffer.
getUnsignedInt(int) - Method in class io.netty.buffer.EmptyByteBuf
 
getUnsignedInt(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
getUnsignedIntLE(int) - Method in class io.netty.buffer.AbstractByteBuf
 
getUnsignedIntLE(int) - Method in class io.netty.buffer.ByteBuf
Gets an unsigned 32-bit integer at the specified absolute index in this buffer in Little Endian Byte Order.
getUnsignedIntLE(int) - Method in class io.netty.buffer.EmptyByteBuf
 
getUnsignedIntLE(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
getUnsignedMedium(int) - Method in class io.netty.buffer.AbstractByteBuf
 
getUnsignedMedium(int) - Method in class io.netty.buffer.ByteBuf
Gets an unsigned 24-bit medium integer at the specified absolute index in this buffer.
getUnsignedMedium(int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
getUnsignedMedium(int) - Method in class io.netty.buffer.EmptyByteBuf
 
getUnsignedMedium(int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
getUnsignedMedium(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
getUnsignedMedium(int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
getUnsignedMedium(int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
getUnsignedMediumLE(int) - Method in class io.netty.buffer.AbstractByteBuf
 
getUnsignedMediumLE(int) - Method in class io.netty.buffer.ByteBuf
Gets an unsigned 24-bit medium integer at the specified absolute index in this buffer in Little Endian Byte Order.
getUnsignedMediumLE(int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
getUnsignedMediumLE(int) - Method in class io.netty.buffer.EmptyByteBuf
 
getUnsignedMediumLE(int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
getUnsignedMediumLE(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
getUnsignedMediumLE(int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
getUnsignedShort(int) - Method in class io.netty.buffer.AbstractByteBuf
 
getUnsignedShort(int) - Method in class io.netty.buffer.ByteBuf
Gets an unsigned 16-bit short integer at the specified absolute index in this buffer.
getUnsignedShort(int) - Method in class io.netty.buffer.EmptyByteBuf
 
getUnsignedShort(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
getUnsignedShortLE(int) - Method in class io.netty.buffer.AbstractByteBuf
 
getUnsignedShortLE(int) - Method in class io.netty.buffer.ByteBuf
Gets an unsigned 16-bit short integer at the specified absolute index in this buffer in Little Endian Byte Order.
getUnsignedShortLE(int) - Method in class io.netty.buffer.EmptyByteBuf
 
getUnsignedShortLE(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
getUserDefinedWritability(int) - Method in class io.netty.channel.ChannelOutboundBuffer
Returns true if and only if the user-defined writability flag at the specified index is set to true.
getValue() - Method in class io.netty.handler.codec.DefaultHeaders.HeaderEntry
 
getVersion() - Method in class io.netty.handler.ssl.PemX509Certificate
 
getWriteBufferHighWaterMark() - Method in interface io.netty.channel.ChannelConfig
Returns the high water mark of the write buffer.
getWriteBufferHighWaterMark() - Method in class io.netty.channel.DefaultChannelConfig
 
getWriteBufferLowWaterMark() - Method in interface io.netty.channel.ChannelConfig
Returns the low water mark of the write buffer.
getWriteBufferLowWaterMark() - Method in class io.netty.channel.DefaultChannelConfig
 
getWriteBufferWaterMark() - Method in interface io.netty.channel.ChannelConfig
Returns the WriteBufferWaterMark which is used for setting the high and low water mark of the write buffer.
getWriteBufferWaterMark() - Method in class io.netty.channel.DefaultChannelConfig
 
getWriteChannelLimit() - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
 
getWriteLimit() - Method in class io.netty.handler.traffic.AbstractTrafficShapingHandler
 
getWriterIdleTimeInMillis() - Method in class io.netty.handler.timeout.IdleStateHandler
Return the writerIdleTime that was given when instance this class in milliseconds.
getWriteSpinCount() - Method in interface io.netty.channel.ChannelConfig
Returns the maximum loop count for a write operation until WritableByteChannel.write(ByteBuffer) returns a non-zero value.
getWriteSpinCount() - Method in class io.netty.channel.DefaultChannelConfig
 
gids() - Method in class io.netty.channel.unix.PeerCredentials
 
GlobalChannelTrafficCounter - Class in io.netty.handler.traffic
GlobalChannelTrafficCounter(GlobalChannelTrafficShapingHandler, ScheduledExecutorService, String, long) - Constructor for class io.netty.handler.traffic.GlobalChannelTrafficCounter
 
GlobalChannelTrafficShapingHandler - Class in io.netty.handler.traffic
This implementation of the AbstractTrafficShapingHandler is for global and per channel traffic shaping, that is to say a global limitation of the bandwidth, whatever the number of opened channels and a per channel limitation of the bandwidth.

This version shall not be in the same pipeline than other TrafficShapingHandler.

The general use should be as follow:
Create your unique GlobalChannelTrafficShapingHandler like:

GlobalChannelTrafficShapingHandler myHandler = new GlobalChannelTrafficShapingHandler(executor);

The executor could be the underlying IO worker pool
pipeline.addLast(myHandler);

Note that this handler has a Pipeline Coverage of "all" which means only one such handler must be created and shared among all channels as the counter must be shared among all channels.

Other arguments can be passed like write or read limitation (in bytes/s where 0 means no limitation) or the check interval (in millisecond) that represents the delay between two computations of the bandwidth and so the call back of the doAccounting method (0 means no accounting at all).
Note that as this is a fusion of both Global and Channel Traffic Shaping, limits are in 2 sets, respectively Global and Channel.

A value of 0 means no accounting for checkInterval.
GlobalChannelTrafficShapingHandler(ScheduledExecutorService, long, long, long, long, long, long) - Constructor for class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
Create a new instance.
GlobalChannelTrafficShapingHandler(ScheduledExecutorService, long, long, long, long, long) - Constructor for class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
Create a new instance.
GlobalChannelTrafficShapingHandler(ScheduledExecutorService, long, long, long, long) - Constructor for class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
Create a new instance.
GlobalChannelTrafficShapingHandler(ScheduledExecutorService, long) - Constructor for class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
Create a new instance.
GlobalChannelTrafficShapingHandler(ScheduledExecutorService) - Constructor for class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
Create a new instance.
GlobalEventExecutor - Class in io.netty.util.concurrent
Single-thread singleton EventExecutor.
GlobalTrafficShapingHandler - Class in io.netty.handler.traffic
This implementation of the AbstractTrafficShapingHandler is for global traffic shaping, that is to say a global limitation of the bandwidth, whatever the number of opened channels.
GlobalTrafficShapingHandler(ScheduledExecutorService, long, long, long, long) - Constructor for class io.netty.handler.traffic.GlobalTrafficShapingHandler
Create a new instance.
GlobalTrafficShapingHandler(ScheduledExecutorService, long, long, long) - Constructor for class io.netty.handler.traffic.GlobalTrafficShapingHandler
Create a new instance using default max time as delay allowed value of 15000 ms.
GlobalTrafficShapingHandler(ScheduledExecutorService, long, long) - Constructor for class io.netty.handler.traffic.GlobalTrafficShapingHandler
Create a new instance using default Check Interval value of 1000 ms and default max time as delay allowed value of 15000 ms.
GlobalTrafficShapingHandler(ScheduledExecutorService, long) - Constructor for class io.netty.handler.traffic.GlobalTrafficShapingHandler
Create a new instance using default max time as delay allowed value of 15000 ms and no limit.
GlobalTrafficShapingHandler(EventExecutor) - Constructor for class io.netty.handler.traffic.GlobalTrafficShapingHandler
Create a new instance using default Check Interval value of 1000 ms and default max time as delay allowed value of 15000 ms and no limit.
grantedQoSLevels() - Method in class io.netty.handler.codec.mqtt.MqttSubAckPayload
 
group(EventLoopGroup) - Method in class io.netty.bootstrap.AbstractBootstrap
The EventLoopGroup which is used to handle all the events for the to-be-created Channel
group() - Method in class io.netty.bootstrap.AbstractBootstrap
Deprecated.
group() - Method in class io.netty.bootstrap.AbstractBootstrapConfig
Returns the configured EventLoopGroup or null if non is configured yet.
group(EventLoopGroup) - Method in class io.netty.bootstrap.ServerBootstrap
Specify the EventLoopGroup which is used for the parent (acceptor) and the child (client).
group(EventLoopGroup, EventLoopGroup) - Method in class io.netty.bootstrap.ServerBootstrap
Set the EventLoopGroup for the parent (acceptor) and the child (client).
group() - Method in interface io.netty.channel.group.ChannelGroupFuture
Returns the ChannelGroup which is associated with this future.
guess() - Method in class io.netty.channel.RecvByteBufAllocator.DelegatingHandle
 
guess() - Method in interface io.netty.channel.RecvByteBufAllocator.Handle
Deprecated.
Similar to RecvByteBufAllocator.Handle.allocate(ByteBufAllocator) except that it does not allocate anything but just tells the capacity.

H

handleInboundMessage(Object) - Method in class io.netty.channel.embedded.EmbeddedChannel
Called for each inbound message.
handleOutboundMessage(Object) - Method in class io.netty.channel.embedded.EmbeddedChannel
Called for each outbound message.
handleOversizedMessage(ChannelHandlerContext, S) - Method in class io.netty.handler.codec.MessageAggregator
Invoked when an incoming request exceeds the maximum content length.
handler(ChannelHandler) - Method in class io.netty.bootstrap.AbstractBootstrap
the ChannelHandler to use for serving the requests.
handler() - Method in class io.netty.bootstrap.AbstractBootstrapConfig
Returns the configured ChannelHandler or null if non is configured yet.
handler() - Method in interface io.netty.channel.ChannelHandlerContext
The ChannelHandler that is bound this ChannelHandlerContext.
handler() - Method in class io.netty.channel.pool.SimpleChannelPool
Returns the ChannelPoolHandler that will be notified for the different pool actions.
handlerAdded(ChannelHandlerContext) - Method in interface io.netty.channel.ChannelHandler
Gets called after the ChannelHandler was added to the actual context and it's ready to handle events.
handlerAdded(ChannelHandlerContext) - Method in class io.netty.channel.ChannelHandlerAdapter
Do nothing by default, sub-classes may override this method.
handlerAdded(ChannelHandlerContext) - Method in class io.netty.channel.ChannelInitializer
Do nothing by default, sub-classes may override this method.
handlerAdded(ChannelHandlerContext) - Method in class io.netty.channel.CombinedChannelDuplexHandler
 
handlerAdded(ChannelHandlerContext) - Method in class io.netty.handler.codec.ByteToMessageCodec
 
handlerAdded(ChannelHandlerContext) - Method in class io.netty.handler.codec.compression.Bzip2Encoder
 
handlerAdded(ChannelHandlerContext) - Method in class io.netty.handler.codec.compression.JdkZlibEncoder
 
handlerAdded(ChannelHandlerContext) - Method in class io.netty.handler.codec.compression.JZlibEncoder
 
handlerAdded(ChannelHandlerContext) - Method in class io.netty.handler.codec.DatagramPacketDecoder
 
handlerAdded(ChannelHandlerContext) - Method in class io.netty.handler.codec.DatagramPacketEncoder
 
handlerAdded(ChannelHandlerContext) - Method in class io.netty.handler.codec.MessageAggregator
 
handlerAdded(ChannelHandlerContext) - Method in class io.netty.handler.flow.FlowControlHandler
 
handlerAdded(ChannelHandlerContext) - Method in class io.netty.handler.flush.FlushConsolidationHandler
 
handlerAdded(ChannelHandlerContext) - Method in class io.netty.handler.ssl.SslHandler
 
handlerAdded(ChannelHandlerContext) - Method in class io.netty.handler.stream.ChunkedWriteHandler
 
handlerAdded(ChannelHandlerContext) - Method in class io.netty.handler.timeout.IdleStateHandler
 
handlerAdded(ChannelHandlerContext) - Method in class io.netty.handler.traffic.ChannelTrafficShapingHandler
 
handlerAdded(ChannelHandlerContext) - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
 
handlerAdded(ChannelHandlerContext) - Method in class io.netty.handler.traffic.GlobalTrafficShapingHandler
 
handlerRemoved(ChannelHandlerContext) - Method in interface io.netty.channel.ChannelHandler
Gets called after the ChannelHandler was removed from the actual context and it doesn't handle events anymore.
handlerRemoved(ChannelHandlerContext) - Method in class io.netty.channel.ChannelHandlerAdapter
Do nothing by default, sub-classes may override this method.
handlerRemoved(ChannelHandlerContext) - Method in class io.netty.channel.CombinedChannelDuplexHandler
 
handlerRemoved(ChannelHandlerContext) - Method in class io.netty.handler.codec.ByteToMessageCodec
 
handlerRemoved(ChannelHandlerContext) - Method in class io.netty.handler.codec.ByteToMessageDecoder
 
handlerRemoved(ChannelHandlerContext) - Method in class io.netty.handler.codec.DatagramPacketDecoder
 
handlerRemoved(ChannelHandlerContext) - Method in class io.netty.handler.codec.DatagramPacketEncoder
 
handlerRemoved(ChannelHandlerContext) - Method in class io.netty.handler.codec.MessageAggregator
 
handlerRemoved(ChannelHandlerContext) - Method in class io.netty.handler.flush.FlushConsolidationHandler
 
handlerRemoved(ChannelHandlerContext) - Method in class io.netty.handler.timeout.IdleStateHandler
 
handlerRemoved(ChannelHandlerContext) - Method in class io.netty.handler.timeout.WriteTimeoutHandler
 
handlerRemoved(ChannelHandlerContext) - Method in class io.netty.handler.traffic.ChannelTrafficShapingHandler
 
handlerRemoved(ChannelHandlerContext) - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
 
handlerRemoved(ChannelHandlerContext) - Method in class io.netty.handler.traffic.GlobalTrafficShapingHandler
 
handlerRemoved0(ChannelHandlerContext) - Method in class io.netty.handler.codec.ByteToMessageDecoder
Gets called after the ByteToMessageDecoder was removed from the actual context and it doesn't handle events anymore.
handlerRemoved0(ChannelHandlerContext) - Method in class io.netty.handler.codec.compression.JdkZlibDecoder
 
handlerRemoved0(ChannelHandlerContext) - Method in class io.netty.handler.ssl.SslHandler
 
handlerSharableCache() - Method in class io.netty.util.internal.InternalThreadLocalMap
 
handshakeFailure(ChannelHandlerContext, Throwable) - Method in class io.netty.handler.ssl.ApplicationProtocolNegotiationHandler
Invoked on failed initial SSL/TLS handshake.
handshakeFuture() - Method in class io.netty.handler.ssl.SslHandler
Returns a Future that will get notified once the current TLS handshake completes.
hardwareAddressFromNetworkInterface(NetworkInterface) - Static method in class io.netty.util.internal.SocketUtils
 
hasArray() - Method in class io.netty.buffer.ByteBuf
Returns true if and only if this buffer has a backing byte array.
hasArray() - Method in class io.netty.buffer.CompositeByteBuf
 
hasArray() - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
hasArray() - Method in class io.netty.buffer.EmptyByteBuf
 
hasArray() - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
hasArray() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
hasArray() - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
hasArray() - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
hasArray() - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
hasAttr(AttributeKey<T>) - Method in interface io.netty.channel.ChannelHandlerContext
hasAttr(AttributeKey<T>) - Method in interface io.netty.util.AttributeMap
Returns true if and only if the given Attribute exists in this AttributeMap.
hasAttr(AttributeKey<T>) - Method in class io.netty.util.DefaultAttributeMap
 
hasDisconnect() - Method in class io.netty.channel.ChannelMetadata
Returns true if and only if the channel has the disconnect() operation that allows a user to disconnect and then call ChannelOutboundInvoker.connect(SocketAddress) again, such as UDP/IP.
hash - Variable in class io.netty.handler.codec.DefaultHeaders.HeaderEntry
 
hashCode() - Method in class io.netty.buffer.AbstractByteBuf
 
hashCode() - Method in class io.netty.buffer.ByteBuf
Returns a hash code which was calculated from the content of this buffer.
hashCode(ByteBuf) - Static method in class io.netty.buffer.ByteBufUtil
Calculates the hash code of the specified buffer.
hashCode() - Method in class io.netty.buffer.DefaultByteBufHolder
 
hashCode() - Method in class io.netty.buffer.EmptyByteBuf
 
hashCode() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
hashCode() - Method in class io.netty.channel.AbstractChannel
Returns the ID of this channel.
hashCode() - Method in class io.netty.channel.DefaultChannelId
 
hashCode() - Method in class io.netty.channel.group.DefaultChannelGroup
 
hashCode() - Method in class io.netty.channel.kqueue.AcceptFilter
 
hashCode() - Method in class io.netty.channel.local.LocalAddress
 
hashCode() - Method in class io.netty.channel.unix.DomainSocketAddress
 
hashCode() - Method in class io.netty.channel.unix.FileDescriptor
 
hashCode() - Method in class io.netty.handler.codec.DefaultHeaders
 
hashCode(HashingStrategy<V>) - Method in class io.netty.handler.codec.DefaultHeaders
Generate a hash code for this object given a HashingStrategy to generate hash codes for individual values.
hashCode() - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
 
hashCode() - Method in class io.netty.handler.codec.dns.AbstractDnsRecord
 
hashCode() - Method in class io.netty.handler.codec.dns.DatagramDnsQuery
 
hashCode() - Method in class io.netty.handler.codec.dns.DatagramDnsResponse
 
hashCode() - Method in class io.netty.handler.codec.dns.DnsOpCode
 
hashCode() - Method in class io.netty.handler.codec.dns.DnsRecordType
 
hashCode() - Method in class io.netty.handler.codec.dns.DnsResponseCode
 
hashCode() - Method in class io.netty.handler.codec.EmptyHeaders
 
hashCode() - Method in class io.netty.handler.codec.smtp.DefaultSmtpRequest
 
hashCode() - Method in class io.netty.handler.codec.smtp.DefaultSmtpResponse
 
hashCode() - Method in class io.netty.handler.codec.smtp.SmtpCommand
 
hashCode() - Method in class io.netty.handler.codec.string.LineSeparator
 
hashCode() - Method in class io.netty.handler.ssl.PemX509Certificate
 
hashCode() - Method in class io.netty.util.AbstractConstant
 
hashCode() - Method in class io.netty.util.AsciiString
hashCode(CharSequence) - Static method in class io.netty.util.AsciiString
Returns the case-insensitive hash code of the specified string.
hashCode() - Method in class io.netty.util.collection.ByteObjectHashMap
 
hashCode() - Method in class io.netty.util.collection.CharObjectHashMap
 
hashCode() - Method in class io.netty.util.collection.IntObjectHashMap
 
hashCode() - Method in class io.netty.util.collection.LongObjectHashMap
 
hashCode() - Method in class io.netty.util.collection.ShortObjectHashMap
 
hashCode(T) - Method in interface io.netty.util.HashingStrategy
Generate a hash code for obj.
hashCode() - Method in class io.netty.util.internal.EmptyPriorityQueue
 
hashCode() - Method in exception io.netty.util.ResourceLeakException
Deprecated.
 
hashCode() - Method in error io.netty.util.Signal
 
hashCodeAscii(byte[], int, int) - Static method in class io.netty.util.internal.PlatformDependent
Calculate a hash code of a byte array assuming ASCII character encoding.
hashCodeAscii(CharSequence) - Static method in class io.netty.util.internal.PlatformDependent
Calculate a hash code of a byte array assuming ASCII character encoding.
HashedWheelTimer - Class in io.netty.util
A Timer optimized for approximated I/O timeout scheduling.
HashedWheelTimer() - Constructor for class io.netty.util.HashedWheelTimer
Creates a new timer with the default thread factory (Executors.defaultThreadFactory()), default tick duration, and default number of ticks per wheel.
HashedWheelTimer(long, TimeUnit) - Constructor for class io.netty.util.HashedWheelTimer
Creates a new timer with the default thread factory (Executors.defaultThreadFactory()) and default number of ticks per wheel.
HashedWheelTimer(long, TimeUnit, int) - Constructor for class io.netty.util.HashedWheelTimer
Creates a new timer with the default thread factory (Executors.defaultThreadFactory()).
HashedWheelTimer(ThreadFactory) - Constructor for class io.netty.util.HashedWheelTimer
Creates a new timer with the default tick duration and default number of ticks per wheel.
HashedWheelTimer(ThreadFactory, long, TimeUnit) - Constructor for class io.netty.util.HashedWheelTimer
Creates a new timer with the default number of ticks per wheel.
HashedWheelTimer(ThreadFactory, long, TimeUnit, int) - Constructor for class io.netty.util.HashedWheelTimer
Creates a new timer.
HashedWheelTimer(ThreadFactory, long, TimeUnit, int, boolean) - Constructor for class io.netty.util.HashedWheelTimer
Creates a new timer.
HashedWheelTimer(ThreadFactory, long, TimeUnit, int, boolean, long) - Constructor for class io.netty.util.HashedWheelTimer
Creates a new timer.
HashingStrategy<T> - Interface in io.netty.util
Abstraction for hash code generation and equality comparison.
hasMemoryAddress() - Method in class io.netty.buffer.ByteBuf
Returns true if and only if this buffer has a reference to the low-level memory address that points to the backing data.
hasMemoryAddress() - Method in class io.netty.buffer.CompositeByteBuf
 
hasMemoryAddress() - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
hasMemoryAddress() - Method in class io.netty.buffer.EmptyByteBuf
 
hasMemoryAddress() - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
hasMemoryAddress() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
hasMemoryAddress() - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
hasMemoryAddress() - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
hasMemoryAddress() - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
hasNext() - Method in class io.netty.util.internal.ReadOnlyIterator
 
hasPassword() - Method in class io.netty.handler.codec.mqtt.MqttConnectVariableHeader
 
hasPassword(boolean) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
 
hasScheduledTasks() - Method in class io.netty.util.concurrent.AbstractScheduledEventExecutor
Returns true if a scheduled task is ready for processing.
hasTasks() - Method in class io.netty.channel.SingleThreadEventLoop
 
hasTasks() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
 
hasThreadLocalCache() - Method in class io.netty.buffer.PooledByteBufAllocator
Deprecated.
hasUnsafe() - Static method in class io.netty.util.internal.PlatformDependent
Return true if sun.misc.Unsafe was found on the classpath and can be used for accelerated direct memory access.
hasUnsupportedCriticalExtension() - Method in class io.netty.handler.ssl.PemX509Certificate
 
hasUser(boolean) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
 
hasUserName() - Method in class io.netty.handler.codec.mqtt.MqttConnectVariableHeader
 
head - Variable in class io.netty.handler.codec.DefaultHeaders
 
HeaderEntry(int, K) - Constructor for class io.netty.handler.codec.DefaultHeaders.HeaderEntry
 
Headers<K,V,T extends Headers<K,V,T>> - Interface in io.netty.handler.codec
Common interface for Headers which represents a mapping of key to value.
headers - Variable in class io.netty.handler.codec.stomp.DefaultStompHeadersSubframe
 
headers() - Method in class io.netty.handler.codec.stomp.DefaultStompHeadersSubframe
 
headers() - Method in interface io.netty.handler.codec.stomp.StompHeadersSubframe
Returns headers of this frame.
HeadersUtils - Class in io.netty.handler.codec
Provides utility methods related to Headers.
healthChecker() - Method in class io.netty.channel.pool.SimpleChannelPool
Returns the ChannelHealthChecker that will be used to check if a Channel is healthy.
heapArenas() - Method in class io.netty.buffer.PooledByteBufAllocator
heapArenas() - Method in class io.netty.buffer.PooledByteBufAllocatorMetric
Return a List of all heap PoolArenaMetrics that are provided by this pool.
heapBuffer() - Method in class io.netty.buffer.AbstractByteBufAllocator
 
heapBuffer(int) - Method in class io.netty.buffer.AbstractByteBufAllocator
 
heapBuffer(int, int) - Method in class io.netty.buffer.AbstractByteBufAllocator
 
heapBuffer() - Method in interface io.netty.buffer.ByteBufAllocator
Allocate a heap ByteBuf.
heapBuffer(int) - Method in interface io.netty.buffer.ByteBufAllocator
Allocate a heap ByteBuf with the given initial capacity.
heapBuffer(int, int) - Method in interface io.netty.buffer.ByteBufAllocator
Allocate a heap ByteBuf with the given initial capacity and the given maximal capacity.
HEART_BEAT - Static variable in interface io.netty.handler.codec.stomp.StompHeaders
 
HELO - Static variable in class io.netty.handler.codec.smtp.SmtpCommand
 
helo(CharSequence) - Static method in class io.netty.handler.codec.smtp.SmtpRequests
Creates a HELO request.
HELP - Static variable in class io.netty.handler.codec.smtp.SmtpCommand
 
help(String) - Static method in class io.netty.handler.codec.smtp.SmtpRequests
Creates a HELP request.
hexDump(ByteBuf) - Static method in class io.netty.buffer.ByteBufUtil
Returns a hex dump of the specified buffer's readable bytes.
hexDump(ByteBuf, int, int) - Static method in class io.netty.buffer.ByteBufUtil
Returns a hex dump of the specified buffer's sub-region.
hexDump(byte[]) - Static method in class io.netty.buffer.ByteBufUtil
Returns a hex dump of the specified byte array.
hexDump(byte[], int, int) - Static method in class io.netty.buffer.ByteBufUtil
Returns a hex dump of the specified byte array's sub-region.
high() - Method in class io.netty.channel.WriteBufferWaterMark
Returns the high water mark for the write buffer.
HIP - Static variable in class io.netty.handler.codec.dns.DnsRecordType
Host Identity Protocol record RFC 5205 Method of separating the end-point identifier and locator roles of IP addresses.
HOST - Static variable in interface io.netty.handler.codec.stomp.StompHeaders
 
hostname() - Method in class io.netty.handler.codec.dns.DefaultDnsPtrRecord
 
hostname() - Method in interface io.netty.handler.codec.dns.DnsPtrRecord
Returns the hostname this PTR record resolves to.
hostname() - Method in class io.netty.handler.ssl.SniHandler
 
hostname() - Method in class io.netty.resolver.dns.DnsCacheEntry
 
HostsFileEntries - Class in io.netty.resolver
A container of hosts file entries
HostsFileEntries(Map<String, Inet4Address>, Map<String, Inet6Address>) - Constructor for class io.netty.resolver.HostsFileEntries
 
hostsFileEntriesResolver() - Method in class io.netty.resolver.dns.DnsNameResolver
Returns the component that tries to resolve hostnames against the hosts file prior to asking to remotes DNS servers.
hostsFileEntriesResolver(HostsFileEntriesResolver) - Method in class io.netty.resolver.dns.DnsNameResolverBuilder
 
HostsFileEntriesResolver - Interface in io.netty.resolver
Resolves a hostname against the hosts file entries.
HostsFileParser - Class in io.netty.resolver
A parser for hosts files.
HTTP_1_1 - Static variable in class io.netty.handler.ssl.ApplicationProtocolNames
"http/1.1": HTTP version 1.1
HTTP_2 - Static variable in class io.netty.handler.ssl.ApplicationProtocolNames
"h2": HTTP version 2

I

id() - Method in class io.netty.channel.AbstractChannel
 
id() - Method in interface io.netty.channel.Channel
Returns the globally unique identifier of this Channel.
id() - Method in class io.netty.channel.local.LocalAddress
Returns the ID of this address.
id() - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
 
id() - Method in interface io.netty.handler.codec.dns.DnsMessage
Returns the ID of this DNS message.
ID - Static variable in interface io.netty.handler.codec.stomp.StompHeaders
 
id() - Method in class io.netty.util.AbstractConstant
 
id() - Method in interface io.netty.util.concurrent.ThreadProperties
 
id() - Method in interface io.netty.util.Constant
Returns the unique number assigned to this Constant.
id() - Method in error io.netty.util.Signal
 
identify() - Static method in class io.netty.util.Version
Retrieves the version information of Netty artifacts using the current context class loader.
identify(ClassLoader) - Static method in class io.netty.util.Version
Retrieves the version information of Netty artifacts using the specified ClassLoader.
IdentityCipherSuiteFilter - Class in io.netty.handler.ssl
This class will not do any filtering of ciphers suites.
IdleState - Enum in io.netty.handler.timeout
An Enum that represents the idle state of a Channel.
IdleStateEvent - Class in io.netty.handler.timeout
A user event triggered by IdleStateHandler when a Channel is idle.
IdleStateEvent(IdleState, boolean) - Constructor for class io.netty.handler.timeout.IdleStateEvent
Constructor for sub-classes.
IdleStateHandler - Class in io.netty.handler.timeout
Triggers an IdleStateEvent when a Channel has not performed read, write, or both operation for a while.
IdleStateHandler(int, int, int) - Constructor for class io.netty.handler.timeout.IdleStateHandler
Creates a new instance firing IdleStateEvents.
IdleStateHandler(long, long, long, TimeUnit) - Constructor for class io.netty.handler.timeout.IdleStateHandler
 
IdleStateHandler(boolean, long, long, long, TimeUnit) - Constructor for class io.netty.handler.timeout.IdleStateHandler
Creates a new instance firing IdleStateEvents.
ignoreContentAfterContinueResponse(Object) - Method in class io.netty.handler.codec.memcache.AbstractMemcacheObjectAggregator
 
ignoreContentAfterContinueResponse(Object) - Method in class io.netty.handler.codec.MessageAggregator
Determine if all objects for the current request/response should be ignored or not.
ignoreContentAfterContinueResponse(Object) - Method in class io.netty.handler.codec.redis.RedisBulkStringAggregator
 
ignoreContentAfterContinueResponse(Object) - Method in class io.netty.handler.codec.stomp.StompSubframeAggregator
 
IllegalReferenceCountException - Exception in io.netty.util
An IllegalStateException which is raised when a user attempts to access a ReferenceCounted whose reference count has been decreased to 0 (and consequently freed).
IllegalReferenceCountException() - Constructor for exception io.netty.util.IllegalReferenceCountException
 
IllegalReferenceCountException(int) - Constructor for exception io.netty.util.IllegalReferenceCountException
 
IllegalReferenceCountException(int, int) - Constructor for exception io.netty.util.IllegalReferenceCountException
 
IllegalReferenceCountException(String) - Constructor for exception io.netty.util.IllegalReferenceCountException
 
IllegalReferenceCountException(String, Throwable) - Constructor for exception io.netty.util.IllegalReferenceCountException
 
IllegalReferenceCountException(Throwable) - Constructor for exception io.netty.util.IllegalReferenceCountException
 
ImmediateEventExecutor - Class in io.netty.util.concurrent
Executes Runnable objects in the caller's thread.
ImmediateExecutor - Class in io.netty.util.concurrent
Executor which execute tasks in the callers thread.
inboundHandler() - Method in class io.netty.channel.CombinedChannelDuplexHandler
 
inboundMessages() - Method in class io.netty.channel.embedded.EmbeddedChannel
Returns the Queue which holds all the Objects that were received by this Channel.
incMessagesRead(int) - Method in class io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator.MaxMessageHandle
 
incMessagesRead(int) - Method in class io.netty.channel.RecvByteBufAllocator.DelegatingHandle
 
incMessagesRead(int) - Method in interface io.netty.channel.RecvByteBufAllocator.Handle
Deprecated.
Increment the number of messages that have been read for the current read loop.
incompleteWrite(boolean) - Method in class io.netty.channel.nio.AbstractNioByteChannel
 
increaseWriteCounter(long) - Method in class io.netty.channel.ChannelFlushPromiseNotifier
Increase the current write counter by the given delta
INCREMENT - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
increment() - Method in interface io.netty.util.internal.LongCounter
 
INCREMENTQ - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
INDEX_NOT_FOUND - Static variable in class io.netty.util.AsciiString
 
INDEX_NOT_IN_QUEUE - Static variable in interface io.netty.util.internal.PriorityQueueNode
This should be used to initialize the storage returned by PriorityQueueNode.priorityQueueIndex(DefaultPriorityQueue).
indexedVariable(int) - Method in class io.netty.util.internal.InternalThreadLocalMap
 
IndexNotOfProcessor(byte) - Constructor for class io.netty.util.ByteProcessor.IndexNotOfProcessor
 
indexOf(int, int, byte) - Method in class io.netty.buffer.AbstractByteBuf
 
indexOf(int, int, byte) - Method in class io.netty.buffer.ByteBuf
Locates the first occurrence of the specified value in this buffer.
indexOf(ByteBuf, ByteBuf) - Static method in class io.netty.buffer.ByteBufUtil
Returns the reader index of needle in haystack, or -1 if needle is not in haystack.
indexOf(ByteBuf, int, int, byte) - Static method in class io.netty.buffer.ByteBufUtil
The default implementation of ByteBuf.indexOf(int, int, byte).
indexOf(int, int, byte) - Method in class io.netty.buffer.EmptyByteBuf
 
indexOf(int, int, byte) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
indexOf(CharSequence) - Method in class io.netty.util.AsciiString
Searches in this string for the first index of the specified string.
indexOf(CharSequence, int) - Method in class io.netty.util.AsciiString
Searches in this string for the index of the specified string.
indexOf(char, int) - Method in class io.netty.util.AsciiString
Searches in this string for the index of the specified char ch.
indexOf(CharSequence, char, int) - Static method in class io.netty.util.AsciiString
Finds the first index in the CharSequence that matches the specified character.
indexOfIgnoreCase(CharSequence, CharSequence, int) - Static method in class io.netty.util.AsciiString
Case in-sensitive find of the first index within a CharSequence from the specified position.
indexOfIgnoreCaseAscii(CharSequence, CharSequence, int) - Static method in class io.netty.util.AsciiString
Case in-sensitive find of the first index within a CharSequence from the specified position.
indexOfNonWhiteSpace(CharSequence, int) - Static method in class io.netty.util.internal.StringUtil
Find the index of the first non-white space character in s starting at offset.
IndexOfProcessor(byte) - Constructor for class io.netty.util.ByteProcessor.IndexOfProcessor
 
inet4Entries() - Method in class io.netty.resolver.HostsFileEntries
The IPv4 entries
inet6Entries() - Method in class io.netty.resolver.HostsFileEntries
The IPv6 entries
InetNameResolver - Class in io.netty.resolver
A skeletal NameResolver implementation that resolves InetAddress.
InetNameResolver(EventExecutor) - Constructor for class io.netty.resolver.InetNameResolver
 
InetSocketAddressResolver - Class in io.netty.resolver
InetSocketAddressResolver(EventExecutor, NameResolver<InetAddress>) - Constructor for class io.netty.resolver.InetSocketAddressResolver
 
inEventLoop() - Method in class io.netty.util.concurrent.AbstractEventExecutor
 
inEventLoop() - Method in interface io.netty.util.concurrent.EventExecutor
inEventLoop(Thread) - Method in interface io.netty.util.concurrent.EventExecutor
Return true if the given Thread is executed in the event loop, false otherwise.
inEventLoop(Thread) - Method in class io.netty.util.concurrent.GlobalEventExecutor
 
inEventLoop() - Method in class io.netty.util.concurrent.ImmediateEventExecutor
 
inEventLoop(Thread) - Method in class io.netty.util.concurrent.ImmediateEventExecutor
 
inEventLoop(Thread) - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
 
inEventLoop() - Method in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor
 
inEventLoop(Thread) - Method in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor
 
info(Throwable) - Method in class io.netty.util.internal.logging.AbstractInternalLogger
 
info(String) - Method in interface io.netty.util.internal.logging.InternalLogger
Log a message at the INFO level.
info(String, Object) - Method in interface io.netty.util.internal.logging.InternalLogger
Log a message at the INFO level according to the specified format and argument.
info(String, Object, Object) - Method in interface io.netty.util.internal.logging.InternalLogger
Log a message at the INFO level according to the specified format and arguments.
info(String, Object...) - Method in interface io.netty.util.internal.logging.InternalLogger
Log a message at the INFO level according to the specified format and arguments.
info(String, Throwable) - Method in interface io.netty.util.internal.logging.InternalLogger
Log an exception (throwable) at the INFO level with an accompanying message.
info(Throwable) - Method in interface io.netty.util.internal.logging.InternalLogger
Log an exception (throwable) at the INFO level.
informReadOperation(ChannelHandlerContext, long) - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
 
init(I, O) - Method in class io.netty.channel.CombinedChannelDuplexHandler
Initialized this handler with the specified handlers.
initCause(Throwable) - Method in error io.netty.util.Signal
 
initChannel(C) - Method in class io.netty.channel.ChannelInitializer
This method will be called once the Channel was registered.
initEngine(SSLEngine) - Method in class io.netty.handler.ssl.DelegatingSslContext
Init the SSLEngine.
initialValue() - Method in class io.netty.util.concurrent.FastThreadLocal
Returns the initial value for this thread-local variable.
InsecureTrustManagerFactory - Class in io.netty.handler.ssl.util
An insecure TrustManagerFactory that trusts all X.509 certificates without any verification.
insertSinceRecycled() - Method in class io.netty.util.internal.RecyclableArrayList
Returns true if any elements where added or set.
INSTANCE - Static variable in class io.netty.channel.DefaultSelectStrategyFactory
 
INSTANCE - Static variable in class io.netty.channel.socket.ChannelInputShutdownEvent
Instance to use
INSTANCE - Static variable in class io.netty.channel.socket.ChannelInputShutdownReadComplete
 
INSTANCE - Static variable in class io.netty.handler.codec.CharSequenceValueConverter
 
INSTANCE - Static variable in class io.netty.handler.codec.mqtt.MqttEncoder
 
INSTANCE - Static variable in class io.netty.handler.codec.redis.FixedRedisMessagePool
A shared object for FixedRedisMessagePool.
instance() - Static method in class io.netty.handler.codec.UnsupportedValueConverter
 
INSTANCE - Static variable in class io.netty.handler.ssl.IdentityCipherSuiteFilter
 
INSTANCE - Static variable in class io.netty.handler.ssl.SupportedCipherSuiteFilter
 
INSTANCE - Static variable in class io.netty.handler.ssl.util.InsecureTrustManagerFactory
 
INSTANCE - Static variable in exception io.netty.handler.timeout.ReadTimeoutException
 
INSTANCE - Static variable in exception io.netty.handler.timeout.WriteTimeoutException
 
INSTANCE - Static variable in class io.netty.resolver.DefaultAddressResolverGroup
 
INSTANCE - Static variable in class io.netty.resolver.dns.DefaultDnsServerAddressStreamProvider
 
INSTANCE - Static variable in class io.netty.resolver.dns.NoopDnsCache
 
INSTANCE - Static variable in class io.netty.resolver.dns.NoopDnsQueryLifecycleObserverFactory
 
INSTANCE - Static variable in class io.netty.resolver.NoopAddressResolverGroup
 
INSTANCE - Static variable in class io.netty.util.concurrent.DefaultEventExecutorChooserFactory
 
INSTANCE - Static variable in class io.netty.util.concurrent.GlobalEventExecutor
 
INSTANCE - Static variable in class io.netty.util.concurrent.ImmediateEventExecutor
 
INSTANCE - Static variable in class io.netty.util.concurrent.ImmediateExecutor
 
instance() - Static method in class io.netty.util.internal.EmptyPriorityQueue
Returns an unmodifiable empty PriorityQueue.
INSTANCE - Static variable in class io.netty.util.internal.logging.CommonsLoggerFactory
Deprecated.
 
INSTANCE - Static variable in class io.netty.util.internal.logging.JdkLoggerFactory
 
INSTANCE - Static variable in class io.netty.util.internal.logging.Log4J2LoggerFactory
 
INSTANCE - Static variable in class io.netty.util.internal.logging.Log4JLoggerFactory
 
INSTANCE - Static variable in class io.netty.util.internal.logging.Slf4JLoggerFactory
 
instance() - Static method in class io.netty.util.ResourceLeakDetectorFactory
Get the singleton instance of this factory class.
IntCollections - Class in io.netty.util.collection
Utilities for int-based primitive collections.
IntegerHolder - Class in io.netty.util.internal
 
IntegerHolder() - Constructor for class io.netty.util.internal.IntegerHolder
 
IntegerRedisMessage - Class in io.netty.handler.codec.redis
Integers of RESP.
IntegerRedisMessage(long) - Constructor for class io.netty.handler.codec.redis.IntegerRedisMessage
Creates a IntegerRedisMessage for the given content.
internalBuffer() - Method in class io.netty.handler.codec.ByteToMessageDecoder
Returns the internal cumulative buffer of this decoder.
internalComponent(int) - Method in class io.netty.buffer.CompositeByteBuf
Return the internal ByteBuf on the specified index.
internalComponentAtOffset(int) - Method in class io.netty.buffer.CompositeByteBuf
Return the internal ByteBuf on the specified offset.
internalLevel - Variable in class io.netty.handler.logging.LoggingHandler
 
InternalLogger - Interface in io.netty.util.internal.logging
Internal-use-only logger used by Netty.
InternalLoggerFactory - Class in io.netty.util.internal.logging
Creates an InternalLogger or changes the default factory implementation.
InternalLoggerFactory() - Constructor for class io.netty.util.internal.logging.InternalLoggerFactory
 
InternalLogLevel - Enum in io.netty.util.internal.logging
The log level that InternalLogger can log at.
internalNioBuffer(int, int) - Method in class io.netty.buffer.AbstractDerivedByteBuf
Deprecated.
 
internalNioBuffer(int, int) - Method in class io.netty.buffer.ByteBuf
Internal use only: Exposes the internal NIO buffer.
internalNioBuffer(int, int) - Method in class io.netty.buffer.CompositeByteBuf
 
internalNioBuffer(int, int) - Method in class io.netty.buffer.EmptyByteBuf
 
internalNioBuffer(int, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
internalNioBuffer(int, int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
internalNioBuffer(int, int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
internalNioBuffer(int, int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
InternalThreadLocalMap - Class in io.netty.util.internal
The internal data structure that stores the thread-local variables for Netty and all FastThreadLocals.
InternetProtocolFamily - Enum in io.netty.channel.socket
Internet Protocol (IP) families used byte the DatagramChannel
interruptThread() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
Interrupt the current running Thread.
IntObjectHashMap<V> - Class in io.netty.util.collection
A hash map implementation of IntObjectMap that uses open addressing for keys.
IntObjectHashMap() - Constructor for class io.netty.util.collection.IntObjectHashMap
 
IntObjectHashMap(int) - Constructor for class io.netty.util.collection.IntObjectHashMap
 
IntObjectHashMap(int, float) - Constructor for class io.netty.util.collection.IntObjectHashMap
 
IntObjectMap<V> - Interface in io.netty.util.collection
Interface for a primitive map that uses ints as keys.
IntObjectMap.PrimitiveEntry<V> - Interface in io.netty.util.collection
A primitive entry in the map, provided by the iterator from IntObjectMap.entries()
IntSupplier - Interface in io.netty.util
Represents a supplier of int-valued results.
intToIpAddress(int) - Static method in class io.netty.util.NetUtil
Converts a 32-bit integer into an IPv4 address.
intValue() - Method in class io.netty.channel.unix.FileDescriptor
Return the int value of the filedescriptor.
intValue() - Method in class io.netty.handler.codec.dns.DnsRecordType
Returns the value of this DnsType as it appears in DNS protocol
intValue() - Method in class io.netty.handler.codec.dns.DnsResponseCode
Returns the error code for this DnsResponseCode.
intValue(Integer, int) - Static method in class io.netty.util.internal.ObjectUtil
Resolves a possibly null Integer to a primitive int, using a default value.
invalid() - Static method in class io.netty.handler.codec.ProtocolDetectionResult
Returns a ProtocolDetectionResult that signals the data was invalid for the protocol.
invalidateLocalAddress() - Method in class io.netty.channel.AbstractChannel
Deprecated.
no use-case for this.
invalidateRemoteAddress() - Method in class io.netty.channel.AbstractChannel
Deprecated.
no use-case for this.
invert(ChannelMatcher) - Static method in class io.netty.channel.group.ChannelMatchers
Invert the given ChannelMatcher.
invokeAll(Collection<? extends Callable<T>>) - Method in class io.netty.util.concurrent.AbstractEventExecutorGroup
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class io.netty.util.concurrent.AbstractEventExecutorGroup
 
invokeAll(Collection<? extends Callable<T>>) - Method in class io.netty.util.concurrent.NonStickyEventExecutorGroup
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class io.netty.util.concurrent.NonStickyEventExecutorGroup
 
invokeAll(Collection<? extends Callable<T>>) - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
 
invokeAny(Collection<? extends Callable<T>>) - Method in class io.netty.util.concurrent.AbstractEventExecutorGroup
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class io.netty.util.concurrent.AbstractEventExecutorGroup
 
invokeAny(Collection<? extends Callable<T>>) - Method in class io.netty.util.concurrent.NonStickyEventExecutorGroup
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class io.netty.util.concurrent.NonStickyEventExecutorGroup
 
invokeAny(Collection<? extends Callable<T>>) - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
 
io.netty.bootstrap - package io.netty.bootstrap
The helper classes with fluent API which enable an easy implementation of typical client side and server side channel initialization.
io.netty.buffer - package io.netty.buffer
Abstraction of a byte buffer - the fundamental data structure to represent a low-level binary and text message.
io.netty.channel - package io.netty.channel
The core channel API which is asynchronous and event-driven abstraction of various transports such as a NIO Channel.
io.netty.channel.embedded - package io.netty.channel.embedded
A virtual Channel that helps wrapping a series of handlers to unit test the handlers or use them in non-I/O context.
io.netty.channel.epoll - package io.netty.channel.epoll
Optimized transport for linux which uses EPOLL Edge-Triggered Mode for maximal performance.
io.netty.channel.group - package io.netty.channel.group
A channel registry which helps a user maintain the list of open Channels and perform bulk operations on them.
io.netty.channel.kqueue - package io.netty.channel.kqueue
BSD specific transport.
io.netty.channel.local - package io.netty.channel.local
A virtual transport that enables the communication between the two parties in the same virtual machine.
io.netty.channel.nio - package io.netty.channel.nio
NIO-based channel API implementation - recommended for a large number of connections (>= 1000).
io.netty.channel.oio - package io.netty.channel.oio
Old blocking I/O based channel API implementation - recommended for a small number of connections (< 1000).
io.netty.channel.pool - package io.netty.channel.pool
Implementations and API for Channel pools.
io.netty.channel.socket - package io.netty.channel.socket
Abstract TCP and UDP socket interfaces which extend the core channel API.
io.netty.channel.socket.nio - package io.netty.channel.socket.nio
NIO-based socket channel API implementation - recommended for a large number of connections (>= 1000).
io.netty.channel.socket.oio - package io.netty.channel.socket.oio
Old blocking I/O based socket channel API implementation - recommended for a small number of connections (< 1000).
io.netty.channel.unix - package io.netty.channel.unix
Unix specific transport.
io.netty.channel.unix.tests - package io.netty.channel.unix.tests
Unix specific transport tests.
io.netty.handler.codec - package io.netty.handler.codec
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.
io.netty.handler.codec.base64 - package io.netty.handler.codec.base64
Encoder and decoder which transform a Base64-encoded String or ByteBuf into a decoded ByteBuf and vice versa.
io.netty.handler.codec.bytes - package io.netty.handler.codec.bytes
Encoder and decoder which transform an array of bytes into a ByteBuf and vice versa.
io.netty.handler.codec.compression - package io.netty.handler.codec.compression
Encoder and decoder which compresses and decompresses ByteBufs in a compression format such as zlib, gzip, and Snappy.
io.netty.handler.codec.dns - package io.netty.handler.codec.dns
DNS codec.
io.netty.handler.codec.json - package io.netty.handler.codec.json
JSON specific codecs.
io.netty.handler.codec.memcache - package io.netty.handler.codec.memcache
Common superset of ascii and binary classes.
io.netty.handler.codec.memcache.binary - package io.netty.handler.codec.memcache.binary
Implementations and Interfaces for the Memcache Binary protocol.
io.netty.handler.codec.mqtt - package io.netty.handler.codec.mqtt
Encoder, decoder and different Message Types for MQTT.
io.netty.handler.codec.redis - package io.netty.handler.codec.redis
Encoder, decoder for Redis.
io.netty.handler.codec.serialization - package io.netty.handler.codec.serialization
Encoder, decoder and their compatibility stream implementations which transform a Serializable object into a byte buffer and vice versa.
io.netty.handler.codec.smtp - package io.netty.handler.codec.smtp
SMTP codec.
io.netty.handler.codec.stomp - package io.netty.handler.codec.stomp
STOMP codec
io.netty.handler.codec.string - package io.netty.handler.codec.string
Encoder and decoder which transform a String into a ByteBuf and vice versa.
io.netty.handler.codec.xml - package io.netty.handler.codec.xml
Xml specific codecs.
io.netty.handler.flow - package io.netty.handler.flow
Package to control the flow of messages.
io.netty.handler.flush - package io.netty.handler.flush
Package to control flush behavior.
io.netty.handler.ipfilter - package io.netty.handler.ipfilter
Package to filter IP addresses (allow/deny).
io.netty.handler.logging - package io.netty.handler.logging
Logs the I/O events for debugging purpose.
io.netty.handler.ssl - package io.netty.handler.ssl
SSL · TLS implementation based on SSLEngine
io.netty.handler.ssl.util - package io.netty.handler.ssl.util
Utility classes that helps easier development of TLS/SSL applications.
io.netty.handler.stream - package io.netty.handler.stream
Writes very large data stream asynchronously neither spending a lot of memory nor getting OutOfMemoryError.
io.netty.handler.timeout - package io.netty.handler.timeout
Adds support for read and write timeout and idle connection notification using a Timer.
io.netty.handler.traffic - package io.netty.handler.traffic
Implementation of a Traffic Shaping Handler and Dynamic Statistics.
io.netty.resolver - package io.netty.resolver
Resolves an arbitrary string that represents the name of an endpoint into an address.
io.netty.resolver.dns - package io.netty.resolver.dns
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.
io.netty.util - package io.netty.util
Utility classes used across multiple packages.
io.netty.util.concurrent - package io.netty.util.concurrent
Utility classes for concurrent / async tasks.
io.netty.util.internal - package io.netty.util.internal
Internal-use-only utilities which is not allowed to be used outside Netty.
io.netty.util.internal.logging - package io.netty.util.internal.logging
Internal-use-only logging API which is not allowed to be used outside Netty.
ioBuffer() - Method in class io.netty.buffer.AbstractByteBufAllocator
 
ioBuffer(int) - Method in class io.netty.buffer.AbstractByteBufAllocator
 
ioBuffer(int, int) - Method in class io.netty.buffer.AbstractByteBufAllocator
 
ioBuffer() - Method in interface io.netty.buffer.ByteBufAllocator
Allocate a ByteBuf, preferably a direct buffer which is suitable for I/O.
ioBuffer(int) - Method in interface io.netty.buffer.ByteBufAllocator
Allocate a ByteBuf, preferably a direct buffer which is suitable for I/O.
ioBuffer(int, int) - Method in interface io.netty.buffer.ByteBufAllocator
Allocate a ByteBuf, preferably a direct buffer which is suitable for I/O.
ioResult(String, int, Errors.NativeIoException, ClosedChannelException) - Static method in class io.netty.channel.unix.Errors
 
IOV_MAX - Static variable in class io.netty.channel.unix.Limits
 
IovArray - Class in io.netty.channel.unix
Represent an array of struct array and so can be passed directly over via JNI without the need to do any more array copies.
IovArray() - Constructor for class io.netty.channel.unix.IovArray
 
IP_FREEBIND - Static variable in class io.netty.channel.epoll.EpollChannelOption
 
IP_MULTICAST_ADDR - Static variable in class io.netty.channel.ChannelOption
 
IP_MULTICAST_IF - Static variable in class io.netty.channel.ChannelOption
 
IP_MULTICAST_LOOP_DISABLED - Static variable in class io.netty.channel.ChannelOption
 
IP_MULTICAST_TTL - Static variable in class io.netty.channel.ChannelOption
 
IP_TOS - Static variable in class io.netty.channel.ChannelOption
 
IP_TRANSPARENT - Static variable in class io.netty.channel.epoll.EpollChannelOption
 
IpFilterRule - Interface in io.netty.handler.ipfilter
Implement this interface to create new rules.
IpFilterRuleType - Enum in io.netty.handler.ipfilter
Used in IpFilterRule to decide if a matching IP Address should be allowed or denied to connect.
IPSECKEY - Static variable in class io.netty.handler.codec.dns.DnsRecordType
IPsec Key record RFC 4025 Key record that can be used with IPsec.
IpSubnetFilterRule - Class in io.netty.handler.ipfilter
Use this class to create rules for RuleBasedIpFilter that group IP addresses into subnets.
IpSubnetFilterRule(String, int, IpFilterRuleType) - Constructor for class io.netty.handler.ipfilter.IpSubnetFilterRule
 
IpSubnetFilterRule(InetAddress, int, IpFilterRuleType) - Constructor for class io.netty.handler.ipfilter.IpSubnetFilterRule
 
ipv4MappedIpv6Address(byte[]) - Static method in class io.netty.channel.unix.NativeInetAddress
 
IQUERY - Static variable in class io.netty.handler.codec.dns.DnsOpCode
The 'IQuery' DNS OpCode, as defined in RFC1035.
is(Channel) - Static method in class io.netty.channel.group.ChannelMatchers
Returns a ChannelMatcher that matches the given Channel.
IS_SUPPORTING_SENDMMSG - Static variable in class io.netty.channel.epoll.Native
 
IS_SUPPORTING_TCP_FASTOPEN - Static variable in class io.netty.channel.epoll.Native
 
isActive() - Method in interface io.netty.channel.Channel
Return true if the Channel is active and so connected.
isActive() - Method in class io.netty.channel.embedded.EmbeddedChannel
 
isActive() - Method in class io.netty.channel.epoll.EpollDatagramChannel
 
isActive() - Method in class io.netty.channel.kqueue.KQueueDatagramChannel
 
isActive() - Method in class io.netty.channel.local.LocalChannel
 
isActive() - Method in class io.netty.channel.local.LocalServerChannel
 
isActive() - Method in class io.netty.channel.oio.OioByteStreamChannel
 
isActive() - Method in class io.netty.channel.socket.nio.NioDatagramChannel
 
isActive() - Method in class io.netty.channel.socket.nio.NioServerSocketChannel
 
isActive() - Method in class io.netty.channel.socket.nio.NioSocketChannel
 
isActive() - Method in class io.netty.channel.socket.oio.OioDatagramChannel
 
isActive() - Method in class io.netty.channel.socket.oio.OioServerSocketChannel
 
isActive() - Method in class io.netty.channel.socket.oio.OioSocketChannel
 
isAggregated(MemcacheObject) - Method in class io.netty.handler.codec.memcache.AbstractMemcacheObjectAggregator
 
isAggregated(I) - Method in class io.netty.handler.codec.MessageAggregator
Returns true if and only if the specified message is already aggregated.
isAggregated(RedisMessage) - Method in class io.netty.handler.codec.redis.RedisBulkStringAggregator
 
isAggregated(StompSubframe) - Method in class io.netty.handler.codec.stomp.StompSubframeAggregator
 
isAlive() - Method in interface io.netty.util.concurrent.ThreadProperties
 
isAllowHalfClosure() - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
 
isAllowHalfClosure() - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
 
isAllowHalfClosure() - Method in class io.netty.channel.socket.DefaultSocketChannelConfig
 
isAllowHalfClosure() - Method in interface io.netty.channel.socket.SocketChannelConfig
Returns true if and only if the channel should not close itself when its remote peer shuts down output to make the connection half-closed.
isAndroid() - Static method in class io.netty.util.internal.PlatformDependent
Returns true if and only if the current platform is Android
isAuthoritativeAnswer() - Method in class io.netty.handler.codec.dns.DefaultDnsResponse
 
isAuthoritativeAnswer() - Method in interface io.netty.handler.codec.dns.DnsResponse
Returns true if responding server is authoritative for the domain name in the query message.
isAutoClose() - Method in interface io.netty.channel.ChannelConfig
Deprecated.
Auto close will be removed in a future release. Returns true if and only if the Channel will be closed automatically and immediately on write failure. The default is false.
isAutoClose() - Method in class io.netty.channel.DefaultChannelConfig
 
isAutoRead() - Method in interface io.netty.channel.ChannelConfig
Returns true if and only if ChannelHandlerContext.read() will be invoked automatically so that a user application doesn't need to call it at all.
isAutoRead() - Method in class io.netty.channel.DefaultChannelConfig
 
isAvailable() - Static method in class io.netty.channel.epoll.Epoll
Returns true if and only if the netty-transport-native-epoll is available.
isAvailable() - Static method in class io.netty.channel.kqueue.KQueue
Returns true if and only if the netty-transport-native-kqueue is available.
isBroadcast() - Method in class io.netty.channel.epoll.EpollDatagramChannelConfig
 
isBroadcast() - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
 
isBroadcast() - Method in interface io.netty.channel.socket.DatagramChannelConfig
isBroadcast() - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
 
isBroadcast() - Method in class io.netty.channel.unix.Socket
 
isBufferCopyNeededForWrite(ByteBuf) - Static method in class io.netty.channel.unix.UnixChannelUtil
Checks if the specified buffer has memory address or is composed of n(n <= IOV_MAX) NIO direct buffers.
isCancellable() - Method in class io.netty.util.concurrent.CompleteFuture
 
isCancellable() - Method in class io.netty.util.concurrent.DefaultPromise
 
isCancellable() - Method in interface io.netty.util.concurrent.Future
returns true if and only if the operation can be cancelled via Future.cancel(boolean).
isCancelled() - Method in class io.netty.util.concurrent.CompleteFuture
 
isCancelled() - Method in class io.netty.util.concurrent.DefaultPromise
 
isCancelled() - Method in interface io.netty.util.Timeout
Returns true if and only if the TimerTask associated with this handle has been cancelled.
isCleanSession() - Method in class io.netty.handler.codec.mqtt.MqttConnectVariableHeader
 
isClient() - Method in class io.netty.handler.ssl.DelegatingSslContext
 
isClient() - Method in class io.netty.handler.ssl.JdkSslContext
 
isClient() - Method in class io.netty.handler.ssl.SslContext
Returns the true if and only if this context is for client-side.
isClosed() - Method in class io.netty.handler.codec.compression.Bzip2Decoder
Returns true if and only if the end of the compressed stream has been reached.
isClosed() - Method in class io.netty.handler.codec.compression.Bzip2Encoder
Returns true if and only if the end of the compressed stream has been reached.
isClosed() - Method in class io.netty.handler.codec.compression.JdkZlibDecoder
 
isClosed() - Method in class io.netty.handler.codec.compression.JdkZlibEncoder
 
isClosed() - Method in class io.netty.handler.codec.compression.JZlibDecoder
Returns true if and only if the end of the compressed stream has been reached.
isClosed() - Method in class io.netty.handler.codec.compression.JZlibEncoder
 
isClosed() - Method in class io.netty.handler.codec.compression.ZlibDecoder
Returns true if and only if the end of the compressed stream has been reached.
isClosed() - Method in class io.netty.handler.codec.compression.ZlibEncoder
Returns true if and only if the end of the compressed stream has been reached.
isCompatible(EventLoop) - Method in class io.netty.channel.AbstractChannel
Return true if the given EventLoop is compatible with this instance.
isCompatible(EventLoop) - Method in class io.netty.channel.embedded.EmbeddedChannel
 
isCompatible(EventLoop) - Method in class io.netty.channel.epoll.AbstractEpollServerChannel
 
isCompatible(EventLoop) - Method in class io.netty.channel.epoll.EpollServerSocketChannel
 
isCompatible(EventLoop) - Method in class io.netty.channel.kqueue.AbstractKQueueServerChannel
 
isCompatible(EventLoop) - Method in class io.netty.channel.kqueue.KQueueServerSocketChannel
 
isCompatible(EventLoop) - Method in class io.netty.channel.local.LocalChannel
 
isCompatible(EventLoop) - Method in class io.netty.channel.local.LocalServerChannel
 
isCompatible(EventLoop) - Method in class io.netty.channel.nio.AbstractNioChannel
 
isCompatible(EventLoop) - Method in class io.netty.channel.oio.AbstractOioChannel
 
isConnected() - Method in class io.netty.channel.epoll.EpollDatagramChannel
 
isConnected() - Method in class io.netty.channel.kqueue.KQueueDatagramChannel
 
isConnected() - Method in interface io.netty.channel.socket.DatagramChannel
Return true if the DatagramChannel is connected to the remote peer.
isConnected() - Method in class io.netty.channel.socket.nio.NioDatagramChannel
 
isConnected() - Method in class io.netty.channel.socket.oio.OioDatagramChannel
 
isContentLengthInvalid(H, int) - Method in class io.netty.handler.codec.memcache.AbstractMemcacheObjectAggregator
 
isContentLengthInvalid(S, int) - Method in class io.netty.handler.codec.MessageAggregator
Determine if the message start's content length is known, and if it greater than maxContentLength.
isContentLengthInvalid(BulkStringHeaderRedisMessage, int) - Method in class io.netty.handler.codec.redis.RedisBulkStringAggregator
 
isContentLengthInvalid(StompHeadersSubframe, int) - Method in class io.netty.handler.codec.stomp.StompSubframeAggregator
 
isContentMessage(MemcacheObject) - Method in class io.netty.handler.codec.memcache.AbstractMemcacheObjectAggregator
 
isContentMessage(I) - Method in class io.netty.handler.codec.MessageAggregator
Returns true if and only if the specified message is a content message.
isContentMessage(RedisMessage) - Method in class io.netty.handler.codec.redis.RedisBulkStringAggregator
 
isContentMessage(StompSubframe) - Method in class io.netty.handler.codec.stomp.StompSubframeAggregator
 
isDaemon() - Method in interface io.netty.util.concurrent.ThreadProperties
 
isDebugEnabled() - Method in interface io.netty.util.internal.logging.InternalLogger
Is the logger instance enabled for the DEBUG level?
isDestroyed() - Method in class io.netty.handler.ssl.PemPrivateKey
NOTE: This is a JDK8 interface/method.
isDirect() - Method in class io.netty.buffer.ByteBuf
Returns true if and only if this buffer is backed by an NIO direct buffer.
isDirect() - Method in class io.netty.buffer.CompositeByteBuf
 
isDirect() - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
isDirect() - Method in class io.netty.buffer.EmptyByteBuf
 
isDirect() - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
isDirect() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
isDirect() - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
isDirect() - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
isDirect() - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
isDirectBufferPooled() - Method in interface io.netty.buffer.ByteBufAllocator
Returns true if direct ByteBuf's are pooled
isDirectBufferPooled() - Method in class io.netty.buffer.PooledByteBufAllocator
 
isDirectBufferPooled() - Method in class io.netty.buffer.UnpooledByteBufAllocator
 
isDirectMemoryCacheAlignmentSupported() - Static method in class io.netty.buffer.PooledByteBufAllocator
Return true if direct memory cache alignment is supported, false otherwise.
isDone() - Method in class io.netty.util.concurrent.CompleteFuture
 
isDone() - Method in class io.netty.util.concurrent.DefaultPromise
 
isDup() - Method in class io.netty.handler.codec.mqtt.MqttFixedHeader
 
isEmpty() - Method in class io.netty.channel.ChannelOutboundBuffer
Returns true if there are flushed messages in this ChannelOutboundBuffer or false otherwise.
isEmpty() - Method in class io.netty.channel.CoalescingBufferQueue
Are there pending buffers in the queue.
isEmpty() - Method in class io.netty.channel.group.DefaultChannelGroup
 
isEmpty() - Method in class io.netty.channel.PendingWriteQueue
Returns true if there are no pending write operations left in this queue.
isEmpty() - Method in class io.netty.channel.pool.AbstractChannelPoolMap
Returns true if the AbstractChannelPoolMap is empty, otherwise false.
isEmpty() - Method in class io.netty.handler.codec.DefaultHeaders
 
isEmpty() - Method in class io.netty.handler.codec.EmptyHeaders
 
isEmpty() - Method in interface io.netty.handler.codec.Headers
Returns true if Headers.size() equals 0.
isEmpty() - Method in class io.netty.util.AsciiString
Determine if this instance has 0 length.
isEmpty() - Method in class io.netty.util.collection.ByteObjectHashMap
 
isEmpty() - Method in class io.netty.util.collection.CharObjectHashMap
 
isEmpty() - Method in class io.netty.util.collection.IntObjectHashMap
 
isEmpty() - Method in class io.netty.util.collection.LongObjectHashMap
 
isEmpty() - Method in class io.netty.util.collection.ShortObjectHashMap
 
isEmpty() - Method in class io.netty.util.internal.DefaultPriorityQueue
 
isEmpty() - Method in class io.netty.util.internal.EmptyPriorityQueue
 
isEnabled(InternalLogLevel) - Method in class io.netty.util.internal.logging.AbstractInternalLogger
 
isEnabled(InternalLogLevel) - Method in interface io.netty.util.internal.logging.InternalLogger
Is the logger instance enabled for the specified level?
isEnabled() - Static method in class io.netty.util.ResourceLeakDetector
Returns true if resource leak detection is enabled.
isEncrypted(ByteBuf) - Static method in class io.netty.handler.ssl.SslHandler
Returns true if the given ByteBuf is encrypted.
isEndOfInput() - Method in class io.netty.handler.stream.ChunkedFile
 
isEndOfInput() - Method in interface io.netty.handler.stream.ChunkedInput
Return true if and only if there is no data left in the stream and the stream has reached at its end.
isEndOfInput() - Method in class io.netty.handler.stream.ChunkedNioFile
 
isEndOfInput() - Method in class io.netty.handler.stream.ChunkedNioStream
 
isEndOfInput() - Method in class io.netty.handler.stream.ChunkedStream
 
isEntireArrayUsed() - Method in class io.netty.util.AsciiString
Determine if the storage represented by AsciiString.array() is entirely used.
isErrorEnabled() - Method in interface io.netty.util.internal.logging.InternalLogger
Is the logger instance enabled for the ERROR level?
isExpired() - Method in interface io.netty.util.Timeout
Returns true if and only if the TimerTask associated with this handle has been expired.
isFailure() - Method in class io.netty.handler.codec.DecoderResult
 
isFinished() - Method in class io.netty.handler.codec.DecoderResult
 
isFirst() - Method in class io.netty.handler.timeout.IdleStateEvent
Returns true if this was the first event for the IdleState
isFreeBind() - Method in class io.netty.channel.epoll.EpollServerSocketChannelConfig
Returns true if IP_FREEBIND is enabled, false otherwise.
isHandlerActive(ChannelHandlerContext) - Static method in class io.netty.handler.traffic.AbstractTrafficShapingHandler
 
isHandlingOversizedMessage() - Method in class io.netty.handler.codec.MessageAggregator
Deprecated.
This method will be removed in future releases.
isHealthy(Channel) - Method in interface io.netty.channel.pool.ChannelHealthChecker
Check if the given channel is healthy which means it can be used.
isIndexedVariableSet(int) - Method in class io.netty.util.internal.InternalThreadLocalMap
 
isInfoEnabled() - Method in interface io.netty.util.internal.logging.InternalLogger
Is the logger instance enabled for the INFO level?
isInline() - Method in enum io.netty.handler.codec.redis.RedisMessageType
Returns true if this type is inline type, or returns false.
isInputShutdown() - Method in class io.netty.channel.epoll.AbstractEpollStreamChannel
 
isInputShutdown() - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel
 
isInputShutdown() - Method in class io.netty.channel.oio.AbstractOioByteChannel
Determine if the input side of this channel is shutdown.
isInputShutdown() - Method in interface io.netty.channel.socket.DuplexChannel
Returns true if and only if the remote peer shut down its output so that no more data is received from this channel.
isInputShutdown() - Method in class io.netty.channel.socket.nio.NioSocketChannel
 
isInputShutdown() - Method in class io.netty.channel.socket.oio.OioSocketChannel
 
isInputShutdown() - Method in class io.netty.channel.unix.Socket
 
isInputShutdown0() - Method in class io.netty.channel.nio.AbstractNioByteChannel
 
isInputShutdown0() - Method in class io.netty.channel.socket.nio.NioSocketChannel
 
isInstanceOf(Class<? extends Channel>) - Static method in class io.netty.channel.group.ChannelMatchers
Returns a ChannelMatcher that matches all Channels that are an instance of sub-type of the given class.
isInterrupted() - Method in interface io.netty.util.concurrent.ThreadProperties
 
isIpTransparent() - Method in class io.netty.channel.epoll.EpollServerSocketChannelConfig
Returns true if IP_TRANSPARENT is enabled, false otherwise.
isIpV4StackPreferred() - Static method in class io.netty.util.NetUtil
Returns true if IPv4 should be used even if the system supports both IPv4 and IPv6.
isIpV6AddressesPreferred() - Static method in class io.netty.util.NetUtil
Returns true if an IPv6 address should be preferred when a host has both an IPv4 address and an IPv6 address.
isKeepAlive() - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
 
isKeepAlive() - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
 
isKeepAlive() - Method in class io.netty.channel.socket.DefaultSocketChannelConfig
 
isKeepAlive() - Method in interface io.netty.channel.socket.SocketChannelConfig
isKeepAlive() - Method in class io.netty.channel.unix.Socket
 
isLastContentMessage(MemcacheContent) - Method in class io.netty.handler.codec.memcache.AbstractMemcacheObjectAggregator
 
isLastContentMessage(C) - Method in class io.netty.handler.codec.MessageAggregator
Returns true if and only if the specified message is the last content message.
isLastContentMessage(BulkStringRedisContent) - Method in class io.netty.handler.codec.redis.RedisBulkStringAggregator
 
isLastContentMessage(StompContentSubframe) - Method in class io.netty.handler.codec.stomp.StompSubframeAggregator
 
isLoopbackModeDisabled() - Method in class io.netty.channel.epoll.EpollDatagramChannelConfig
 
isLoopbackModeDisabled() - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
 
isLoopbackModeDisabled() - Method in interface io.netty.channel.socket.DatagramChannelConfig
isLoopbackModeDisabled() - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
 
isNonServerChannel() - Static method in class io.netty.channel.group.ChannelMatchers
Returns a ChannelMatcher that matches all Channels that are not of type ServerChannel.
isNot(Channel) - Static method in class io.netty.channel.group.ChannelMatchers
Returns a ChannelMatcher that matches all Channels except the given.
isNotInstanceOf(Class<? extends Channel>) - Static method in class io.netty.channel.group.ChannelMatchers
Returns a ChannelMatcher that matches all Channels that are not an instance of sub-type of the given class.
isNull() - Method in class io.netty.handler.codec.redis.ArrayHeaderRedisMessage
Returns whether the content of this message is null.
isNull() - Method in class io.netty.handler.codec.redis.ArrayRedisMessage
Returns whether the content of this message is null.
isNull() - Method in class io.netty.handler.codec.redis.BulkStringHeaderRedisMessage
Returns whether the content of this message is null.
isNull() - Method in class io.netty.handler.codec.redis.FullBulkStringRedisMessage
Returns whether the content of this message is null.
isNullOrEmpty(String) - Static method in class io.netty.util.internal.StringUtil
Determine if a string is null or String.isEmpty() returns true.
ISO_8859_1 - Static variable in class io.netty.util.CharsetUtil
ISO Latin Alphabet No.
isOpen() - Method in interface io.netty.channel.Channel
Returns true if the Channel is open and may get active later
isOpen() - Method in class io.netty.channel.DefaultFileRegion
Returns true if the FileRegion has a open file-descriptor
isOpen() - Method in class io.netty.channel.embedded.EmbeddedChannel
 
isOpen() - Method in class io.netty.channel.local.LocalChannel
 
isOpen() - Method in class io.netty.channel.local.LocalServerChannel
 
isOpen() - Method in class io.netty.channel.nio.AbstractNioChannel
 
isOpen() - Method in class io.netty.channel.socket.oio.OioDatagramChannel
 
isOpen() - Method in class io.netty.channel.socket.oio.OioServerSocketChannel
 
isOpen() - Method in class io.netty.channel.socket.oio.OioSocketChannel
 
isOpen() - Method in class io.netty.channel.unix.FileDescriptor
Returns true if the file descriptor is open.
isOpen() - Method in class io.netty.channel.unix.SocketWritableByteChannel
 
isOptResourceEnabled() - Method in class io.netty.resolver.dns.DnsNameResolver
Returns the automatic inclusion of a optional records that tries to give the remote DNS server a hint about how much data the resolver can read per response is enabled.
isOutOfBounds(int, int, int) - Static method in class io.netty.util.internal.MathUtil
Determine if the requested index and length will fit within capacity.
isOutputShutdown() - Method in class io.netty.channel.epoll.AbstractEpollStreamChannel
 
isOutputShutdown() - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel
 
isOutputShutdown() - Method in interface io.netty.channel.socket.DuplexChannel
 
isOutputShutdown() - Method in class io.netty.channel.socket.nio.NioSocketChannel
 
isOutputShutdown() - Method in class io.netty.channel.socket.oio.OioSocketChannel
 
isOutputShutdown() - Method in class io.netty.channel.unix.Socket
 
isPartialFailure() - Method in interface io.netty.channel.group.ChannelGroupFuture
Returns true if and only if the I/O operations associated with this future have failed partially with some success.
isPartialSuccess() - Method in interface io.netty.channel.group.ChannelGroupFuture
Returns true if and only if the I/O operations associated with this future were partially successful with some failure.
isPreferDirect() - Method in class io.netty.handler.codec.MessageToByteEncoder
 
isReadable() - Method in class io.netty.buffer.AbstractByteBuf
 
isReadable(int) - Method in class io.netty.buffer.AbstractByteBuf
 
isReadable() - Method in class io.netty.buffer.ByteBuf
Returns true if and only if (this.writerIndex - this.readerIndex) is greater than 0.
isReadable(int) - Method in class io.netty.buffer.ByteBuf
Returns true if and only if this buffer contains equal to or more than the specified number of elements.
isReadable() - Method in class io.netty.buffer.EmptyByteBuf
 
isReadable(int) - Method in class io.netty.buffer.EmptyByteBuf
 
isReadable() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
isReadable(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
isReadOnly() - Method in class io.netty.buffer.AbstractByteBuf
 
isReadOnly() - Method in class io.netty.buffer.AbstractDerivedByteBuf
Deprecated.
 
isReadOnly() - Method in class io.netty.buffer.ByteBuf
Returns true if and only if this buffer is read-only.
isReadOnly() - Method in class io.netty.buffer.EmptyByteBuf
 
isReadOnly() - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
isReadOnly() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
isReadPending() - Method in class io.netty.channel.nio.AbstractNioChannel
Deprecated.
No longer supported. No longer supported.
isReadPending() - Method in class io.netty.channel.oio.AbstractOioChannel
Deprecated.
No longer supported. No longer supported.
isRecursionAvailable() - Method in class io.netty.handler.codec.dns.DefaultDnsResponse
 
isRecursionAvailable() - Method in interface io.netty.handler.codec.dns.DnsResponse
Returns true if DNS server can handle recursive queries.
isRecursionDesired() - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
 
isRecursionDesired() - Method in interface io.netty.handler.codec.dns.DnsMessage
Returns the RD (recursion desired} field of this DNS message.
isRecursionDesired() - Method in class io.netty.resolver.dns.DnsNameResolver
Returns true if and only if this resolver sends a DNS query with the RD (recursion desired) flag set.
isRegistered() - Method in class io.netty.channel.AbstractChannel
 
isRegistered() - Method in interface io.netty.channel.Channel
Returns true if the Channel is registered with an EventLoop.
isRemoved() - Method in interface io.netty.channel.ChannelHandlerContext
Return true if the ChannelHandler which belongs to this context was removed from the ChannelPipeline.
isResolved(SocketAddress) - Method in class io.netty.resolver.AbstractAddressResolver
 
isResolved(SocketAddress) - Method in interface io.netty.resolver.AddressResolver
Returns true if and only if the specified address has been resolved.
isRetain() - Method in class io.netty.handler.codec.mqtt.MqttFixedHeader
 
isReuseAddress() - Method in class io.netty.channel.epoll.EpollDatagramChannelConfig
 
isReuseAddress() - Method in class io.netty.channel.epoll.EpollServerChannelConfig
 
isReuseAddress() - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
 
isReuseAddress() - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
 
isReuseAddress() - Method in class io.netty.channel.kqueue.KQueueServerChannelConfig
 
isReuseAddress() - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
 
isReuseAddress() - Method in interface io.netty.channel.socket.DatagramChannelConfig
isReuseAddress() - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
 
isReuseAddress() - Method in class io.netty.channel.socket.DefaultServerSocketChannelConfig
 
isReuseAddress() - Method in class io.netty.channel.socket.DefaultSocketChannelConfig
 
isReuseAddress() - Method in interface io.netty.channel.socket.ServerSocketChannelConfig
isReuseAddress() - Method in interface io.netty.channel.socket.SocketChannelConfig
isReuseAddress() - Method in class io.netty.channel.unix.Socket
 
isReusePort() - Method in class io.netty.channel.epoll.EpollDatagramChannelConfig
Returns true if the SO_REUSEPORT option is set.
isReusePort() - Method in class io.netty.channel.epoll.EpollServerSocketChannelConfig
Returns true if the SO_REUSEPORT option is set.
isReusePort() - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
Returns true if the SO_REUSEPORT option is set.
isReusePort() - Method in class io.netty.channel.kqueue.KQueueServerSocketChannelConfig
 
isReusePort() - Method in class io.netty.channel.unix.Socket
 
isSensitive() - Method in class io.netty.handler.ssl.PemPrivateKey
 
isSensitive() - Method in class io.netty.handler.ssl.PemX509Certificate
 
isServer() - Method in class io.netty.handler.ssl.SslContext
Returns true if and only if this context is for server-side.
isServerChannel() - Static method in class io.netty.channel.group.ChannelMatchers
Returns a ChannelMatcher that matches all Channels that are of type ServerChannel.
isSessionPresent() - Method in class io.netty.handler.codec.mqtt.MqttConnAckVariableHeader
 
isSet() - Method in class io.netty.util.concurrent.FastThreadLocal
Returns true if and only if this thread-local variable is set.
isSet(InternalThreadLocalMap) - Method in class io.netty.util.concurrent.FastThreadLocal
Returns true if and only if this thread-local variable is set.
isSharable() - Method in class io.netty.channel.ChannelHandlerAdapter
Return true if the implementation is Sharable and so can be added to different ChannelPipelines.
isSharable() - Method in class io.netty.handler.codec.DatagramPacketDecoder
 
isSharable() - Method in class io.netty.handler.codec.DatagramPacketEncoder
 
isShutdown() - Method in class io.netty.channel.epoll.AbstractEpollStreamChannel
 
isShutdown() - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel
 
isShutdown() - Method in interface io.netty.channel.socket.DuplexChannel
Determine if both the input and output of this channel have been shutdown.
isShutdown() - Method in class io.netty.channel.socket.nio.NioSocketChannel
 
isShutdown() - Method in class io.netty.channel.socket.oio.OioSocketChannel
 
isShutdown() - Method in class io.netty.channel.ThreadPerChannelEventLoopGroup
 
isShutdown() - Method in class io.netty.channel.unix.Socket
 
isShutdown() - Method in class io.netty.util.concurrent.GlobalEventExecutor
 
isShutdown() - Method in class io.netty.util.concurrent.ImmediateEventExecutor
 
isShutdown() - Method in class io.netty.util.concurrent.MultithreadEventExecutorGroup
 
isShutdown() - Method in class io.netty.util.concurrent.NonStickyEventExecutorGroup
 
isShutdown() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
 
isShuttingDown() - Method in class io.netty.channel.ThreadPerChannelEventLoopGroup
 
isShuttingDown() - Method in interface io.netty.util.concurrent.EventExecutorGroup
Returns true if and only if all EventExecutors managed by this EventExecutorGroup are being shut down gracefully or was shut down.
isShuttingDown() - Method in class io.netty.util.concurrent.GlobalEventExecutor
 
isShuttingDown() - Method in class io.netty.util.concurrent.ImmediateEventExecutor
 
isShuttingDown() - Method in class io.netty.util.concurrent.MultithreadEventExecutorGroup
 
isShuttingDown() - Method in class io.netty.util.concurrent.NonStickyEventExecutorGroup
 
isShuttingDown() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
 
isShuttingDown() - Method in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor
 
isSingleDecode() - Method in class io.netty.handler.codec.ByteToMessageDecoder
If true then only one message is decoded on each ByteToMessageDecoder.channelRead(ChannelHandlerContext, Object) call.
isStartMessage(MemcacheObject) - Method in class io.netty.handler.codec.memcache.binary.BinaryMemcacheObjectAggregator
 
isStartMessage(I) - Method in class io.netty.handler.codec.MessageAggregator
Returns true if and only if the specified message is a start message.
isStartMessage(RedisMessage) - Method in class io.netty.handler.codec.redis.RedisBulkStringAggregator
 
isStartMessage(StompSubframe) - Method in class io.netty.handler.codec.stomp.StompSubframeAggregator
 
isSuccess() - Method in interface io.netty.channel.group.ChannelGroupFuture
Returns true if and only if all I/O operations associated with this future were successful without any failure.
isSuccess() - Method in class io.netty.handler.codec.DecoderResult
 
isSuccess() - Method in class io.netty.handler.ssl.SslCompletionEvent
Return true if the completion was successful
isSuccess() - Method in class io.netty.util.concurrent.DefaultPromise
 
isSuccess() - Method in class io.netty.util.concurrent.FailedFuture
 
isSuccess() - Method in interface io.netty.util.concurrent.Future
Returns true if and only if the I/O operation was completed successfully.
isSuccess() - Method in class io.netty.util.concurrent.SucceededFuture
 
isSupported(SocketAddress) - Method in class io.netty.resolver.AbstractAddressResolver
 
isSupported(SocketAddress) - Method in interface io.netty.resolver.AddressResolver
Returns true if and only if the specified address is supported by this resolved.
isSupportingWindowSizeAndMemLevel() - Static method in class io.netty.handler.codec.compression.ZlibCodecFactory
Returns true if specify a custom window size and mem level is supported.
isSurrogate(char) - Static method in class io.netty.util.internal.StringUtil
Determine if c lies within the range of values defined for Surrogate Code Point.
isTcpCork() - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
Get the TCP_CORK option on the socket.
isTcpNoDelay() - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
 
isTcpNoDelay() - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
 
isTcpNoDelay() - Method in class io.netty.channel.socket.DefaultSocketChannelConfig
 
isTcpNoDelay() - Method in interface io.netty.channel.socket.SocketChannelConfig
isTcpNoDelay() - Method in class io.netty.channel.unix.Socket
 
isTcpNoPush() - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
 
isTcpQuickAck() - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
Returns true if TCP_QUICKACK is enabled, false otherwise.
isTerminated() - Method in class io.netty.channel.ThreadPerChannelEventLoopGroup
 
isTerminated() - Method in class io.netty.util.concurrent.GlobalEventExecutor
 
isTerminated() - Method in class io.netty.util.concurrent.ImmediateEventExecutor
 
isTerminated() - Method in class io.netty.util.concurrent.MultithreadEventExecutorGroup
 
isTerminated() - Method in class io.netty.util.concurrent.NonStickyEventExecutorGroup
 
isTerminated() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
 
isText(ByteBuf, Charset) - Static method in class io.netty.buffer.ByteBufUtil
Returns true if the given ByteBuf is valid text using the given Charset, otherwise return false.
isText(ByteBuf, int, int, Charset) - Static method in class io.netty.buffer.ByteBufUtil
Returns true if the specified ByteBuf starting at index with length is valid text using the given Charset, otherwise return false.
isTraceEnabled() - Method in interface io.netty.util.internal.logging.InternalLogger
Is the logger instance enabled for the TRACE level?
isTruncated() - Method in class io.netty.handler.codec.dns.DefaultDnsResponse
 
isTruncated() - Method in interface io.netty.handler.codec.dns.DnsResponse
Returns true if response has been truncated, usually if it is over 512 bytes.
isUnaligned() - Static method in class io.netty.util.internal.PlatformDependent
true if and only if the platform supports unaligned access.
isUpperCase(byte) - Static method in class io.netty.util.AsciiString
 
isUpperCase(char) - Static method in class io.netty.util.AsciiString
 
isValidIpV4Address(String) - Static method in class io.netty.util.NetUtil
Takes a string and parses it to see if it is a valid IPV4 address.
isValidIpV6Address(String) - Static method in class io.netty.util.NetUtil
 
isVoid() - Method in interface io.netty.channel.ChannelFuture
isVoid() - Method in class io.netty.channel.DefaultChannelProgressivePromise
 
isVoid() - Method in class io.netty.channel.DefaultChannelPromise
 
isWarnEnabled() - Method in interface io.netty.util.internal.logging.InternalLogger
Is the logger instance enabled for the WARN level?
isWillFlag() - Method in class io.netty.handler.codec.mqtt.MqttConnectVariableHeader
 
isWillRetain() - Method in class io.netty.handler.codec.mqtt.MqttConnectVariableHeader
 
isWindows() - Static method in class io.netty.util.internal.PlatformDependent
Return true if the JVM is running on Windows
isWritable() - Method in class io.netty.buffer.AbstractByteBuf
 
isWritable(int) - Method in class io.netty.buffer.AbstractByteBuf
 
isWritable() - Method in class io.netty.buffer.ByteBuf
Returns true if and only if (this.capacity - this.writerIndex) is greater than 0.
isWritable(int) - Method in class io.netty.buffer.ByteBuf
Returns true if and only if this buffer has enough room to allow writing the specified number of elements.
isWritable() - Method in class io.netty.buffer.EmptyByteBuf
 
isWritable(int) - Method in class io.netty.buffer.EmptyByteBuf
 
isWritable() - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
isWritable(int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
isWritable() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
isWritable(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
isWritable() - Method in class io.netty.channel.AbstractChannel
 
isWritable() - Method in interface io.netty.channel.Channel
Returns true if and only if the I/O thread will perform the requested write operation immediately.
isWritable() - Method in class io.netty.channel.ChannelOutboundBuffer
Returns true if and only if the total number of pending bytes did not exceed the write watermark of the Channel and no user-defined writability flag has been set to false.
isZero(byte[], int, int) - Static method in class io.netty.util.internal.PlatformDependent
Determine if a subsection of an array is zero.
iterator() - Method in class io.netty.buffer.CompositeByteBuf
 
iterator() - Method in class io.netty.channel.DefaultChannelPipeline
 
iterator() - Method in exception io.netty.channel.group.ChannelGroupException
Returns a Iterator which contains all the Throwable that was a cause of the failure and the related id of the Channel.
iterator() - Method in interface io.netty.channel.group.ChannelGroupFuture
Returns the Iterator that enumerates all ChannelFutures which are associated with this future.
iterator() - Method in class io.netty.channel.group.DefaultChannelGroup
 
iterator() - Method in class io.netty.channel.pool.AbstractChannelPoolMap
 
iterator() - Method in class io.netty.channel.ThreadPerChannelEventLoopGroup
 
iterator() - Method in class io.netty.handler.codec.DefaultHeaders
 
iterator() - Method in class io.netty.handler.codec.EmptyHeaders
 
iterator() - Method in interface io.netty.handler.codec.Headers
 
iterator() - Method in class io.netty.util.concurrent.AbstractEventExecutor
 
iterator() - Method in interface io.netty.util.concurrent.EventExecutorGroup
 
iterator() - Method in class io.netty.util.concurrent.MultithreadEventExecutorGroup
 
iterator() - Method in class io.netty.util.concurrent.NonStickyEventExecutorGroup
 
iterator() - Method in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor
 
iterator() - Method in class io.netty.util.internal.ConcurrentSet
 
iterator() - Method in class io.netty.util.internal.DefaultPriorityQueue
This iterator does not return elements in any particular order.
iterator() - Method in class io.netty.util.internal.EmptyPriorityQueue
 
iteratorAsString(Iterable<Map.Entry<CharSequence, CharSequence>>) - Static method in class io.netty.handler.codec.HeadersUtils
Headers.iterator() which converts each Map.Entry's key and value to a String.
iteratorAsString() - Method in class io.netty.handler.codec.stomp.DefaultStompHeaders
 
iteratorAsString() - Method in interface io.netty.handler.codec.stomp.StompHeaders
Headers.iterator() that converts each Map.Entry's key and value to a String.
IXFR - Static variable in class io.netty.handler.codec.dns.DnsRecordType
Incremental Zone Transfer record RFC 1996 Requests a zone transfer of the given zone but only differences from a previous serial number.

J

JAVA_HASHER - Static variable in interface io.netty.util.HashingStrategy
javaChannel() - Method in class io.netty.channel.nio.AbstractNioChannel
 
javaChannel() - Method in class io.netty.channel.socket.nio.NioDatagramChannel
 
javaChannel() - Method in class io.netty.channel.socket.nio.NioServerSocketChannel
 
javaChannel() - Method in class io.netty.channel.socket.nio.NioSocketChannel
 
javaSocket - Variable in class io.netty.channel.socket.DefaultServerSocketChannelConfig
 
javaSocket - Variable in class io.netty.channel.socket.DefaultSocketChannelConfig
 
javaVersion() - Static method in class io.netty.util.internal.PlatformDependent
Return the version of Java under which this library is used.
JdkAlpnApplicationProtocolNegotiator - Class in io.netty.handler.ssl
The JdkApplicationProtocolNegotiator to use if you need ALPN and are using SslProvider.JDK.
JdkAlpnApplicationProtocolNegotiator(Iterable<String>) - Constructor for class io.netty.handler.ssl.JdkAlpnApplicationProtocolNegotiator
Create a new instance.
JdkAlpnApplicationProtocolNegotiator(String...) - Constructor for class io.netty.handler.ssl.JdkAlpnApplicationProtocolNegotiator
Create a new instance.
JdkAlpnApplicationProtocolNegotiator(boolean, Iterable<String>) - Constructor for class io.netty.handler.ssl.JdkAlpnApplicationProtocolNegotiator
Create a new instance.
JdkAlpnApplicationProtocolNegotiator(boolean, String...) - Constructor for class io.netty.handler.ssl.JdkAlpnApplicationProtocolNegotiator
Create a new instance.
JdkAlpnApplicationProtocolNegotiator(boolean, boolean, Iterable<String>) - Constructor for class io.netty.handler.ssl.JdkAlpnApplicationProtocolNegotiator
Create a new instance.
JdkAlpnApplicationProtocolNegotiator(boolean, boolean, String...) - Constructor for class io.netty.handler.ssl.JdkAlpnApplicationProtocolNegotiator
Create a new instance.
JdkAlpnApplicationProtocolNegotiator(JdkApplicationProtocolNegotiator.ProtocolSelectorFactory, JdkApplicationProtocolNegotiator.ProtocolSelectionListenerFactory, Iterable<String>) - Constructor for class io.netty.handler.ssl.JdkAlpnApplicationProtocolNegotiator
Create a new instance.
JdkAlpnApplicationProtocolNegotiator(JdkApplicationProtocolNegotiator.ProtocolSelectorFactory, JdkApplicationProtocolNegotiator.ProtocolSelectionListenerFactory, String...) - Constructor for class io.netty.handler.ssl.JdkAlpnApplicationProtocolNegotiator
Create a new instance.
JdkApplicationProtocolNegotiator - Interface in io.netty.handler.ssl
JDK extension methods to support ApplicationProtocolNegotiator
JdkApplicationProtocolNegotiator.ProtocolSelectionListener - Interface in io.netty.handler.ssl
A listener to be notified by which protocol was select by its peer.
JdkApplicationProtocolNegotiator.ProtocolSelectionListenerFactory - Interface in io.netty.handler.ssl
JdkApplicationProtocolNegotiator.ProtocolSelector - Interface in io.netty.handler.ssl
Interface to define the role of an application protocol selector in the SSL handshake process.
JdkApplicationProtocolNegotiator.ProtocolSelectorFactory - Interface in io.netty.handler.ssl
JdkApplicationProtocolNegotiator.SslEngineWrapperFactory - Interface in io.netty.handler.ssl
Abstract factory pattern for wrapping an SSLEngine object.
JdkLoggerFactory - Class in io.netty.util.internal.logging
Logger factory which creates a java.util.logging logger.
JdkLoggerFactory() - Constructor for class io.netty.util.internal.logging.JdkLoggerFactory
Deprecated.
JdkSslClientContext - Class in io.netty.handler.ssl
Deprecated.
Use SslContextBuilder to create JdkSslContext instances and only use JdkSslContext in your code.
JdkSslClientContext() - Constructor for class io.netty.handler.ssl.JdkSslClientContext
Deprecated.
JdkSslClientContext(File) - Constructor for class io.netty.handler.ssl.JdkSslClientContext
Deprecated.
JdkSslClientContext(TrustManagerFactory) - Constructor for class io.netty.handler.ssl.JdkSslClientContext
Deprecated.
JdkSslClientContext(File, TrustManagerFactory) - Constructor for class io.netty.handler.ssl.JdkSslClientContext
Deprecated.
JdkSslClientContext(File, TrustManagerFactory, Iterable<String>, Iterable<String>, long, long) - Constructor for class io.netty.handler.ssl.JdkSslClientContext
Deprecated.
JdkSslClientContext(File, TrustManagerFactory, Iterable<String>, CipherSuiteFilter, ApplicationProtocolConfig, long, long) - Constructor for class io.netty.handler.ssl.JdkSslClientContext
Deprecated.
JdkSslClientContext(File, TrustManagerFactory, Iterable<String>, CipherSuiteFilter, JdkApplicationProtocolNegotiator, long, long) - Constructor for class io.netty.handler.ssl.JdkSslClientContext
Deprecated.
JdkSslClientContext(File, TrustManagerFactory, File, File, String, KeyManagerFactory, Iterable<String>, CipherSuiteFilter, ApplicationProtocolConfig, long, long) - Constructor for class io.netty.handler.ssl.JdkSslClientContext
Deprecated.
JdkSslClientContext(File, TrustManagerFactory, File, File, String, KeyManagerFactory, Iterable<String>, CipherSuiteFilter, JdkApplicationProtocolNegotiator, long, long) - Constructor for class io.netty.handler.ssl.JdkSslClientContext
Deprecated.
JdkSslContext - Class in io.netty.handler.ssl
An SslContext which uses JDK's SSL/TLS implementation.
JdkSslContext(SSLContext, boolean, ClientAuth) - Constructor for class io.netty.handler.ssl.JdkSslContext
Creates a new JdkSslContext from a pre-configured SSLContext.
JdkSslContext(SSLContext, boolean, Iterable<String>, CipherSuiteFilter, ApplicationProtocolConfig, ClientAuth) - Constructor for class io.netty.handler.ssl.JdkSslContext
Creates a new JdkSslContext from a pre-configured SSLContext.
JdkSslServerContext - Class in io.netty.handler.ssl
Deprecated.
Use SslContextBuilder to create JdkSslContext instances and only use JdkSslContext in your code.
JdkSslServerContext(File, File) - Constructor for class io.netty.handler.ssl.JdkSslServerContext
Deprecated.
JdkSslServerContext(File, File, String) - Constructor for class io.netty.handler.ssl.JdkSslServerContext
Deprecated.
JdkSslServerContext(File, File, String, Iterable<String>, Iterable<String>, long, long) - Constructor for class io.netty.handler.ssl.JdkSslServerContext
Deprecated.
JdkSslServerContext(File, File, String, Iterable<String>, CipherSuiteFilter, ApplicationProtocolConfig, long, long) - Constructor for class io.netty.handler.ssl.JdkSslServerContext
Deprecated.
JdkSslServerContext(File, File, String, Iterable<String>, CipherSuiteFilter, JdkApplicationProtocolNegotiator, long, long) - Constructor for class io.netty.handler.ssl.JdkSslServerContext
Deprecated.
JdkSslServerContext(File, TrustManagerFactory, File, File, String, KeyManagerFactory, Iterable<String>, CipherSuiteFilter, ApplicationProtocolConfig, long, long) - Constructor for class io.netty.handler.ssl.JdkSslServerContext
Deprecated.
JdkSslServerContext(File, TrustManagerFactory, File, File, String, KeyManagerFactory, Iterable<String>, CipherSuiteFilter, JdkApplicationProtocolNegotiator, long, long) - Constructor for class io.netty.handler.ssl.JdkSslServerContext
Deprecated.
JdkZlibDecoder - Class in io.netty.handler.codec.compression
Decompress a ByteBuf using the inflate algorithm.
JdkZlibDecoder() - Constructor for class io.netty.handler.codec.compression.JdkZlibDecoder
Creates a new instance with the default wrapper (ZlibWrapper.ZLIB).
JdkZlibDecoder(byte[]) - Constructor for class io.netty.handler.codec.compression.JdkZlibDecoder
Creates a new instance with the specified preset dictionary.
JdkZlibDecoder(ZlibWrapper) - Constructor for class io.netty.handler.codec.compression.JdkZlibDecoder
Creates a new instance with the specified wrapper.
JdkZlibEncoder - Class in io.netty.handler.codec.compression
Compresses a ByteBuf using the deflate algorithm.
JdkZlibEncoder() - Constructor for class io.netty.handler.codec.compression.JdkZlibEncoder
Creates a new zlib encoder with the default compression level (6) and the default wrapper (ZlibWrapper.ZLIB).
JdkZlibEncoder(int) - Constructor for class io.netty.handler.codec.compression.JdkZlibEncoder
Creates a new zlib encoder with the specified compressionLevel and the default wrapper (ZlibWrapper.ZLIB).
JdkZlibEncoder(ZlibWrapper) - Constructor for class io.netty.handler.codec.compression.JdkZlibEncoder
Creates a new zlib encoder with the default compression level (6) and the specified wrapper.
JdkZlibEncoder(ZlibWrapper, int) - Constructor for class io.netty.handler.codec.compression.JdkZlibEncoder
Creates a new zlib encoder with the specified compressionLevel and the specified wrapper.
JdkZlibEncoder(byte[]) - Constructor for class io.netty.handler.codec.compression.JdkZlibEncoder
Creates a new zlib encoder with the default compression level (6) and the specified preset dictionary.
JdkZlibEncoder(int, byte[]) - Constructor for class io.netty.handler.codec.compression.JdkZlibEncoder
Creates a new zlib encoder with the specified compressionLevel and the specified preset dictionary.
joinGroup(InetAddress) - Method in class io.netty.channel.epoll.EpollDatagramChannel
 
joinGroup(InetAddress, ChannelPromise) - Method in class io.netty.channel.epoll.EpollDatagramChannel
 
joinGroup(InetSocketAddress, NetworkInterface) - Method in class io.netty.channel.epoll.EpollDatagramChannel
 
joinGroup(InetSocketAddress, NetworkInterface, ChannelPromise) - Method in class io.netty.channel.epoll.EpollDatagramChannel
 
joinGroup(InetAddress, NetworkInterface, InetAddress) - Method in class io.netty.channel.epoll.EpollDatagramChannel
 
joinGroup(InetAddress, NetworkInterface, InetAddress, ChannelPromise) - Method in class io.netty.channel.epoll.EpollDatagramChannel
 
joinGroup(InetAddress) - Method in class io.netty.channel.kqueue.KQueueDatagramChannel
 
joinGroup(InetAddress, ChannelPromise) - Method in class io.netty.channel.kqueue.KQueueDatagramChannel
 
joinGroup(InetSocketAddress, NetworkInterface) - Method in class io.netty.channel.kqueue.KQueueDatagramChannel
 
joinGroup(InetSocketAddress, NetworkInterface, ChannelPromise) - Method in class io.netty.channel.kqueue.KQueueDatagramChannel
 
joinGroup(InetAddress, NetworkInterface, InetAddress) - Method in class io.netty.channel.kqueue.KQueueDatagramChannel
 
joinGroup(InetAddress, NetworkInterface, InetAddress, ChannelPromise) - Method in class io.netty.channel.kqueue.KQueueDatagramChannel
 
joinGroup(InetAddress) - Method in interface io.netty.channel.socket.DatagramChannel
Joins a multicast group and notifies the ChannelFuture once the operation completes.
joinGroup(InetAddress, ChannelPromise) - Method in interface io.netty.channel.socket.DatagramChannel
Joins a multicast group and notifies the ChannelFuture once the operation completes.
joinGroup(InetSocketAddress, NetworkInterface) - Method in interface io.netty.channel.socket.DatagramChannel
Joins the specified multicast group at the specified interface and notifies the ChannelFuture once the operation completes.
joinGroup(InetSocketAddress, NetworkInterface, ChannelPromise) - Method in interface io.netty.channel.socket.DatagramChannel
Joins the specified multicast group at the specified interface and notifies the ChannelFuture once the operation completes.
joinGroup(InetAddress, NetworkInterface, InetAddress) - Method in interface io.netty.channel.socket.DatagramChannel
Joins the specified multicast group at the specified interface and notifies the ChannelFuture once the operation completes.
joinGroup(InetAddress, NetworkInterface, InetAddress, ChannelPromise) - Method in interface io.netty.channel.socket.DatagramChannel
Joins the specified multicast group at the specified interface and notifies the ChannelFuture once the operation completes.
joinGroup(InetAddress) - Method in class io.netty.channel.socket.nio.NioDatagramChannel
 
joinGroup(InetAddress, ChannelPromise) - Method in class io.netty.channel.socket.nio.NioDatagramChannel
 
joinGroup(InetSocketAddress, NetworkInterface) - Method in class io.netty.channel.socket.nio.NioDatagramChannel
 
joinGroup(InetSocketAddress, NetworkInterface, ChannelPromise) - Method in class io.netty.channel.socket.nio.NioDatagramChannel
 
joinGroup(InetAddress, NetworkInterface, InetAddress) - Method in class io.netty.channel.socket.nio.NioDatagramChannel
 
joinGroup(InetAddress, NetworkInterface, InetAddress, ChannelPromise) - Method in class io.netty.channel.socket.nio.NioDatagramChannel
 
joinGroup(InetAddress) - Method in class io.netty.channel.socket.oio.OioDatagramChannel
 
joinGroup(InetAddress, ChannelPromise) - Method in class io.netty.channel.socket.oio.OioDatagramChannel
 
joinGroup(InetSocketAddress, NetworkInterface) - Method in class io.netty.channel.socket.oio.OioDatagramChannel
 
joinGroup(InetSocketAddress, NetworkInterface, ChannelPromise) - Method in class io.netty.channel.socket.oio.OioDatagramChannel
 
joinGroup(InetAddress, NetworkInterface, InetAddress) - Method in class io.netty.channel.socket.oio.OioDatagramChannel
 
joinGroup(InetAddress, NetworkInterface, InetAddress, ChannelPromise) - Method in class io.netty.channel.socket.oio.OioDatagramChannel
 
JsonObjectDecoder - Class in io.netty.handler.codec.json
Splits a byte stream of JSON objects and arrays into individual objects/arrays and passes them up the ChannelPipeline.
JsonObjectDecoder() - Constructor for class io.netty.handler.codec.json.JsonObjectDecoder
 
JsonObjectDecoder(int) - Constructor for class io.netty.handler.codec.json.JsonObjectDecoder
 
JsonObjectDecoder(boolean) - Constructor for class io.netty.handler.codec.json.JsonObjectDecoder
 
JsonObjectDecoder(int, boolean) - Constructor for class io.netty.handler.codec.json.JsonObjectDecoder
 
JZlibDecoder - Class in io.netty.handler.codec.compression
 
JZlibDecoder() - Constructor for class io.netty.handler.codec.compression.JZlibDecoder
Creates a new instance with the default wrapper (ZlibWrapper.ZLIB).
JZlibDecoder(ZlibWrapper) - Constructor for class io.netty.handler.codec.compression.JZlibDecoder
Creates a new instance with the specified wrapper.
JZlibDecoder(byte[]) - Constructor for class io.netty.handler.codec.compression.JZlibDecoder
Creates a new instance with the specified preset dictionary.
JZlibEncoder - Class in io.netty.handler.codec.compression
Compresses a ByteBuf using the deflate algorithm.
JZlibEncoder() - Constructor for class io.netty.handler.codec.compression.JZlibEncoder
Creates a new zlib encoder with the default compression level (6), default window bits (15), default memory level (8), and the default wrapper (ZlibWrapper.ZLIB).
JZlibEncoder(int) - Constructor for class io.netty.handler.codec.compression.JZlibEncoder
Creates a new zlib encoder with the specified compressionLevel, default window bits (15), default memory level (8), and the default wrapper (ZlibWrapper.ZLIB).
JZlibEncoder(ZlibWrapper) - Constructor for class io.netty.handler.codec.compression.JZlibEncoder
Creates a new zlib encoder with the default compression level (6), default window bits (15), default memory level (8), and the specified wrapper.
JZlibEncoder(ZlibWrapper, int) - Constructor for class io.netty.handler.codec.compression.JZlibEncoder
Creates a new zlib encoder with the specified compressionLevel, default window bits (15), default memory level (8), and the specified wrapper.
JZlibEncoder(ZlibWrapper, int, int, int) - Constructor for class io.netty.handler.codec.compression.JZlibEncoder
Creates a new zlib encoder with the specified compressionLevel, the specified windowBits, the specified memLevel, and the specified wrapper.
JZlibEncoder(byte[]) - Constructor for class io.netty.handler.codec.compression.JZlibEncoder
Creates a new zlib encoder with the default compression level (6), default window bits (15), default memory level (8), and the specified preset dictionary.
JZlibEncoder(int, byte[]) - Constructor for class io.netty.handler.codec.compression.JZlibEncoder
Creates a new zlib encoder with the specified compressionLevel, default window bits (15), default memory level (8), and the specified preset dictionary.
JZlibEncoder(int, int, int, byte[]) - Constructor for class io.netty.handler.codec.compression.JZlibEncoder
Creates a new zlib encoder with the specified compressionLevel, the specified windowBits, the specified memLevel, and the specified preset dictionary.

K

keepAlive(int) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
 
keepAliveTimeSeconds() - Method in class io.netty.handler.codec.mqtt.MqttConnectVariableHeader
 
KERNEL_VERSION - Static variable in class io.netty.channel.epoll.Native
 
key - Variable in class io.netty.handler.codec.DefaultHeaders.HeaderEntry
 
KEY - Static variable in class io.netty.handler.codec.dns.DnsRecordType
key record RFC 2535 and RFC 2930 Used only for SIG(0) (RFC 2931) and TKEY (RFC 2930).
key() - Method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
key() - Method in interface io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Returns the optional key of the document.
key() - Method in class io.netty.handler.ssl.util.SelfSignedCertificate
Returns the generated RSA private key.
key() - Method in interface io.netty.util.Attribute
Returns the key of this attribute.
key() - Method in interface io.netty.util.collection.ByteObjectMap.PrimitiveEntry
Gets the key for this entry.
key() - Method in interface io.netty.util.collection.CharObjectMap.PrimitiveEntry
Gets the key for this entry.
key() - Method in interface io.netty.util.collection.IntObjectMap.PrimitiveEntry
Gets the key for this entry.
key() - Method in interface io.netty.util.collection.LongObjectMap.PrimitiveEntry
Gets the key for this entry.
key() - Method in interface io.netty.util.collection.ShortObjectMap.PrimitiveEntry
Gets the key for this entry.
KEY_EEXISTS - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseStatus
 
KEY_ENOENT - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseStatus
 
keyLength() - Method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
keyLength() - Method in interface io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Returns the key length of the message.
keyManager(File, File) - Method in class io.netty.handler.ssl.SslContextBuilder
Identifying certificate for this host.
keyManager(InputStream, InputStream) - Method in class io.netty.handler.ssl.SslContextBuilder
Identifying certificate for this host.
keyManager(PrivateKey, X509Certificate...) - Method in class io.netty.handler.ssl.SslContextBuilder
Identifying certificate for this host.
keyManager(File, File, String) - Method in class io.netty.handler.ssl.SslContextBuilder
Identifying certificate for this host.
keyManager(InputStream, InputStream, String) - Method in class io.netty.handler.ssl.SslContextBuilder
Identifying certificate for this host.
keyManager(PrivateKey, String, X509Certificate...) - Method in class io.netty.handler.ssl.SslContextBuilder
Identifying certificate for this host.
keyManager(KeyManagerFactory) - Method in class io.netty.handler.ssl.SslContextBuilder
Identifying manager for this host.
keySet() - Method in class io.netty.util.collection.ByteObjectHashMap
 
keySet() - Method in class io.netty.util.collection.CharObjectHashMap
 
keySet() - Method in class io.netty.util.collection.IntObjectHashMap
 
keySet() - Method in class io.netty.util.collection.LongObjectHashMap
 
keySet() - Method in class io.netty.util.collection.ShortObjectHashMap
 
keyToString(byte) - Method in class io.netty.util.collection.ByteObjectHashMap
Helper method called by ByteObjectHashMap.toString() in order to convert a single map key into a string.
keyToString(char) - Method in class io.netty.util.collection.CharObjectHashMap
Helper method called by CharObjectHashMap.toString() in order to convert a single map key into a string.
keyToString(int) - Method in class io.netty.util.collection.IntObjectHashMap
Helper method called by IntObjectHashMap.toString() in order to convert a single map key into a string.
keyToString(long) - Method in class io.netty.util.collection.LongObjectHashMap
Helper method called by LongObjectHashMap.toString() in order to convert a single map key into a string.
keyToString(short) - Method in class io.netty.util.collection.ShortObjectHashMap
Helper method called by ShortObjectHashMap.toString() in order to convert a single map key into a string.
KQueue - Class in io.netty.channel.kqueue
If KQueue is available the JNI resources will be loaded when this class loads.
KQueueChannelConfig - Class in io.netty.channel.kqueue
 
KQueueChannelOption<T> - Class in io.netty.channel.kqueue
 
KQueueDatagramChannel - Class in io.netty.channel.kqueue
 
KQueueDatagramChannel() - Constructor for class io.netty.channel.kqueue.KQueueDatagramChannel
 
KQueueDatagramChannel(int) - Constructor for class io.netty.channel.kqueue.KQueueDatagramChannel
 
KQueueDatagramChannelConfig - Class in io.netty.channel.kqueue
 
KQueueDomainSocketChannel - Class in io.netty.channel.kqueue
 
KQueueDomainSocketChannel() - Constructor for class io.netty.channel.kqueue.KQueueDomainSocketChannel
 
KQueueDomainSocketChannel(int) - Constructor for class io.netty.channel.kqueue.KQueueDomainSocketChannel
 
KQueueDomainSocketChannelConfig - Class in io.netty.channel.kqueue
 
KQueueEventLoopGroup - Class in io.netty.channel.kqueue
 
KQueueEventLoopGroup() - Constructor for class io.netty.channel.kqueue.KQueueEventLoopGroup
Create a new instance using the default number of threads and the default ThreadFactory.
KQueueEventLoopGroup(int) - Constructor for class io.netty.channel.kqueue.KQueueEventLoopGroup
Create a new instance using the specified number of threads and the default ThreadFactory.
KQueueEventLoopGroup(int, SelectStrategyFactory) - Constructor for class io.netty.channel.kqueue.KQueueEventLoopGroup
Create a new instance using the specified number of threads and the default ThreadFactory.
KQueueEventLoopGroup(int, ThreadFactory) - Constructor for class io.netty.channel.kqueue.KQueueEventLoopGroup
Create a new instance using the specified number of threads and the given ThreadFactory.
KQueueEventLoopGroup(int, Executor) - Constructor for class io.netty.channel.kqueue.KQueueEventLoopGroup
 
KQueueEventLoopGroup(int, ThreadFactory, SelectStrategyFactory) - Constructor for class io.netty.channel.kqueue.KQueueEventLoopGroup
Create a new instance using the specified number of threads and the given ThreadFactory.
KQueueEventLoopGroup(int, ThreadFactory, int) - Constructor for class io.netty.channel.kqueue.KQueueEventLoopGroup
KQueueEventLoopGroup(int, ThreadFactory, int, SelectStrategyFactory) - Constructor for class io.netty.channel.kqueue.KQueueEventLoopGroup
KQueueEventLoopGroup(int, Executor, SelectStrategyFactory) - Constructor for class io.netty.channel.kqueue.KQueueEventLoopGroup
 
KQueueEventLoopGroup(int, Executor, EventExecutorChooserFactory, SelectStrategyFactory) - Constructor for class io.netty.channel.kqueue.KQueueEventLoopGroup
 
KQueueEventLoopGroup(int, Executor, EventExecutorChooserFactory, SelectStrategyFactory, RejectedExecutionHandler) - Constructor for class io.netty.channel.kqueue.KQueueEventLoopGroup
 
KQueueServerChannelConfig - Class in io.netty.channel.kqueue
 
KQueueServerDomainSocketChannel - Class in io.netty.channel.kqueue
 
KQueueServerDomainSocketChannel() - Constructor for class io.netty.channel.kqueue.KQueueServerDomainSocketChannel
 
KQueueServerDomainSocketChannel(int) - Constructor for class io.netty.channel.kqueue.KQueueServerDomainSocketChannel
 
KQueueServerSocketChannel - Class in io.netty.channel.kqueue
 
KQueueServerSocketChannel() - Constructor for class io.netty.channel.kqueue.KQueueServerSocketChannel
 
KQueueServerSocketChannel(int) - Constructor for class io.netty.channel.kqueue.KQueueServerSocketChannel
 
KQueueServerSocketChannelConfig - Class in io.netty.channel.kqueue
 
KQueueSocketChannel - Class in io.netty.channel.kqueue
 
KQueueSocketChannel() - Constructor for class io.netty.channel.kqueue.KQueueSocketChannel
 
KQueueSocketChannel(int) - Constructor for class io.netty.channel.kqueue.KQueueSocketChannel
 
KQueueSocketChannelConfig - Class in io.netty.channel.kqueue
 
KX - Static variable in class io.netty.handler.codec.dns.DnsRecordType
Key eXchanger record RFC 2230 Used with some cryptographic systems (not including DNSSEC) to identify a key management agent for the associated domain-name.

L

last() - Method in interface io.netty.channel.ChannelPipeline
Returns the last ChannelHandler in this pipeline.
last() - Method in class io.netty.channel.DefaultChannelPipeline
 
lastAckRecv() - Method in class io.netty.channel.epoll.EpollTcpInfo
 
lastAckSent() - Method in class io.netty.channel.epoll.EpollTcpInfo
 
LastBulkStringRedisContent - Interface in io.netty.handler.codec.redis
A last chunk of Bulk Strings.
lastBytesRead(int) - Method in class io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator.MaxMessageHandle
 
lastBytesRead() - Method in class io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator.MaxMessageHandle
 
lastBytesRead(int) - Method in class io.netty.channel.RecvByteBufAllocator.DelegatingHandle
 
lastBytesRead() - Method in class io.netty.channel.RecvByteBufAllocator.DelegatingHandle
 
lastBytesRead(int) - Method in interface io.netty.channel.RecvByteBufAllocator.Handle
Deprecated.
Set the bytes that have been read for the last read operation.
lastBytesRead() - Method in interface io.netty.channel.RecvByteBufAllocator.Handle
Deprecated.
Get the amount of bytes for the previous read operation.
lastContext() - Method in interface io.netty.channel.ChannelPipeline
Returns the context of the last ChannelHandler in this pipeline.
lastContext() - Method in class io.netty.channel.DefaultChannelPipeline
 
lastCumulativeTime() - Method in class io.netty.handler.traffic.TrafficCounter
 
lastDataRecv() - Method in class io.netty.channel.epoll.EpollTcpInfo
 
lastDataSent() - Method in class io.netty.channel.epoll.EpollTcpInfo
 
lastInboundBuffer() - Method in class io.netty.channel.embedded.EmbeddedChannel
lastIndexOf(CharSequence) - Method in class io.netty.util.AsciiString
Searches in this string for the last index of the specified string.
lastIndexOf(CharSequence, int) - Method in class io.netty.util.AsciiString
Searches in this string for the index of the specified string.
LastMemcacheContent - Interface in io.netty.handler.codec.memcache
The MemcacheContent which signals the end of the content batch.
lastOutboundBuffer() - Method in class io.netty.channel.embedded.EmbeddedChannel
lastReadBytes() - Method in class io.netty.handler.traffic.TrafficCounter
 
lastReadThroughput() - Method in class io.netty.handler.traffic.TrafficCounter
 
LastSmtpContent - Interface in io.netty.handler.codec.smtp
The last part of a sequence of SmtpContents that are sent after a DATA request.
LastStompContentSubframe - Interface in io.netty.handler.codec.stomp
The last StompContentSubframe which signals the end of the content batch

Note, even when no content is emitted by the protocol, an empty LastStompContentSubframe is issued to make the upstream parsing easier.

lastTime() - Method in class io.netty.handler.traffic.TrafficCounter
 
lastVariableIndex() - Static method in class io.netty.util.internal.InternalThreadLocalMap
 
lastWriteThroughput() - Method in class io.netty.handler.traffic.TrafficCounter
 
lastWrittenBytes() - Method in class io.netty.handler.traffic.TrafficCounter
 
leaveGroup(InetAddress) - Method in class io.netty.channel.epoll.EpollDatagramChannel
 
leaveGroup(InetAddress, ChannelPromise) - Method in class io.netty.channel.epoll.EpollDatagramChannel
 
leaveGroup(InetSocketAddress, NetworkInterface) - Method in class io.netty.channel.epoll.EpollDatagramChannel
 
leaveGroup(InetSocketAddress, NetworkInterface, ChannelPromise) - Method in class io.netty.channel.epoll.EpollDatagramChannel
 
leaveGroup(InetAddress, NetworkInterface, InetAddress) - Method in class io.netty.channel.epoll.EpollDatagramChannel
 
leaveGroup(InetAddress, NetworkInterface, InetAddress, ChannelPromise) - Method in class io.netty.channel.epoll.EpollDatagramChannel
 
leaveGroup(InetAddress) - Method in class io.netty.channel.kqueue.KQueueDatagramChannel
 
leaveGroup(InetAddress, ChannelPromise) - Method in class io.netty.channel.kqueue.KQueueDatagramChannel
 
leaveGroup(InetSocketAddress, NetworkInterface) - Method in class io.netty.channel.kqueue.KQueueDatagramChannel
 
leaveGroup(InetSocketAddress, NetworkInterface, ChannelPromise) - Method in class io.netty.channel.kqueue.KQueueDatagramChannel
 
leaveGroup(InetAddress, NetworkInterface, InetAddress) - Method in class io.netty.channel.kqueue.KQueueDatagramChannel
 
leaveGroup(InetAddress, NetworkInterface, InetAddress, ChannelPromise) - Method in class io.netty.channel.kqueue.KQueueDatagramChannel
 
leaveGroup(InetAddress) - Method in interface io.netty.channel.socket.DatagramChannel
Leaves a multicast group and notifies the ChannelFuture once the operation completes.
leaveGroup(InetAddress, ChannelPromise) - Method in interface io.netty.channel.socket.DatagramChannel
Leaves a multicast group and notifies the ChannelFuture once the operation completes.
leaveGroup(InetSocketAddress, NetworkInterface) - Method in interface io.netty.channel.socket.DatagramChannel
Leaves a multicast group on a specified local interface and notifies the ChannelFuture once the operation completes.
leaveGroup(InetSocketAddress, NetworkInterface, ChannelPromise) - Method in interface io.netty.channel.socket.DatagramChannel
Leaves a multicast group on a specified local interface and notifies the ChannelFuture once the operation completes.
leaveGroup(InetAddress, NetworkInterface, InetAddress) - Method in interface io.netty.channel.socket.DatagramChannel
Leave the specified multicast group at the specified interface using the specified source and notifies the ChannelFuture once the operation completes.
leaveGroup(InetAddress, NetworkInterface, InetAddress, ChannelPromise) - Method in interface io.netty.channel.socket.DatagramChannel
Leave the specified multicast group at the specified interface using the specified source and notifies the ChannelFuture once the operation completes.
leaveGroup(InetAddress) - Method in class io.netty.channel.socket.nio.NioDatagramChannel
 
leaveGroup(InetAddress, ChannelPromise) - Method in class io.netty.channel.socket.nio.NioDatagramChannel
 
leaveGroup(InetSocketAddress, NetworkInterface) - Method in class io.netty.channel.socket.nio.NioDatagramChannel
 
leaveGroup(InetSocketAddress, NetworkInterface, ChannelPromise) - Method in class io.netty.channel.socket.nio.NioDatagramChannel
 
leaveGroup(InetAddress, NetworkInterface, InetAddress) - Method in class io.netty.channel.socket.nio.NioDatagramChannel
 
leaveGroup(InetAddress, NetworkInterface, InetAddress, ChannelPromise) - Method in class io.netty.channel.socket.nio.NioDatagramChannel
 
leaveGroup(InetAddress) - Method in class io.netty.channel.socket.oio.OioDatagramChannel
 
leaveGroup(InetAddress, ChannelPromise) - Method in class io.netty.channel.socket.oio.OioDatagramChannel
 
leaveGroup(InetSocketAddress, NetworkInterface) - Method in class io.netty.channel.socket.oio.OioDatagramChannel
 
leaveGroup(InetSocketAddress, NetworkInterface, ChannelPromise) - Method in class io.netty.channel.socket.oio.OioDatagramChannel
 
leaveGroup(InetAddress, NetworkInterface, InetAddress) - Method in class io.netty.channel.socket.oio.OioDatagramChannel
 
leaveGroup(InetAddress, NetworkInterface, InetAddress, ChannelPromise) - Method in class io.netty.channel.socket.oio.OioDatagramChannel
 
length() - Method in class io.netty.handler.codec.redis.ArrayHeaderRedisMessage
Get length of this array object.
length() - Method in class io.netty.handler.stream.ChunkedFile
 
length() - Method in interface io.netty.handler.stream.ChunkedInput
Returns the length of the input.
length() - Method in class io.netty.handler.stream.ChunkedNioFile
 
length() - Method in class io.netty.handler.stream.ChunkedNioStream
 
length() - Method in class io.netty.handler.stream.ChunkedStream
 
length() - Method in class io.netty.util.AsciiString
The length in bytes of this instance.
length() - Method in class io.netty.util.internal.AppendableCharSequence
 
length(String) - Static method in class io.netty.util.internal.StringUtil
Get the length of a string, null input is considered 0 length.
LengthFieldBasedFrameDecoder - Class in io.netty.handler.codec
A decoder that splits the received ByteBufs dynamically by the value of the length field in the message.
LengthFieldBasedFrameDecoder(int, int, int) - Constructor for class io.netty.handler.codec.LengthFieldBasedFrameDecoder
Creates a new instance.
LengthFieldBasedFrameDecoder(int, int, int, int, int) - Constructor for class io.netty.handler.codec.LengthFieldBasedFrameDecoder
Creates a new instance.
LengthFieldBasedFrameDecoder(int, int, int, int, int, boolean) - Constructor for class io.netty.handler.codec.LengthFieldBasedFrameDecoder
Creates a new instance.
LengthFieldBasedFrameDecoder(ByteOrder, int, int, int, int, int, boolean) - Constructor for class io.netty.handler.codec.LengthFieldBasedFrameDecoder
Creates a new instance.
LengthFieldPrepender - Class in io.netty.handler.codec
An encoder that prepends the length of the message.
LengthFieldPrepender(int) - Constructor for class io.netty.handler.codec.LengthFieldPrepender
Creates a new instance.
LengthFieldPrepender(int, boolean) - Constructor for class io.netty.handler.codec.LengthFieldPrepender
Creates a new instance.
LengthFieldPrepender(int, int) - Constructor for class io.netty.handler.codec.LengthFieldPrepender
Creates a new instance.
LengthFieldPrepender(int, int, boolean) - Constructor for class io.netty.handler.codec.LengthFieldPrepender
Creates a new instance.
LengthFieldPrepender(ByteOrder, int, int, boolean) - Constructor for class io.netty.handler.codec.LengthFieldPrepender
Creates a new instance.
level() - Method in class io.netty.handler.logging.LoggingHandler
Returns the LogLevel that this handler uses to log
Limits - Class in io.netty.channel.unix
 
LINE_FEED - Static variable in class io.netty.util.internal.StringUtil
 
LineBasedFrameDecoder - Class in io.netty.handler.codec
A decoder that splits the received ByteBufs on line endings.
LineBasedFrameDecoder(int) - Constructor for class io.netty.handler.codec.LineBasedFrameDecoder
Creates a new decoder.
LineBasedFrameDecoder(int, boolean, boolean) - Constructor for class io.netty.handler.codec.LineBasedFrameDecoder
Creates a new decoder.
lineDelimiter() - Static method in class io.netty.handler.codec.Delimiters
Returns CR ('\r') and LF ('\n') delimiters, which could be used for text-based line protocols.
LineEncoder - Class in io.netty.handler.codec.string
Apply a line separator to the requested String and encode it into a ByteBuf.
LineEncoder() - Constructor for class io.netty.handler.codec.string.LineEncoder
Creates a new instance with the current system line separator and UTF-8 charset encoding.
LineEncoder(LineSeparator) - Constructor for class io.netty.handler.codec.string.LineEncoder
Creates a new instance with the specified line separator and UTF-8 charset encoding.
LineEncoder(Charset) - Constructor for class io.netty.handler.codec.string.LineEncoder
Creates a new instance with the specified character set.
LineEncoder(LineSeparator, Charset) - Constructor for class io.netty.handler.codec.string.LineEncoder
Creates a new instance with the specified line separator and character set.
LineSeparator - Class in io.netty.handler.codec.string
A class to represent line separators in different environments.
LineSeparator(String) - Constructor for class io.netty.handler.codec.string.LineSeparator
Create LineSeparator with the specified lineSeparator string.
listen(int) - Method in class io.netty.channel.unix.Socket
 
LITTLE_ENDIAN - Static variable in class io.netty.buffer.Unpooled
Little endian byte order.
load(String, ClassLoader) - Static method in class io.netty.util.internal.NativeLibraryLoader
Load the given library with the specified ClassLoader
loadFirstAvailable(ClassLoader, String...) - Static method in class io.netty.util.internal.NativeLibraryLoader
Loads the first available library in the collection with the specified ClassLoader.
LOC - Static variable in class io.netty.handler.codec.dns.DnsRecordType
Location record RFC 1876 Specifies a geographical location associated with a domain name.
localAddress(SocketAddress) - Method in class io.netty.bootstrap.AbstractBootstrap
The SocketAddress which is used to bind the local "end" to.
localAddress(int) - Method in class io.netty.bootstrap.AbstractBootstrap
 
localAddress(String, int) - Method in class io.netty.bootstrap.AbstractBootstrap
 
localAddress(InetAddress, int) - Method in class io.netty.bootstrap.AbstractBootstrap
 
localAddress() - Method in class io.netty.bootstrap.AbstractBootstrapConfig
Returns the configured local address or null if non is configured yet.
localAddress() - Method in class io.netty.channel.AbstractChannel.AbstractUnsafe
 
localAddress() - Method in class io.netty.channel.AbstractChannel
 
localAddress() - Method in interface io.netty.channel.Channel
Returns the local address where this channel is bound to.
localAddress() - Method in interface io.netty.channel.Channel.Unsafe
Return the SocketAddress to which is bound local or null if none.
localAddress() - Method in class io.netty.channel.epoll.EpollDatagramChannel
 
localAddress() - Method in class io.netty.channel.epoll.EpollDomainSocketChannel
 
localAddress() - Method in class io.netty.channel.epoll.EpollServerDomainSocketChannel
 
localAddress() - Method in class io.netty.channel.epoll.EpollServerSocketChannel
 
localAddress() - Method in class io.netty.channel.epoll.EpollSocketChannel
 
localAddress() - Method in class io.netty.channel.kqueue.KQueueDatagramChannel
 
localAddress() - Method in class io.netty.channel.kqueue.KQueueDomainSocketChannel
 
localAddress() - Method in class io.netty.channel.kqueue.KQueueServerDomainSocketChannel
 
localAddress() - Method in class io.netty.channel.kqueue.KQueueServerSocketChannel
 
localAddress() - Method in class io.netty.channel.kqueue.KQueueSocketChannel
 
LocalAddress - Class in io.netty.channel.local
An endpoint in the local transport.
LocalAddress(String) - Constructor for class io.netty.channel.local.LocalAddress
Creates a new instance with the specified ID.
localAddress() - Method in class io.netty.channel.local.LocalChannel
 
localAddress() - Method in class io.netty.channel.local.LocalServerChannel
 
localAddress() - Method in interface io.netty.channel.socket.DatagramChannel
 
localAddress() - Method in class io.netty.channel.socket.nio.NioDatagramChannel
 
localAddress() - Method in class io.netty.channel.socket.nio.NioServerSocketChannel
 
localAddress() - Method in class io.netty.channel.socket.nio.NioSocketChannel
 
localAddress() - Method in class io.netty.channel.socket.oio.OioDatagramChannel
 
localAddress() - Method in class io.netty.channel.socket.oio.OioServerSocketChannel
 
localAddress() - Method in class io.netty.channel.socket.oio.OioSocketChannel
 
localAddress() - Method in interface io.netty.channel.socket.ServerSocketChannel
 
localAddress() - Method in interface io.netty.channel.socket.SocketChannel
 
localAddress() - Method in interface io.netty.channel.unix.DomainSocketChannel
 
localAddress() - Method in interface io.netty.channel.unix.ServerDomainSocketChannel
 
localAddress() - Method in class io.netty.channel.unix.Socket
 
localAddress0() - Method in class io.netty.channel.AbstractChannel
Returns the SocketAddress which is bound locally.
localAddress0() - Method in class io.netty.channel.embedded.EmbeddedChannel
 
localAddress0() - Method in class io.netty.channel.epoll.EpollDatagramChannel
 
localAddress0() - Method in class io.netty.channel.epoll.EpollDomainSocketChannel
 
localAddress0() - Method in class io.netty.channel.epoll.EpollServerDomainSocketChannel
 
localAddress0() - Method in class io.netty.channel.epoll.EpollServerSocketChannel
 
localAddress0() - Method in class io.netty.channel.epoll.EpollSocketChannel
 
localAddress0() - Method in class io.netty.channel.kqueue.KQueueDatagramChannel
 
localAddress0() - Method in class io.netty.channel.kqueue.KQueueDomainSocketChannel
 
localAddress0() - Method in class io.netty.channel.kqueue.KQueueServerDomainSocketChannel
 
localAddress0() - Method in class io.netty.channel.kqueue.KQueueServerSocketChannel
 
localAddress0() - Method in class io.netty.channel.kqueue.KQueueSocketChannel
 
localAddress0() - Method in class io.netty.channel.local.LocalChannel
 
localAddress0() - Method in class io.netty.channel.local.LocalServerChannel
 
localAddress0() - Method in class io.netty.channel.socket.nio.NioDatagramChannel
 
localAddress0() - Method in class io.netty.channel.socket.nio.NioServerSocketChannel
 
localAddress0() - Method in class io.netty.channel.socket.nio.NioSocketChannel
 
localAddress0() - Method in class io.netty.channel.socket.oio.OioDatagramChannel
 
localAddress0() - Method in class io.netty.channel.socket.oio.OioServerSocketChannel
 
localAddress0() - Method in class io.netty.channel.socket.oio.OioSocketChannel
 
LocalChannel - Class in io.netty.channel.local
A Channel for the local transport.
LocalChannel() - Constructor for class io.netty.channel.local.LocalChannel
 
LocalChannel(LocalServerChannel, LocalChannel) - Constructor for class io.netty.channel.local.LocalChannel
 
localChannelReaderStackDepth() - Method in class io.netty.util.internal.InternalThreadLocalMap
 
LocalEventLoopGroup - Class in io.netty.channel.local
Deprecated.
LocalEventLoopGroup() - Constructor for class io.netty.channel.local.LocalEventLoopGroup
Deprecated.
Create a new instance with the default number of threads.
LocalEventLoopGroup(int) - Constructor for class io.netty.channel.local.LocalEventLoopGroup
Deprecated.
Create a new instance
LocalEventLoopGroup(int, ThreadFactory) - Constructor for class io.netty.channel.local.LocalEventLoopGroup
Deprecated.
Create a new instance
localhost() - Method in enum io.netty.channel.socket.InternetProtocolFamily
Returns the InetAddress that represent the LOCALHOST for the family.
LOCALHOST - Static variable in class io.netty.util.NetUtil
The InetAddress that represents the loopback address.
LOCALHOST4 - Static variable in class io.netty.util.NetUtil
The Inet4Address that represents the IPv4 loopback address '127.0.0.1'
LOCALHOST6 - Static variable in class io.netty.util.NetUtil
The Inet6Address that represents the IPv6 loopback address '::1'
LocalServerChannel - Class in io.netty.channel.local
A ServerChannel for the local transport which allows in VM communication.
LocalServerChannel() - Constructor for class io.netty.channel.local.LocalServerChannel
 
localSocketAddress(ServerSocket) - Static method in class io.netty.util.internal.SocketUtils
 
log(InternalLogLevel, String, Throwable) - Method in class io.netty.util.internal.logging.AbstractInternalLogger
 
log(InternalLogLevel, Throwable) - Method in class io.netty.util.internal.logging.AbstractInternalLogger
 
log(InternalLogLevel, String) - Method in class io.netty.util.internal.logging.AbstractInternalLogger
 
log(InternalLogLevel, String, Object) - Method in class io.netty.util.internal.logging.AbstractInternalLogger
 
log(InternalLogLevel, String, Object, Object) - Method in class io.netty.util.internal.logging.AbstractInternalLogger
 
log(InternalLogLevel, String, Object...) - Method in class io.netty.util.internal.logging.AbstractInternalLogger
 
log(InternalLogLevel, String) - Method in interface io.netty.util.internal.logging.InternalLogger
Log a message at the specified level.
log(InternalLogLevel, String, Object) - Method in interface io.netty.util.internal.logging.InternalLogger
Log a message at the specified level according to the specified format and argument.
log(InternalLogLevel, String, Object, Object) - Method in interface io.netty.util.internal.logging.InternalLogger
Log a message at the specified level according to the specified format and arguments.
log(InternalLogLevel, String, Object...) - Method in interface io.netty.util.internal.logging.InternalLogger
Log a message at the specified level according to the specified format and arguments.
log(InternalLogLevel, String, Throwable) - Method in interface io.netty.util.internal.logging.InternalLogger
Log an exception (throwable) at the specified level with an accompanying message.
log(InternalLogLevel, Throwable) - Method in interface io.netty.util.internal.logging.InternalLogger
Log an exception (throwable) at the specified level.
Log4J2LoggerFactory - Class in io.netty.util.internal.logging
 
Log4J2LoggerFactory() - Constructor for class io.netty.util.internal.logging.Log4J2LoggerFactory
Deprecated.
Log4JLoggerFactory - Class in io.netty.util.internal.logging
Logger factory which creates an Apache Log4J logger.
Log4JLoggerFactory() - Constructor for class io.netty.util.internal.logging.Log4JLoggerFactory
Deprecated.
logger - Variable in class io.netty.handler.logging.LoggingHandler
 
LoggingHandler - Class in io.netty.handler.logging
A ChannelHandler that logs all events using a logging framework.
LoggingHandler() - Constructor for class io.netty.handler.logging.LoggingHandler
Creates a new instance whose logger name is the fully qualified class name of the instance with hex dump enabled.
LoggingHandler(LogLevel) - Constructor for class io.netty.handler.logging.LoggingHandler
Creates a new instance whose logger name is the fully qualified class name of the instance.
LoggingHandler(Class<?>) - Constructor for class io.netty.handler.logging.LoggingHandler
Creates a new instance with the specified logger name and with hex dump enabled.
LoggingHandler(Class<?>, LogLevel) - Constructor for class io.netty.handler.logging.LoggingHandler
Creates a new instance with the specified logger name.
LoggingHandler(String) - Constructor for class io.netty.handler.logging.LoggingHandler
Creates a new instance with the specified logger name using the default log level.
LoggingHandler(String, LogLevel) - Constructor for class io.netty.handler.logging.LoggingHandler
Creates a new instance with the specified logger name.
LOGIN - Static variable in interface io.netty.handler.codec.stomp.StompHeaders
 
LogLevel - Enum in io.netty.handler.logging
Maps the regular LogLevels with the InternalLogLevel ones.
LongCollections - Class in io.netty.util.collection
Utilities for long-based primitive collections.
longCommitHash() - Method in class io.netty.util.Version
 
LongCounter - Interface in io.netty.util.internal
Counter for long.
LongObjectHashMap<V> - Class in io.netty.util.collection
A hash map implementation of LongObjectMap that uses open addressing for keys.
LongObjectHashMap() - Constructor for class io.netty.util.collection.LongObjectHashMap
 
LongObjectHashMap(int) - Constructor for class io.netty.util.collection.LongObjectHashMap
 
LongObjectHashMap(int, float) - Constructor for class io.netty.util.collection.LongObjectHashMap
 
LongObjectMap<V> - Interface in io.netty.util.collection
Interface for a primitive map that uses longs as keys.
LongObjectMap.PrimitiveEntry<V> - Interface in io.netty.util.collection
A primitive entry in the map, provided by the iterator from LongObjectMap.entries()
longValue(Long, long) - Static method in class io.netty.util.internal.ObjectUtil
Resolves a possibly null Long to a primitive long, using a default value.
lookup(ChannelHandlerContext, String) - Method in class io.netty.handler.ssl.AbstractSniHandler
Kicks off a lookup for the given SNI value and returns a Future which in turn will notify the AbstractSniHandler.onLookupComplete(ChannelHandlerContext, String, Future) on completion.
lookup(ChannelHandlerContext, String) - Method in class io.netty.handler.ssl.SniHandler
The default implementation will simply call AsyncMapping.map(Object, Promise) but users can override this method to implement custom behavior.
LOOPBACK_IF - Static variable in class io.netty.util.NetUtil
The loopback NetworkInterface of the current machine
loopbackAddress() - Static method in class io.netty.util.internal.SocketUtils
 
lost() - Method in class io.netty.channel.epoll.EpollTcpInfo
 
low() - Method in class io.netty.channel.WriteBufferWaterMark
Returns the low water mark for the write buffer.

M

MacAddressUtil - Class in io.netty.util.internal
 
magic() - Method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
magic() - Method in interface io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Returns the magic byte for the message.
MAIL - Static variable in class io.netty.handler.codec.smtp.SmtpCommand
 
mail(CharSequence, CharSequence...) - Static method in class io.netty.handler.codec.smtp.SmtpRequests
Creates a MAIL request.
main(String[]) - Static method in class io.netty.util.Version
Prints the version information to System.err.
map(IN, Promise<OUT>) - Method in interface io.netty.util.AsyncMapping
Returns the Future that will provide the result of the mapping.
map(String) - Method in class io.netty.util.DomainNameMapping
 
map(IN) - Method in interface io.netty.util.Mapping
Returns mapped value of the specified input.
mapping - Variable in class io.netty.handler.ssl.SniHandler
 
Mapping<IN,OUT> - Interface in io.netty.util
Maintains the mapping from the objects of one type to the objects of the other type.
mark(int) - Method in class io.netty.buffer.ByteBufInputStream
 
mark(int) - Method in class io.netty.handler.codec.serialization.ObjectDecoderInputStream
 
markReaderIndex() - Method in class io.netty.buffer.AbstractByteBuf
 
markReaderIndex() - Method in class io.netty.buffer.ByteBuf
Marks the current readerIndex in this buffer.
markReaderIndex() - Method in class io.netty.buffer.CompositeByteBuf
 
markReaderIndex() - Method in class io.netty.buffer.EmptyByteBuf
 
markReaderIndex() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
markSupported() - Method in class io.netty.buffer.ByteBufInputStream
 
markSupported() - Method in class io.netty.handler.codec.serialization.ObjectDecoderInputStream
 
markWriterIndex() - Method in class io.netty.buffer.AbstractByteBuf
 
markWriterIndex() - Method in class io.netty.buffer.ByteBuf
Marks the current writerIndex in this buffer.
markWriterIndex() - Method in class io.netty.buffer.CompositeByteBuf
 
markWriterIndex() - Method in class io.netty.buffer.EmptyByteBuf
 
markWriterIndex() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
match(Object) - Method in class io.netty.util.internal.NoOpTypeParameterMatcher
 
match(Object) - Method in class io.netty.util.internal.TypeParameterMatcher
 
matches(Channel) - Method in interface io.netty.channel.group.ChannelMatcher
Returns true if the operation should be also executed on the given Channel.
matches(InetSocketAddress) - Method in interface io.netty.handler.ipfilter.IpFilterRule
 
matches(InetSocketAddress) - Method in class io.netty.handler.ipfilter.IpSubnetFilterRule
 
matches(String) - Method in class io.netty.util.AsciiString
Determines whether this string matches a given regular expression.
MathUtil - Class in io.netty.util.internal
Math utility methods.
MAX_MESSAGES_PER_READ - Static variable in class io.netty.channel.ChannelOption
maxBytesPerIndividualRead() - Method in class io.netty.channel.DefaultMaxBytesRecvByteBufAllocator
 
maxBytesPerIndividualRead(int) - Method in class io.netty.channel.DefaultMaxBytesRecvByteBufAllocator
 
maxBytesPerIndividualRead() - Method in interface io.netty.channel.MaxBytesRecvByteBufAllocator
Returns the maximum number of bytes to read per individual read operation.
maxBytesPerIndividualRead(int) - Method in interface io.netty.channel.MaxBytesRecvByteBufAllocator
Sets the maximum number of bytes to read per individual read operation.
maxBytesPerRead() - Method in class io.netty.channel.DefaultMaxBytesRecvByteBufAllocator
 
maxBytesPerRead(int) - Method in class io.netty.channel.DefaultMaxBytesRecvByteBufAllocator
 
maxBytesPerRead() - Method in interface io.netty.channel.MaxBytesRecvByteBufAllocator
Returns the maximum number of bytes to read per read loop.
maxBytesPerRead(int) - Method in interface io.netty.channel.MaxBytesRecvByteBufAllocator
Sets the maximum number of bytes to read per read loop.
maxBytesPerReadPair() - Method in class io.netty.channel.DefaultMaxBytesRecvByteBufAllocator
 
maxBytesPerReadPair(int, int) - Method in class io.netty.channel.DefaultMaxBytesRecvByteBufAllocator
 
maxBytesPerReadPair() - Method in interface io.netty.channel.MaxBytesRecvByteBufAllocator
Atomic way to get the maximum number of bytes to read for a read loop and per individual read operation.
maxBytesPerReadPair(int, int) - Method in interface io.netty.channel.MaxBytesRecvByteBufAllocator
Sets the maximum number of bytes to read for a read loop and per individual read operation.
MaxBytesRecvByteBufAllocator - Interface in io.netty.channel
RecvByteBufAllocator that limits a read operation based upon a maximum value per individual read and a maximum amount when a read operation is attempted by the event loop.
maxCapacity() - Method in class io.netty.buffer.AbstractByteBuf
 
maxCapacity(int) - Method in class io.netty.buffer.AbstractByteBuf
 
maxCapacity() - Method in class io.netty.buffer.ByteBuf
Returns the maximum allowed capacity of this buffer.
maxCapacity() - Method in class io.netty.buffer.EmptyByteBuf
 
maxCapacity() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
maxContentLength() - Method in class io.netty.handler.codec.MessageAggregator
Returns the maximum allowed length of the aggregated message in bytes.
maxCumulationBufferComponents() - Method in class io.netty.handler.codec.MessageAggregator
Returns the maximum number of components in the cumulation buffer.
maxDeviation() - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
 
maxDirectMemory() - Static method in class io.netty.util.internal.PlatformDependent
Returns the maximum memory reserved for direct buffer allocation.
maximumCumulativeReadBytes() - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
 
maximumCumulativeWrittenBytes() - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
 
MaxMessageHandle() - Constructor for class io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator.MaxMessageHandle
 
maxMessagesPerRead() - Method in class io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator
 
maxMessagesPerRead(int) - Method in class io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator
 
maxMessagesPerRead() - Method in interface io.netty.channel.MaxMessagesRecvByteBufAllocator
Returns the maximum number of messages to read per read loop.
maxMessagesPerRead(int) - Method in interface io.netty.channel.MaxMessagesRecvByteBufAllocator
Sets the maximum number of messages to read per read loop.
MaxMessagesRecvByteBufAllocator - Interface in io.netty.channel
RecvByteBufAllocator that limits the number of read operations that will be attempted when a read operation is attempted by the event loop.
maxNumComponents() - Method in class io.netty.buffer.CompositeByteBuf
Return the max number of ByteBuf's that are composed in this instance
maxNumElements() - Method in interface io.netty.buffer.PoolSubpageMetric
Return the number of maximal elements that can be allocated out of the sub-page.
maxPayloadSize() - Method in class io.netty.resolver.dns.DnsNameResolver
Returns the capacity of the datagram packet buffer (in bytes).
maxPayloadSize(int) - Method in class io.netty.resolver.dns.DnsNameResolverBuilder
Sets the capacity of the datagram packet buffer (in bytes).
maxQueriesPerResolve() - Method in class io.netty.resolver.dns.DnsNameResolver
Returns the maximum allowed number of DNS queries to send when resolving a host name.
maxQueriesPerResolve(int) - Method in class io.netty.resolver.dns.DnsNameResolverBuilder
Sets the maximum allowed number of DNS queries to send when resolving a host name.
maxTime - Variable in class io.netty.handler.traffic.AbstractTrafficShapingHandler
Max delay in wait
maxTtl() - Method in class io.netty.resolver.dns.DefaultDnsCache
Returns the maximum TTL of the cached DNS resource records (in seconds).
maxUsage() - Method in interface io.netty.buffer.PoolChunkListMetric
Return the maximum usage of the chunk list after which chunks are promoted to the next list.
maxWritableBytes() - Method in class io.netty.buffer.AbstractByteBuf
 
maxWritableBytes() - Method in class io.netty.buffer.ByteBuf
Returns the maximum possible number of writable bytes, which is equal to (this.maxCapacity - this.writerIndex).
maxWritableBytes() - Method in class io.netty.buffer.EmptyByteBuf
 
maxWritableBytes() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
maybeSuperUser() - Static method in class io.netty.util.internal.PlatformDependent
Return true if the current user may be a super-user.
MemcacheContent - Interface in io.netty.handler.codec.memcache
An Memcache content chunk.
MemcacheMessage - Interface in io.netty.handler.codec.memcache
Marker interface for both ascii and binary messages.
MemcacheObject - Interface in io.netty.handler.codec.memcache
Defines a common interface for all MemcacheObject implementations.
memoryAddress() - Method in class io.netty.buffer.ByteBuf
Returns the low-level memory address that point to the first byte of ths backing data.
memoryAddress() - Method in class io.netty.buffer.CompositeByteBuf
 
memoryAddress() - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
memoryAddress() - Method in class io.netty.buffer.EmptyByteBuf
 
memoryAddress() - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
memoryAddress() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
memoryAddress() - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
memoryAddress() - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
memoryAddress() - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
memoryAddress(int) - Method in class io.netty.channel.unix.IovArray
Returns the memoryAddress for the given offset.
MERGE_CUMULATOR - Static variable in class io.netty.handler.codec.ByteToMessageDecoder
Cumulate ByteBufs by merge them into one ByteBuf's, using memory copies.
MESSAGE - Static variable in interface io.netty.handler.codec.stomp.StompHeaders
 
MESSAGE_ID - Static variable in interface io.netty.handler.codec.stomp.StompHeaders
 
MESSAGE_SIZE_ESTIMATOR - Static variable in class io.netty.channel.ChannelOption
 
MessageAggregationException - Exception in io.netty.handler.codec
Raised by MessageAggregator when aggregation fails due to an unexpected message sequence.
MessageAggregationException() - Constructor for exception io.netty.handler.codec.MessageAggregationException
 
MessageAggregationException(String) - Constructor for exception io.netty.handler.codec.MessageAggregationException
 
MessageAggregationException(String, Throwable) - Constructor for exception io.netty.handler.codec.MessageAggregationException
 
MessageAggregationException(Throwable) - Constructor for exception io.netty.handler.codec.MessageAggregationException
 
MessageAggregator<I,S,C extends ByteBufHolder,O extends ByteBufHolder> - Class in io.netty.handler.codec
An abstract ChannelHandler that aggregates a series of message objects into a single aggregated message.
MessageAggregator(int) - Constructor for class io.netty.handler.codec.MessageAggregator
Creates a new instance.
MessageAggregator(int, Class<? extends I>) - Constructor for class io.netty.handler.codec.MessageAggregator
 
messageId(int) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.PublishBuilder
 
messageId(int) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.SubscribeBuilder
 
messageId(int) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.UnsubscribeBuilder
 
messageId() - Method in class io.netty.handler.codec.mqtt.MqttMessageIdVariableHeader
 
messageId() - Method in class io.netty.handler.codec.mqtt.MqttPublishVariableHeader
Deprecated.
MessageSizeEstimator - Interface in io.netty.channel
Responsible to estimate size of a message.
MessageSizeEstimator.Handle - Interface in io.netty.channel
 
MessageToByteEncoder<I> - Class in io.netty.handler.codec
ChannelOutboundHandlerAdapter which encodes message in a stream-like fashion from one message to an ByteBuf.
MessageToByteEncoder() - Constructor for class io.netty.handler.codec.MessageToByteEncoder
see MessageToByteEncoder.MessageToByteEncoder(boolean) with true as boolean parameter.
MessageToByteEncoder(Class<? extends I>) - Constructor for class io.netty.handler.codec.MessageToByteEncoder
MessageToByteEncoder(boolean) - Constructor for class io.netty.handler.codec.MessageToByteEncoder
Create a new instance which will try to detect the types to match out of the type parameter of the class.
MessageToByteEncoder(Class<? extends I>, boolean) - Constructor for class io.netty.handler.codec.MessageToByteEncoder
Create a new instance
MessageToMessageCodec<INBOUND_IN,OUTBOUND_IN> - Class in io.netty.handler.codec
A Codec for on-the-fly encoding/decoding of message.
MessageToMessageCodec() - Constructor for class io.netty.handler.codec.MessageToMessageCodec
Create a new instance which will try to detect the types to decode and encode out of the type parameter of the class.
MessageToMessageCodec(Class<? extends INBOUND_IN>, Class<? extends OUTBOUND_IN>) - Constructor for class io.netty.handler.codec.MessageToMessageCodec
Create a new instance.
MessageToMessageDecoder<I> - Class in io.netty.handler.codec
ChannelInboundHandlerAdapter which decodes from one message to an other message.
MessageToMessageDecoder() - Constructor for class io.netty.handler.codec.MessageToMessageDecoder
Create a new instance which will try to detect the types to match out of the type parameter of the class.
MessageToMessageDecoder(Class<? extends I>) - Constructor for class io.netty.handler.codec.MessageToMessageDecoder
Create a new instance
MessageToMessageEncoder<I> - Class in io.netty.handler.codec
ChannelOutboundHandlerAdapter which encodes from one message to an other message For example here is an implementation which decodes an Integer to an String.
MessageToMessageEncoder() - Constructor for class io.netty.handler.codec.MessageToMessageEncoder
Create a new instance which will try to detect the types to match out of the type parameter of the class.
MessageToMessageEncoder(Class<? extends I>) - Constructor for class io.netty.handler.codec.MessageToMessageEncoder
Create a new instance
messageType() - Method in class io.netty.handler.codec.mqtt.MqttFixedHeader
 
metadata() - Method in class io.netty.channel.AbstractServerChannel
 
metadata() - Method in interface io.netty.channel.Channel
Return the ChannelMetadata of the Channel which describe the nature of the Channel.
metadata() - Method in class io.netty.channel.embedded.EmbeddedChannel
 
metadata() - Method in class io.netty.channel.epoll.AbstractEpollServerChannel
 
metadata() - Method in class io.netty.channel.epoll.AbstractEpollStreamChannel
 
metadata() - Method in class io.netty.channel.epoll.EpollDatagramChannel
 
metadata() - Method in class io.netty.channel.kqueue.AbstractKQueueServerChannel
 
metadata() - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel
 
metadata() - Method in class io.netty.channel.kqueue.KQueueDatagramChannel
 
metadata() - Method in class io.netty.channel.local.LocalChannel
 
metadata() - Method in class io.netty.channel.nio.AbstractNioByteChannel
 
metadata() - Method in class io.netty.channel.oio.AbstractOioByteChannel
 
metadata() - Method in class io.netty.channel.socket.nio.NioDatagramChannel
 
metadata() - Method in class io.netty.channel.socket.nio.NioServerSocketChannel
 
metadata() - Method in class io.netty.channel.socket.oio.OioDatagramChannel
 
metadata() - Method in class io.netty.channel.socket.oio.OioServerSocketChannel
 
metric() - Method in interface io.netty.buffer.ByteBufAllocatorMetricProvider
metric() - Method in class io.netty.buffer.PooledByteBufAllocator
 
metric() - Method in class io.netty.buffer.UnpooledByteBufAllocator
 
milliSecondFromNano() - Static method in class io.netty.handler.traffic.TrafficCounter
 
minTtl() - Method in class io.netty.resolver.dns.DefaultDnsCache
Returns the minimum TTL of the cached DNS resource records (in seconds).
minUsage() - Method in interface io.netty.buffer.PoolChunkListMetric
Return the minimum usage of the chunk list before which chunks are promoted to the previous list.
MqttConnAckMessage - Class in io.netty.handler.codec.mqtt
MqttConnAckMessage(MqttFixedHeader, MqttConnAckVariableHeader) - Constructor for class io.netty.handler.codec.mqtt.MqttConnAckMessage
 
MqttConnAckVariableHeader - Class in io.netty.handler.codec.mqtt
Variable header of MqttConnectMessage
MqttConnAckVariableHeader(MqttConnectReturnCode, boolean) - Constructor for class io.netty.handler.codec.mqtt.MqttConnAckVariableHeader
 
MqttConnectMessage - Class in io.netty.handler.codec.mqtt
MqttConnectMessage(MqttFixedHeader, MqttConnectVariableHeader, MqttConnectPayload) - Constructor for class io.netty.handler.codec.mqtt.MqttConnectMessage
 
MqttConnectPayload - Class in io.netty.handler.codec.mqtt
MqttConnectPayload(String, String, String, String, String) - Constructor for class io.netty.handler.codec.mqtt.MqttConnectPayload
MqttConnectPayload(String, String, byte[], String, byte[]) - Constructor for class io.netty.handler.codec.mqtt.MqttConnectPayload
 
MqttConnectReturnCode - Enum in io.netty.handler.codec.mqtt
Return Code of MqttConnAckMessage
MqttConnectVariableHeader - Class in io.netty.handler.codec.mqtt
Variable Header for the MqttConnectMessage
MqttConnectVariableHeader(String, int, boolean, boolean, boolean, int, boolean, boolean, int) - Constructor for class io.netty.handler.codec.mqtt.MqttConnectVariableHeader
 
MqttDecoder - Class in io.netty.handler.codec.mqtt
Decodes Mqtt messages from bytes, following the MQTT protocol specification v3.1
MqttDecoder() - Constructor for class io.netty.handler.codec.mqtt.MqttDecoder
 
MqttDecoder(int) - Constructor for class io.netty.handler.codec.mqtt.MqttDecoder
 
MqttEncoder - Class in io.netty.handler.codec.mqtt
Encodes Mqtt messages into bytes following the protocol specification v3.1 as described here MQTTV3.1
MqttFixedHeader - Class in io.netty.handler.codec.mqtt
MqttFixedHeader(MqttMessageType, boolean, MqttQoS, boolean, int) - Constructor for class io.netty.handler.codec.mqtt.MqttFixedHeader
 
MqttIdentifierRejectedException - Exception in io.netty.handler.codec.mqtt
A MqttIdentifierRejectedException which is thrown when a CONNECT request contains invalid client identifier.
MqttIdentifierRejectedException() - Constructor for exception io.netty.handler.codec.mqtt.MqttIdentifierRejectedException
Creates a new instance
MqttIdentifierRejectedException(String, Throwable) - Constructor for exception io.netty.handler.codec.mqtt.MqttIdentifierRejectedException
Creates a new instance
MqttIdentifierRejectedException(String) - Constructor for exception io.netty.handler.codec.mqtt.MqttIdentifierRejectedException
Creates a new instance
MqttIdentifierRejectedException(Throwable) - Constructor for exception io.netty.handler.codec.mqtt.MqttIdentifierRejectedException
Creates a new instance
MqttMessage - Class in io.netty.handler.codec.mqtt
Base class for all MQTT message types.
MqttMessage(MqttFixedHeader) - Constructor for class io.netty.handler.codec.mqtt.MqttMessage
 
MqttMessage(MqttFixedHeader, Object) - Constructor for class io.netty.handler.codec.mqtt.MqttMessage
 
MqttMessage(MqttFixedHeader, Object, Object) - Constructor for class io.netty.handler.codec.mqtt.MqttMessage
 
MqttMessage(MqttFixedHeader, Object, Object, DecoderResult) - Constructor for class io.netty.handler.codec.mqtt.MqttMessage
 
MqttMessageBuilders - Class in io.netty.handler.codec.mqtt
 
MqttMessageBuilders.ConnAckBuilder - Class in io.netty.handler.codec.mqtt
 
MqttMessageBuilders.ConnectBuilder - Class in io.netty.handler.codec.mqtt
 
MqttMessageBuilders.PublishBuilder - Class in io.netty.handler.codec.mqtt
 
MqttMessageBuilders.SubscribeBuilder - Class in io.netty.handler.codec.mqtt
 
MqttMessageBuilders.UnsubscribeBuilder - Class in io.netty.handler.codec.mqtt
 
MqttMessageFactory - Class in io.netty.handler.codec.mqtt
Utility class with factory methods to create different types of MQTT messages.
MqttMessageIdVariableHeader - Class in io.netty.handler.codec.mqtt
Variable Header containing only Message Id See MQTTV3.1/msg-id
MqttMessageType - Enum in io.netty.handler.codec.mqtt
MQTT Message Types.
MqttPubAckMessage - Class in io.netty.handler.codec.mqtt
MqttPubAckMessage(MqttFixedHeader, MqttMessageIdVariableHeader) - Constructor for class io.netty.handler.codec.mqtt.MqttPubAckMessage
 
MqttPublishMessage - Class in io.netty.handler.codec.mqtt
MqttPublishMessage(MqttFixedHeader, MqttPublishVariableHeader, ByteBuf) - Constructor for class io.netty.handler.codec.mqtt.MqttPublishMessage
 
MqttPublishVariableHeader - Class in io.netty.handler.codec.mqtt
Variable Header of the MqttPublishMessage
MqttPublishVariableHeader(String, int) - Constructor for class io.netty.handler.codec.mqtt.MqttPublishVariableHeader
 
MqttQoS - Enum in io.netty.handler.codec.mqtt
 
MqttSubAckMessage - Class in io.netty.handler.codec.mqtt
MqttSubAckMessage(MqttFixedHeader, MqttMessageIdVariableHeader, MqttSubAckPayload) - Constructor for class io.netty.handler.codec.mqtt.MqttSubAckMessage
 
MqttSubAckPayload - Class in io.netty.handler.codec.mqtt
Payload of the MqttSubAckMessage
MqttSubAckPayload(int...) - Constructor for class io.netty.handler.codec.mqtt.MqttSubAckPayload
 
MqttSubAckPayload(Iterable<Integer>) - Constructor for class io.netty.handler.codec.mqtt.MqttSubAckPayload
 
MqttSubscribeMessage - Class in io.netty.handler.codec.mqtt
MqttSubscribeMessage(MqttFixedHeader, MqttMessageIdVariableHeader, MqttSubscribePayload) - Constructor for class io.netty.handler.codec.mqtt.MqttSubscribeMessage
 
MqttSubscribePayload - Class in io.netty.handler.codec.mqtt
Payload of the MqttSubscribeMessage
MqttSubscribePayload(List<MqttTopicSubscription>) - Constructor for class io.netty.handler.codec.mqtt.MqttSubscribePayload
 
MqttTopicSubscription - Class in io.netty.handler.codec.mqtt
Contains a topic name and Qos Level.
MqttTopicSubscription(String, MqttQoS) - Constructor for class io.netty.handler.codec.mqtt.MqttTopicSubscription
 
MqttUnacceptableProtocolVersionException - Exception in io.netty.handler.codec.mqtt
A MqttUnacceptableProtocolVersionException which is thrown when a CONNECT request contains unacceptable protocol version.
MqttUnacceptableProtocolVersionException() - Constructor for exception io.netty.handler.codec.mqtt.MqttUnacceptableProtocolVersionException
Creates a new instance
MqttUnacceptableProtocolVersionException(String, Throwable) - Constructor for exception io.netty.handler.codec.mqtt.MqttUnacceptableProtocolVersionException
Creates a new instance
MqttUnacceptableProtocolVersionException(String) - Constructor for exception io.netty.handler.codec.mqtt.MqttUnacceptableProtocolVersionException
Creates a new instance
MqttUnacceptableProtocolVersionException(Throwable) - Constructor for exception io.netty.handler.codec.mqtt.MqttUnacceptableProtocolVersionException
Creates a new instance
MqttUnsubAckMessage - Class in io.netty.handler.codec.mqtt
MqttUnsubAckMessage(MqttFixedHeader, MqttMessageIdVariableHeader) - Constructor for class io.netty.handler.codec.mqtt.MqttUnsubAckMessage
 
MqttUnsubscribeMessage - Class in io.netty.handler.codec.mqtt
MqttUnsubscribeMessage(MqttFixedHeader, MqttMessageIdVariableHeader, MqttUnsubscribePayload) - Constructor for class io.netty.handler.codec.mqtt.MqttUnsubscribeMessage
 
MqttUnsubscribePayload - Class in io.netty.handler.codec.mqtt
Payload of the MqttUnsubscribeMessage
MqttUnsubscribePayload(List<String>) - Constructor for class io.netty.handler.codec.mqtt.MqttUnsubscribePayload
 
MqttVersion - Enum in io.netty.handler.codec.mqtt
Mqtt version specific constant values used by multiple classes in mqtt-codec.
msg() - Method in class io.netty.util.internal.PendingWrite
 
MultiDnsServerAddressStreamProvider - Class in io.netty.resolver.dns
A DnsServerAddressStreamProvider which iterates through a collection of DnsServerAddressStreamProvider until the first non-null result is found.
MultiDnsServerAddressStreamProvider(List<DnsServerAddressStreamProvider>) - Constructor for class io.netty.resolver.dns.MultiDnsServerAddressStreamProvider
Create a new instance.
MultiDnsServerAddressStreamProvider(DnsServerAddressStreamProvider...) - Constructor for class io.netty.resolver.dns.MultiDnsServerAddressStreamProvider
Create a new instance.
MultithreadEventExecutorGroup - Class in io.netty.util.concurrent
Abstract base class for EventExecutorGroup implementations that handles their tasks with multiple threads at the same time.
MultithreadEventExecutorGroup(int, ThreadFactory, Object...) - Constructor for class io.netty.util.concurrent.MultithreadEventExecutorGroup
Create a new instance.
MultithreadEventExecutorGroup(int, Executor, Object...) - Constructor for class io.netty.util.concurrent.MultithreadEventExecutorGroup
Create a new instance.
MultithreadEventExecutorGroup(int, Executor, EventExecutorChooserFactory, Object...) - Constructor for class io.netty.util.concurrent.MultithreadEventExecutorGroup
Create a new instance.
MultithreadEventLoopGroup - Class in io.netty.channel
Abstract base class for EventLoopGroup implementations that handles their tasks with multiple threads at the same time.
MultithreadEventLoopGroup(int, Executor, Object...) - Constructor for class io.netty.channel.MultithreadEventLoopGroup
 
MultithreadEventLoopGroup(int, ThreadFactory, Object...) - Constructor for class io.netty.channel.MultithreadEventLoopGroup
 
MultithreadEventLoopGroup(int, Executor, EventExecutorChooserFactory, Object...) - Constructor for class io.netty.channel.MultithreadEventLoopGroup
 
MX - Static variable in class io.netty.handler.codec.dns.DnsRecordType
Mail exchange record RFC 1035 Maps a domain name to a list of message transfer agents for that domain.

N

name() - Method in interface io.netty.channel.ChannelHandlerContext
The unique name of the ChannelHandlerContext.The name was used when then ChannelHandler was added to the ChannelPipeline.
name() - Method in interface io.netty.channel.group.ChannelGroup
Returns the name of this group.
name() - Method in class io.netty.channel.group.DefaultChannelGroup
 
name() - Method in class io.netty.handler.codec.dns.AbstractDnsRecord
 
name() - Method in interface io.netty.handler.codec.dns.DnsRecord
Returns the name of this resource record.
name() - Method in class io.netty.handler.codec.dns.DnsRecordType
Returns the name of this type, as seen in bind config files
name() - Method in class io.netty.handler.codec.mqtt.MqttConnectVariableHeader
 
name() - Method in class io.netty.handler.codec.smtp.SmtpCommand
Return the command name.
name() - Method in class io.netty.handler.traffic.TrafficCounter
 
name() - Method in class io.netty.util.AbstractConstant
 
name() - Method in interface io.netty.util.concurrent.ThreadProperties
 
name() - Method in interface io.netty.util.Constant
Returns the name of this Constant.
name() - Method in class io.netty.util.internal.logging.AbstractInternalLogger
 
name() - Method in interface io.netty.util.internal.logging.InternalLogger
Return the name of this InternalLogger instance.
name() - Method in error io.netty.util.Signal
 
NameResolver<T> - Interface in io.netty.resolver
Resolves an arbitrary string that represents the name of an endpoint into an address.
names() - Method in interface io.netty.channel.ChannelPipeline
Returns the List of the handler names.
names() - Method in class io.netty.channel.DefaultChannelPipeline
 
names() - Method in class io.netty.handler.codec.DefaultHeaders
 
names() - Method in class io.netty.handler.codec.EmptyHeaders
 
names() - Method in interface io.netty.handler.codec.Headers
Returns a Set of all header names in this object.
namesAsString(Headers<CharSequence, CharSequence, ?>) - Static method in class io.netty.handler.codec.HeadersUtils
Headers.names() and convert each element of Set to a String.
nameServerAddressStream(String) - Method in class io.netty.resolver.dns.DefaultDnsServerAddressStreamProvider
 
nameServerAddressStream(String) - Method in interface io.netty.resolver.dns.DnsServerAddressStreamProvider
Ask this provider for the name servers to query for hostname.
nameServerAddressStream(String) - Method in class io.netty.resolver.dns.MultiDnsServerAddressStreamProvider
 
nameServerAddressStream(String) - Method in class io.netty.resolver.dns.UnixResolverDnsServerAddressStreamProvider
 
nameServerProvider(DnsServerAddressStreamProvider) - Method in class io.netty.resolver.dns.DnsNameResolverBuilder
Set the DnsServerAddressStreamProvider which is used to determine which DNS server is used to resolve each hostname.
nanoTime() - Static method in class io.netty.util.concurrent.AbstractScheduledEventExecutor
 
NAPTR - Static variable in class io.netty.handler.codec.dns.DnsRecordType
Naming Authority Pointer record RFC 3403 Allows regular expression based rewriting of domain names which can then be used as URIs, further domain names to lookups, etc.
Native - Class in io.netty.channel.epoll
Native helper methods
NativeInetAddress - Class in io.netty.channel.unix
Internal usage only!
NativeInetAddress(byte[], int) - Constructor for class io.netty.channel.unix.NativeInetAddress
 
NativeInetAddress(byte[]) - Constructor for class io.netty.channel.unix.NativeInetAddress
 
NativeIoException(String, int) - Constructor for exception io.netty.channel.unix.Errors.NativeIoException
 
NativeLibraryLoader - Class in io.netty.util.internal
Helper class to load JNI resources.
ndots(int) - Method in class io.netty.resolver.dns.DnsNameResolverBuilder
Set the number of dots which must appear in a name before an initial absolute query is made.
needsMoreData() - Static method in class io.netty.handler.codec.ProtocolDetectionResult
Returns a ProtocolDetectionResult that signals that more data is needed to detect the protocol.
negativeTtl() - Method in class io.netty.resolver.dns.DefaultDnsCache
Returns the TTL of the cache for the failed DNS queries (in seconds).
negativeTtl(int) - Method in class io.netty.resolver.dns.DnsNameResolverBuilder
Sets the TTL of the cache for the failed DNS queries (in seconds).
NettyRuntime - Class in io.netty.util
A utility class for wrapping calls to Runtime.
NetUtil - Class in io.netty.util
A class that holds a number of network-related constants.
newAddressResolver(EventLoop, NameResolver<InetAddress>) - Method in class io.netty.resolver.dns.DnsAddressResolverGroup
Creates a new AddressResolver.
newAddressResolver(EventLoop, NameResolver<InetAddress>) - Method in class io.netty.resolver.dns.RoundRobinDnsAddressResolverGroup
newChannel() - Method in interface io.netty.bootstrap.ChannelFactory
Deprecated.
Creates a new channel.
newChannel() - Method in interface io.netty.channel.ChannelFactory
Creates a new channel.
newChannel() - Method in class io.netty.channel.ReflectiveChannelFactory
 
newChannelPipeline() - Method in class io.netty.channel.AbstractChannel
Returns a new DefaultChannelPipeline instance.
newChannelPipeline() - Method in class io.netty.channel.embedded.EmbeddedChannel
 
newChild(Executor, Object...) - Method in class io.netty.channel.DefaultEventLoopGroup
 
newChild(Executor, Object...) - Method in class io.netty.channel.epoll.EpollEventLoopGroup
 
newChild(Executor, Object...) - Method in class io.netty.channel.kqueue.KQueueEventLoopGroup
 
newChild(Executor, Object...) - Method in class io.netty.channel.MultithreadEventLoopGroup
 
newChild(Executor, Object...) - Method in class io.netty.channel.nio.NioEventLoopGroup
 
newChild(Object...) - Method in class io.netty.channel.ThreadPerChannelEventLoopGroup
Creates a new EventLoop.
newChild(Executor, Object...) - Method in class io.netty.util.concurrent.DefaultEventExecutorGroup
 
newChild(Executor, Object...) - Method in class io.netty.util.concurrent.MultithreadEventExecutorGroup
Create a new EventExecutor which will later then accessible via the MultithreadEventExecutorGroup.next() method.
newChildChannel(int, byte[], int, int) - Method in class io.netty.channel.epoll.EpollServerDomainSocketChannel
 
newChildChannel(int, byte[], int, int) - Method in class io.netty.channel.epoll.EpollServerSocketChannel
 
newChildChannel(int, byte[], int, int) - Method in class io.netty.channel.kqueue.KQueueServerDomainSocketChannel
 
newChildChannel(int, byte[], int, int) - Method in class io.netty.channel.kqueue.KQueueServerSocketChannel
 
newChooser(EventExecutor[]) - Method in class io.netty.util.concurrent.DefaultEventExecutorChooserFactory
 
newChooser(EventExecutor[]) - Method in interface io.netty.util.concurrent.EventExecutorChooserFactory
newClientContext() - Static method in class io.netty.handler.ssl.SslContext
Deprecated.
Replaced by SslContextBuilder
newClientContext(File) - Static method in class io.netty.handler.ssl.SslContext
Deprecated.
Replaced by SslContextBuilder
newClientContext(TrustManagerFactory) - Static method in class io.netty.handler.ssl.SslContext
Deprecated.
Replaced by SslContextBuilder
newClientContext(File, TrustManagerFactory) - Static method in class io.netty.handler.ssl.SslContext
Deprecated.
Replaced by SslContextBuilder
newClientContext(File, TrustManagerFactory, Iterable<String>, Iterable<String>, long, long) - Static method in class io.netty.handler.ssl.SslContext
Deprecated.
Replaced by SslContextBuilder
newClientContext(File, TrustManagerFactory, Iterable<String>, CipherSuiteFilter, ApplicationProtocolConfig, long, long) - Static method in class io.netty.handler.ssl.SslContext
Deprecated.
Replaced by SslContextBuilder
newClientContext(SslProvider) - Static method in class io.netty.handler.ssl.SslContext
Deprecated.
Replaced by SslContextBuilder
newClientContext(SslProvider, File) - Static method in class io.netty.handler.ssl.SslContext
Deprecated.
Replaced by SslContextBuilder
newClientContext(SslProvider, TrustManagerFactory) - Static method in class io.netty.handler.ssl.SslContext
Deprecated.
Replaced by SslContextBuilder
newClientContext(SslProvider, File, TrustManagerFactory) - Static method in class io.netty.handler.ssl.SslContext
Deprecated.
Replaced by SslContextBuilder
newClientContext(SslProvider, File, TrustManagerFactory, Iterable<String>, Iterable<String>, long, long) - Static method in class io.netty.handler.ssl.SslContext
Deprecated.
Replaced by SslContextBuilder
newClientContext(SslProvider, File, TrustManagerFactory, Iterable<String>, CipherSuiteFilter, ApplicationProtocolConfig, long, long) - Static method in class io.netty.handler.ssl.SslContext
Deprecated.
Replaced by SslContextBuilder
newClientContext(SslProvider, File, TrustManagerFactory, File, File, String, KeyManagerFactory, Iterable<String>, CipherSuiteFilter, ApplicationProtocolConfig, long, long) - Static method in class io.netty.handler.ssl.SslContext
Deprecated.
Replaced by SslContextBuilder
newCloseFuture() - Method in interface io.netty.channel.group.ChannelGroup
Returns the ChannelGroupFuture which will be notified when all Channels that are part of this ChannelGroup, at the time of calling, are closed.
newCloseFuture(ChannelMatcher) - Method in interface io.netty.channel.group.ChannelGroup
Returns the ChannelGroupFuture which will be notified when all Channels that are part of this ChannelGroup, at the time of calling, are closed.
newCloseFuture() - Method in class io.netty.channel.group.DefaultChannelGroup
 
newCloseFuture(ChannelMatcher) - Method in class io.netty.channel.group.DefaultChannelGroup
 
newConcurrentDeque() - Static method in class io.netty.util.internal.PlatformDependent
Returns a new concurrent Deque.
newConcurrentHashMap() - Static method in class io.netty.util.internal.PlatformDependent
Creates a new fastest ConcurrentMap implementation for the current platform.
newConcurrentHashMap(int) - Static method in class io.netty.util.internal.PlatformDependent
Creates a new fastest ConcurrentMap implementation for the current platform.
newConcurrentHashMap(int, float) - Static method in class io.netty.util.internal.PlatformDependent
Creates a new fastest ConcurrentMap implementation for the current platform.
newConcurrentHashMap(int, float, int) - Static method in class io.netty.util.internal.PlatformDependent
Creates a new fastest ConcurrentMap implementation for the current platform.
newConcurrentHashMap(Map<? extends K, ? extends V>) - Static method in class io.netty.util.internal.PlatformDependent
Creates a new fastest ConcurrentMap implementation for the current platform.
newConnectionResetException(String, int) - Static method in class io.netty.channel.unix.Errors
 
newConstant(int, String) - Method in class io.netty.util.ConstantPool
 
newContinueResponse(H, int, ChannelPipeline) - Method in class io.netty.handler.codec.memcache.AbstractMemcacheObjectAggregator
 
newContinueResponse(S, int, ChannelPipeline) - Method in class io.netty.handler.codec.MessageAggregator
Returns the 'continue response' for the specified start message if necessary.
newContinueResponse(BulkStringHeaderRedisMessage, int, ChannelPipeline) - Method in class io.netty.handler.codec.redis.RedisBulkStringAggregator
 
newContinueResponse(StompHeadersSubframe, int, ChannelPipeline) - Method in class io.netty.handler.codec.stomp.StompSubframeAggregator
 
newDefaultThreadFactory() - Method in class io.netty.channel.MultithreadEventLoopGroup
 
newDefaultThreadFactory() - Method in class io.netty.util.concurrent.MultithreadEventExecutorGroup
 
newDirectBuffer(int, int) - Method in class io.netty.buffer.AbstractByteBufAllocator
Create a direct ByteBuf with the given initialCapacity and maxCapacity.
newDirectBuffer(int, int) - Method in class io.netty.buffer.PooledByteBufAllocator
 
newDirectBuffer(int, int) - Method in class io.netty.buffer.UnpooledByteBufAllocator
 
newDirectBuffer(ByteBuf) - Method in class io.netty.channel.nio.AbstractNioChannel
Returns an off-heap copy of the specified ByteBuf, and releases the original one.
newDirectBuffer(ReferenceCounted, ByteBuf) - Method in class io.netty.channel.nio.AbstractNioChannel
Returns an off-heap copy of the specified ByteBuf, and releases the specified holder.
newDnsQueryLifecycleObserver(DnsQuestion) - Method in class io.netty.resolver.dns.BiDnsQueryLifecycleObserverFactory
 
newDnsQueryLifecycleObserver(DnsQuestion) - Method in interface io.netty.resolver.dns.DnsQueryLifecycleObserverFactory
Create a new instance of a DnsQueryLifecycleObserver.
newDnsQueryLifecycleObserver(DnsQuestion) - Method in class io.netty.resolver.dns.NoopDnsQueryLifecycleObserverFactory
 
newEngine(ByteBufAllocator) - Method in class io.netty.handler.ssl.DelegatingSslContext
 
newEngine(ByteBufAllocator, String, int) - Method in class io.netty.handler.ssl.DelegatingSslContext
 
newEngine(ByteBufAllocator) - Method in class io.netty.handler.ssl.JdkSslContext
 
newEngine(ByteBufAllocator, String, int) - Method in class io.netty.handler.ssl.JdkSslContext
 
newEngine(ByteBufAllocator) - Method in class io.netty.handler.ssl.SslContext
Creates a new SSLEngine.
newEngine(ByteBufAllocator, String, int) - Method in class io.netty.handler.ssl.SslContext
Creates a new SSLEngine using advisory peer information.
newEpollCreate() - Static method in class io.netty.channel.epoll.Native
 
newEventFd() - Static method in class io.netty.channel.epoll.Native
 
newFailedFuture(Throwable) - Method in class io.netty.channel.AbstractChannel
 
newFailedFuture(Throwable) - Method in interface io.netty.channel.ChannelOutboundInvoker
Create a new ChannelFuture which is marked as failed already.
newFailedFuture(Throwable) - Method in class io.netty.channel.DefaultChannelPipeline
 
newFailedFuture(Throwable) - Method in class io.netty.util.concurrent.AbstractEventExecutor
 
newFailedFuture(Throwable) - Method in interface io.netty.util.concurrent.EventExecutor
Create a new Future which is marked as failed already.
newFailedFuture(Throwable) - Method in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor
 
newFixedMpscQueue(int) - Static method in class io.netty.util.internal.PlatformDependent
Create a new Queue which is safe to use for multiple producers (different threads) and a single consumer (one thread!) with the given fixes capacity.
newHandle() - Method in class io.netty.channel.AdaptiveRecvByteBufAllocator
 
newHandle() - Method in class io.netty.channel.DefaultMaxBytesRecvByteBufAllocator
 
newHandle() - Method in class io.netty.channel.DefaultMessageSizeEstimator
 
newHandle() - Method in class io.netty.channel.FixedRecvByteBufAllocator
 
newHandle() - Method in interface io.netty.channel.MessageSizeEstimator
Creates a new handle.
newHandle() - Method in interface io.netty.channel.RecvByteBufAllocator
Creates a new handle.
newHandler(ByteBufAllocator) - Method in class io.netty.handler.ssl.SslContext
Creates a new SslHandler.
newHandler(ByteBufAllocator, String, int) - Method in class io.netty.handler.ssl.SslContext
Creates a new SslHandler with advisory peer information.
newHeaderEntry(int, K, V, DefaultHeaders.HeaderEntry<K, V>) - Method in class io.netty.handler.codec.DefaultHeaders
 
newHeapBuffer(int, int) - Method in class io.netty.buffer.AbstractByteBufAllocator
Create a heap ByteBuf with the given initialCapacity and maxCapacity.
newHeapBuffer(int, int) - Method in class io.netty.buffer.PooledByteBufAllocator
 
newHeapBuffer(int, int) - Method in class io.netty.buffer.UnpooledByteBufAllocator
 
newId() - Method in class io.netty.channel.AbstractChannel
Returns a new DefaultChannelId instance.
newIdleStateEvent(IdleState, boolean) - Method in class io.netty.handler.timeout.IdleStateHandler
Returns a IdleStateEvent.
newInstance(String) - Static method in class io.netty.channel.ChannelOption
Creates a new ChannelOption for the given name or fail with an IllegalArgumentException if a ChannelOption for the given name exists.
newInstance() - Static method in class io.netty.channel.DefaultChannelId
Returns a new DefaultChannelId instance.
newInstance(InetAddress) - Static method in class io.netty.channel.unix.NativeInetAddress
 
newInstance(String) - Static method in class io.netty.util.AttributeKey
Creates a new AttributeKey for the given name or fail with an IllegalArgumentException if a AttributeKey for the given name exists.
newInstance(String) - Method in class io.netty.util.ConstantPool
Creates a new Constant for the given name or fail with an IllegalArgumentException if a Constant for the given name exists.
newInstance(String) - Method in class io.netty.util.internal.logging.CommonsLoggerFactory
Deprecated.
 
newInstance(String) - Method in class io.netty.util.internal.logging.InternalLoggerFactory
Creates a new logger instance with the specified name.
newInstance(String) - Method in class io.netty.util.internal.logging.JdkLoggerFactory
 
newInstance(String) - Method in class io.netty.util.internal.logging.Log4J2LoggerFactory
 
newInstance(String) - Method in class io.netty.util.internal.logging.Log4JLoggerFactory
 
newInstance(String) - Method in class io.netty.util.internal.logging.Slf4JLoggerFactory
 
newInstance(Object, Promise<Void>) - Static method in class io.netty.util.internal.PendingWrite
Create a new empty RecyclableArrayList instance
newInstance() - Static method in class io.netty.util.internal.RecyclableArrayList
Create a new empty RecyclableArrayList instance
newInstance(int) - Static method in class io.netty.util.internal.RecyclableArrayList
Create a new empty RecyclableArrayList instance with the given capacity.
newInvalidMessage(Throwable) - Static method in class io.netty.handler.codec.mqtt.MqttMessageFactory
 
newIOException(String, int) - Static method in class io.netty.channel.unix.Errors
 
NEWLINE - Static variable in class io.netty.util.internal.StringUtil
 
newListener(SSLEngine, List<String>) - Method in interface io.netty.handler.ssl.JdkApplicationProtocolNegotiator.ProtocolSelectionListenerFactory
newLocalChannel(LocalChannel) - Method in class io.netty.channel.local.LocalServerChannel
A factory method for LocalChannels.
newLongCounter() - Static method in class io.netty.util.internal.PlatformDependent
Creates a new fastest LongCounter implementation for the current platform.
newMessage(MqttFixedHeader, Object, Object) - Static method in class io.netty.handler.codec.mqtt.MqttMessageFactory
 
newMpscQueue() - Static method in class io.netty.util.internal.PlatformDependent
Create a new Queue which is safe to use for multiple producers (different threads) and a single consumer (one thread!).
newMpscQueue(int) - Static method in class io.netty.util.internal.PlatformDependent
Create a new Queue which is safe to use for multiple producers (different threads) and a single consumer (one thread!).
newNameResolver(EventLoop, ChannelFactory<? extends DatagramChannel>, DnsServerAddressStreamProvider) - Method in class io.netty.resolver.dns.DnsAddressResolverGroup
Creates a new NameResolver.
newNonSslHandler(ChannelHandlerContext) - Method in class io.netty.handler.ssl.OptionalSslHandler
Override to configure the ChannelHandler.
newNonSslHandlerName() - Method in class io.netty.handler.ssl.OptionalSslHandler
Optionally specify the non-SSL handler name, this method may return null.
newObject(Recycler.Handle<T>) - Method in class io.netty.util.Recycler
 
newObjectOutputStream(OutputStream) - Method in class io.netty.handler.codec.serialization.CompatibleObjectEncoder
Creates a new ObjectOutputStream which wraps the specified OutputStream.
newPool(K) - Method in class io.netty.channel.pool.AbstractChannelPoolMap
Called once a new ChannelPool needs to be created as non exists yet for the key.
newProgressivePromise() - Method in class io.netty.channel.AbstractChannel
 
newProgressivePromise() - Method in interface io.netty.channel.ChannelOutboundInvoker
newProgressivePromise() - Method in class io.netty.channel.DefaultChannelPipeline
 
newProgressivePromise() - Method in class io.netty.util.concurrent.AbstractEventExecutor
 
newProgressivePromise() - Method in interface io.netty.util.concurrent.EventExecutor
Create a new ProgressivePromise.
newProgressivePromise() - Method in class io.netty.util.concurrent.ImmediateEventExecutor
 
newProgressivePromise() - Method in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor
 
newPromise() - Method in class io.netty.channel.AbstractChannel
 
newPromise() - Method in interface io.netty.channel.ChannelOutboundInvoker
Return a new ChannelPromise.
newPromise() - Method in class io.netty.channel.DefaultChannelPipeline
 
newPromise() - Method in class io.netty.util.concurrent.AbstractEventExecutor
 
newPromise() - Method in interface io.netty.util.concurrent.EventExecutor
Return a new Promise.
newPromise() - Method in class io.netty.util.concurrent.ImmediateEventExecutor
 
newPromise() - Method in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor
 
newResolver(EventExecutor) - Method in class io.netty.resolver.AddressResolverGroup
newResolver(EventExecutor) - Method in class io.netty.resolver.DefaultAddressResolverGroup
 
newResolver(EventExecutor) - Method in class io.netty.resolver.dns.DnsAddressResolverGroup
 
newResolver(EventLoop, ChannelFactory<? extends DatagramChannel>, DnsServerAddressStreamProvider) - Method in class io.netty.resolver.dns.DnsAddressResolverGroup
newResolver(EventExecutor) - Method in class io.netty.resolver.NoopAddressResolverGroup
 
newResourceLeakDetector(Class<T>) - Method in class io.netty.util.ResourceLeakDetectorFactory
Returns a new instance of a ResourceLeakDetector with the given resource class.
newResourceLeakDetector(Class<T>, int, long) - Method in class io.netty.util.ResourceLeakDetectorFactory
Deprecated.
Use ResourceLeakDetectorFactory.newResourceLeakDetector(Class, int) instead.

Returns a new instance of a ResourceLeakDetector with the given resource class.

newResourceLeakDetector(Class<T>, int) - Method in class io.netty.util.ResourceLeakDetectorFactory
Returns a new instance of a ResourceLeakDetector with the given resource class.
newSelector(SSLEngine, Set<String>) - Method in interface io.netty.handler.ssl.JdkApplicationProtocolNegotiator.ProtocolSelectorFactory
newSelectStrategy() - Method in class io.netty.channel.DefaultSelectStrategyFactory
 
newSelectStrategy() - Method in interface io.netty.channel.SelectStrategyFactory
Creates a new SelectStrategy.
newServerContext(File, File) - Static method in class io.netty.handler.ssl.SslContext
Deprecated.
Replaced by SslContextBuilder
newServerContext(File, File, String) - Static method in class io.netty.handler.ssl.SslContext
Deprecated.
Replaced by SslContextBuilder
newServerContext(File, File, String, Iterable<String>, Iterable<String>, long, long) - Static method in class io.netty.handler.ssl.SslContext
Deprecated.
Replaced by SslContextBuilder
newServerContext(File, File, String, Iterable<String>, CipherSuiteFilter, ApplicationProtocolConfig, long, long) - Static method in class io.netty.handler.ssl.SslContext
Deprecated.
Replaced by SslContextBuilder
newServerContext(SslProvider, File, File) - Static method in class io.netty.handler.ssl.SslContext
Deprecated.
Replaced by SslContextBuilder
newServerContext(SslProvider, File, File, String) - Static method in class io.netty.handler.ssl.SslContext
Deprecated.
Replaced by SslContextBuilder
newServerContext(SslProvider, File, File, String, Iterable<String>, Iterable<String>, long, long) - Static method in class io.netty.handler.ssl.SslContext
Deprecated.
Replaced by SslContextBuilder
newServerContext(SslProvider, File, File, String, TrustManagerFactory, Iterable<String>, Iterable<String>, long, long) - Static method in class io.netty.handler.ssl.SslContext
Deprecated.
Replaced by SslContextBuilder
newServerContext(SslProvider, File, File, String, Iterable<String>, CipherSuiteFilter, ApplicationProtocolConfig, long, long) - Static method in class io.netty.handler.ssl.SslContext
Deprecated.
Replaced by SslContextBuilder
newServerContext(SslProvider, File, TrustManagerFactory, File, File, String, KeyManagerFactory, Iterable<String>, CipherSuiteFilter, ApplicationProtocolConfig, long, long) - Static method in class io.netty.handler.ssl.SslContext
Deprecated.
Replaced by SslContextBuilder
newSocket() - Method in class io.netty.channel.unix.tests.SocketTest
 
newSocketAddress() - Static method in class io.netty.channel.unix.tests.UnixTestUtils
 
newSocketDgram() - Static method in class io.netty.channel.unix.Socket
 
newSocketDgram0() - Static method in class io.netty.channel.unix.Socket
 
newSocketDomain() - Static method in class io.netty.channel.unix.Socket
 
newSocketDomain0() - Static method in class io.netty.channel.unix.Socket
 
newSocketStream() - Static method in class io.netty.channel.unix.Socket
 
newSocketStream0() - Static method in class io.netty.channel.unix.Socket
 
newSpscQueue() - Static method in class io.netty.util.internal.PlatformDependent
Create a new Queue which is safe to use for single producer (one thread!) and a single consumer (one thread!).
newSslHandler(ChannelHandlerContext, SslContext) - Method in class io.netty.handler.ssl.OptionalSslHandler
Override to configure the SslHandler eg.
newSslHandlerName() - Method in class io.netty.handler.ssl.OptionalSslHandler
Optionally specify the SSL handler name, this method may return null.
newSucceededFuture() - Method in class io.netty.channel.AbstractChannel
 
newSucceededFuture() - Method in interface io.netty.channel.ChannelOutboundInvoker
Create a new ChannelFuture which is marked as succeeded already.
newSucceededFuture() - Method in class io.netty.channel.DefaultChannelPipeline
 
newSucceededFuture(V) - Method in class io.netty.util.concurrent.AbstractEventExecutor
 
newSucceededFuture(V) - Method in interface io.netty.util.concurrent.EventExecutor
Create a new Future which is marked as succeeded already.
newSucceededFuture(V) - Method in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor
 
newSwappedByteBuf() - Method in class io.netty.buffer.AbstractByteBuf
Creates a new SwappedByteBuf for this ByteBuf instance.
newSwappedByteBuf() - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
newTaskFor(Runnable, T) - Method in class io.netty.util.concurrent.AbstractEventExecutor
 
newTaskFor(Callable<T>) - Method in class io.netty.util.concurrent.AbstractEventExecutor
 
newTaskQueue(int) - Method in class io.netty.channel.nio.NioEventLoop
 
newTaskQueue() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
Deprecated.
newTaskQueue(int) - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
Create a new Queue which will holds the tasks to execute.
newThread(Runnable) - Method in class io.netty.util.concurrent.DefaultThreadFactory
 
newThread(Runnable, String) - Method in class io.netty.util.concurrent.DefaultThreadFactory
 
newTimeout(TimerTask, long, TimeUnit) - Method in class io.netty.util.HashedWheelTimer
 
newTimeout(TimerTask, long, TimeUnit) - Method in interface io.netty.util.Timer
Schedules the specified TimerTask for one-time execution after the specified delay.
newUnsafe() - Method in class io.netty.channel.AbstractChannel
Create a new AbstractChannel.AbstractUnsafe instance which will be used for the life-time of the Channel
newUnsafe() - Method in class io.netty.channel.AbstractServerChannel
 
newUnsafe() - Method in class io.netty.channel.embedded.EmbeddedChannel
 
newUnsafe() - Method in class io.netty.channel.epoll.AbstractEpollServerChannel
 
newUnsafe() - Method in class io.netty.channel.epoll.AbstractEpollStreamChannel
 
newUnsafe() - Method in class io.netty.channel.epoll.EpollDatagramChannel
 
newUnsafe() - Method in class io.netty.channel.epoll.EpollDomainSocketChannel
 
newUnsafe() - Method in class io.netty.channel.epoll.EpollSocketChannel
 
newUnsafe() - Method in class io.netty.channel.kqueue.AbstractKQueueServerChannel
 
newUnsafe() - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel
 
newUnsafe() - Method in class io.netty.channel.kqueue.KQueueDatagramChannel
 
newUnsafe() - Method in class io.netty.channel.kqueue.KQueueDomainSocketChannel
 
newUnsafe() - Method in class io.netty.channel.kqueue.KQueueSocketChannel
 
newUnsafe() - Method in class io.netty.channel.local.LocalChannel
 
newUnsafe() - Method in class io.netty.channel.nio.AbstractNioByteChannel
 
newUnsafe() - Method in class io.netty.channel.nio.AbstractNioMessageChannel
 
newUnsafe() - Method in class io.netty.channel.oio.AbstractOioChannel
 
newUnsafe() - Method in class io.netty.channel.socket.nio.NioSocketChannel
 
newZlibDecoder() - Static method in class io.netty.handler.codec.compression.ZlibCodecFactory
 
newZlibDecoder(ZlibWrapper) - Static method in class io.netty.handler.codec.compression.ZlibCodecFactory
 
newZlibDecoder(byte[]) - Static method in class io.netty.handler.codec.compression.ZlibCodecFactory
 
newZlibEncoder(int) - Static method in class io.netty.handler.codec.compression.ZlibCodecFactory
 
newZlibEncoder(ZlibWrapper) - Static method in class io.netty.handler.codec.compression.ZlibCodecFactory
 
newZlibEncoder(ZlibWrapper, int) - Static method in class io.netty.handler.codec.compression.ZlibCodecFactory
 
newZlibEncoder(ZlibWrapper, int, int, int) - Static method in class io.netty.handler.codec.compression.ZlibCodecFactory
 
newZlibEncoder(byte[]) - Static method in class io.netty.handler.codec.compression.ZlibCodecFactory
 
newZlibEncoder(int, byte[]) - Static method in class io.netty.handler.codec.compression.ZlibCodecFactory
 
newZlibEncoder(int, int, int, byte[]) - Static method in class io.netty.handler.codec.compression.ZlibCodecFactory
 
next() - Method in class io.netty.channel.AbstractEventLoop
 
next() - Method in class io.netty.channel.AbstractEventLoopGroup
 
next() - Method in interface io.netty.channel.EventLoopGroup
Return the next EventLoop to use
next() - Method in class io.netty.channel.MultithreadEventLoopGroup
 
next() - Method in class io.netty.channel.SingleThreadEventLoop
 
next() - Method in class io.netty.channel.ThreadPerChannelEventLoopGroup
 
next - Variable in class io.netty.handler.codec.DefaultHeaders.HeaderEntry
In bucket linked list
next() - Method in interface io.netty.resolver.dns.DnsServerAddressStream
Retrieves the next DNS server address from the stream.
next() - Method in class io.netty.util.concurrent.AbstractEventExecutor
 
next() - Method in interface io.netty.util.concurrent.EventExecutor
Returns a reference to itself.
next() - Method in interface io.netty.util.concurrent.EventExecutorChooserFactory.EventExecutorChooser
Returns the new EventExecutor to use.
next() - Method in interface io.netty.util.concurrent.EventExecutorGroup
Returns one of the EventExecutors managed by this EventExecutorGroup.
next() - Method in class io.netty.util.concurrent.MultithreadEventExecutorGroup
 
next() - Method in class io.netty.util.concurrent.NonStickyEventExecutorGroup
 
next() - Method in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor
 
next() - Method in class io.netty.util.internal.ReadOnlyIterator
 
next(int) - Method in class io.netty.util.internal.ThreadLocalRandom
 
nextDouble(double) - Method in class io.netty.util.internal.ThreadLocalRandom
Returns a pseudorandom, uniformly distributed double value between 0 (inclusive) and the specified value (exclusive).
nextDouble(double, double) - Method in class io.netty.util.internal.ThreadLocalRandom
Returns a pseudorandom, uniformly distributed value between the given least value (inclusive) and bound (exclusive).
nextId() - Method in class io.netty.util.ConstantPool
Deprecated.
nextInt(int, int) - Method in class io.netty.util.internal.ThreadLocalRandom
Returns a pseudorandom, uniformly distributed value between the given least value (inclusive) and bound (exclusive).
nextLong(long) - Method in class io.netty.util.internal.ThreadLocalRandom
Returns a pseudorandom, uniformly distributed value between 0 (inclusive) and the specified value (exclusive).
nextLong(long, long) - Method in class io.netty.util.internal.ThreadLocalRandom
Returns a pseudorandom, uniformly distributed value between the given least value (inclusive) and bound (exclusive).
nextProtocols() - Method in class io.netty.handler.ssl.SslContext
nextScheduledTaskNano() - Method in class io.netty.util.concurrent.AbstractScheduledEventExecutor
Return the nanoseconds when the next scheduled task is ready to be run or -1 if no task is scheduled.
nextVariableIndex() - Static method in class io.netty.util.internal.InternalThreadLocalMap
 
nioBuffer() - Method in class io.netty.buffer.AbstractByteBuf
 
nioBuffer(int, int) - Method in class io.netty.buffer.AbstractDerivedByteBuf
Deprecated.
 
nioBuffer() - Method in class io.netty.buffer.ByteBuf
Exposes this buffer's readable bytes as an NIO ByteBuffer.
nioBuffer(int, int) - Method in class io.netty.buffer.ByteBuf
Exposes this buffer's sub-region as an NIO ByteBuffer.
nioBuffer(int, int) - Method in class io.netty.buffer.CompositeByteBuf
 
nioBuffer() - Method in class io.netty.buffer.EmptyByteBuf
 
nioBuffer(int, int) - Method in class io.netty.buffer.EmptyByteBuf
 
nioBuffer(int, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
nioBuffer() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
nioBuffer(int, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
nioBuffer(int, int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
nioBuffer(int, int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
nioBuffer(int, int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
nioBufferCount() - Method in class io.netty.buffer.ByteBuf
Returns the maximum number of NIO ByteBuffers that consist this buffer.
nioBufferCount() - Method in class io.netty.buffer.CompositeByteBuf
 
nioBufferCount() - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
nioBufferCount() - Method in class io.netty.buffer.EmptyByteBuf
 
nioBufferCount() - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
nioBufferCount() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
nioBufferCount() - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
nioBufferCount() - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
nioBufferCount() - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
nioBufferCount() - Method in class io.netty.channel.ChannelOutboundBuffer
Returns the number of ByteBuffer that can be written out of the ByteBuffer array that was obtained via ChannelOutboundBuffer.nioBuffers().
nioBuffers() - Method in class io.netty.buffer.AbstractByteBuf
 
nioBuffers() - Method in class io.netty.buffer.ByteBuf
Exposes this buffer's readable bytes as an NIO ByteBuffer's.
nioBuffers(int, int) - Method in class io.netty.buffer.ByteBuf
Exposes this buffer's bytes as an NIO ByteBuffer's for the specified index and length The returned buffer shares the content with this buffer, while changing the position and limit of the returned NIO buffer does not affect the indexes and marks of this buffer.
nioBuffers(int, int) - Method in class io.netty.buffer.CompositeByteBuf
 
nioBuffers() - Method in class io.netty.buffer.CompositeByteBuf
 
nioBuffers(int, int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
nioBuffers() - Method in class io.netty.buffer.EmptyByteBuf
 
nioBuffers(int, int) - Method in class io.netty.buffer.EmptyByteBuf
 
nioBuffers(int, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
nioBuffers() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
nioBuffers(int, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
nioBuffers(int, int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
nioBuffers(int, int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
nioBuffers(int, int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
nioBuffers() - Method in class io.netty.channel.ChannelOutboundBuffer
Returns an array of direct NIO buffers if the currently pending messages are made of ByteBuf only.
nioBufferSize() - Method in class io.netty.channel.ChannelOutboundBuffer
Returns the number of bytes that can be written out of the ByteBuffer array that was obtained via ChannelOutboundBuffer.nioBuffers().
NioByteUnsafe() - Constructor for class io.netty.channel.nio.AbstractNioByteChannel.NioByteUnsafe
 
NioDatagramChannel - Class in io.netty.channel.socket.nio
An NIO datagram Channel that sends and receives an AddressedEnvelope.
NioDatagramChannel() - Constructor for class io.netty.channel.socket.nio.NioDatagramChannel
Create a new instance which will use the Operation Systems default InternetProtocolFamily.
NioDatagramChannel(SelectorProvider) - Constructor for class io.netty.channel.socket.nio.NioDatagramChannel
Create a new instance using the given SelectorProvider which will use the Operation Systems default InternetProtocolFamily.
NioDatagramChannel(InternetProtocolFamily) - Constructor for class io.netty.channel.socket.nio.NioDatagramChannel
Create a new instance using the given InternetProtocolFamily.
NioDatagramChannel(SelectorProvider, InternetProtocolFamily) - Constructor for class io.netty.channel.socket.nio.NioDatagramChannel
Create a new instance using the given SelectorProvider and InternetProtocolFamily.
NioDatagramChannel(DatagramChannel) - Constructor for class io.netty.channel.socket.nio.NioDatagramChannel
Create a new instance from the given DatagramChannel.
NioEventLoop - Class in io.netty.channel.nio
SingleThreadEventLoop implementation which register the Channel's to a Selector and so does the multi-plexing of these in the event loop.
NioEventLoopGroup - Class in io.netty.channel.nio
MultithreadEventLoopGroup implementations which is used for NIO Selector based Channels.
NioEventLoopGroup() - Constructor for class io.netty.channel.nio.NioEventLoopGroup
Create a new instance using the default number of threads, the default ThreadFactory and the SelectorProvider which is returned by SelectorProvider.provider().
NioEventLoopGroup(int) - Constructor for class io.netty.channel.nio.NioEventLoopGroup
Create a new instance using the specified number of threads, ThreadFactory and the SelectorProvider which is returned by SelectorProvider.provider().
NioEventLoopGroup(int, ThreadFactory) - Constructor for class io.netty.channel.nio.NioEventLoopGroup
Create a new instance using the specified number of threads, the given ThreadFactory and the SelectorProvider which is returned by SelectorProvider.provider().
NioEventLoopGroup(int, Executor) - Constructor for class io.netty.channel.nio.NioEventLoopGroup
 
NioEventLoopGroup(int, ThreadFactory, SelectorProvider) - Constructor for class io.netty.channel.nio.NioEventLoopGroup
Create a new instance using the specified number of threads, the given ThreadFactory and the given SelectorProvider.
NioEventLoopGroup(int, ThreadFactory, SelectorProvider, SelectStrategyFactory) - Constructor for class io.netty.channel.nio.NioEventLoopGroup
 
NioEventLoopGroup(int, Executor, SelectorProvider) - Constructor for class io.netty.channel.nio.NioEventLoopGroup
 
NioEventLoopGroup(int, Executor, SelectorProvider, SelectStrategyFactory) - Constructor for class io.netty.channel.nio.NioEventLoopGroup
 
NioEventLoopGroup(int, Executor, EventExecutorChooserFactory, SelectorProvider, SelectStrategyFactory) - Constructor for class io.netty.channel.nio.NioEventLoopGroup
 
NioEventLoopGroup(int, Executor, EventExecutorChooserFactory, SelectorProvider, SelectStrategyFactory, RejectedExecutionHandler) - Constructor for class io.netty.channel.nio.NioEventLoopGroup
 
NioServerSocketChannel - Class in io.netty.channel.socket.nio
A ServerSocketChannel implementation which uses NIO selector based implementation to accept new connections.
NioServerSocketChannel() - Constructor for class io.netty.channel.socket.nio.NioServerSocketChannel
Create a new instance
NioServerSocketChannel(SelectorProvider) - Constructor for class io.netty.channel.socket.nio.NioServerSocketChannel
Create a new instance using the given SelectorProvider.
NioServerSocketChannel(ServerSocketChannel) - Constructor for class io.netty.channel.socket.nio.NioServerSocketChannel
Create a new instance using the given ServerSocketChannel.
NioSocketChannel - Class in io.netty.channel.socket.nio
SocketChannel which uses NIO selector based implementation.
NioSocketChannel() - Constructor for class io.netty.channel.socket.nio.NioSocketChannel
Create a new instance
NioSocketChannel(SelectorProvider) - Constructor for class io.netty.channel.socket.nio.NioSocketChannel
Create a new instance using the given SelectorProvider.
NioSocketChannel(SocketChannel) - Constructor for class io.netty.channel.socket.nio.NioSocketChannel
Create a new instance using the given SocketChannel.
NioSocketChannel(Channel, SocketChannel) - Constructor for class io.netty.channel.socket.nio.NioSocketChannel
Create a new instance
NioTask<C extends SelectableChannel> - Interface in io.netty.channel.nio
An arbitrary task that can be executed by NioEventLoop when a SelectableChannel becomes ready.
NOERROR - Static variable in class io.netty.handler.codec.dns.DnsResponseCode
The 'NoError' DNS RCODE (0), as defined in RFC1035.
NonStickyEventExecutorGroup - Class in io.netty.util.concurrent
EventExecutorGroup which will preserve Runnable execution order but makes no guarantees about what EventExecutor (and therefore Thread) will be used to execute the Runnables.
NonStickyEventExecutorGroup(EventExecutorGroup) - Constructor for class io.netty.util.concurrent.NonStickyEventExecutorGroup
Creates a new instance.
NonStickyEventExecutorGroup(EventExecutorGroup, int) - Constructor for class io.netty.util.concurrent.NonStickyEventExecutorGroup
Creates a new instance.
NOOP - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
NOOP - Static variable in class io.netty.handler.codec.smtp.SmtpCommand
 
noop() - Static method in class io.netty.handler.codec.smtp.SmtpRequests
Creates a NOOP request.
NoopAddressResolver - Class in io.netty.resolver
A AddressResolver that does not perform any resolution but always reports successful resolution.
NoopAddressResolver(EventExecutor) - Constructor for class io.netty.resolver.NoopAddressResolver
 
NoopAddressResolverGroup - Class in io.netty.resolver
NoopDnsCache - Class in io.netty.resolver.dns
A noop DNS cache that actually never caches anything.
NoopDnsQueryLifecycleObserverFactory - Class in io.netty.resolver.dns
 
NoOpTypeParameterMatcher - Class in io.netty.util.internal
 
NoOpTypeParameterMatcher() - Constructor for class io.netty.util.internal.NoOpTypeParameterMatcher
 
normalCacheSize() - Method in class io.netty.buffer.PooledByteBufAllocator
normalCacheSize() - Method in class io.netty.buffer.PooledByteBufAllocatorMetric
Return the size of the normal cache.
NOT_NULL - Static variable in interface io.netty.handler.codec.DefaultHeaders.NameValidator
 
NOT_STORED - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseStatus
 
NOTAUTH - Static variable in class io.netty.handler.codec.dns.DnsResponseCode
The 'NotAuth' DNS RCODE (9), as defined in RFC2136.
NOTIFY - Static variable in class io.netty.handler.codec.dns.DnsOpCode
The 'Notify' DNS OpCode, as defined in RFC1996.
notifyFlushFutures() - Method in class io.netty.channel.ChannelFlushPromiseNotifier
notifyFlushFutures(Throwable) - Method in class io.netty.channel.ChannelFlushPromiseNotifier
notifyFlushFutures(Throwable, Throwable) - Method in class io.netty.channel.ChannelFlushPromiseNotifier
notifyListener(EventExecutor, Future<?>, GenericFutureListener<?>) - Static method in class io.netty.util.concurrent.DefaultPromise
Notify a listener that a future has completed.
notifyPromises() - Method in class io.netty.channel.ChannelFlushPromiseNotifier
Notify all ChannelFutures that were registered with ChannelFlushPromiseNotifier.add(ChannelPromise, int) and their pendingDatasize is smaller after the the current writeCounter returned by ChannelFlushPromiseNotifier.writeCounter().
notifyPromises(Throwable) - Method in class io.netty.channel.ChannelFlushPromiseNotifier
Notify all ChannelFutures that were registered with ChannelFlushPromiseNotifier.add(ChannelPromise, int) and their pendingDatasize isis smaller then the current writeCounter returned by ChannelFlushPromiseNotifier.writeCounter().
notifyPromises(Throwable, Throwable) - Method in class io.netty.channel.ChannelFlushPromiseNotifier
Notify all ChannelFutures that were registered with ChannelFlushPromiseNotifier.add(ChannelPromise, int) and their pendingDatasize is smaller then the current writeCounter returned by ChannelFlushPromiseNotifier.writeCounter() using the given cause1.
NOTIMP - Static variable in class io.netty.handler.codec.dns.DnsResponseCode
The 'NotImp' DNS RCODE (4), as defined in RFC1035.
NotSslRecordException - Exception in io.netty.handler.ssl
Special SSLException which will get thrown if a packet is received that not looks like a TLS/SSL record.
NotSslRecordException() - Constructor for exception io.netty.handler.ssl.NotSslRecordException
 
NotSslRecordException(String) - Constructor for exception io.netty.handler.ssl.NotSslRecordException
 
NotSslRecordException(Throwable) - Constructor for exception io.netty.handler.ssl.NotSslRecordException
 
NotSslRecordException(String, Throwable) - Constructor for exception io.netty.handler.ssl.NotSslRecordException
 
NOTZONE - Static variable in class io.netty.handler.codec.dns.DnsResponseCode
The 'NotZone' DNS RCODE (10), as defined in RFC2136.
NS - Static variable in class io.netty.handler.codec.dns.DnsRecordType
Name server record RFC 1035 Delegates a DNS zone to use the given authoritative name servers
NSEC - Static variable in class io.netty.handler.codec.dns.DnsRecordType
Next-Secure record RFC 4034 Part of DNSSEC, used to prove a name does not exist.
NSEC3 - Static variable in class io.netty.handler.codec.dns.DnsRecordType
NSEC record version 3 RFC 5155 An extension to DNSSEC that allows proof of nonexistence for a name without permitting zonewalking.
NSEC3PARAM - Static variable in class io.netty.handler.codec.dns.DnsRecordType
NSEC3 parameters record RFC 5155 Parameter record for use with NSEC3.
nulDelimiter() - Static method in class io.netty.handler.codec.Delimiters
Returns a NUL (0x00) delimiter, which could be used for Flash XML socket or any similar protocols.
NULL_INSTANCE - Static variable in class io.netty.handler.codec.redis.ArrayRedisMessage
A predefined null array instance for ArrayRedisMessage.
NULL_INSTANCE - Static variable in class io.netty.handler.codec.redis.FullBulkStringRedisMessage
A predefined null instance of FullBulkStringRedisMessage.
numActiveAllocations() - Method in interface io.netty.buffer.PoolArenaMetric
Return the number of currently active allocations.
numActiveBytes() - Method in interface io.netty.buffer.PoolArenaMetric
Return the number of active bytes that are currently allocated by the arena.
numActiveHugeAllocations() - Method in interface io.netty.buffer.PoolArenaMetric
Return the number of currently active huge allocations.
numActiveNormalAllocations() - Method in interface io.netty.buffer.PoolArenaMetric
Return the number of currently active normal allocations.
numActiveSmallAllocations() - Method in interface io.netty.buffer.PoolArenaMetric
Return the number of currently active small allocations.
numActiveTinyAllocations() - Method in interface io.netty.buffer.PoolArenaMetric
Return the number of currently active tiny allocations.
numAllocations() - Method in interface io.netty.buffer.PoolArenaMetric
Return the number of allocations done via the arena.
numAvailable() - Method in interface io.netty.buffer.PoolSubpageMetric
Return the number of available elements to be allocated.
numChunkLists() - Method in interface io.netty.buffer.PoolArenaMetric
Returns the number of chunk lists for the arena.
numComponents() - Method in class io.netty.buffer.CompositeByteBuf
Return the current number of ByteBuf's that are composed in this instance
numDeallocations() - Method in interface io.netty.buffer.PoolArenaMetric
Return the number of deallocations done via the arena.
numDirectArenas() - Method in class io.netty.buffer.PooledByteBufAllocator
numDirectArenas() - Method in class io.netty.buffer.PooledByteBufAllocatorMetric
Return the number of direct arenas.
numHeapArenas() - Method in class io.netty.buffer.PooledByteBufAllocator
numHeapArenas() - Method in class io.netty.buffer.PooledByteBufAllocatorMetric
Return the number of heap arenas.
numHugeAllocations() - Method in interface io.netty.buffer.PoolArenaMetric
Return the number of huge allocations done via the arena.
numHugeDeallocations() - Method in interface io.netty.buffer.PoolArenaMetric
Return the number of huge deallocations done via the arena.
numNormalAllocations() - Method in interface io.netty.buffer.PoolArenaMetric
Return the number of normal allocations done via the arena.
numNormalDeallocations() - Method in interface io.netty.buffer.PoolArenaMetric
Return the number of normal deallocations done via the arena.
numSmallAllocations() - Method in interface io.netty.buffer.PoolArenaMetric
Return the number of small allocations done via the arena.
numSmallDeallocations() - Method in interface io.netty.buffer.PoolArenaMetric
Return the number of small deallocations done via the arena.
numSmallSubpages() - Method in interface io.netty.buffer.PoolArenaMetric
Returns the number of small sub-pages for the arena.
numThreadCaches() - Method in interface io.netty.buffer.PoolArenaMetric
Returns the number of thread caches backed by this arena.
numThreadLocalCaches() - Method in class io.netty.buffer.PooledByteBufAllocator
numThreadLocalCaches() - Method in class io.netty.buffer.PooledByteBufAllocatorMetric
Return the number of thread local caches used by this PooledByteBufAllocator.
numTinyAllocations() - Method in interface io.netty.buffer.PoolArenaMetric
Return the number of tiny allocations done via the arena.
numTinyDeallocations() - Method in interface io.netty.buffer.PoolArenaMetric
Return the number of tiny deallocations done via the arena.
numTinySubpages() - Method in interface io.netty.buffer.PoolArenaMetric
Returns the number of tiny sub-pages for the arena.
NXDOMAIN - Static variable in class io.netty.handler.codec.dns.DnsResponseCode
The 'NXDomain' DNS RCODE (3), as defined in RFC1035.
NXRRSET - Static variable in class io.netty.handler.codec.dns.DnsResponseCode
The 'NXRRSet' DNS RCODE (8), as defined in RFC2136.

O

ObjectDecoder - Class in io.netty.handler.codec.serialization
A decoder which deserializes the received ByteBufs into Java objects.
ObjectDecoder(ClassResolver) - Constructor for class io.netty.handler.codec.serialization.ObjectDecoder
Creates a new decoder whose maximum object size is 1048576 bytes.
ObjectDecoder(int, ClassResolver) - Constructor for class io.netty.handler.codec.serialization.ObjectDecoder
Creates a new decoder with the specified maximum object size.
ObjectDecoderInputStream - Class in io.netty.handler.codec.serialization
An ObjectInput which is interoperable with ObjectEncoder and ObjectEncoderOutputStream.
ObjectDecoderInputStream(InputStream) - Constructor for class io.netty.handler.codec.serialization.ObjectDecoderInputStream
Creates a new ObjectInput.
ObjectDecoderInputStream(InputStream, ClassLoader) - Constructor for class io.netty.handler.codec.serialization.ObjectDecoderInputStream
Creates a new ObjectInput.
ObjectDecoderInputStream(InputStream, int) - Constructor for class io.netty.handler.codec.serialization.ObjectDecoderInputStream
Creates a new ObjectInput.
ObjectDecoderInputStream(InputStream, ClassLoader, int) - Constructor for class io.netty.handler.codec.serialization.ObjectDecoderInputStream
Creates a new ObjectInput.
ObjectEncoder - Class in io.netty.handler.codec.serialization
An encoder which serializes a Java object into a ByteBuf.
ObjectEncoder() - Constructor for class io.netty.handler.codec.serialization.ObjectEncoder
 
ObjectEncoderOutputStream - Class in io.netty.handler.codec.serialization
An ObjectOutput which is interoperable with ObjectDecoder and ObjectDecoderInputStream.
ObjectEncoderOutputStream(OutputStream) - Constructor for class io.netty.handler.codec.serialization.ObjectEncoderOutputStream
Creates a new ObjectOutput with the estimated length of 512 bytes.
ObjectEncoderOutputStream(OutputStream, int) - Constructor for class io.netty.handler.codec.serialization.ObjectEncoderOutputStream
Creates a new ObjectOutput.
ObjectUtil - Class in io.netty.util.internal
A grab-bag of useful utility methods.
of(InetAddress) - Static method in enum io.netty.channel.socket.InternetProtocolFamily
Returns the InternetProtocolFamily for the given InetAddress.
of(CharSequence) - Static method in class io.netty.util.AsciiString
Returns an AsciiString containing the given character sequence.
offer(T) - Method in class io.netty.util.internal.DefaultPriorityQueue
 
offer(T) - Method in class io.netty.util.internal.EmptyPriorityQueue
 
offerChannel(Channel) - Method in class io.netty.channel.pool.SimpleChannelPool
Offer a Channel back to the internal storage.
offsetofEpollData() - Static method in class io.netty.channel.epoll.Native
 
OioByteStreamChannel - Class in io.netty.channel.oio
Abstract base class for OIO Channels that are based on streams.
OioByteStreamChannel(Channel) - Constructor for class io.netty.channel.oio.OioByteStreamChannel
Create a new instance
OioDatagramChannel - Class in io.netty.channel.socket.oio
An OIO datagram Channel that sends and receives an AddressedEnvelope.
OioDatagramChannel() - Constructor for class io.netty.channel.socket.oio.OioDatagramChannel
Create a new instance with an new MulticastSocket.
OioDatagramChannel(MulticastSocket) - Constructor for class io.netty.channel.socket.oio.OioDatagramChannel
Create a new instance from the given MulticastSocket.
OioEventLoopGroup - Class in io.netty.channel.oio
EventLoopGroup which is used to handle OIO Channel's.
OioEventLoopGroup() - Constructor for class io.netty.channel.oio.OioEventLoopGroup
Create a new OioEventLoopGroup with no limit in place.
OioEventLoopGroup(int) - Constructor for class io.netty.channel.oio.OioEventLoopGroup
Create a new OioEventLoopGroup.
OioEventLoopGroup(int, Executor) - Constructor for class io.netty.channel.oio.OioEventLoopGroup
Create a new OioEventLoopGroup.
OioEventLoopGroup(int, ThreadFactory) - Constructor for class io.netty.channel.oio.OioEventLoopGroup
Create a new OioEventLoopGroup.
OioServerSocketChannel - Class in io.netty.channel.socket.oio
ServerSocketChannel which accepts new connections and create the OioSocketChannel's for them.
OioServerSocketChannel() - Constructor for class io.netty.channel.socket.oio.OioServerSocketChannel
Create a new instance with an new Socket
OioServerSocketChannel(ServerSocket) - Constructor for class io.netty.channel.socket.oio.OioServerSocketChannel
Create a new instance from the given ServerSocket
OioServerSocketChannelConfig - Interface in io.netty.channel.socket.oio
OioSocketChannel - Class in io.netty.channel.socket.oio
A SocketChannel which is using Old-Blocking-IO
OioSocketChannel() - Constructor for class io.netty.channel.socket.oio.OioSocketChannel
Create a new instance with an new Socket
OioSocketChannel(Socket) - Constructor for class io.netty.channel.socket.oio.OioSocketChannel
Create a new instance from the given Socket
OioSocketChannel(Channel, Socket) - Constructor for class io.netty.channel.socket.oio.OioSocketChannel
Create a new instance from the given Socket
OioSocketChannelConfig - Interface in io.netty.channel.socket.oio
onLookupComplete(ChannelHandlerContext, String, Future<T>) - Method in class io.netty.handler.ssl.AbstractSniHandler
onLookupComplete(ChannelHandlerContext, String, Future<SslContext>) - Method in class io.netty.handler.ssl.SniHandler
 
onRemoval(V) - Method in class io.netty.util.concurrent.FastThreadLocal
Invoked when this thread local variable is removed by FastThreadLocal.remove().
onUnhandledInboundException(Throwable) - Method in class io.netty.channel.DefaultChannelPipeline
Called once a Throwable hit the end of the ChannelPipeline without been handled by the user in ChannelHandler.exceptionCaught(ChannelHandlerContext, Throwable).
onUnhandledInboundMessage(Object) - Method in class io.netty.channel.DefaultChannelPipeline
Called once a message hit the end of the ChannelPipeline without been handled by the user in ChannelInboundHandler.channelRead(ChannelHandlerContext, Object).
opaque() - Method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
opaque() - Method in interface io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Returns the opaque value.
opCode() - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
 
opCode() - Method in interface io.netty.handler.codec.dns.DnsMessage
Returns the opCode of this DNS message.
opcode() - Method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
opcode() - Method in interface io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Returns the opcode for the message.
open() - Method in class io.netty.channel.DefaultFileRegion
Explicitly open the underlying file-descriptor if not done yet.
open(T) - Method in class io.netty.util.ResourceLeakDetector
OpenSslApplicationProtocolNegotiator - Interface in io.netty.handler.ssl
OpenSSL version of ApplicationProtocolNegotiator.
OpenSslDefaultApplicationProtocolNegotiator - Class in io.netty.handler.ssl
OpenSSL ApplicationProtocolNegotiator for ALPN and NPN.
OpenSslDefaultApplicationProtocolNegotiator(ApplicationProtocolConfig) - Constructor for class io.netty.handler.ssl.OpenSslDefaultApplicationProtocolNegotiator
 
OpenSslNpnApplicationProtocolNegotiator - Class in io.netty.handler.ssl
OpenSslNpnApplicationProtocolNegotiator(Iterable<String>) - Constructor for class io.netty.handler.ssl.OpenSslNpnApplicationProtocolNegotiator
Deprecated.
 
OpenSslNpnApplicationProtocolNegotiator(String...) - Constructor for class io.netty.handler.ssl.OpenSslNpnApplicationProtocolNegotiator
Deprecated.
 
operationComplete(F) - Method in interface io.netty.util.concurrent.GenericFutureListener
Invoked when the operation associated with the Future has been completed.
operationComplete(F) - Method in class io.netty.util.concurrent.PromiseAggregator
Deprecated.
 
operationComplete(F) - Method in class io.netty.util.concurrent.PromiseNotifier
 
operationComplete(Future<T>) - Method in class io.netty.util.concurrent.UnaryPromiseNotifier
 
operationProgressed(F, long, long) - Method in interface io.netty.util.concurrent.GenericProgressiveFutureListener
Invoked when the operation has progressed.
OPT - Static variable in class io.netty.handler.codec.dns.DnsRecordType
Option record RFC 2671 This is a pseudo DNS record type needed to support EDNS.
option(ChannelOption<T>, T) - Method in class io.netty.bootstrap.AbstractBootstrap
Allow to specify a ChannelOption which is used for the Channel instances once they got created.
OptionalSslHandler - Class in io.netty.handler.ssl
OptionalSslHandler is a utility decoder to support both SSL and non-SSL handlers based on the first message received.
OptionalSslHandler(SslContext) - Constructor for class io.netty.handler.ssl.OptionalSslHandler
 
options() - Method in class io.netty.bootstrap.AbstractBootstrapConfig
Returns a copy of the configured options.
options() - Method in class io.netty.channel.epoll.EpollTcpInfo
 
optResourceEnabled(boolean) - Method in class io.netty.resolver.dns.DnsNameResolverBuilder
Enable the automatic inclusion of a optional records that tries to give the remote DNS server a hint about how much data the resolver can read per response.
order(ByteOrder) - Method in class io.netty.buffer.AbstractByteBuf
 
order() - Method in class io.netty.buffer.ByteBuf
Deprecated.
use the Little Endian accessors, e.g. getShortLE, getIntLE instead of creating a buffer with swapped endianness.
order(ByteOrder) - Method in class io.netty.buffer.ByteBuf
Deprecated.
use the Little Endian accessors, e.g. getShortLE, getIntLE instead of creating a buffer with swapped endianness.
order() - Method in class io.netty.buffer.CompositeByteBuf
 
order() - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
order() - Method in class io.netty.buffer.EmptyByteBuf
 
order(ByteOrder) - Method in class io.netty.buffer.EmptyByteBuf
 
order() - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
order() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
order(ByteOrder) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
order() - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
order() - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
order() - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
OrderedEventExecutor - Interface in io.netty.util.concurrent
Marker interface for EventExecutors that will process all submitted tasks in an ordered / serial fashion.
outboundBuffer() - Method in class io.netty.channel.AbstractChannel.AbstractUnsafe
 
outboundBuffer() - Method in interface io.netty.channel.Channel.Unsafe
Returns the ChannelOutboundBuffer of the Channel where the pending write requests are stored.
outboundHandler() - Method in class io.netty.channel.CombinedChannelDuplexHandler
 
outboundMessages() - Method in class io.netty.channel.embedded.EmbeddedChannel
Returns the Queue which holds all the Objects that were written by this Channel.
OutOfDirectMemoryError - Error in io.netty.util.internal
OutOfMemoryError that is throws if PlatformDependent.allocateDirectNoCleaner(int) can not allocate a new ByteBuffer due memory restrictions.

P

packetId() - Method in class io.netty.handler.codec.mqtt.MqttPublishVariableHeader
 
pageSize() - Method in interface io.netty.buffer.PoolSubpageMetric
Return the size (in bytes) of this page.
parameters() - Method in class io.netty.handler.codec.smtp.DefaultSmtpRequest
 
parameters() - Method in interface io.netty.handler.codec.smtp.SmtpRequest
Returns a List which holds all the parameters of a request, which may be an empty list.
parent() - Method in class io.netty.channel.AbstractChannel
 
parent() - Method in class io.netty.channel.AbstractEventLoop
 
parent() - Method in interface io.netty.channel.Channel
Returns the parent of this channel.
parent() - Method in class io.netty.channel.epoll.EpollSocketChannel
 
parent() - Method in interface io.netty.channel.EventLoop
 
parent() - Method in class io.netty.channel.kqueue.KQueueSocketChannel
 
parent() - Method in class io.netty.channel.local.LocalChannel
 
parent() - Method in class io.netty.channel.SingleThreadEventLoop
 
parent() - Method in class io.netty.channel.socket.nio.NioSocketChannel
 
parent() - Method in class io.netty.channel.socket.oio.OioSocketChannel
 
parent() - Method in interface io.netty.channel.socket.SocketChannel
 
parent() - Method in class io.netty.util.concurrent.AbstractEventExecutor
 
parent() - Method in interface io.netty.util.concurrent.EventExecutor
Return the EventExecutorGroup which is the parent of this EventExecutor,
parent() - Method in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor
 
parse() - Static method in class io.netty.resolver.HostsFileParser
Parse hosts file at standard OS location.
parse(File) - Static method in class io.netty.resolver.HostsFileParser
Parse a hosts file.
parse(Reader) - Static method in class io.netty.resolver.HostsFileParser
Parse a reader of hosts file format.
parseBoolean() - Method in class io.netty.util.AsciiString
 
parseChar() - Method in class io.netty.util.AsciiString
 
parseChar(int) - Method in class io.netty.util.AsciiString
 
parseDouble() - Method in class io.netty.util.AsciiString
 
parseDouble(int, int) - Method in class io.netty.util.AsciiString
 
parseFloat() - Method in class io.netty.util.AsciiString
 
parseFloat(int, int) - Method in class io.netty.util.AsciiString
 
parseHttpDate(CharSequence) - Static method in class io.netty.handler.codec.DateFormatter
Parse some text into a Date, according to RFC6265
parseHttpDate(CharSequence, int, int) - Static method in class io.netty.handler.codec.DateFormatter
Parse some text into a Date, according to RFC6265
parseInt() - Method in class io.netty.util.AsciiString
 
parseInt(int) - Method in class io.netty.util.AsciiString
 
parseInt(int, int) - Method in class io.netty.util.AsciiString
 
parseInt(int, int, int) - Method in class io.netty.util.AsciiString
 
parseLong() - Method in class io.netty.util.AsciiString
 
parseLong(int) - Method in class io.netty.util.AsciiString
 
parseLong(int, int) - Method in class io.netty.util.AsciiString
 
parseLong(int, int, int) - Method in class io.netty.util.AsciiString
 
parseMAC(String) - Static method in class io.netty.util.internal.MacAddressUtil
Parse a EUI-48, MAC-48, or EUI-64 MAC address from a String and return it as a byte[].
parseShort() - Method in class io.netty.util.AsciiString
 
parseShort(int) - Method in class io.netty.util.AsciiString
 
parseShort(int, int) - Method in class io.netty.util.AsciiString
 
parseShort(int, int, int) - Method in class io.netty.util.AsciiString
 
parseSilently() - Static method in class io.netty.resolver.HostsFileParser
Parse hosts file at standard OS location.
PASSCODE - Static variable in interface io.netty.handler.codec.stomp.StompHeaders
 
password() - Method in class io.netty.handler.codec.mqtt.MqttConnectPayload
Deprecated.
password(String) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
password(byte[]) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
 
passwordInBytes() - Method in class io.netty.handler.codec.mqtt.MqttConnectPayload
 
path() - Method in class io.netty.channel.unix.DomainSocketAddress
The path to the domain socket.
payload() - Method in class io.netty.handler.codec.mqtt.MqttConnectMessage
 
payload() - Method in class io.netty.handler.codec.mqtt.MqttMessage
 
payload(ByteBuf) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.PublishBuilder
 
payload() - Method in class io.netty.handler.codec.mqtt.MqttPublishMessage
 
payload() - Method in class io.netty.handler.codec.mqtt.MqttSubAckMessage
 
payload() - Method in class io.netty.handler.codec.mqtt.MqttSubscribeMessage
 
payload() - Method in class io.netty.handler.codec.mqtt.MqttUnsubscribeMessage
 
peek() - Method in class io.netty.util.internal.DefaultPriorityQueue
 
peek() - Method in class io.netty.util.internal.EmptyPriorityQueue
 
peekTask() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
 
peerCredentials() - Method in class io.netty.channel.epoll.EpollDomainSocketChannel
Returns the unix credentials (uid, gid, pid) of the peer SO_PEERCRED
peerCredentials() - Method in class io.netty.channel.kqueue.KQueueDomainSocketChannel
Returns the unix credentials (uid, gid, pid) of the peer SO_PEERCRED
PeerCredentials - Class in io.netty.channel.unix
User credentials discovered for the peer unix domain socket.
PemPrivateKey - Class in io.netty.handler.ssl
This is a special purpose implementation of a PrivateKey which allows the user to pass PEM/PKCS#8 encoded key material straight into OpenSslContext without having to parse and re-encode bytes in Java land.
PemX509Certificate - Class in io.netty.handler.ssl
This is a special purpose implementation of a X509Certificate which allows the user to pass PEM/PKCS#8 encoded data straight into OpenSslContext without having to parse and re-encode bytes in Java land.
pendingTasks() - Method in class io.netty.channel.nio.NioEventLoop
 
pendingTasks() - Method in class io.netty.channel.SingleThreadEventLoop
 
pendingTasks() - Method in class io.netty.util.concurrent.GlobalEventExecutor
Return the number of tasks that are pending for processing.
pendingTasks() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
Return the number of tasks that are pending for processing.
pendingTimeouts() - Method in class io.netty.util.HashedWheelTimer
Returns the number of pending timeouts of this Timer.
PendingWrite - Class in io.netty.util.internal
Some pending write which should be picked up later.
PendingWriteQueue - Class in io.netty.channel
A queue of write operations which are pending for later execution.
PendingWriteQueue(ChannelHandlerContext) - Constructor for class io.netty.channel.PendingWriteQueue
 
pid() - Method in class io.netty.channel.unix.PeerCredentials
Get the PID of the peer process.
pipe() - Static method in class io.netty.channel.unix.FileDescriptor
 
pipeline() - Method in class io.netty.channel.AbstractChannel
 
pipeline() - Method in interface io.netty.channel.Channel
Return the assigned ChannelPipeline.
pipeline() - Method in interface io.netty.channel.ChannelHandlerContext
Return the assigned ChannelPipeline
platformDefault() - Static method in class io.netty.resolver.dns.DnsServerAddressStreamProviders
A DnsServerAddressStreamProvider which inherits the DNS servers from your local host's configuration.
PlatformDependent - Class in io.netty.util.internal
Utility that detects various properties specific to the current runtime environment, such as Java version and the availability of the sun.misc.Unsafe object.
pmtu() - Method in class io.netty.channel.epoll.EpollTcpInfo
 
pointNeighborsToThis() - Method in class io.netty.handler.codec.DefaultHeaders.HeaderEntry
 
poll() - Method in class io.netty.util.internal.DefaultPriorityQueue
 
poll() - Method in class io.netty.util.internal.EmptyPriorityQueue
 
pollChannel() - Method in class io.netty.channel.pool.SimpleChannelPool
Poll a Channel out of the internal storage to reuse it.
pollScheduledTask() - Method in class io.netty.util.concurrent.AbstractScheduledEventExecutor
 
pollScheduledTask(long) - Method in class io.netty.util.concurrent.AbstractScheduledEventExecutor
Return the Runnable which is ready to be executed with the given nanoTime.
pollTask() - Method in class io.netty.channel.nio.NioEventLoop
 
pollTask() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
 
pollTaskFrom(Queue<Runnable>) - Static method in class io.netty.util.concurrent.SingleThreadEventExecutor
 
PoolArenaMetric - Interface in io.netty.buffer
Expose metrics for an arena.
PoolChunkListMetric - Interface in io.netty.buffer
Metrics for a list of chunks.
PoolChunkMetric - Interface in io.netty.buffer
Metrics for a chunk.
PooledByteBufAllocator - Class in io.netty.buffer
 
PooledByteBufAllocator() - Constructor for class io.netty.buffer.PooledByteBufAllocator
 
PooledByteBufAllocator(boolean) - Constructor for class io.netty.buffer.PooledByteBufAllocator
 
PooledByteBufAllocator(int, int, int, int) - Constructor for class io.netty.buffer.PooledByteBufAllocator
 
PooledByteBufAllocator(boolean, int, int, int, int) - Constructor for class io.netty.buffer.PooledByteBufAllocator
PooledByteBufAllocator(boolean, int, int, int, int, int, int, int) - Constructor for class io.netty.buffer.PooledByteBufAllocator
PooledByteBufAllocator(boolean, int, int, int, int, int, int, int, boolean) - Constructor for class io.netty.buffer.PooledByteBufAllocator
 
PooledByteBufAllocator(boolean, int, int, int, int, int, int, int, boolean, int) - Constructor for class io.netty.buffer.PooledByteBufAllocator
 
PooledByteBufAllocatorMetric - Class in io.netty.buffer
Exposed metric for PooledByteBufAllocator.
PoolSubpageMetric - Interface in io.netty.buffer
Metrics for a sub-page.
position() - Method in class io.netty.channel.DefaultFileRegion
 
position() - Method in interface io.netty.channel.FileRegion
Returns the offset in the file where the transfer began.
PrematureChannelClosureException - Exception in io.netty.handler.codec
A CodecException which is thrown when a Channel is closed unexpectedly before the codec finishes handling the current message, such as missing response while waiting for a request.
PrematureChannelClosureException() - Constructor for exception io.netty.handler.codec.PrematureChannelClosureException
Creates a new instance.
PrematureChannelClosureException(String, Throwable) - Constructor for exception io.netty.handler.codec.PrematureChannelClosureException
Creates a new instance.
PrematureChannelClosureException(String) - Constructor for exception io.netty.handler.codec.PrematureChannelClosureException
Creates a new instance.
PrematureChannelClosureException(Throwable) - Constructor for exception io.netty.handler.codec.PrematureChannelClosureException
Creates a new instance.
prepareToClose() - Method in class io.netty.channel.AbstractChannel.AbstractUnsafe
Prepares to close the Channel.
PREPEND - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
PREPENDQ - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
prettyHexDump(ByteBuf) - Static method in class io.netty.buffer.ByteBufUtil
Returns a multi-line hexadecimal dump of the specified ByteBuf that is easy to read by humans.
prettyHexDump(ByteBuf, int, int) - Static method in class io.netty.buffer.ByteBufUtil
Returns a multi-line hexadecimal dump of the specified ByteBuf that is easy to read by humans, starting at the given offset using the given length.
priority() - Method in interface io.netty.util.concurrent.ThreadProperties
 
priorityChanged(T) - Method in class io.netty.util.internal.DefaultPriorityQueue
 
priorityChanged(T) - Method in class io.netty.util.internal.EmptyPriorityQueue
 
priorityChanged(T) - Method in interface io.netty.util.internal.PriorityQueue
Notify the queue that the priority for node has changed.
PriorityQueue<T> - Interface in io.netty.util.internal
 
priorityQueueIndex(DefaultPriorityQueue<?>) - Method in interface io.netty.util.internal.PriorityQueueNode
Get the last value set by PriorityQueueNode.priorityQueueIndex(DefaultPriorityQueue, int) for the value corresponding to queue.
priorityQueueIndex(DefaultPriorityQueue<?>, int) - Method in interface io.netty.util.internal.PriorityQueueNode
Used by DefaultPriorityQueue to maintain state for an element in the queue.
PriorityQueueNode - Interface in io.netty.util.internal
Provides methods for DefaultPriorityQueue to maintain internal state.
privateKey() - Method in class io.netty.handler.ssl.util.SelfSignedCertificate
Returns the generated RSA private key file in PEM format.
probes() - Method in class io.netty.channel.epoll.EpollTcpInfo
 
process(byte) - Method in class io.netty.util.ByteProcessor.IndexNotOfProcessor
 
process(byte) - Method in class io.netty.util.ByteProcessor.IndexOfProcessor
 
process(byte) - Method in interface io.netty.util.ByteProcessor
 
processMessage(Object) - Method in interface io.netty.channel.ChannelOutboundBuffer.MessageProcessor
Will be called for each flushed message until it either there are no more flushed messages or this method returns false.
processMessage(Object) - Method in class io.netty.channel.unix.IovArray
 
processWritten(int, long) - Method in class io.netty.channel.unix.IovArray
Process the written iov entries.
progress(long) - Method in class io.netty.channel.ChannelOutboundBuffer
Notify the ChannelPromise of the current message about writing progress.
progress() - Method in class io.netty.handler.stream.ChunkedFile
 
progress() - Method in interface io.netty.handler.stream.ChunkedInput
Returns current transfer progress.
progress() - Method in class io.netty.handler.stream.ChunkedNioFile
 
progress() - Method in class io.netty.handler.stream.ChunkedNioStream
 
progress() - Method in class io.netty.handler.stream.ChunkedStream
 
ProgressiveFuture<V> - Interface in io.netty.util.concurrent
A Future which is used to indicate the progress of an operation.
ProgressivePromise<V> - Interface in io.netty.util.concurrent
Special ProgressiveFuture which is writable.
promise() - Method in class io.netty.channel.DefaultChannelProgressivePromise
 
promise() - Method in class io.netty.channel.DefaultChannelPromise
 
Promise<V> - Interface in io.netty.util.concurrent
Special Future which is writable.
promise() - Method in class io.netty.util.internal.PendingWrite
 
PromiseAggregator<V,F extends Future<V>> - Class in io.netty.util.concurrent
Deprecated.
Use PromiseCombiner GenericFutureListener implementation which consolidates multiple Futures into one, by listening to individual Futures and producing an aggregated result (success/failure) when all Futures have completed.
PromiseAggregator(Promise<Void>, boolean) - Constructor for class io.netty.util.concurrent.PromiseAggregator
Deprecated.
Creates a new instance.
PromiseAggregator(Promise<Void>) - Constructor for class io.netty.util.concurrent.PromiseAggregator
Deprecated.
PromiseCombiner - Class in io.netty.util.concurrent
A promise combiner monitors the outcome of a number of discrete futures, then notifies a final, aggregate promise when all of the combined futures are finished.
PromiseCombiner() - Constructor for class io.netty.util.concurrent.PromiseCombiner
 
PromiseNotificationUtil - Class in io.netty.util.internal
Internal utilities to notify Promises.
PromiseNotifier<V,F extends Future<V>> - Class in io.netty.util.concurrent
GenericFutureListener implementation which takes other Promises and notifies them on completion.
PromiseNotifier(Promise<? super V>...) - Constructor for class io.netty.util.concurrent.PromiseNotifier
Create a new instance.
PromiseNotifier(boolean, Promise<? super V>...) - Constructor for class io.netty.util.concurrent.PromiseNotifier
Create a new instance.
protocol() - Method in class io.netty.handler.ssl.ApplicationProtocolConfig
Get which application level protocol negotiation to use.
protocol() - Method in interface io.netty.handler.ssl.OpenSslApplicationProtocolNegotiator
Returns the ApplicationProtocolConfig.Protocol which should be used.
protocol() - Method in class io.netty.handler.ssl.OpenSslDefaultApplicationProtocolNegotiator
 
protocol() - Method in class io.netty.handler.ssl.OpenSslNpnApplicationProtocolNegotiator
Deprecated.
 
ProtocolDetectionResult<T> - Class in io.netty.handler.codec
Result of detecting a protocol.
ProtocolDetectionState - Enum in io.netty.handler.codec
The state of the current detection.
protocolLevel() - Method in enum io.netty.handler.codec.mqtt.MqttVersion
 
protocolListenerFactory() - Method in interface io.netty.handler.ssl.JdkApplicationProtocolNegotiator
protocolName() - Method in enum io.netty.handler.codec.mqtt.MqttVersion
 
protocolNameBytes() - Method in enum io.netty.handler.codec.mqtt.MqttVersion
 
protocols() - Method in interface io.netty.handler.ssl.ApplicationProtocolNegotiator
Get the collection of application protocols supported by this application (in preference order).
protocols() - Method in class io.netty.handler.ssl.OpenSslDefaultApplicationProtocolNegotiator
 
protocols() - Method in class io.netty.handler.ssl.OpenSslNpnApplicationProtocolNegotiator
Deprecated.
 
protocols(String...) - Method in class io.netty.handler.ssl.SslContextBuilder
The TLS protocol versions to enable.
protocolSelectorFactory() - Method in interface io.netty.handler.ssl.JdkApplicationProtocolNegotiator
protocolVersion(MqttVersion) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
 
PTR - Static variable in class io.netty.handler.codec.dns.DnsRecordType
Pointer record RFC 1035 Pointer to a canonical name.
publish() - Static method in class io.netty.handler.codec.mqtt.MqttMessageBuilders
 
put(byte, V) - Method in class io.netty.util.collection.ByteObjectHashMap
 
put(Byte, V) - Method in class io.netty.util.collection.ByteObjectHashMap
 
put(byte, V) - Method in interface io.netty.util.collection.ByteObjectMap
Puts the given entry into the map.
put(char, V) - Method in class io.netty.util.collection.CharObjectHashMap
 
put(Character, V) - Method in class io.netty.util.collection.CharObjectHashMap
 
put(char, V) - Method in interface io.netty.util.collection.CharObjectMap
Puts the given entry into the map.
put(int, V) - Method in class io.netty.util.collection.IntObjectHashMap
 
put(Integer, V) - Method in class io.netty.util.collection.IntObjectHashMap
 
put(int, V) - Method in interface io.netty.util.collection.IntObjectMap
Puts the given entry into the map.
put(long, V) - Method in class io.netty.util.collection.LongObjectHashMap
 
put(Long, V) - Method in class io.netty.util.collection.LongObjectHashMap
 
put(long, V) - Method in interface io.netty.util.collection.LongObjectMap
Puts the given entry into the map.
put(short, V) - Method in class io.netty.util.collection.ShortObjectHashMap
 
put(Short, V) - Method in class io.netty.util.collection.ShortObjectHashMap
 
put(short, V) - Method in interface io.netty.util.collection.ShortObjectMap
Puts the given entry into the map.
putAll(Map<? extends Byte, ? extends V>) - Method in class io.netty.util.collection.ByteObjectHashMap
 
putAll(Map<? extends Character, ? extends V>) - Method in class io.netty.util.collection.CharObjectHashMap
 
putAll(Map<? extends Integer, ? extends V>) - Method in class io.netty.util.collection.IntObjectHashMap
 
putAll(Map<? extends Long, ? extends V>) - Method in class io.netty.util.collection.LongObjectHashMap
 
putAll(Map<? extends Short, ? extends V>) - Method in class io.netty.util.collection.ShortObjectHashMap
 
putByte(long, byte) - Static method in class io.netty.util.internal.PlatformDependent
 
putByte(byte[], int, byte) - Static method in class io.netty.util.internal.PlatformDependent
 
putInt(long, int) - Static method in class io.netty.util.internal.PlatformDependent
 
putInt(byte[], int, int) - Static method in class io.netty.util.internal.PlatformDependent
 
putLong(long, long) - Static method in class io.netty.util.internal.PlatformDependent
 
putLong(byte[], int, long) - Static method in class io.netty.util.internal.PlatformDependent
 
putShort(long, short) - Static method in class io.netty.util.internal.PlatformDependent
 
putShort(byte[], int, short) - Static method in class io.netty.util.internal.PlatformDependent
 

Q

qos(MqttQoS) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.PublishBuilder
 
qosLevel() - Method in class io.netty.handler.codec.mqtt.MqttFixedHeader
 
qualityOfService() - Method in class io.netty.handler.codec.mqtt.MqttTopicSubscription
 
QUERY - Static variable in class io.netty.handler.codec.dns.DnsOpCode
The 'Query' DNS OpCode, as defined in RFC1035.
query(DnsQuestion) - Method in class io.netty.resolver.dns.DnsNameResolver
Sends a DNS query with the specified question.
query(DnsQuestion, Iterable<DnsRecord>) - Method in class io.netty.resolver.dns.DnsNameResolver
Sends a DNS query with the specified question with additional records.
query(DnsQuestion, Promise<AddressedEnvelope<? extends DnsResponse, InetSocketAddress>>) - Method in class io.netty.resolver.dns.DnsNameResolver
Sends a DNS query with the specified question.
query(InetSocketAddress, DnsQuestion) - Method in class io.netty.resolver.dns.DnsNameResolver
Sends a DNS query with the specified question using the specified name server list.
query(InetSocketAddress, DnsQuestion, Iterable<DnsRecord>) - Method in class io.netty.resolver.dns.DnsNameResolver
Sends a DNS query with the specified question with additional records using the specified name server list.
query(InetSocketAddress, DnsQuestion, Promise<AddressedEnvelope<? extends DnsResponse, InetSocketAddress>>) - Method in class io.netty.resolver.dns.DnsNameResolver
Sends a DNS query with the specified question using the specified name server list.
query(InetSocketAddress, DnsQuestion, Iterable<DnsRecord>, Promise<AddressedEnvelope<? extends DnsResponse, InetSocketAddress>>) - Method in class io.netty.resolver.dns.DnsNameResolver
Sends a DNS query with the specified question with additional records using the specified name server list.
queryCancelled(int) - Method in class io.netty.resolver.dns.BiDnsQueryLifecycleObserver
 
queryCancelled(int) - Method in interface io.netty.resolver.dns.DnsQueryLifecycleObserver
The query may have been written but it was cancelled at some point.
queryCNAMEd(DnsQuestion) - Method in class io.netty.resolver.dns.BiDnsQueryLifecycleObserver
 
queryCNAMEd(DnsQuestion) - Method in interface io.netty.resolver.dns.DnsQueryLifecycleObserver
The query returned a CNAME which we may attempt to follow with a new query.
queryFailed(Throwable) - Method in class io.netty.resolver.dns.BiDnsQueryLifecycleObserver
 
queryFailed(Throwable) - Method in interface io.netty.resolver.dns.DnsQueryLifecycleObserver
The following criteria are possible: IO Error Server responded with an invalid DNS response Server responded with a valid DNS response, but it didn't progress the resolution
queryNoAnswer(DnsResponseCode) - Method in class io.netty.resolver.dns.BiDnsQueryLifecycleObserver
 
queryNoAnswer(DnsResponseCode) - Method in interface io.netty.resolver.dns.DnsQueryLifecycleObserver
The response to the query didn't provide the expected response code, but it didn't return DnsResponseCode.NXDOMAIN so we may try to query again.
queryRedirected(List<InetSocketAddress>) - Method in class io.netty.resolver.dns.BiDnsQueryLifecycleObserver
 
queryRedirected(List<InetSocketAddress>) - Method in interface io.netty.resolver.dns.DnsQueryLifecycleObserver
The query has been redirected to another list of DNS servers.
querySucceed() - Method in class io.netty.resolver.dns.BiDnsQueryLifecycleObserver
 
querySucceed() - Method in interface io.netty.resolver.dns.DnsQueryLifecycleObserver
The query received the expected results.
queryTimeoutMillis() - Method in class io.netty.resolver.dns.DnsNameResolver
Returns the timeout of each DNS query performed by this resolver (in milliseconds).
queryTimeoutMillis(long) - Method in class io.netty.resolver.dns.DnsNameResolverBuilder
Sets the timeout of each DNS query performed by this resolver (in milliseconds).
queryWritten(InetSocketAddress, ChannelFuture) - Method in class io.netty.resolver.dns.BiDnsQueryLifecycleObserver
 
queryWritten(InetSocketAddress, ChannelFuture) - Method in interface io.netty.resolver.dns.DnsQueryLifecycleObserver
The query has been written.
question() - Method in exception io.netty.resolver.dns.DnsNameResolverException
Returns the DnsQuestion of the DNS query that has failed.
queueSize() - Method in class io.netty.handler.traffic.ChannelTrafficShapingHandler
 
queuesSize() - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
 
queuesSize() - Method in class io.netty.handler.traffic.GlobalTrafficShapingHandler
 
QUIT - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
QUIT - Static variable in class io.netty.handler.codec.smtp.SmtpCommand
 
quit() - Static method in class io.netty.handler.codec.smtp.SmtpRequests
Creates a QUIT request.
QUITQ - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 

R

random() - Method in class io.netty.util.internal.InternalThreadLocalMap
 
RCPT - Static variable in class io.netty.handler.codec.smtp.SmtpCommand
 
rcpt(CharSequence, CharSequence...) - Static method in class io.netty.handler.codec.smtp.SmtpRequests
Creates a RCPT request.
RCV_ALLOC_TRANSPORT_PROVIDES_GUESS - Static variable in class io.netty.channel.kqueue.KQueueChannelOption
If this is true then the RecvByteBufAllocator.Handle#guess() will be overriden to always attempt to read as many bytes as kqueue says are available.
RCVBUF_ALLOCATOR - Static variable in class io.netty.channel.ChannelOption
 
rcvMss() - Method in class io.netty.channel.epoll.EpollTcpInfo
 
rcvRtt() - Method in class io.netty.channel.epoll.EpollTcpInfo
 
rcvSpace() - Method in class io.netty.channel.epoll.EpollTcpInfo
 
rcvSsthresh() - Method in class io.netty.channel.epoll.EpollTcpInfo
 
rcvWscale() - Method in class io.netty.channel.epoll.EpollTcpInfo
 
read() - Method in class io.netty.buffer.ByteBufInputStream
 
read(byte[], int, int) - Method in class io.netty.buffer.ByteBufInputStream
 
read() - Method in class io.netty.channel.AbstractChannel
 
read() - Method in interface io.netty.channel.Channel
 
read(ChannelHandlerContext) - Method in class io.netty.channel.ChannelDuplexHandler
read() - Method in interface io.netty.channel.ChannelHandlerContext
 
read(ChannelHandlerContext) - Method in interface io.netty.channel.ChannelOutboundHandler
read(ChannelHandlerContext) - Method in class io.netty.channel.ChannelOutboundHandlerAdapter
read() - Method in interface io.netty.channel.ChannelOutboundInvoker
Request to Read data from the Channel into the first inbound buffer, triggers an ChannelInboundHandler.channelRead(ChannelHandlerContext, Object) event if data was read, and triggers a channelReadComplete event so the handler can decide to continue reading.
read(ChannelHandlerContext) - Method in class io.netty.channel.CombinedChannelDuplexHandler
 
read() - Method in class io.netty.channel.DefaultChannelPipeline
 
read() - Method in class io.netty.channel.nio.AbstractNioByteChannel.NioByteUnsafe
 
read() - Method in interface io.netty.channel.nio.AbstractNioChannel.NioUnsafe
Read from underlying SelectableChannel
read(ByteBuffer, int, int) - Method in class io.netty.channel.unix.FileDescriptor
 
read(ChannelHandlerContext) - Method in class io.netty.handler.codec.DatagramPacketEncoder
 
read() - Method in class io.netty.handler.codec.serialization.ObjectDecoderInputStream
 
read(byte[], int, int) - Method in class io.netty.handler.codec.serialization.ObjectDecoderInputStream
 
read(byte[]) - Method in class io.netty.handler.codec.serialization.ObjectDecoderInputStream
 
read(ChannelHandlerContext) - Method in class io.netty.handler.flow.FlowControlHandler
 
read(ChannelHandlerContext) - Method in class io.netty.handler.ssl.AbstractSniHandler
 
read(ChannelHandlerContext) - Method in class io.netty.handler.ssl.SslHandler
 
read(ChannelHandlerContext) - Method in class io.netty.handler.traffic.AbstractTrafficShapingHandler
 
readableBytes() - Method in class io.netty.buffer.AbstractByteBuf
 
readableBytes() - Method in class io.netty.buffer.ByteBuf
Returns the number of readable bytes which is equal to (this.writerIndex - this.readerIndex).
readableBytes() - Method in class io.netty.buffer.EmptyByteBuf
 
readableBytes() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
readableBytes() - Method in class io.netty.channel.CoalescingBufferQueue
The number of readable bytes.
readAddress(long, int, int) - Method in class io.netty.channel.unix.FileDescriptor
 
readBoolean() - Method in class io.netty.buffer.AbstractByteBuf
 
readBoolean() - Method in class io.netty.buffer.ByteBuf
Gets a boolean at the current readerIndex and increases the readerIndex by 1 in this buffer.
readBoolean() - Method in class io.netty.buffer.ByteBufInputStream
 
readBoolean() - Method in class io.netty.buffer.EmptyByteBuf
 
readBoolean() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
readBoolean() - Method in class io.netty.handler.codec.serialization.ObjectDecoderInputStream
 
readByte() - Method in class io.netty.buffer.AbstractByteBuf
 
readByte() - Method in class io.netty.buffer.ByteBuf
Gets a byte at the current readerIndex and increases the readerIndex by 1 in this buffer.
readByte() - Method in class io.netty.buffer.ByteBufInputStream
 
readByte() - Method in class io.netty.buffer.EmptyByteBuf
 
readByte() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
readByte() - Method in class io.netty.handler.codec.serialization.ObjectDecoderInputStream
 
readBytes(int) - Method in class io.netty.buffer.AbstractByteBuf
 
readBytes(byte[], int, int) - Method in class io.netty.buffer.AbstractByteBuf
 
readBytes(byte[]) - Method in class io.netty.buffer.AbstractByteBuf
 
readBytes(ByteBuf) - Method in class io.netty.buffer.AbstractByteBuf
 
readBytes(ByteBuf, int) - Method in class io.netty.buffer.AbstractByteBuf
 
readBytes(ByteBuf, int, int) - Method in class io.netty.buffer.AbstractByteBuf
 
readBytes(ByteBuffer) - Method in class io.netty.buffer.AbstractByteBuf
 
readBytes(GatheringByteChannel, int) - Method in class io.netty.buffer.AbstractByteBuf
 
readBytes(FileChannel, long, int) - Method in class io.netty.buffer.AbstractByteBuf
 
readBytes(OutputStream, int) - Method in class io.netty.buffer.AbstractByteBuf
 
readBytes(int) - Method in class io.netty.buffer.ByteBuf
Transfers this buffer's data to a newly created buffer starting at the current readerIndex and increases the readerIndex by the number of the transferred bytes (= length).
readBytes(ByteBuf) - Method in class io.netty.buffer.ByteBuf
Transfers this buffer's data to the specified destination starting at the current readerIndex until the destination becomes non-writable, and increases the readerIndex by the number of the transferred bytes.
readBytes(ByteBuf, int) - Method in class io.netty.buffer.ByteBuf
Transfers this buffer's data to the specified destination starting at the current readerIndex and increases the readerIndex by the number of the transferred bytes (= length).
readBytes(ByteBuf, int, int) - Method in class io.netty.buffer.ByteBuf
Transfers this buffer's data to the specified destination starting at the current readerIndex and increases the readerIndex by the number of the transferred bytes (= length).
readBytes(byte[]) - Method in class io.netty.buffer.ByteBuf
Transfers this buffer's data to the specified destination starting at the current readerIndex and increases the readerIndex by the number of the transferred bytes (= dst.length).
readBytes(byte[], int, int) - Method in class io.netty.buffer.ByteBuf
Transfers this buffer's data to the specified destination starting at the current readerIndex and increases the readerIndex by the number of the transferred bytes (= length).
readBytes(ByteBuffer) - Method in class io.netty.buffer.ByteBuf
Transfers this buffer's data to the specified destination starting at the current readerIndex until the destination's position reaches its limit, and increases the readerIndex by the number of the transferred bytes.
readBytes(OutputStream, int) - Method in class io.netty.buffer.ByteBuf
Transfers this buffer's data to the specified stream starting at the current readerIndex.
readBytes(GatheringByteChannel, int) - Method in class io.netty.buffer.ByteBuf
Transfers this buffer's data to the specified stream starting at the current readerIndex.
readBytes(FileChannel, long, int) - Method in class io.netty.buffer.ByteBuf
Transfers this buffer's data starting at the current readerIndex to the specified channel starting at the given file position.
readBytes() - Method in class io.netty.buffer.ByteBufInputStream
Returns the number of read bytes by this stream so far.
readBytes(ByteBufAllocator, ByteBuf, int) - Static method in class io.netty.buffer.ByteBufUtil
Read the given amount of bytes into a new ByteBuf that is allocated from the ByteBufAllocator.
readBytes(ByteBuf) - Method in class io.netty.buffer.CompositeByteBuf
 
readBytes(ByteBuf, int) - Method in class io.netty.buffer.CompositeByteBuf
 
readBytes(ByteBuf, int, int) - Method in class io.netty.buffer.CompositeByteBuf
 
readBytes(byte[]) - Method in class io.netty.buffer.CompositeByteBuf
 
readBytes(byte[], int, int) - Method in class io.netty.buffer.CompositeByteBuf
 
readBytes(ByteBuffer) - Method in class io.netty.buffer.CompositeByteBuf
 
readBytes(OutputStream, int) - Method in class io.netty.buffer.CompositeByteBuf
 
readBytes(int) - Method in class io.netty.buffer.EmptyByteBuf
 
readBytes(ByteBuf) - Method in class io.netty.buffer.EmptyByteBuf
 
readBytes(ByteBuf, int) - Method in class io.netty.buffer.EmptyByteBuf
 
readBytes(ByteBuf, int, int) - Method in class io.netty.buffer.EmptyByteBuf
 
readBytes(byte[]) - Method in class io.netty.buffer.EmptyByteBuf
 
readBytes(byte[], int, int) - Method in class io.netty.buffer.EmptyByteBuf
 
readBytes(ByteBuffer) - Method in class io.netty.buffer.EmptyByteBuf
 
readBytes(OutputStream, int) - Method in class io.netty.buffer.EmptyByteBuf
 
readBytes(GatheringByteChannel, int) - Method in class io.netty.buffer.EmptyByteBuf
 
readBytes(FileChannel, long, int) - Method in class io.netty.buffer.EmptyByteBuf
 
readBytes(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
readBytes(ByteBuf) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
readBytes(ByteBuf, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
readBytes(ByteBuf, int, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
readBytes(byte[]) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
readBytes(byte[], int, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
readBytes(ByteBuffer) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
readBytes(OutputStream, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
readBytes(GatheringByteChannel, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
readBytes(FileChannel, long, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
readBytes(byte[], int, int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
readBytes(ByteBuffer) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
readBytes(OutputStream, int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
readBytes(GatheringByteChannel, int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
readBytes(FileChannel, long, int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
readBytes(GatheringByteChannel, int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
readBytes(FileChannel, long, int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
readBytes(ByteBuffer) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
readBytes(GatheringByteChannel, int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
readBytes(FileChannel, long, int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
readChar() - Method in class io.netty.buffer.AbstractByteBuf
 
readChar() - Method in class io.netty.buffer.ByteBuf
Gets a 2-byte UTF-16 character at the current readerIndex and increases the readerIndex by 2 in this buffer.
readChar() - Method in class io.netty.buffer.ByteBufInputStream
 
readChar() - Method in class io.netty.buffer.EmptyByteBuf
 
readChar() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
readChar() - Method in class io.netty.handler.codec.serialization.ObjectDecoderInputStream
 
readCharSequence(int, Charset) - Method in class io.netty.buffer.AbstractByteBuf
 
readCharSequence(int, Charset) - Method in class io.netty.buffer.ByteBuf
Gets a CharSequence with the given length at the current readerIndex and increases the readerIndex by the given length.
readCharSequence(int, Charset) - Method in class io.netty.buffer.EmptyByteBuf
 
readCharSequence(int, Charset) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
readChunk(ChannelHandlerContext) - Method in class io.netty.handler.stream.ChunkedFile
Deprecated.
readChunk(ByteBufAllocator) - Method in class io.netty.handler.stream.ChunkedFile
 
readChunk(ChannelHandlerContext) - Method in interface io.netty.handler.stream.ChunkedInput
Deprecated.
Use ChunkedInput.readChunk(ByteBufAllocator).

Fetches a chunked data from the stream. Once this method returns the last chunk and thus the stream has reached at its end, any subsequent ChunkedInput.isEndOfInput() call must return true.

readChunk(ByteBufAllocator) - Method in interface io.netty.handler.stream.ChunkedInput
Fetches a chunked data from the stream.
readChunk(ChannelHandlerContext) - Method in class io.netty.handler.stream.ChunkedNioFile
Deprecated.
readChunk(ByteBufAllocator) - Method in class io.netty.handler.stream.ChunkedNioFile
 
readChunk(ChannelHandlerContext) - Method in class io.netty.handler.stream.ChunkedNioStream
Deprecated.
readChunk(ByteBufAllocator) - Method in class io.netty.handler.stream.ChunkedNioStream
 
readChunk(ChannelHandlerContext) - Method in class io.netty.handler.stream.ChunkedStream
Deprecated.
readChunk(ByteBufAllocator) - Method in class io.netty.handler.stream.ChunkedStream
 
readComplete() - Method in class io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator.MaxMessageHandle
 
readComplete() - Method in class io.netty.channel.RecvByteBufAllocator.DelegatingHandle
 
readComplete() - Method in interface io.netty.channel.RecvByteBufAllocator.Handle
Deprecated.
The read has completed.
readDouble() - Method in class io.netty.buffer.AbstractByteBuf
 
readDouble() - Method in class io.netty.buffer.ByteBuf
Gets a 64-bit floating point number at the current readerIndex and increases the readerIndex by 8 in this buffer.
readDouble() - Method in class io.netty.buffer.ByteBufInputStream
 
readDouble() - Method in class io.netty.buffer.EmptyByteBuf
 
readDouble() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
readDouble() - Method in class io.netty.handler.codec.serialization.ObjectDecoderInputStream
 
READER_IDLE_STATE_EVENT - Static variable in class io.netty.handler.timeout.IdleStateEvent
 
readerIndex() - Method in class io.netty.buffer.AbstractByteBuf
 
readerIndex(int) - Method in class io.netty.buffer.AbstractByteBuf
 
readerIndex() - Method in class io.netty.buffer.ByteBuf
Returns the readerIndex of this buffer.
readerIndex(int) - Method in class io.netty.buffer.ByteBuf
Sets the readerIndex of this buffer.
readerIndex(int) - Method in class io.netty.buffer.CompositeByteBuf
 
readerIndex() - Method in class io.netty.buffer.EmptyByteBuf
 
readerIndex(int) - Method in class io.netty.buffer.EmptyByteBuf
 
readerIndex() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
readerIndex(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
readFloat() - Method in class io.netty.buffer.AbstractByteBuf
 
readFloat() - Method in class io.netty.buffer.ByteBuf
Gets a 32-bit floating point number at the current readerIndex and increases the readerIndex by 4 in this buffer.
readFloat() - Method in class io.netty.buffer.ByteBufInputStream
 
readFloat() - Method in class io.netty.buffer.EmptyByteBuf
 
readFloat() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
readFloat() - Method in class io.netty.handler.codec.serialization.ObjectDecoderInputStream
 
readFully(byte[]) - Method in class io.netty.buffer.ByteBufInputStream
 
readFully(byte[], int, int) - Method in class io.netty.buffer.ByteBufInputStream
 
readFully(byte[], int, int) - Method in class io.netty.handler.codec.serialization.ObjectDecoderInputStream
 
readFully(byte[]) - Method in class io.netty.handler.codec.serialization.ObjectDecoderInputStream
 
readInbound() - Method in class io.netty.channel.embedded.EmbeddedChannel
Return received data from this Channel
readInt() - Method in class io.netty.buffer.AbstractByteBuf
 
readInt() - Method in class io.netty.buffer.ByteBuf
Gets a 32-bit integer at the current readerIndex and increases the readerIndex by 4 in this buffer.
readInt() - Method in class io.netty.buffer.ByteBufInputStream
 
readInt() - Method in class io.netty.buffer.EmptyByteBuf
 
readInt() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
readInt() - Method in class io.netty.handler.codec.serialization.ObjectDecoderInputStream
 
readInterestOp - Variable in class io.netty.channel.nio.AbstractNioChannel
 
readIntLE() - Method in class io.netty.buffer.AbstractByteBuf
 
readIntLE() - Method in class io.netty.buffer.ByteBuf
Gets a 32-bit integer at the current readerIndex in the Little Endian Byte Order and increases the readerIndex by 4 in this buffer.
readIntLE() - Method in class io.netty.buffer.EmptyByteBuf
 
readIntLE() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
readLine() - Method in class io.netty.buffer.ByteBufInputStream
 
readLine() - Method in class io.netty.handler.codec.serialization.ObjectDecoderInputStream
Deprecated.
readLong() - Method in class io.netty.buffer.AbstractByteBuf
 
readLong() - Method in class io.netty.buffer.ByteBuf
Gets a 64-bit integer at the current readerIndex and increases the readerIndex by 8 in this buffer.
readLong() - Method in class io.netty.buffer.ByteBufInputStream
 
readLong() - Method in class io.netty.buffer.EmptyByteBuf
 
readLong() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
readLong() - Method in class io.netty.handler.codec.serialization.ObjectDecoderInputStream
 
readLongLE() - Method in class io.netty.buffer.AbstractByteBuf
 
readLongLE() - Method in class io.netty.buffer.ByteBuf
Gets a 64-bit integer at the current readerIndex in the Little Endian Byte Order and increases the readerIndex by 8 in this buffer.
readLongLE() - Method in class io.netty.buffer.EmptyByteBuf
 
readLongLE() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
readMedium() - Method in class io.netty.buffer.AbstractByteBuf
 
readMedium() - Method in class io.netty.buffer.ByteBuf
Gets a 24-bit medium integer at the current readerIndex and increases the readerIndex by 3 in this buffer.
readMedium() - Method in class io.netty.buffer.EmptyByteBuf
 
readMedium() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
readMediumLE() - Method in class io.netty.buffer.AbstractByteBuf
 
readMediumLE() - Method in class io.netty.buffer.ByteBuf
Gets a 24-bit medium integer at the current readerIndex in the Little Endian Byte Order and increases the readerIndex by 3 in this buffer.
readMediumLE() - Method in class io.netty.buffer.EmptyByteBuf
 
readMediumLE() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
readObject() - Method in class io.netty.handler.codec.serialization.ObjectDecoderInputStream
 
ReadOnlyByteBuf - Class in io.netty.buffer
Deprecated.
Do not use.
ReadOnlyByteBuf(ByteBuf) - Constructor for class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
ReadOnlyIterator<T> - Class in io.netty.util.internal
 
ReadOnlyIterator(Iterator<? extends T>) - Constructor for class io.netty.util.internal.ReadOnlyIterator
 
readOutbound() - Method in class io.netty.channel.embedded.EmbeddedChannel
Read data from the outbound.
readResolve() - Method in class io.netty.util.internal.logging.AbstractInternalLogger
 
readRetainedSlice(int) - Method in class io.netty.buffer.AbstractByteBuf
 
readRetainedSlice(int) - Method in class io.netty.buffer.ByteBuf
Returns a new retained slice of this buffer's sub-region starting at the current readerIndex and increases the readerIndex by the size of the new slice (= length).
readRetainedSlice(int) - Method in class io.netty.buffer.EmptyByteBuf
 
readRetainedSlice(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
readShort() - Method in class io.netty.buffer.AbstractByteBuf
 
readShort() - Method in class io.netty.buffer.ByteBuf
Gets a 16-bit short integer at the current readerIndex and increases the readerIndex by 2 in this buffer.
readShort() - Method in class io.netty.buffer.ByteBufInputStream
 
readShort() - Method in class io.netty.buffer.EmptyByteBuf
 
readShort() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
readShort() - Method in class io.netty.handler.codec.serialization.ObjectDecoderInputStream
 
readShortLE() - Method in class io.netty.buffer.AbstractByteBuf
 
readShortLE() - Method in class io.netty.buffer.ByteBuf
Gets a 16-bit short integer at the current readerIndex in the Little Endian Byte Order and increases the readerIndex by 2 in this buffer.
readShortLE() - Method in class io.netty.buffer.EmptyByteBuf
 
readShortLE() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
readSlice(int) - Method in class io.netty.buffer.AbstractByteBuf
 
readSlice(int) - Method in class io.netty.buffer.ByteBuf
Returns a new slice of this buffer's sub-region starting at the current readerIndex and increases the readerIndex by the size of the new slice (= length).
readSlice(int) - Method in class io.netty.buffer.EmptyByteBuf
 
readSlice(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
readTimedOut(ChannelHandlerContext) - Method in class io.netty.handler.timeout.ReadTimeoutHandler
Is called when a read timeout was detected.
ReadTimeoutException - Exception in io.netty.handler.timeout
A TimeoutException raised by ReadTimeoutHandler when no data was read within a certain period of time.
ReadTimeoutHandler - Class in io.netty.handler.timeout
Raises a ReadTimeoutException when no data was read within a certain period of time.
ReadTimeoutHandler(int) - Constructor for class io.netty.handler.timeout.ReadTimeoutHandler
Creates a new instance.
ReadTimeoutHandler(long, TimeUnit) - Constructor for class io.netty.handler.timeout.ReadTimeoutHandler
Creates a new instance.
readTimeToWait(long, long, long) - Method in class io.netty.handler.traffic.TrafficCounter
Deprecated.
readTimeToWait(long, long, long, long) - Method in class io.netty.handler.traffic.TrafficCounter
Returns the time to wait (if any) for the given length message, using the given limitTraffic and the max wait time.
readUnsignedByte() - Method in class io.netty.buffer.AbstractByteBuf
 
readUnsignedByte() - Method in class io.netty.buffer.ByteBuf
Gets an unsigned byte at the current readerIndex and increases the readerIndex by 1 in this buffer.
readUnsignedByte() - Method in class io.netty.buffer.ByteBufInputStream
 
readUnsignedByte() - Method in class io.netty.buffer.EmptyByteBuf
 
readUnsignedByte() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
readUnsignedByte() - Method in class io.netty.handler.codec.serialization.ObjectDecoderInputStream
 
readUnsignedInt() - Method in class io.netty.buffer.AbstractByteBuf
 
readUnsignedInt() - Method in class io.netty.buffer.ByteBuf
Gets an unsigned 32-bit integer at the current readerIndex and increases the readerIndex by 4 in this buffer.
readUnsignedInt() - Method in class io.netty.buffer.EmptyByteBuf
 
readUnsignedInt() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
readUnsignedIntLE() - Method in class io.netty.buffer.AbstractByteBuf
 
readUnsignedIntLE() - Method in class io.netty.buffer.ByteBuf
Gets an unsigned 32-bit integer at the current readerIndex in the Little Endian Byte Order and increases the readerIndex by 4 in this buffer.
readUnsignedIntLE() - Method in class io.netty.buffer.EmptyByteBuf
 
readUnsignedIntLE() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
readUnsignedMedium() - Method in class io.netty.buffer.AbstractByteBuf
 
readUnsignedMedium() - Method in class io.netty.buffer.ByteBuf
Gets an unsigned 24-bit medium integer at the current readerIndex and increases the readerIndex by 3 in this buffer.
readUnsignedMedium() - Method in class io.netty.buffer.EmptyByteBuf
 
readUnsignedMedium() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
readUnsignedMediumLE() - Method in class io.netty.buffer.AbstractByteBuf
 
readUnsignedMediumLE() - Method in class io.netty.buffer.ByteBuf
Gets an unsigned 24-bit medium integer at the current readerIndex in the Little Endian Byte Order and increases the readerIndex by 3 in this buffer.
readUnsignedMediumLE() - Method in class io.netty.buffer.EmptyByteBuf
 
readUnsignedMediumLE() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
readUnsignedShort() - Method in class io.netty.buffer.AbstractByteBuf
 
readUnsignedShort() - Method in class io.netty.buffer.ByteBuf
Gets an unsigned 16-bit short integer at the current readerIndex and increases the readerIndex by 2 in this buffer.
readUnsignedShort() - Method in class io.netty.buffer.ByteBufInputStream
 
readUnsignedShort() - Method in class io.netty.buffer.EmptyByteBuf
 
readUnsignedShort() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
readUnsignedShort() - Method in class io.netty.handler.codec.serialization.ObjectDecoderInputStream
 
readUnsignedShortLE() - Method in class io.netty.buffer.AbstractByteBuf
 
readUnsignedShortLE() - Method in class io.netty.buffer.ByteBuf
Gets an unsigned 16-bit short integer at the current readerIndex in the Little Endian Byte Order and increases the readerIndex by 2 in this buffer.
readUnsignedShortLE() - Method in class io.netty.buffer.EmptyByteBuf
 
readUnsignedShortLE() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
readUTF() - Method in class io.netty.buffer.ByteBufInputStream
 
readUTF() - Method in class io.netty.handler.codec.serialization.ObjectDecoderInputStream
 
reallocateDirectNoCleaner(ByteBuffer, int) - Static method in class io.netty.util.internal.PlatformDependent
Reallocate a new ByteBuffer with the given capacity.
reallocateMemory(long, long) - Static method in class io.netty.util.internal.PlatformDependent
 
rebuildSelector() - Method in class io.netty.channel.nio.NioEventLoop
Replaces the current Selector of this event loop with newly created Selectors to work around the infamous epoll 100% CPU bug.
rebuildSelectors() - Method in class io.netty.channel.nio.NioEventLoopGroup
Replaces the current Selectors of the child event loops with newly created Selectors to work around the infamous epoll 100% CPU bug.
RECEIPT - Static variable in interface io.netty.handler.codec.stomp.StompHeaders
 
RECEIPT_ID - Static variable in interface io.netty.handler.codec.stomp.StompHeaders
 
receivedAmount() - Method in class io.netty.channel.unix.DatagramSocketAddress
 
recipient() - Method in interface io.netty.channel.AddressedEnvelope
Returns the address of the recipient of this message.
recipient() - Method in class io.netty.channel.DefaultAddressedEnvelope
 
recipient() - Method in class io.netty.handler.codec.dns.DatagramDnsQuery
 
recipient() - Method in class io.netty.handler.codec.dns.DatagramDnsResponse
 
record() - Method in interface io.netty.util.ResourceLeak
Deprecated.
Records the caller's current stack trace so that the ResourceLeakDetector can tell where the leaked resource was accessed lastly.
record(Object) - Method in interface io.netty.util.ResourceLeak
Deprecated.
Records the caller's current stack trace and the specified additional arbitrary information so that the ResourceLeakDetector can tell where the leaked resource was accessed lastly.
record() - Method in interface io.netty.util.ResourceLeakTracker
Records the caller's current stack trace so that the ResourceLeakDetector can tell where the leaked resource was accessed lastly.
record(Object) - Method in interface io.netty.util.ResourceLeakTracker
Records the caller's current stack trace and the specified additional arbitrary information so that the ResourceLeakDetector can tell where the leaked resource was accessed lastly.
recordAt(DnsSection) - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
 
recordAt(DnsSection, int) - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
 
recordAt(DnsSection) - Method in interface io.netty.handler.codec.dns.DnsMessage
Returns the first record in the specified section of this DNS message.
recordAt(DnsSection, int) - Method in interface io.netty.handler.codec.dns.DnsMessage
Returns the record at the specified index of the specified section of this DNS message.
recursionDesired(boolean) - Method in class io.netty.resolver.dns.DnsNameResolverBuilder
Sets if this resolver has to send a DNS query with the RD (recursion desired) flag set.
recvBufAllocHandle() - Method in class io.netty.channel.AbstractChannel.AbstractUnsafe
 
recvBufAllocHandle() - Method in interface io.netty.channel.Channel.Unsafe
Return the assigned RecvByteBufAllocator.Handle which will be used to allocate ByteBuf's when receiving data.
RecvByteBufAllocator - Interface in io.netty.channel
Allocates a new receive buffer whose capacity is probably large enough to read all inbound data and small enough not to waste its space.
RecvByteBufAllocator.DelegatingHandle - Class in io.netty.channel
A RecvByteBufAllocator.Handle which delegates all call to some other RecvByteBufAllocator.Handle.
RecvByteBufAllocator.ExtendedHandle - Interface in io.netty.channel
 
RecvByteBufAllocator.Handle - Interface in io.netty.channel
recvFd() - Method in class io.netty.channel.unix.Socket
 
recvFrom(ByteBuffer, int, int) - Method in class io.netty.channel.unix.Socket
 
recvFromAddress(long, int, int) - Method in class io.netty.channel.unix.Socket
 
RecyclableArrayList - Class in io.netty.util.internal
A simple list which is recyclable.
recycle() - Method in class io.netty.channel.ChannelOutboundBuffer
Deprecated.
recycle() - Method in class io.netty.util.internal.PendingWrite
Clear and recycle this instance.
recycle() - Method in class io.netty.util.internal.RecyclableArrayList
Clear and recycle this instance.
recycle(T) - Method in interface io.netty.util.Recycler.Handle
 
recycle(T, Recycler.Handle<T>) - Method in class io.netty.util.Recycler
recycleAndGet() - Method in class io.netty.util.internal.PendingWrite
Recycle this instance and return the Promise.
Recycler<T> - Class in io.netty.util
Light-weight object pool based on a thread-local stack.
Recycler() - Constructor for class io.netty.util.Recycler
 
Recycler(int) - Constructor for class io.netty.util.Recycler
 
Recycler(int, int) - Constructor for class io.netty.util.Recycler
 
Recycler(int, int, int, int) - Constructor for class io.netty.util.Recycler
 
Recycler.Handle<T> - Interface in io.netty.util
 
RedisArrayAggregator - Class in io.netty.handler.codec.redis
Aggregates RedisMessage parts into ArrayRedisMessage.
RedisArrayAggregator() - Constructor for class io.netty.handler.codec.redis.RedisArrayAggregator
 
RedisBulkStringAggregator - Class in io.netty.handler.codec.redis
A ChannelHandler that aggregates an BulkStringHeaderRedisMessage and its following BulkStringRedisContents into a single FullBulkStringRedisMessage with no following BulkStringRedisContents.
RedisBulkStringAggregator() - Constructor for class io.netty.handler.codec.redis.RedisBulkStringAggregator
Creates a new instance.
RedisCodecException - Exception in io.netty.handler.codec.redis
An Exception which is thrown by RedisEncoder or RedisDecoder.
RedisCodecException(String) - Constructor for exception io.netty.handler.codec.redis.RedisCodecException
Creates a new instance.
RedisCodecException(Throwable) - Constructor for exception io.netty.handler.codec.redis.RedisCodecException
Creates a new instance.
RedisDecoder - Class in io.netty.handler.codec.redis
Decodes the Redis protocol into RedisMessage objects following RESP (REdis Serialization Protocol).
RedisDecoder() - Constructor for class io.netty.handler.codec.redis.RedisDecoder
Creates a new instance with default maxInlineMessageLength and messagePool.
RedisDecoder(int, RedisMessagePool) - Constructor for class io.netty.handler.codec.redis.RedisDecoder
Creates a new instance.
RedisEncoder - Class in io.netty.handler.codec.redis
RedisEncoder() - Constructor for class io.netty.handler.codec.redis.RedisEncoder
Creates a new instance with default messagePool.
RedisEncoder(RedisMessagePool) - Constructor for class io.netty.handler.codec.redis.RedisEncoder
Creates a new instance.
RedisMessage - Interface in io.netty.handler.codec.redis
RedisMessage is base interface for codec-redis.
RedisMessagePool - Interface in io.netty.handler.codec.redis
A strategy interface for caching RedisMessages.
RedisMessageType - Enum in io.netty.handler.codec.redis
refCnt() - Method in class io.netty.buffer.AbstractDerivedByteBuf
Deprecated.
 
refCnt() - Method in class io.netty.buffer.AbstractReferenceCountedByteBuf
 
refCnt() - Method in class io.netty.buffer.DefaultByteBufHolder
 
refCnt() - Method in class io.netty.buffer.EmptyByteBuf
 
refCnt() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
refCnt() - Method in class io.netty.channel.DefaultAddressedEnvelope
 
refCnt() - Method in class io.netty.handler.codec.dns.DefaultDnsRawRecord
 
refCnt() - Method in class io.netty.handler.codec.mqtt.MqttPublishMessage
 
refCnt() - Method in class io.netty.handler.codec.stomp.DefaultStompFrame
 
refCnt() - Method in class io.netty.handler.ssl.PemX509Certificate
 
refCnt() - Method in class io.netty.util.AbstractReferenceCounted
 
refCnt() - Method in interface io.netty.util.ReferenceCounted
Returns the reference count of this object.
refCnt(Object) - Static method in class io.netty.util.ReferenceCountUtil
Returns reference count of a ReferenceCounted object.
ReferenceCounted - Interface in io.netty.util
A reference-counted object that requires explicit deallocation.
ReferenceCountUtil - Class in io.netty.util
Collection of method to handle objects that may implement ReferenceCounted.
ReflectionUtil - Class in io.netty.util.internal
 
ReflectiveChannelFactory<T extends Channel> - Class in io.netty.channel
A ChannelFactory that instantiates a new Channel by invoking its default constructor reflectively.
ReflectiveChannelFactory(Class<? extends T>) - Constructor for class io.netty.channel.ReflectiveChannelFactory
 
REFUSED - Static variable in class io.netty.handler.codec.dns.DnsResponseCode
The 'Refused' DNS RCODE (5), as defined in RFC1035.
regionMatches(int, CharSequence, int, int) - Method in class io.netty.util.AsciiString
Compares the specified string to this string and compares the specified range of characters to determine if they are the same.
regionMatches(boolean, int, CharSequence, int, int) - Method in class io.netty.util.AsciiString
Compares the specified string to this string and compares the specified range of characters to determine if they are the same.
regionMatches(CharSequence, boolean, int, CharSequence, int, int) - Static method in class io.netty.util.AsciiString
This methods make regionMatches operation correctly for any chars in strings
regionMatchesAscii(CharSequence, boolean, int, CharSequence, int, int) - Static method in class io.netty.util.AsciiString
This is optimized version of regionMatches for string with ASCII chars only
register() - Method in class io.netty.bootstrap.AbstractBootstrap
Create a new Channel and register it with an EventLoop.
register(EventLoop, ChannelPromise) - Method in class io.netty.channel.AbstractChannel.AbstractUnsafe
 
register(EventLoop, ChannelPromise) - Method in interface io.netty.channel.Channel.Unsafe
Register the Channel of the ChannelPromise and notify the ChannelFuture once the registration was complete.
register(Channel) - Method in interface io.netty.channel.EventLoopGroup
Register a Channel with this EventLoop.
register(ChannelPromise) - Method in interface io.netty.channel.EventLoopGroup
Register a Channel with this EventLoop using a ChannelFuture.
register(Channel, ChannelPromise) - Method in interface io.netty.channel.EventLoopGroup
Deprecated.
register(Channel) - Method in class io.netty.channel.MultithreadEventLoopGroup
 
register(ChannelPromise) - Method in class io.netty.channel.MultithreadEventLoopGroup
 
register(Channel, ChannelPromise) - Method in class io.netty.channel.MultithreadEventLoopGroup
Deprecated.
register(SelectableChannel, int, NioTask<?>) - Method in class io.netty.channel.nio.NioEventLoop
Registers an arbitrary SelectableChannel, not necessarily created by Netty, to the Selector of this event loop.
register(Channel) - Method in class io.netty.channel.SingleThreadEventLoop
 
register(ChannelPromise) - Method in class io.netty.channel.SingleThreadEventLoop
 
register(Channel, ChannelPromise) - Method in class io.netty.channel.SingleThreadEventLoop
Deprecated.
register(ChannelPromise) - Method in class io.netty.channel.ThreadPerChannelEventLoop
 
register(Channel, ChannelPromise) - Method in class io.netty.channel.ThreadPerChannelEventLoop
Deprecated.
register(Channel) - Method in class io.netty.channel.ThreadPerChannelEventLoopGroup
 
register(ChannelPromise) - Method in class io.netty.channel.ThreadPerChannelEventLoopGroup
 
register(Channel, ChannelPromise) - Method in class io.netty.channel.ThreadPerChannelEventLoopGroup
Deprecated.
reject() - Static method in class io.netty.util.concurrent.RejectedExecutionHandlers
Returns a RejectedExecutionHandler that will always just throw a RejectedExecutionException.
reject() - Static method in class io.netty.util.concurrent.SingleThreadEventExecutor
 
reject(Runnable) - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
Offers the task to the associated RejectedExecutionHandler.
rejected(Runnable, SingleThreadEventExecutor) - Method in interface io.netty.util.concurrent.RejectedExecutionHandler
Called when someone tried to add a task to SingleThreadEventExecutor but this failed due capacity restrictions.
RejectedExecutionHandler - Interface in io.netty.util.concurrent
RejectedExecutionHandlers - Class in io.netty.util.concurrent
Expose helper methods which create different RejectedExecutionHandlers.
release() - Method in class io.netty.buffer.AbstractDerivedByteBuf
Deprecated.
 
release(int) - Method in class io.netty.buffer.AbstractDerivedByteBuf
Deprecated.
 
release() - Method in class io.netty.buffer.AbstractReferenceCountedByteBuf
 
release(int) - Method in class io.netty.buffer.AbstractReferenceCountedByteBuf
 
release() - Method in class io.netty.buffer.DefaultByteBufHolder
 
release(int) - Method in class io.netty.buffer.DefaultByteBufHolder
 
release() - Method in class io.netty.buffer.EmptyByteBuf
 
release(int) - Method in class io.netty.buffer.EmptyByteBuf
 
release() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
release(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
release() - Method in class io.netty.channel.DefaultAddressedEnvelope
 
release(int) - Method in class io.netty.channel.DefaultAddressedEnvelope
 
release(Channel) - Method in interface io.netty.channel.pool.ChannelPool
Release a Channel back to this ChannelPool.
release(Channel, Promise<Void>) - Method in interface io.netty.channel.pool.ChannelPool
Release a Channel back to this ChannelPool.
release(Channel, Promise<Void>) - Method in class io.netty.channel.pool.FixedChannelPool
 
release(Channel) - Method in class io.netty.channel.pool.SimpleChannelPool
 
release(Channel, Promise<Void>) - Method in class io.netty.channel.pool.SimpleChannelPool
 
release() - Method in class io.netty.channel.unix.IovArray
Release the IovArray.
release() - Method in class io.netty.handler.codec.dns.DefaultDnsRawRecord
 
release(int) - Method in class io.netty.handler.codec.dns.DefaultDnsRawRecord
 
release() - Method in class io.netty.handler.codec.mqtt.MqttPublishMessage
 
release(int) - Method in class io.netty.handler.codec.mqtt.MqttPublishMessage
 
release() - Method in class io.netty.handler.codec.stomp.DefaultStompFrame
 
release(int) - Method in class io.netty.handler.codec.stomp.DefaultStompFrame
 
release() - Method in class io.netty.handler.ssl.PemX509Certificate
 
release(int) - Method in class io.netty.handler.ssl.PemX509Certificate
 
release() - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
Release all internal resources of this instance.
release() - Method in class io.netty.handler.traffic.GlobalTrafficShapingHandler
Release all internal resources of this instance.
release() - Method in class io.netty.util.AbstractReferenceCounted
 
release(int) - Method in class io.netty.util.AbstractReferenceCounted
 
release() - Method in interface io.netty.util.ReferenceCounted
Decreases the reference count by 1 and deallocates this object if the reference count reaches at 0.
release(int) - Method in interface io.netty.util.ReferenceCounted
Decreases the reference count by the specified decrement and deallocates this object if the reference count reaches at 0.
release(Object) - Static method in class io.netty.util.ReferenceCountUtil
Try to call ReferenceCounted.release() if the specified message implements ReferenceCounted.
release(Object, int) - Static method in class io.netty.util.ReferenceCountUtil
Try to call ReferenceCounted.release(int) if the specified message implements ReferenceCounted.
releaseAndFailAll(Throwable) - Method in class io.netty.channel.CoalescingBufferQueue
Release all buffers in the queue and complete all listeners and promises.
releaseHealthCheck() - Method in class io.netty.channel.pool.SimpleChannelPool
Indicates whether this pool will check the health of channels before offering them back into the pool.
releaseInbound() - Method in class io.netty.channel.embedded.EmbeddedChannel
Release all buffered inbound messages and return true if any were in the inbound buffer, false otherwise.
releaseLater(T) - Static method in class io.netty.util.ReferenceCountUtil
Deprecated.
this may introduce a lot of memory usage so it is generally preferable to manually release objects.
releaseLater(T, int) - Static method in class io.netty.util.ReferenceCountUtil
Deprecated.
this may introduce a lot of memory usage so it is generally preferable to manually release objects.
releaseOutbound() - Method in class io.netty.channel.embedded.EmbeddedChannel
Release all buffered outbound messages and return true if any were in the outbound buffer, false otherwise.
remainingLength() - Method in class io.netty.handler.codec.mqtt.MqttFixedHeader
 
remoteAddress(SocketAddress) - Method in class io.netty.bootstrap.Bootstrap
The SocketAddress to connect to once the Bootstrap.connect() method is called.
remoteAddress(String, int) - Method in class io.netty.bootstrap.Bootstrap
 
remoteAddress(InetAddress, int) - Method in class io.netty.bootstrap.Bootstrap
 
remoteAddress() - Method in class io.netty.bootstrap.BootstrapConfig
Returns the configured remote address or null if non is configured yet.
remoteAddress() - Method in class io.netty.channel.AbstractChannel.AbstractUnsafe
 
remoteAddress() - Method in class io.netty.channel.AbstractChannel
 
remoteAddress() - Method in class io.netty.channel.AbstractServerChannel
 
remoteAddress() - Method in interface io.netty.channel.Channel
Returns the remote address where this channel is connected to.
remoteAddress() - Method in interface io.netty.channel.Channel.Unsafe
Return the SocketAddress to which is bound remote or null if none is bound yet.
remoteAddress() - Method in class io.netty.channel.epoll.EpollDatagramChannel
 
remoteAddress() - Method in class io.netty.channel.epoll.EpollDomainSocketChannel
 
remoteAddress() - Method in class io.netty.channel.epoll.EpollServerDomainSocketChannel
 
remoteAddress() - Method in class io.netty.channel.epoll.EpollServerSocketChannel
 
remoteAddress() - Method in class io.netty.channel.epoll.EpollSocketChannel
 
remoteAddress() - Method in class io.netty.channel.kqueue.KQueueDatagramChannel
 
remoteAddress() - Method in class io.netty.channel.kqueue.KQueueDomainSocketChannel
 
remoteAddress() - Method in class io.netty.channel.kqueue.KQueueServerDomainSocketChannel
 
remoteAddress() - Method in class io.netty.channel.kqueue.KQueueServerSocketChannel
 
remoteAddress() - Method in class io.netty.channel.kqueue.KQueueSocketChannel
 
remoteAddress() - Method in class io.netty.channel.local.LocalChannel
 
remoteAddress() - Method in class io.netty.channel.local.LocalServerChannel
 
remoteAddress() - Method in interface io.netty.channel.socket.DatagramChannel
 
remoteAddress() - Method in class io.netty.channel.socket.nio.NioDatagramChannel
 
remoteAddress() - Method in class io.netty.channel.socket.nio.NioServerSocketChannel
 
remoteAddress() - Method in class io.netty.channel.socket.nio.NioSocketChannel
 
remoteAddress() - Method in class io.netty.channel.socket.oio.OioDatagramChannel
 
remoteAddress() - Method in class io.netty.channel.socket.oio.OioServerSocketChannel
 
remoteAddress() - Method in class io.netty.channel.socket.oio.OioSocketChannel
 
remoteAddress() - Method in interface io.netty.channel.socket.ServerSocketChannel
 
remoteAddress() - Method in interface io.netty.channel.socket.SocketChannel
 
remoteAddress() - Method in interface io.netty.channel.unix.DomainSocketChannel
 
remoteAddress() - Method in interface io.netty.channel.unix.ServerDomainSocketChannel
 
remoteAddress() - Method in class io.netty.channel.unix.Socket
 
remoteAddress() - Method in exception io.netty.resolver.dns.DnsNameResolverException
Returns the InetSocketAddress of the DNS query that has failed.
remoteAddress0() - Method in class io.netty.channel.AbstractChannel
Return the SocketAddress which the Channel is connected to.
remoteAddress0() - Method in class io.netty.channel.AbstractServerChannel
 
remoteAddress0() - Method in class io.netty.channel.embedded.EmbeddedChannel
 
remoteAddress0() - Method in class io.netty.channel.epoll.AbstractEpollServerChannel
 
remoteAddress0() - Method in class io.netty.channel.epoll.EpollDatagramChannel
 
remoteAddress0() - Method in class io.netty.channel.epoll.EpollDomainSocketChannel
 
remoteAddress0() - Method in class io.netty.channel.epoll.EpollSocketChannel
 
remoteAddress0() - Method in class io.netty.channel.kqueue.AbstractKQueueServerChannel
 
remoteAddress0() - Method in class io.netty.channel.kqueue.KQueueDatagramChannel
 
remoteAddress0() - Method in class io.netty.channel.kqueue.KQueueDomainSocketChannel
 
remoteAddress0() - Method in class io.netty.channel.kqueue.KQueueSocketChannel
 
remoteAddress0() - Method in class io.netty.channel.local.LocalChannel
 
remoteAddress0() - Method in class io.netty.channel.socket.nio.NioDatagramChannel
 
remoteAddress0() - Method in class io.netty.channel.socket.nio.NioServerSocketChannel
 
remoteAddress0() - Method in class io.netty.channel.socket.nio.NioSocketChannel
 
remoteAddress0() - Method in class io.netty.channel.socket.oio.OioDatagramChannel
 
remoteAddress0() - Method in class io.netty.channel.socket.oio.OioServerSocketChannel
 
remoteAddress0() - Method in class io.netty.channel.socket.oio.OioSocketChannel
 
remove() - Method in class io.netty.channel.ChannelOutboundBuffer
Will remove the current message, mark its ChannelPromise as success and return true.
remove(Throwable) - Method in class io.netty.channel.ChannelOutboundBuffer
Will remove the current message, mark its ChannelPromise as failure using the given Throwable and return true.
remove(ChannelHandler) - Method in interface io.netty.channel.ChannelPipeline
Removes the specified ChannelHandler from this pipeline.
remove(String) - Method in interface io.netty.channel.ChannelPipeline
Removes the ChannelHandler with the specified name from this pipeline.
remove(Class<T>) - Method in interface io.netty.channel.ChannelPipeline
Removes the ChannelHandler of the specified type from this pipeline.
remove(int, ChannelPromise) - Method in class io.netty.channel.CoalescingBufferQueue
Remove a ByteBuf from the queue with the specified number of bytes.
remove(ChannelHandler) - Method in class io.netty.channel.DefaultChannelPipeline
 
remove(String) - Method in class io.netty.channel.DefaultChannelPipeline
 
remove(Class<T>) - Method in class io.netty.channel.DefaultChannelPipeline
 
remove(Object) - Method in class io.netty.channel.group.DefaultChannelGroup
 
remove() - Method in class io.netty.channel.PendingWriteQueue
Removes a pending write operation and release it's message via ReferenceCountUtil.safeRelease(Object).
remove(K) - Method in class io.netty.channel.pool.AbstractChannelPoolMap
Remove the ChannelPool from this AbstractChannelPoolMap.
remove() - Method in class io.netty.handler.codec.DefaultHeaders.HeaderEntry
 
remove(K) - Method in class io.netty.handler.codec.DefaultHeaders
 
remove(K) - Method in class io.netty.handler.codec.EmptyHeaders
 
remove(K) - Method in interface io.netty.handler.codec.Headers
Removes all headers with the specified name.
remove() - Method in interface io.netty.util.Attribute
Deprecated.
please consider using Attribute.set(Object) (with value of null).
remove(byte) - Method in class io.netty.util.collection.ByteObjectHashMap
 
remove(Object) - Method in class io.netty.util.collection.ByteObjectHashMap
 
remove(byte) - Method in interface io.netty.util.collection.ByteObjectMap
Removes the entry with the specified key.
remove(char) - Method in class io.netty.util.collection.CharObjectHashMap
 
remove(Object) - Method in class io.netty.util.collection.CharObjectHashMap
 
remove(char) - Method in interface io.netty.util.collection.CharObjectMap
Removes the entry with the specified key.
remove(int) - Method in class io.netty.util.collection.IntObjectHashMap
 
remove(Object) - Method in class io.netty.util.collection.IntObjectHashMap
 
remove(int) - Method in interface io.netty.util.collection.IntObjectMap
Removes the entry with the specified key.
remove(long) - Method in class io.netty.util.collection.LongObjectHashMap
 
remove(Object) - Method in class io.netty.util.collection.LongObjectHashMap
 
remove(long) - Method in interface io.netty.util.collection.LongObjectMap
Removes the entry with the specified key.
remove(short) - Method in class io.netty.util.collection.ShortObjectHashMap
 
remove(Object) - Method in class io.netty.util.collection.ShortObjectHashMap
 
remove(short) - Method in interface io.netty.util.collection.ShortObjectMap
Removes the entry with the specified key.
remove() - Method in class io.netty.util.concurrent.FastThreadLocal
Sets the value to uninitialized; a proceeding call to get() will trigger a call to initialValue().
remove(InternalThreadLocalMap) - Method in class io.netty.util.concurrent.FastThreadLocal
Sets the value to uninitialized for the specified thread local map; a proceeding call to get() will trigger a call to initialValue().
remove(Object) - Method in class io.netty.util.internal.ConcurrentSet
 
remove(Object) - Method in class io.netty.util.internal.DefaultPriorityQueue
 
remove(Object) - Method in class io.netty.util.internal.EmptyPriorityQueue
 
remove() - Method in class io.netty.util.internal.EmptyPriorityQueue
 
remove() - Static method in class io.netty.util.internal.InternalThreadLocalMap
 
remove() - Method in class io.netty.util.internal.ReadOnlyIterator
 
removeAll() - Static method in class io.netty.util.concurrent.FastThreadLocal
Removes all FastThreadLocal variables bound to the current thread.
removeAll(Collection<?>) - Method in class io.netty.util.internal.EmptyPriorityQueue
 
removeAndFail(Throwable) - Method in class io.netty.channel.PendingWriteQueue
Remove a pending write operation and fail it with the given Throwable.
removeAndFailAll(Throwable) - Method in class io.netty.channel.PendingWriteQueue
Remove all pending write operation and fail them with the given Throwable.
removeAndWrite() - Method in class io.netty.channel.PendingWriteQueue
Removes a pending write operation and performs it via ChannelOutboundInvoker.write(Object, ChannelPromise).
removeAndWriteAll() - Method in class io.netty.channel.PendingWriteQueue
Remove all pending write operation and performs them via ChannelOutboundInvoker.write(Object, ChannelPromise).
removeBytes(long) - Method in class io.netty.channel.ChannelOutboundBuffer
Removes the fully written entries and update the reader index of the partially written entry.
removeComponent(int) - Method in class io.netty.buffer.CompositeByteBuf
Remove the ByteBuf from the given index.
removeComponents(int, int) - Method in class io.netty.buffer.CompositeByteBuf
Remove the number of ByteBufs starting from the given index.
removeFirst() - Method in interface io.netty.channel.ChannelPipeline
Removes the first ChannelHandler in this pipeline.
removeFirst() - Method in class io.netty.channel.DefaultChannelPipeline
 
removeInboundHandler() - Method in class io.netty.channel.CombinedChannelDuplexHandler
Removes the ChannelInboundHandler that was combined in this CombinedChannelDuplexHandler.
removeIndexedVariable(int) - Method in class io.netty.util.internal.InternalThreadLocalMap
 
removeLast() - Method in interface io.netty.channel.ChannelPipeline
Removes the last ChannelHandler in this pipeline.
removeLast() - Method in class io.netty.channel.DefaultChannelPipeline
 
removeListener(GenericFutureListener<? extends Future<? super Void>>) - Method in interface io.netty.channel.ChannelFuture
 
removeListener(GenericFutureListener<? extends Future<? super Void>>) - Method in interface io.netty.channel.ChannelProgressiveFuture
 
removeListener(GenericFutureListener<? extends Future<? super Void>>) - Method in interface io.netty.channel.ChannelProgressivePromise
 
removeListener(GenericFutureListener<? extends Future<? super Void>>) - Method in interface io.netty.channel.ChannelPromise
 
removeListener(GenericFutureListener<? extends Future<? super Void>>) - Method in class io.netty.channel.DefaultChannelProgressivePromise
 
removeListener(GenericFutureListener<? extends Future<? super Void>>) - Method in class io.netty.channel.DefaultChannelPromise
 
removeListener(GenericFutureListener<? extends Future<? super Void>>) - Method in interface io.netty.channel.group.ChannelGroupFuture
 
removeListener(GenericFutureListener<? extends Future<? super V>>) - Method in class io.netty.util.concurrent.CompleteFuture
 
removeListener(GenericFutureListener<? extends Future<? super V>>) - Method in class io.netty.util.concurrent.DefaultProgressivePromise
 
removeListener(GenericFutureListener<? extends Future<? super V>>) - Method in class io.netty.util.concurrent.DefaultPromise
 
removeListener(GenericFutureListener<? extends Future<? super V>>) - Method in interface io.netty.util.concurrent.Future
Removes the first occurrence of the specified listener from this future.
removeListener(GenericFutureListener<? extends Future<? super V>>) - Method in interface io.netty.util.concurrent.ProgressiveFuture
 
removeListener(GenericFutureListener<? extends Future<? super V>>) - Method in interface io.netty.util.concurrent.ProgressivePromise
 
removeListener(GenericFutureListener<? extends Future<? super V>>) - Method in interface io.netty.util.concurrent.Promise
 
removeListeners(GenericFutureListener<? extends Future<? super Void>>...) - Method in interface io.netty.channel.ChannelFuture
 
removeListeners(GenericFutureListener<? extends Future<? super Void>>...) - Method in interface io.netty.channel.ChannelProgressiveFuture
 
removeListeners(GenericFutureListener<? extends Future<? super Void>>...) - Method in interface io.netty.channel.ChannelProgressivePromise
 
removeListeners(GenericFutureListener<? extends Future<? super Void>>...) - Method in interface io.netty.channel.ChannelPromise
 
removeListeners(GenericFutureListener<? extends Future<? super Void>>...) - Method in class io.netty.channel.DefaultChannelProgressivePromise
 
removeListeners(GenericFutureListener<? extends Future<? super Void>>...) - Method in class io.netty.channel.DefaultChannelPromise
 
removeListeners(GenericFutureListener<? extends Future<? super Void>>...) - Method in interface io.netty.channel.group.ChannelGroupFuture
 
removeListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in class io.netty.util.concurrent.CompleteFuture
 
removeListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in class io.netty.util.concurrent.DefaultProgressivePromise
 
removeListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in class io.netty.util.concurrent.DefaultPromise
 
removeListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in interface io.netty.util.concurrent.Future
Removes the first occurrence for each of the listeners from this future.
removeListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in interface io.netty.util.concurrent.ProgressiveFuture
 
removeListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in interface io.netty.util.concurrent.ProgressivePromise
 
removeListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in interface io.netty.util.concurrent.Promise
 
removeOutboundHandler() - Method in class io.netty.channel.CombinedChannelDuplexHandler
Removes the ChannelOutboundHandler that was combined in this CombinedChannelDuplexHandler.
removeReadOp() - Method in class io.netty.channel.nio.AbstractNioChannel.AbstractNioUnsafe
 
removeRecord(DnsSection, int) - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
 
removeRecord(DnsSection, int) - Method in interface io.netty.handler.codec.dns.DnsMessage
Removes the record at the specified index of the specified section from this DNS message.
removeShutdownHook(Runnable) - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
Remove a previous added Runnable as a shutdown hook
removeTask(Runnable) - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
 
removeTyped(T) - Method in class io.netty.util.internal.DefaultPriorityQueue
 
removeTyped(T) - Method in class io.netty.util.internal.EmptyPriorityQueue
 
removeTyped(T) - Method in interface io.netty.util.internal.PriorityQueue
Same as Collection.remove(Object) but typed using generics.
renegotiate() - Method in class io.netty.handler.ssl.SslHandler
Performs TLS renegotiation.
renegotiate(Promise<Channel>) - Method in class io.netty.handler.ssl.SslHandler
Performs TLS renegotiation.
reordering() - Method in class io.netty.channel.epoll.EpollTcpInfo
 
replace(ByteBuf) - Method in interface io.netty.buffer.ByteBufHolder
Returns a new ByteBufHolder which contains the specified content.
replace(ByteBuf) - Method in class io.netty.buffer.DefaultByteBufHolder
Returns a new ByteBufHolder which contains the specified content.
replace(ChannelHandler, String, ChannelHandler) - Method in interface io.netty.channel.ChannelPipeline
Replaces the specified ChannelHandler with a new handler in this pipeline.
replace(String, String, ChannelHandler) - Method in interface io.netty.channel.ChannelPipeline
Replaces the ChannelHandler of the specified name with a new handler in this pipeline.
replace(Class<T>, String, ChannelHandler) - Method in interface io.netty.channel.ChannelPipeline
Replaces the ChannelHandler of the specified type with a new handler in this pipeline.
replace(ChannelHandler, String, ChannelHandler) - Method in class io.netty.channel.DefaultChannelPipeline
 
replace(String, String, ChannelHandler) - Method in class io.netty.channel.DefaultChannelPipeline
 
replace(Class<T>, String, ChannelHandler) - Method in class io.netty.channel.DefaultChannelPipeline
 
replace(ByteBuf) - Method in class io.netty.channel.socket.DatagramPacket
 
replace(ByteBuf) - Method in class io.netty.handler.codec.dns.DefaultDnsRawRecord
 
replace(ByteBuf) - Method in interface io.netty.handler.codec.dns.DnsRawRecord
 
REPLACE - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
replace(ByteBuf) - Method in class io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheRequest
 
replace(ByteBuf) - Method in class io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheResponse
 
replace(ByteBuf) - Method in interface io.netty.handler.codec.memcache.binary.FullBinaryMemcacheRequest
 
replace(ByteBuf) - Method in interface io.netty.handler.codec.memcache.binary.FullBinaryMemcacheResponse
 
replace(ByteBuf) - Method in class io.netty.handler.codec.memcache.DefaultLastMemcacheContent
 
replace(ByteBuf) - Method in class io.netty.handler.codec.memcache.DefaultMemcacheContent
 
replace(ByteBuf) - Method in interface io.netty.handler.codec.memcache.FullMemcacheMessage
 
replace(ByteBuf) - Method in interface io.netty.handler.codec.memcache.LastMemcacheContent
 
replace(ByteBuf) - Method in interface io.netty.handler.codec.memcache.MemcacheContent
 
replace(ByteBuf) - Method in class io.netty.handler.codec.mqtt.MqttPublishMessage
 
replace(ByteBuf) - Method in interface io.netty.handler.codec.redis.BulkStringRedisContent
 
replace(ByteBuf) - Method in class io.netty.handler.codec.redis.DefaultBulkStringRedisContent
 
replace(ByteBuf) - Method in class io.netty.handler.codec.redis.DefaultLastBulkStringRedisContent
 
replace(ByteBuf) - Method in class io.netty.handler.codec.redis.FullBulkStringRedisMessage
 
replace(ByteBuf) - Method in interface io.netty.handler.codec.redis.LastBulkStringRedisContent
 
replace(ByteBuf) - Method in class io.netty.handler.codec.smtp.DefaultLastSmtpContent
 
replace(ByteBuf) - Method in class io.netty.handler.codec.smtp.DefaultSmtpContent
 
replace(ByteBuf) - Method in interface io.netty.handler.codec.smtp.LastSmtpContent
 
replace(ByteBuf) - Method in interface io.netty.handler.codec.smtp.SmtpContent
 
replace(ByteBuf) - Method in class io.netty.handler.codec.stomp.DefaultLastStompContentSubframe
 
replace(ByteBuf) - Method in class io.netty.handler.codec.stomp.DefaultStompContentSubframe
 
replace(ByteBuf) - Method in class io.netty.handler.codec.stomp.DefaultStompFrame
 
replace(ByteBuf) - Method in interface io.netty.handler.codec.stomp.LastStompContentSubframe
 
replace(ByteBuf) - Method in interface io.netty.handler.codec.stomp.StompContentSubframe
 
replace(ByteBuf) - Method in interface io.netty.handler.codec.stomp.StompFrame
 
replace(ByteBuf) - Method in class io.netty.handler.ssl.PemPrivateKey
 
replace(ByteBuf) - Method in class io.netty.handler.ssl.PemX509Certificate
 
replace(char, char) - Method in class io.netty.util.AsciiString
Copies this string replacing occurrences of the specified character with another character.
replaceHandler(ChannelHandlerContext, String, SslContext) - Method in class io.netty.handler.ssl.SniHandler
The default implementation of this method will simply replace this SniHandler instance with a SslHandler.
REPLACEQ - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
ReplayingDecoder<S> - Class in io.netty.handler.codec
A specialized variation of ByteToMessageDecoder which enables implementation of a non-blocking decoder in the blocking I/O paradigm.
ReplayingDecoder() - Constructor for class io.netty.handler.codec.ReplayingDecoder
Creates a new instance with no initial state (i.e: null).
ReplayingDecoder(S) - Constructor for class io.netty.handler.codec.ReplayingDecoder
Creates a new instance with the specified initial state.
reportInstancesLeak(String) - Method in class io.netty.util.ResourceLeakDetector
Deprecated.
This method will no longer be invoked by ResourceLeakDetector.
reportTracedLeak(String, String) - Method in class io.netty.util.ResourceLeakDetector
This method is called when a traced leak is detected.
reportUntracedLeak(String) - Method in class io.netty.util.ResourceLeakDetector
This method is called when an untraced leak is detected.
repositoryStatus() - Method in class io.netty.util.Version
 
REQUEST_MAGIC_BYTE - Static variable in class io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheRequest
Default magic byte for a request.
reserved() - Method in interface io.netty.handler.codec.memcache.binary.BinaryMemcacheRequest
Returns the reserved field value.
reserved() - Method in class io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheRequest
 
reset() - Method in class io.netty.buffer.ByteBufInputStream
 
reset(ChannelConfig) - Method in class io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator.MaxMessageHandle
reset(ChannelConfig) - Method in class io.netty.channel.RecvByteBufAllocator.DelegatingHandle
 
reset(ChannelConfig) - Method in interface io.netty.channel.RecvByteBufAllocator.Handle
Deprecated.
Reset any counters that have accumulated and recommend how many messages/bytes should be read for the next read loop.
reset() - Method in class io.netty.handler.codec.compression.Snappy
 
reset() - Method in class io.netty.handler.codec.DateFormatter
 
reset() - Method in class io.netty.handler.codec.serialization.ObjectDecoderInputStream
 
reset() - Method in class io.netty.util.internal.AppendableCharSequence
resetCumulativeTime() - Method in class io.netty.handler.traffic.GlobalChannelTrafficCounter
 
resetCumulativeTime() - Method in class io.netty.handler.traffic.TrafficCounter
Reset both read and written cumulative bytes counters and the associated absolute time from System.currentTimeMillis().
resetDecoder() - Method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheDecoder
Prepare for next decoding iteration.
resetReaderIndex() - Method in class io.netty.buffer.AbstractByteBuf
 
resetReaderIndex() - Method in class io.netty.buffer.ByteBuf
Repositions the current readerIndex to the marked readerIndex in this buffer.
resetReaderIndex() - Method in class io.netty.buffer.CompositeByteBuf
 
resetReaderIndex() - Method in class io.netty.buffer.EmptyByteBuf
 
resetReaderIndex() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
resetWriterIndex() - Method in class io.netty.buffer.AbstractByteBuf
 
resetWriterIndex() - Method in class io.netty.buffer.ByteBuf
Repositions the current writerIndex to the marked writerIndex in this buffer.
resetWriterIndex() - Method in class io.netty.buffer.CompositeByteBuf
 
resetWriterIndex() - Method in class io.netty.buffer.EmptyByteBuf
 
resetWriterIndex() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
resolve(String) - Method in interface io.netty.handler.codec.serialization.ClassResolver
 
resolve(SocketAddress) - Method in class io.netty.resolver.AbstractAddressResolver
 
resolve(SocketAddress, Promise<T>) - Method in class io.netty.resolver.AbstractAddressResolver
 
resolve(SocketAddress) - Method in interface io.netty.resolver.AddressResolver
Resolves the specified address.
resolve(SocketAddress, Promise<T>) - Method in interface io.netty.resolver.AddressResolver
Resolves the specified address.
resolve(String, Iterable<DnsRecord>) - Method in class io.netty.resolver.dns.DnsNameResolver
Resolves the specified name into an address.
resolve(String, Iterable<DnsRecord>, Promise<InetAddress>) - Method in class io.netty.resolver.dns.DnsNameResolver
Resolves the specified name into an address.
resolve(String) - Method in interface io.netty.resolver.NameResolver
Resolves the specified name into an address.
resolve(String, Promise<T>) - Method in interface io.netty.resolver.NameResolver
Resolves the specified name into an address.
resolve(String) - Method in class io.netty.resolver.SimpleNameResolver
 
resolve(String, Promise<T>) - Method in class io.netty.resolver.SimpleNameResolver
 
resolveAll(SocketAddress) - Method in class io.netty.resolver.AbstractAddressResolver
 
resolveAll(SocketAddress, Promise<List<T>>) - Method in class io.netty.resolver.AbstractAddressResolver
 
resolveAll(SocketAddress) - Method in interface io.netty.resolver.AddressResolver
Resolves the specified address.
resolveAll(SocketAddress, Promise<List<T>>) - Method in interface io.netty.resolver.AddressResolver
Resolves the specified address.
resolveAll(String, Iterable<DnsRecord>) - Method in class io.netty.resolver.dns.DnsNameResolver
Resolves the specified host name and port into a list of address.
resolveAll(String, Iterable<DnsRecord>, Promise<List<InetAddress>>) - Method in class io.netty.resolver.dns.DnsNameResolver
Resolves the specified host name and port into a list of address.
resolveAll(String) - Method in interface io.netty.resolver.NameResolver
Resolves the specified host name and port into a list of address.
resolveAll(String, Promise<List<T>>) - Method in interface io.netty.resolver.NameResolver
Resolves the specified host name and port into a list of address.
resolveAll(String) - Method in class io.netty.resolver.SimpleNameResolver
 
resolveAll(String, Promise<List<T>>) - Method in class io.netty.resolver.SimpleNameResolver
 
resolveCache() - Method in class io.netty.resolver.dns.DnsNameResolver
Returns the resolution cache.
resolveCache(DnsCache) - Method in class io.netty.resolver.dns.DnsNameResolverBuilder
Sets the cache for resolution results.
resolvedAddressTypes() - Method in class io.netty.resolver.dns.DnsNameResolver
resolvedAddressTypes(ResolvedAddressTypes) - Method in class io.netty.resolver.dns.DnsNameResolverBuilder
Sets the list of the protocol families of the address resolved.
ResolvedAddressTypes - Enum in io.netty.resolver
Defined resolved address types.
resolver(AddressResolverGroup<?>) - Method in class io.netty.bootstrap.Bootstrap
Sets the NameResolver which will resolve the address of the unresolved named address.
resolver() - Method in class io.netty.bootstrap.BootstrapConfig
Returns the configured AddressResolverGroup or the default if non is configured yet.
ResourceLeak - Interface in io.netty.util
Deprecated.
please use ResourceLeakTracker as it may lead to false-positives.
ResourceLeakDetector<T> - Class in io.netty.util
 
ResourceLeakDetector(Class<?>) - Constructor for class io.netty.util.ResourceLeakDetector
ResourceLeakDetector(String) - Constructor for class io.netty.util.ResourceLeakDetector
ResourceLeakDetector(Class<?>, int, long) - Constructor for class io.netty.util.ResourceLeakDetector
ResourceLeakDetector(Class<?>, int) - Constructor for class io.netty.util.ResourceLeakDetector
This should not be used directly by users of ResourceLeakDetector.
ResourceLeakDetector(String, int, long) - Constructor for class io.netty.util.ResourceLeakDetector
ResourceLeakDetector.Level - Enum in io.netty.util
Represents the level of resource leak detection.
ResourceLeakDetectorFactory - Class in io.netty.util
This static factory should be used to load ResourceLeakDetectors as needed
ResourceLeakDetectorFactory() - Constructor for class io.netty.util.ResourceLeakDetectorFactory
 
ResourceLeakException - Exception in io.netty.util
Deprecated.
This class will be removed in the future version.
ResourceLeakException() - Constructor for exception io.netty.util.ResourceLeakException
Deprecated.
 
ResourceLeakException(String) - Constructor for exception io.netty.util.ResourceLeakException
Deprecated.
 
ResourceLeakException(String, Throwable) - Constructor for exception io.netty.util.ResourceLeakException
Deprecated.
 
ResourceLeakException(Throwable) - Constructor for exception io.netty.util.ResourceLeakException
Deprecated.
 
ResourceLeakHint - Interface in io.netty.util
A hint object that provides human-readable message for easier resource leak tracking.
ResourceLeakTracker<T> - Interface in io.netty.util
 
RESPONSE_MAGIC_BYTE - Static variable in class io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheResponse
Default magic byte for a request.
resumeTransfer() - Method in class io.netty.handler.stream.ChunkedWriteHandler
Continues to fetch the chunks from the input.
retain() - Method in class io.netty.buffer.AbstractDerivedByteBuf
Deprecated.
 
retain(int) - Method in class io.netty.buffer.AbstractDerivedByteBuf
Deprecated.
 
retain() - Method in class io.netty.buffer.AbstractReferenceCountedByteBuf
 
retain(int) - Method in class io.netty.buffer.AbstractReferenceCountedByteBuf
 
retain(int) - Method in class io.netty.buffer.ByteBuf
 
retain() - Method in class io.netty.buffer.ByteBuf
 
retain() - Method in interface io.netty.buffer.ByteBufHolder
 
retain(int) - Method in interface io.netty.buffer.ByteBufHolder
 
retain(int) - Method in class io.netty.buffer.CompositeByteBuf
 
retain() - Method in class io.netty.buffer.CompositeByteBuf
 
retain() - Method in class io.netty.buffer.DefaultByteBufHolder
 
retain(int) - Method in class io.netty.buffer.DefaultByteBufHolder
 
retain() - Method in class io.netty.buffer.EmptyByteBuf
 
retain(int) - Method in class io.netty.buffer.EmptyByteBuf
 
retain() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
retain(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
retain() - Method in interface io.netty.channel.AddressedEnvelope
 
retain(int) - Method in interface io.netty.channel.AddressedEnvelope
 
retain() - Method in class io.netty.channel.DefaultAddressedEnvelope
 
retain(int) - Method in class io.netty.channel.DefaultAddressedEnvelope
 
retain() - Method in class io.netty.channel.DefaultFileRegion
 
retain(int) - Method in class io.netty.channel.DefaultFileRegion
 
retain() - Method in interface io.netty.channel.FileRegion
 
retain(int) - Method in interface io.netty.channel.FileRegion
 
retain() - Method in class io.netty.channel.socket.DatagramPacket
 
retain(int) - Method in class io.netty.channel.socket.DatagramPacket
 
retain() - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
 
retain(int) - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
 
retain() - Method in class io.netty.handler.codec.dns.DatagramDnsQuery
 
retain(int) - Method in class io.netty.handler.codec.dns.DatagramDnsQuery
 
retain() - Method in class io.netty.handler.codec.dns.DatagramDnsResponse
 
retain(int) - Method in class io.netty.handler.codec.dns.DatagramDnsResponse
 
retain() - Method in class io.netty.handler.codec.dns.DefaultDnsQuery
 
retain(int) - Method in class io.netty.handler.codec.dns.DefaultDnsQuery
 
retain() - Method in class io.netty.handler.codec.dns.DefaultDnsRawRecord
 
retain(int) - Method in class io.netty.handler.codec.dns.DefaultDnsRawRecord
 
retain() - Method in class io.netty.handler.codec.dns.DefaultDnsResponse
 
retain(int) - Method in class io.netty.handler.codec.dns.DefaultDnsResponse
 
retain() - Method in interface io.netty.handler.codec.dns.DnsMessage
 
retain(int) - Method in interface io.netty.handler.codec.dns.DnsMessage
 
retain() - Method in interface io.netty.handler.codec.dns.DnsQuery
 
retain(int) - Method in interface io.netty.handler.codec.dns.DnsQuery
 
retain() - Method in interface io.netty.handler.codec.dns.DnsRawRecord
 
retain(int) - Method in interface io.netty.handler.codec.dns.DnsRawRecord
 
retain() - Method in interface io.netty.handler.codec.dns.DnsResponse
 
retain(int) - Method in interface io.netty.handler.codec.dns.DnsResponse
 
retain() - Method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
retain(int) - Method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
retain() - Method in interface io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Increases the reference count by 1.
retain(int) - Method in interface io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Increases the reference count by the specified increment.
retain() - Method in interface io.netty.handler.codec.memcache.binary.BinaryMemcacheRequest
 
retain(int) - Method in interface io.netty.handler.codec.memcache.binary.BinaryMemcacheRequest
 
retain() - Method in interface io.netty.handler.codec.memcache.binary.BinaryMemcacheResponse
 
retain(int) - Method in interface io.netty.handler.codec.memcache.binary.BinaryMemcacheResponse
 
retain() - Method in class io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheRequest
 
retain(int) - Method in class io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheRequest
 
retain() - Method in class io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheResponse
 
retain(int) - Method in class io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheResponse
 
retain() - Method in class io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheRequest
 
retain(int) - Method in class io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheRequest
 
retain() - Method in class io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheResponse
 
retain(int) - Method in class io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheResponse
 
retain(int) - Method in interface io.netty.handler.codec.memcache.binary.FullBinaryMemcacheRequest
 
retain() - Method in interface io.netty.handler.codec.memcache.binary.FullBinaryMemcacheRequest
 
retain(int) - Method in interface io.netty.handler.codec.memcache.binary.FullBinaryMemcacheResponse
 
retain() - Method in interface io.netty.handler.codec.memcache.binary.FullBinaryMemcacheResponse
 
retain() - Method in class io.netty.handler.codec.memcache.DefaultLastMemcacheContent
 
retain(int) - Method in class io.netty.handler.codec.memcache.DefaultLastMemcacheContent
 
retain() - Method in class io.netty.handler.codec.memcache.DefaultMemcacheContent
 
retain(int) - Method in class io.netty.handler.codec.memcache.DefaultMemcacheContent
 
retain(int) - Method in interface io.netty.handler.codec.memcache.FullMemcacheMessage
 
retain() - Method in interface io.netty.handler.codec.memcache.FullMemcacheMessage
 
retain(int) - Method in interface io.netty.handler.codec.memcache.LastMemcacheContent
 
retain() - Method in interface io.netty.handler.codec.memcache.LastMemcacheContent
 
retain() - Method in interface io.netty.handler.codec.memcache.MemcacheContent
 
retain(int) - Method in interface io.netty.handler.codec.memcache.MemcacheContent
 
retain() - Method in interface io.netty.handler.codec.memcache.MemcacheMessage
Increases the reference count by 1.
retain(int) - Method in interface io.netty.handler.codec.memcache.MemcacheMessage
Increases the reference count by the specified increment.
retain() - Method in class io.netty.handler.codec.mqtt.MqttPublishMessage
 
retain(int) - Method in class io.netty.handler.codec.mqtt.MqttPublishMessage
 
retain() - Method in interface io.netty.handler.codec.redis.BulkStringRedisContent
 
retain(int) - Method in interface io.netty.handler.codec.redis.BulkStringRedisContent
 
retain() - Method in class io.netty.handler.codec.redis.DefaultBulkStringRedisContent
 
retain(int) - Method in class io.netty.handler.codec.redis.DefaultBulkStringRedisContent
 
retain() - Method in class io.netty.handler.codec.redis.DefaultLastBulkStringRedisContent
 
retain(int) - Method in class io.netty.handler.codec.redis.DefaultLastBulkStringRedisContent
 
retain() - Method in class io.netty.handler.codec.redis.FullBulkStringRedisMessage
 
retain(int) - Method in class io.netty.handler.codec.redis.FullBulkStringRedisMessage
 
retain() - Method in interface io.netty.handler.codec.redis.LastBulkStringRedisContent
 
retain(int) - Method in interface io.netty.handler.codec.redis.LastBulkStringRedisContent
 
retain() - Method in class io.netty.handler.codec.smtp.DefaultLastSmtpContent
 
retain(int) - Method in class io.netty.handler.codec.smtp.DefaultLastSmtpContent
 
retain() - Method in class io.netty.handler.codec.smtp.DefaultSmtpContent
 
retain(int) - Method in class io.netty.handler.codec.smtp.DefaultSmtpContent
 
retain() - Method in interface io.netty.handler.codec.smtp.LastSmtpContent
 
retain(int) - Method in interface io.netty.handler.codec.smtp.LastSmtpContent
 
retain() - Method in interface io.netty.handler.codec.smtp.SmtpContent
 
retain(int) - Method in interface io.netty.handler.codec.smtp.SmtpContent
 
retain() - Method in class io.netty.handler.codec.stomp.DefaultLastStompContentSubframe
 
retain(int) - Method in class io.netty.handler.codec.stomp.DefaultLastStompContentSubframe
 
retain() - Method in class io.netty.handler.codec.stomp.DefaultStompContentSubframe
 
retain(int) - Method in class io.netty.handler.codec.stomp.DefaultStompContentSubframe
 
retain() - Method in class io.netty.handler.codec.stomp.DefaultStompFrame
 
retain(int) - Method in class io.netty.handler.codec.stomp.DefaultStompFrame
 
retain() - Method in interface io.netty.handler.codec.stomp.LastStompContentSubframe
 
retain(int) - Method in interface io.netty.handler.codec.stomp.LastStompContentSubframe
 
retain() - Method in interface io.netty.handler.codec.stomp.StompContentSubframe
 
retain(int) - Method in interface io.netty.handler.codec.stomp.StompContentSubframe
 
retain() - Method in interface io.netty.handler.codec.stomp.StompFrame
 
retain(int) - Method in interface io.netty.handler.codec.stomp.StompFrame
 
retain() - Method in class io.netty.handler.ssl.PemPrivateKey
 
retain(int) - Method in class io.netty.handler.ssl.PemPrivateKey
 
retain() - Method in class io.netty.handler.ssl.PemX509Certificate
 
retain(int) - Method in class io.netty.handler.ssl.PemX509Certificate
 
retain() - Method in class io.netty.util.AbstractReferenceCounted
 
retain(int) - Method in class io.netty.util.AbstractReferenceCounted
 
retain() - Method in interface io.netty.util.ReferenceCounted
Increases the reference count by 1.
retain(int) - Method in interface io.netty.util.ReferenceCounted
Increases the reference count by the specified increment.
retain(T) - Static method in class io.netty.util.ReferenceCountUtil
Try to call ReferenceCounted.retain() if the specified message implements ReferenceCounted.
retain(T, int) - Static method in class io.netty.util.ReferenceCountUtil
Try to call ReferenceCounted.retain(int) if the specified message implements ReferenceCounted.
retainAll(Collection<?>) - Method in class io.netty.util.internal.EmptyPriorityQueue
 
retained(boolean) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.PublishBuilder
 
retainedDuplicate() - Method in class io.netty.buffer.AbstractByteBuf
 
retainedDuplicate() - Method in class io.netty.buffer.ByteBuf
Returns a retained buffer which shares the whole region of this buffer.
retainedDuplicate() - Method in interface io.netty.buffer.ByteBufHolder
Duplicates this ByteBufHolder.
retainedDuplicate() - Method in class io.netty.buffer.DefaultByteBufHolder
Duplicates this ByteBufHolder.
retainedDuplicate() - Method in class io.netty.buffer.EmptyByteBuf
 
retainedDuplicate() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
retainedDuplicate() - Method in class io.netty.channel.socket.DatagramPacket
 
retainedDuplicate() - Method in class io.netty.handler.codec.dns.DefaultDnsRawRecord
 
retainedDuplicate() - Method in interface io.netty.handler.codec.dns.DnsRawRecord
 
retainedDuplicate() - Method in class io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheRequest
 
retainedDuplicate() - Method in class io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheResponse
 
retainedDuplicate() - Method in interface io.netty.handler.codec.memcache.binary.FullBinaryMemcacheRequest
 
retainedDuplicate() - Method in interface io.netty.handler.codec.memcache.binary.FullBinaryMemcacheResponse
 
retainedDuplicate() - Method in class io.netty.handler.codec.memcache.DefaultLastMemcacheContent
 
retainedDuplicate() - Method in class io.netty.handler.codec.memcache.DefaultMemcacheContent
 
retainedDuplicate() - Method in interface io.netty.handler.codec.memcache.FullMemcacheMessage
 
retainedDuplicate() - Method in interface io.netty.handler.codec.memcache.LastMemcacheContent
 
retainedDuplicate() - Method in interface io.netty.handler.codec.memcache.MemcacheContent
 
retainedDuplicate() - Method in class io.netty.handler.codec.mqtt.MqttPublishMessage
 
retainedDuplicate() - Method in interface io.netty.handler.codec.redis.BulkStringRedisContent
 
retainedDuplicate() - Method in class io.netty.handler.codec.redis.DefaultBulkStringRedisContent
 
retainedDuplicate() - Method in class io.netty.handler.codec.redis.DefaultLastBulkStringRedisContent
 
retainedDuplicate() - Method in class io.netty.handler.codec.redis.FullBulkStringRedisMessage
 
retainedDuplicate() - Method in interface io.netty.handler.codec.redis.LastBulkStringRedisContent
 
retainedDuplicate() - Method in class io.netty.handler.codec.smtp.DefaultLastSmtpContent
 
retainedDuplicate() - Method in class io.netty.handler.codec.smtp.DefaultSmtpContent
 
retainedDuplicate() - Method in interface io.netty.handler.codec.smtp.LastSmtpContent
 
retainedDuplicate() - Method in interface io.netty.handler.codec.smtp.SmtpContent
 
retainedDuplicate() - Method in class io.netty.handler.codec.stomp.DefaultLastStompContentSubframe
 
retainedDuplicate() - Method in class io.netty.handler.codec.stomp.DefaultStompContentSubframe
 
retainedDuplicate() - Method in class io.netty.handler.codec.stomp.DefaultStompFrame
 
retainedDuplicate() - Method in interface io.netty.handler.codec.stomp.LastStompContentSubframe
 
retainedDuplicate() - Method in interface io.netty.handler.codec.stomp.StompContentSubframe
 
retainedDuplicate() - Method in interface io.netty.handler.codec.stomp.StompFrame
 
retainedDuplicate() - Method in class io.netty.handler.ssl.PemPrivateKey
 
retainedDuplicate() - Method in class io.netty.handler.ssl.PemX509Certificate
 
retainedSlice() - Method in class io.netty.buffer.AbstractByteBuf
 
retainedSlice(int, int) - Method in class io.netty.buffer.AbstractByteBuf
 
retainedSlice() - Method in class io.netty.buffer.ByteBuf
Returns a retained slice of this buffer's readable bytes.
retainedSlice(int, int) - Method in class io.netty.buffer.ByteBuf
Returns a retained slice of this buffer's sub-region.
retainedSlice() - Method in class io.netty.buffer.EmptyByteBuf
 
retainedSlice(int, int) - Method in class io.netty.buffer.EmptyByteBuf
 
retainedSlice() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
retainedSlice(int, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
retrans() - Method in class io.netty.channel.epoll.EpollTcpInfo
 
retransmits() - Method in class io.netty.channel.epoll.EpollTcpInfo
 
returnCode(MqttConnectReturnCode) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnAckBuilder
 
rotational(Iterable<? extends InetSocketAddress>) - Static method in class io.netty.resolver.dns.DnsServerAddresses
Returns the DnsServerAddresses that yields the specified addresses in a rotational sequential order.
rotational(InetSocketAddress...) - Static method in class io.netty.resolver.dns.DnsServerAddresses
Returns the DnsServerAddresses that yields the specified addresses in a rotational sequential order.
RoundRobinDnsAddressResolverGroup - Class in io.netty.resolver.dns
A AddressResolverGroup of DnsNameResolvers that supports random selection of destination addresses if multiple are provided by the nameserver.
RoundRobinDnsAddressResolverGroup(Class<? extends DatagramChannel>, DnsServerAddressStreamProvider) - Constructor for class io.netty.resolver.dns.RoundRobinDnsAddressResolverGroup
 
RoundRobinDnsAddressResolverGroup(ChannelFactory<? extends DatagramChannel>, DnsServerAddressStreamProvider) - Constructor for class io.netty.resolver.dns.RoundRobinDnsAddressResolverGroup
 
RoundRobinInetAddressResolver - Class in io.netty.resolver
A NameResolver that resolves InetAddress and force Round Robin by choosing a single address randomly in SimpleNameResolver.resolve(String) and SimpleNameResolver.resolve(String, Promise) if multiple are returned by the NameResolver.
RoundRobinInetAddressResolver(EventExecutor, NameResolver<InetAddress>) - Constructor for class io.netty.resolver.RoundRobinInetAddressResolver
 
RP - Static variable in class io.netty.handler.codec.dns.DnsRecordType
Responsible person record RFC 1183 Information about the responsible person(s) for the domain.
rp1 - Variable in class io.netty.util.internal.InternalThreadLocalMap
 
rp2 - Variable in class io.netty.util.internal.InternalThreadLocalMap
 
rp3 - Variable in class io.netty.util.internal.InternalThreadLocalMap
 
rp4 - Variable in class io.netty.util.internal.InternalThreadLocalMap
 
rp5 - Variable in class io.netty.util.internal.InternalThreadLocalMap
 
rp6 - Variable in class io.netty.util.internal.InternalThreadLocalMap
 
rp7 - Variable in class io.netty.util.internal.InternalThreadLocalMap
 
rp8 - Variable in class io.netty.util.internal.InternalThreadLocalMap
 
rp9 - Variable in class io.netty.util.internal.InternalThreadLocalMap
 
RRSIG - Static variable in class io.netty.handler.codec.dns.DnsRecordType
DNSSEC signature record RFC 4034 Signature for a DNSSEC-secured record set.
RSET - Static variable in class io.netty.handler.codec.smtp.SmtpCommand
 
rset() - Static method in class io.netty.handler.codec.smtp.SmtpRequests
Creates a RSET request.
rto() - Method in class io.netty.channel.epoll.EpollTcpInfo
 
rtt() - Method in class io.netty.channel.epoll.EpollTcpInfo
 
rttvar() - Method in class io.netty.channel.epoll.EpollTcpInfo
 
RuleBasedIpFilter - Class in io.netty.handler.ipfilter
This class allows one to filter new Channels based on the IpFilterRules passed to its constructor.
RuleBasedIpFilter(IpFilterRule...) - Constructor for class io.netty.handler.ipfilter.RuleBasedIpFilter
 
ruleType() - Method in interface io.netty.handler.ipfilter.IpFilterRule
 
ruleType() - Method in class io.netty.handler.ipfilter.IpSubnetFilterRule
 
run() - Method in class io.netty.channel.DefaultEventLoop
 
run() - Method in class io.netty.channel.nio.NioEventLoop
 
run() - Method in class io.netty.channel.ThreadPerChannelEventLoop
 
run() - Method in class io.netty.util.concurrent.DefaultEventExecutor
 
run() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
 
run(Timeout) - Method in interface io.netty.util.TimerTask
Executed after the delay specified with Timer.newTimeout(TimerTask, long, TimeUnit).
runAllTasks() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
Poll all tasks from the task queue and run them via Runnable.run() method.
runAllTasks(long) - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
Poll all tasks from the task queue and run them via Runnable.run() method.
runAllTasksFrom(Queue<Runnable>) - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
Runs all tasks from the passed taskQueue.
runPendingTasks() - Method in class io.netty.channel.embedded.EmbeddedChannel
Run all tasks (which also includes scheduled tasks) that are pending in the EventLoop for this Channel
runScheduledPendingTasks() - Method in class io.netty.channel.embedded.EmbeddedChannel
Run all pending scheduled tasks in the EventLoop for this Channel and return the nanoseconds when the next scheduled task is ready to run.

S

sacked() - Method in class io.netty.channel.epoll.EpollTcpInfo
 
safeExecute(Runnable) - Static method in class io.netty.util.concurrent.AbstractEventExecutor
Try to execute the given Runnable and just log if it throws a Throwable.
safeFindNextPositivePowerOfTwo(int) - Static method in class io.netty.util.internal.MathUtil
Fast method of finding the next power of 2 greater than or equal to the supplied value.
safeRelease(Object) - Static method in class io.netty.util.ReferenceCountUtil
Try to call ReferenceCounted.release() if the specified message implements ReferenceCounted.
safeRelease(Object, int) - Static method in class io.netty.util.ReferenceCountUtil
Try to call ReferenceCounted.release(int) if the specified message implements ReferenceCounted.
safeSetFailure(ChannelPromise, Throwable) - Method in class io.netty.channel.AbstractChannel.AbstractUnsafe
Marks the specified promise as failure.
safeSetSuccess(ChannelPromise) - Method in class io.netty.channel.AbstractChannel.AbstractUnsafe
Marks the specified promise as success.
SASL_AUTH - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
SASL_LIST_MECHS - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
SASL_STEP - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
schedule(Runnable, long, TimeUnit) - Method in class io.netty.util.concurrent.AbstractEventExecutor
 
schedule(Callable<V>, long, TimeUnit) - Method in class io.netty.util.concurrent.AbstractEventExecutor
 
schedule(Runnable, long, TimeUnit) - Method in class io.netty.util.concurrent.AbstractEventExecutorGroup
 
schedule(Callable<V>, long, TimeUnit) - Method in class io.netty.util.concurrent.AbstractEventExecutorGroup
 
schedule(Runnable, long, TimeUnit) - Method in class io.netty.util.concurrent.AbstractScheduledEventExecutor
 
schedule(Callable<V>, long, TimeUnit) - Method in class io.netty.util.concurrent.AbstractScheduledEventExecutor
 
schedule(Runnable, long, TimeUnit) - Method in interface io.netty.util.concurrent.EventExecutorGroup
 
schedule(Callable<V>, long, TimeUnit) - Method in interface io.netty.util.concurrent.EventExecutorGroup
 
schedule(Runnable, long, TimeUnit) - Method in class io.netty.util.concurrent.NonStickyEventExecutorGroup
 
schedule(Callable<V>, long, TimeUnit) - Method in class io.netty.util.concurrent.NonStickyEventExecutorGroup
 
schedule(Runnable, long, TimeUnit) - Method in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor
 
schedule(Callable<V>, long, TimeUnit) - Method in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class io.netty.util.concurrent.AbstractEventExecutor
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class io.netty.util.concurrent.AbstractEventExecutorGroup
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class io.netty.util.concurrent.AbstractScheduledEventExecutor
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in interface io.netty.util.concurrent.EventExecutorGroup
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class io.netty.util.concurrent.NonStickyEventExecutorGroup
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor
 
ScheduledFuture<V> - Interface in io.netty.util.concurrent
The result of an scheduled asynchronous operation.
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class io.netty.util.concurrent.AbstractEventExecutor
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class io.netty.util.concurrent.AbstractEventExecutorGroup
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class io.netty.util.concurrent.AbstractScheduledEventExecutor
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in interface io.netty.util.concurrent.EventExecutorGroup
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class io.netty.util.concurrent.NonStickyEventExecutorGroup
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor
 
scopeId() - Method in class io.netty.channel.unix.NativeInetAddress
 
scopePrefixLength() - Method in class io.netty.handler.codec.dns.DefaultDnsOptEcsRecord
 
scopePrefixLength() - Method in interface io.netty.handler.codec.dns.DnsOptEcsRecord
Returns the leftmost number of significant bits of ADDRESS that the response covers.
searchDomains(Iterable<String>) - Method in class io.netty.resolver.dns.DnsNameResolverBuilder
Set the list of search domains of the resolver.
SELECT - Static variable in interface io.netty.channel.SelectStrategy
Indicates a blocking select should follow.
select(List<String>) - Method in interface io.netty.handler.ssl.JdkApplicationProtocolNegotiator.ProtocolSelector
Callback invoked to select the application level protocol from the protocols provided.
selected(String) - Method in interface io.netty.handler.ssl.JdkApplicationProtocolNegotiator.ProtocolSelectionListener
Callback invoked to let this application know the protocol chosen by the peer.
selectedListenerFailureBehavior() - Method in class io.netty.handler.ssl.ApplicationProtocolConfig
Get the desired behavior for the peer who is notified of the selected protocol.
selectedListenerFailureBehavior() - Method in interface io.netty.handler.ssl.OpenSslApplicationProtocolNegotiator
Get the desired behavior for the peer who is notified of the selected protocol.
selectedListenerFailureBehavior() - Method in class io.netty.handler.ssl.OpenSslDefaultApplicationProtocolNegotiator
 
selectedListenerFailureBehavior() - Method in class io.netty.handler.ssl.OpenSslNpnApplicationProtocolNegotiator
Deprecated.
 
selectionKey() - Method in class io.netty.channel.nio.AbstractNioChannel
Return the current SelectionKey
selectorFailureBehavior() - Method in class io.netty.handler.ssl.ApplicationProtocolConfig
Get the desired behavior for the peer who selects the application protocol.
selectorFailureBehavior() - Method in interface io.netty.handler.ssl.OpenSslApplicationProtocolNegotiator
Get the desired behavior for the peer who selects the application protocol.
selectorFailureBehavior() - Method in class io.netty.handler.ssl.OpenSslDefaultApplicationProtocolNegotiator
 
selectorFailureBehavior() - Method in class io.netty.handler.ssl.OpenSslNpnApplicationProtocolNegotiator
Deprecated.
 
selectorProvider() - Method in class io.netty.channel.nio.NioEventLoop
Returns the SelectorProvider used by this NioEventLoop to obtain the Selector.
SelectStrategy - Interface in io.netty.channel
Select strategy interface.
SelectStrategyFactory - Interface in io.netty.channel
Factory that creates a new SelectStrategy every time.
SelfSignedCertificate - Class in io.netty.handler.ssl.util
Generates a temporary self-signed certificate for testing purposes.
SelfSignedCertificate() - Constructor for class io.netty.handler.ssl.util.SelfSignedCertificate
Creates a new instance.
SelfSignedCertificate(Date, Date) - Constructor for class io.netty.handler.ssl.util.SelfSignedCertificate
Creates a new instance.
SelfSignedCertificate(String) - Constructor for class io.netty.handler.ssl.util.SelfSignedCertificate
Creates a new instance.
SelfSignedCertificate(String, Date, Date) - Constructor for class io.netty.handler.ssl.util.SelfSignedCertificate
Creates a new instance.
SelfSignedCertificate(String, SecureRandom, int) - Constructor for class io.netty.handler.ssl.util.SelfSignedCertificate
Creates a new instance.
SelfSignedCertificate(String, SecureRandom, int, Date, Date) - Constructor for class io.netty.handler.ssl.util.SelfSignedCertificate
Creates a new instance.
sender() - Method in interface io.netty.channel.AddressedEnvelope
Returns the address of the sender of this message.
sender() - Method in class io.netty.channel.DefaultAddressedEnvelope
 
sender() - Method in class io.netty.handler.codec.dns.DatagramDnsQuery
 
sender() - Method in class io.netty.handler.codec.dns.DatagramDnsResponse
 
sendFd(int) - Method in class io.netty.channel.unix.Socket
 
sendfile(int, DefaultFileRegion, long, long, long) - Static method in class io.netty.channel.epoll.Native
 
sendmmsg(int, NativeDatagramPacketArray.NativeDatagramPacket[], int, int) - Static method in class io.netty.channel.epoll.Native
 
sendTo(ByteBuffer, int, int, InetAddress, int) - Method in class io.netty.channel.unix.Socket
 
sendToAddress(long, int, int, InetAddress, int) - Method in class io.netty.channel.unix.Socket
 
sendToAddresses(long, int, InetAddress, int) - Method in class io.netty.channel.unix.Socket
 
sequential(Iterable<? extends InetSocketAddress>) - Static method in class io.netty.resolver.dns.DnsServerAddresses
Returns the DnsServerAddresses that yields the specified addresses sequentially.
sequential(InetSocketAddress...) - Static method in class io.netty.resolver.dns.DnsServerAddresses
Returns the DnsServerAddresses that yields the specified addresses sequentially.
SequentialDnsServerAddressStreamProvider - Class in io.netty.resolver.dns
A DnsServerAddressStreamProvider which is backed by a sequential list of DNS servers.
SequentialDnsServerAddressStreamProvider(InetSocketAddress...) - Constructor for class io.netty.resolver.dns.SequentialDnsServerAddressStreamProvider
Create a new instance.
SequentialDnsServerAddressStreamProvider(Iterable<? extends InetSocketAddress>) - Constructor for class io.netty.resolver.dns.SequentialDnsServerAddressStreamProvider
Create a new instance.
SERVER - Static variable in interface io.netty.handler.codec.stomp.StompHeaders
 
ServerBootstrap - Class in io.netty.bootstrap
Bootstrap sub-class which allows easy bootstrap of ServerChannel
ServerBootstrap() - Constructor for class io.netty.bootstrap.ServerBootstrap
 
ServerBootstrapConfig - Class in io.netty.bootstrap
Exposes the configuration of a ServerBootstrapConfig.
ServerChannel - Interface in io.netty.channel
A Channel that accepts an incoming connection attempt and creates its child Channels by accepting them.
ServerDomainSocketChannel - Interface in io.netty.channel.unix
ServerSocketChannel - Interface in io.netty.channel.socket
A TCP/IP ServerChannel which accepts incoming TCP/IP connections.
ServerSocketChannelConfig - Interface in io.netty.channel.socket
SERVFAIL - Static variable in class io.netty.handler.codec.dns.DnsResponseCode
The 'ServFail' DNS RCODE (2), as defined in RFC1035.
SESSION - Static variable in interface io.netty.handler.codec.stomp.StompHeaders
 
sessionCacheSize() - Method in class io.netty.handler.ssl.DelegatingSslContext
 
sessionCacheSize() - Method in class io.netty.handler.ssl.JdkSslContext
 
sessionCacheSize() - Method in class io.netty.handler.ssl.SslContext
Returns the size of the cache used for storing SSL session objects.
sessionCacheSize(long) - Method in class io.netty.handler.ssl.SslContextBuilder
Set the size of the cache used for storing SSL session objects.
sessionContext() - Method in class io.netty.handler.ssl.DelegatingSslContext
 
sessionContext() - Method in class io.netty.handler.ssl.JdkSslContext
Returns the JDK SSLSessionContext object held by this context.
sessionContext() - Method in class io.netty.handler.ssl.SslContext
Returns the SSLSessionContext object held by this context.
sessionPresent(boolean) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnAckBuilder
 
sessionTimeout() - Method in class io.netty.handler.ssl.DelegatingSslContext
 
sessionTimeout() - Method in class io.netty.handler.ssl.JdkSslContext
 
sessionTimeout() - Method in class io.netty.handler.ssl.SslContext
Returns the timeout for the cached SSL session objects, in seconds.
sessionTimeout(long) - Method in class io.netty.handler.ssl.SslContextBuilder
Set the timeout for the cached SSL session objects, in seconds.
set(K, V) - Method in class io.netty.handler.codec.DefaultHeaders
 
set(K, Iterable<? extends V>) - Method in class io.netty.handler.codec.DefaultHeaders
 
set(K, V...) - Method in class io.netty.handler.codec.DefaultHeaders
 
set(Headers<? extends K, ? extends V, ?>) - Method in class io.netty.handler.codec.DefaultHeaders
 
set(K, V) - Method in class io.netty.handler.codec.EmptyHeaders
 
set(K, Iterable<? extends V>) - Method in class io.netty.handler.codec.EmptyHeaders
 
set(K, V...) - Method in class io.netty.handler.codec.EmptyHeaders
 
set(Headers<? extends K, ? extends V, ?>) - Method in class io.netty.handler.codec.EmptyHeaders
 
set(K, V) - Method in interface io.netty.handler.codec.Headers
Sets a header with the specified name and value.
set(K, Iterable<? extends V>) - Method in interface io.netty.handler.codec.Headers
Sets a new header with the specified name and values.
set(K, V...) - Method in interface io.netty.handler.codec.Headers
Sets a header with the specified name and values.
set(Headers<? extends K, ? extends V, ?>) - Method in interface io.netty.handler.codec.Headers
Clears the current header entries and copies all header entries of the specified headers.
SET - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
set(T) - Method in interface io.netty.util.Attribute
Sets the value
set(V) - Method in class io.netty.util.concurrent.FastThreadLocal
Set the value for the current thread.
set(InternalThreadLocalMap, V) - Method in class io.netty.util.concurrent.FastThreadLocal
Set the value for the specified thread local map.
set(int, Object) - Method in class io.netty.util.internal.RecyclableArrayList
 
setAcceptFilter(AcceptFilter) - Method in class io.netty.channel.kqueue.KQueueServerSocketChannelConfig
 
setAll(Headers<? extends K, ? extends V, ?>) - Method in class io.netty.handler.codec.DefaultHeaders
 
setAll(Headers<? extends K, ? extends V, ?>) - Method in class io.netty.handler.codec.EmptyHeaders
 
setAll(Headers<? extends K, ? extends V, ?>) - Method in interface io.netty.handler.codec.Headers
Retains all current headers but calls #set(K, V) for each entry in headers.
setAllocator(ByteBufAllocator) - Method in interface io.netty.channel.ChannelConfig
Set the ByteBufAllocator which is used for the channel to allocate buffers.
setAllocator(ByteBufAllocator) - Method in class io.netty.channel.DefaultChannelConfig
 
setAllocator(ByteBufAllocator) - Method in class io.netty.channel.epoll.EpollChannelConfig
 
setAllocator(ByteBufAllocator) - Method in class io.netty.channel.epoll.EpollDatagramChannelConfig
 
setAllocator(ByteBufAllocator) - Method in class io.netty.channel.epoll.EpollDomainSocketChannelConfig
 
setAllocator(ByteBufAllocator) - Method in class io.netty.channel.epoll.EpollServerChannelConfig
 
setAllocator(ByteBufAllocator) - Method in class io.netty.channel.epoll.EpollServerSocketChannelConfig
 
setAllocator(ByteBufAllocator) - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
 
setAllocator(ByteBufAllocator) - Method in class io.netty.channel.kqueue.KQueueChannelConfig
 
setAllocator(ByteBufAllocator) - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
 
setAllocator(ByteBufAllocator) - Method in class io.netty.channel.kqueue.KQueueDomainSocketChannelConfig
 
setAllocator(ByteBufAllocator) - Method in class io.netty.channel.kqueue.KQueueServerChannelConfig
 
setAllocator(ByteBufAllocator) - Method in class io.netty.channel.kqueue.KQueueServerSocketChannelConfig
 
setAllocator(ByteBufAllocator) - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
 
setAllocator(ByteBufAllocator) - Method in interface io.netty.channel.socket.DatagramChannelConfig
 
setAllocator(ByteBufAllocator) - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
 
setAllocator(ByteBufAllocator) - Method in class io.netty.channel.socket.DefaultServerSocketChannelConfig
 
setAllocator(ByteBufAllocator) - Method in class io.netty.channel.socket.DefaultSocketChannelConfig
 
setAllocator(ByteBufAllocator) - Method in class io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig
 
setAllocator(ByteBufAllocator) - Method in class io.netty.channel.socket.oio.DefaultOioSocketChannelConfig
 
setAllocator(ByteBufAllocator) - Method in interface io.netty.channel.socket.oio.OioServerSocketChannelConfig
 
setAllocator(ByteBufAllocator) - Method in interface io.netty.channel.socket.oio.OioSocketChannelConfig
 
setAllocator(ByteBufAllocator) - Method in interface io.netty.channel.socket.ServerSocketChannelConfig
 
setAllocator(ByteBufAllocator) - Method in interface io.netty.channel.socket.SocketChannelConfig
 
setAllocator(ByteBufAllocator) - Method in interface io.netty.channel.unix.DomainSocketChannelConfig
 
setAllowHalfClosure(boolean) - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
 
setAllowHalfClosure(boolean) - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
 
setAllowHalfClosure(boolean) - Method in class io.netty.channel.socket.DefaultSocketChannelConfig
 
setAllowHalfClosure(boolean) - Method in class io.netty.channel.socket.oio.DefaultOioSocketChannelConfig
 
setAllowHalfClosure(boolean) - Method in interface io.netty.channel.socket.oio.OioSocketChannelConfig
 
setAllowHalfClosure(boolean) - Method in interface io.netty.channel.socket.SocketChannelConfig
Sets whether the channel should not close itself when its remote peer shuts down output to make the connection half-closed.
setAuthoritativeAnswer(boolean) - Method in class io.netty.handler.codec.dns.DatagramDnsResponse
 
setAuthoritativeAnswer(boolean) - Method in class io.netty.handler.codec.dns.DefaultDnsResponse
 
setAuthoritativeAnswer(boolean) - Method in interface io.netty.handler.codec.dns.DnsResponse
Set to true if responding server is authoritative for the domain name in the query message.
setAutoClose(boolean) - Method in interface io.netty.channel.ChannelConfig
Deprecated.
Auto close will be removed in a future release. Sets whether the Channel should be closed automatically and immediately on write failure. The default is false.
setAutoClose(boolean) - Method in class io.netty.channel.DefaultChannelConfig
 
setAutoClose(boolean) - Method in class io.netty.channel.epoll.EpollDatagramChannelConfig
 
setAutoClose(boolean) - Method in class io.netty.channel.epoll.EpollDomainSocketChannelConfig
 
setAutoClose(boolean) - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
 
setAutoClose(boolean) - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
 
setAutoClose(boolean) - Method in class io.netty.channel.kqueue.KQueueDomainSocketChannelConfig
 
setAutoClose(boolean) - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
 
setAutoClose(boolean) - Method in interface io.netty.channel.socket.DatagramChannelConfig
 
setAutoClose(boolean) - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
 
setAutoClose(boolean) - Method in class io.netty.channel.socket.DefaultSocketChannelConfig
 
setAutoClose(boolean) - Method in class io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig
 
setAutoClose(boolean) - Method in class io.netty.channel.socket.oio.DefaultOioSocketChannelConfig
 
setAutoClose(boolean) - Method in interface io.netty.channel.socket.oio.OioServerSocketChannelConfig
 
setAutoClose(boolean) - Method in interface io.netty.channel.socket.oio.OioSocketChannelConfig
 
setAutoClose(boolean) - Method in interface io.netty.channel.socket.SocketChannelConfig
 
setAutoClose(boolean) - Method in interface io.netty.channel.unix.DomainSocketChannelConfig
 
setAutoRead(boolean) - Method in interface io.netty.channel.ChannelConfig
Sets if ChannelHandlerContext.read() will be invoked automatically so that a user application doesn't need to call it at all.
setAutoRead(boolean) - Method in class io.netty.channel.DefaultChannelConfig
 
setAutoRead(boolean) - Method in class io.netty.channel.epoll.EpollChannelConfig
 
setAutoRead(boolean) - Method in class io.netty.channel.epoll.EpollDatagramChannelConfig
 
setAutoRead(boolean) - Method in class io.netty.channel.epoll.EpollDomainSocketChannelConfig
 
setAutoRead(boolean) - Method in class io.netty.channel.epoll.EpollServerChannelConfig
 
setAutoRead(boolean) - Method in class io.netty.channel.epoll.EpollServerSocketChannelConfig
 
setAutoRead(boolean) - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
 
setAutoRead(boolean) - Method in class io.netty.channel.kqueue.KQueueChannelConfig
 
setAutoRead(boolean) - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
 
setAutoRead(boolean) - Method in class io.netty.channel.kqueue.KQueueDomainSocketChannelConfig
 
setAutoRead(boolean) - Method in class io.netty.channel.kqueue.KQueueServerChannelConfig
 
setAutoRead(boolean) - Method in class io.netty.channel.kqueue.KQueueServerSocketChannelConfig
 
setAutoRead(boolean) - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
 
setAutoRead(boolean) - Method in interface io.netty.channel.socket.DatagramChannelConfig
 
setAutoRead(boolean) - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
 
setAutoRead(boolean) - Method in class io.netty.channel.socket.DefaultServerSocketChannelConfig
 
setAutoRead(boolean) - Method in class io.netty.channel.socket.DefaultSocketChannelConfig
 
setAutoRead(boolean) - Method in class io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig
 
setAutoRead(boolean) - Method in class io.netty.channel.socket.oio.DefaultOioSocketChannelConfig
 
setAutoRead(boolean) - Method in interface io.netty.channel.socket.oio.OioServerSocketChannelConfig
 
setAutoRead(boolean) - Method in interface io.netty.channel.socket.oio.OioSocketChannelConfig
 
setAutoRead(boolean) - Method in interface io.netty.channel.socket.ServerSocketChannelConfig
 
setAutoRead(boolean) - Method in interface io.netty.channel.socket.SocketChannelConfig
 
setAutoRead(boolean) - Method in interface io.netty.channel.unix.DomainSocketChannelConfig
 
setAvailableProcessors(int) - Static method in class io.netty.util.NettyRuntime
Set the number of available processors.
setBacklog(int) - Method in class io.netty.channel.epoll.EpollServerChannelConfig
 
setBacklog(int) - Method in class io.netty.channel.epoll.EpollServerSocketChannelConfig
 
setBacklog(int) - Method in class io.netty.channel.kqueue.KQueueServerChannelConfig
 
setBacklog(int) - Method in class io.netty.channel.kqueue.KQueueServerSocketChannelConfig
 
setBacklog(int) - Method in class io.netty.channel.socket.DefaultServerSocketChannelConfig
 
setBacklog(int) - Method in class io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig
 
setBacklog(int) - Method in interface io.netty.channel.socket.oio.OioServerSocketChannelConfig
 
setBacklog(int) - Method in interface io.netty.channel.socket.ServerSocketChannelConfig
Sets the backlog value to specify when the channel binds to a local address.
setBoolean(int, boolean) - Method in class io.netty.buffer.AbstractByteBuf
 
setBoolean(int, boolean) - Method in class io.netty.buffer.ByteBuf
Sets the specified boolean at the specified absolute index in this buffer.
setBoolean(int, boolean) - Method in class io.netty.buffer.CompositeByteBuf
 
setBoolean(int, boolean) - Method in class io.netty.buffer.EmptyByteBuf
 
setBoolean(int, boolean) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
setBoolean(K, boolean) - Method in class io.netty.handler.codec.DefaultHeaders
 
setBoolean(K, boolean) - Method in class io.netty.handler.codec.EmptyHeaders
 
setBoolean(K, boolean) - Method in interface io.netty.handler.codec.Headers
Set the name to value.
setBroadcast(boolean) - Method in class io.netty.channel.epoll.EpollDatagramChannelConfig
 
setBroadcast(boolean) - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
 
setBroadcast(boolean) - Method in interface io.netty.channel.socket.DatagramChannelConfig
setBroadcast(boolean) - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
 
setBroadcast(boolean) - Method in class io.netty.channel.unix.Socket
 
setByte(int, int) - Method in class io.netty.buffer.AbstractByteBuf
 
setByte(int, int) - Method in class io.netty.buffer.ByteBuf
Sets the specified byte at the specified absolute index in this buffer.
setByte(int, int) - Method in class io.netty.buffer.CompositeByteBuf
 
setByte(int, int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
setByte(int, int) - Method in class io.netty.buffer.EmptyByteBuf
 
setByte(int, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
setByte(int, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
setByte(int, int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
setByte(int, int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
setByte(K, byte) - Method in class io.netty.handler.codec.DefaultHeaders
 
setByte(K, byte) - Method in class io.netty.handler.codec.EmptyHeaders
 
setByte(K, byte) - Method in interface io.netty.handler.codec.Headers
Set the name to value.
setBytes(int, byte[]) - Method in class io.netty.buffer.AbstractByteBuf
 
setBytes(int, ByteBuf) - Method in class io.netty.buffer.AbstractByteBuf
 
setBytes(int, ByteBuf, int) - Method in class io.netty.buffer.AbstractByteBuf
 
setBytes(int, ByteBuf) - Method in class io.netty.buffer.ByteBuf
Transfers the specified source buffer's data to this buffer starting at the specified absolute index until the source buffer becomes unreadable.
setBytes(int, ByteBuf, int) - Method in class io.netty.buffer.ByteBuf
Transfers the specified source buffer's data to this buffer starting at the specified absolute index.
setBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.ByteBuf
Transfers the specified source buffer's data to this buffer starting at the specified absolute index.
setBytes(int, byte[]) - Method in class io.netty.buffer.ByteBuf
Transfers the specified source array's data to this buffer starting at the specified absolute index.
setBytes(int, byte[], int, int) - Method in class io.netty.buffer.ByteBuf
Transfers the specified source array's data to this buffer starting at the specified absolute index.
setBytes(int, ByteBuffer) - Method in class io.netty.buffer.ByteBuf
Transfers the specified source buffer's data to this buffer starting at the specified absolute index until the source buffer's position reaches its limit.
setBytes(int, InputStream, int) - Method in class io.netty.buffer.ByteBuf
Transfers the content of the specified source stream to this buffer starting at the specified absolute index.
setBytes(int, ScatteringByteChannel, int) - Method in class io.netty.buffer.ByteBuf
Transfers the content of the specified source channel to this buffer starting at the specified absolute index.
setBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.ByteBuf
Transfers the content of the specified source channel starting at the given file position to this buffer starting at the specified absolute index.
setBytes(int, byte[], int, int) - Method in class io.netty.buffer.CompositeByteBuf
 
setBytes(int, ByteBuffer) - Method in class io.netty.buffer.CompositeByteBuf
 
setBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.CompositeByteBuf
 
setBytes(int, InputStream, int) - Method in class io.netty.buffer.CompositeByteBuf
 
setBytes(int, ScatteringByteChannel, int) - Method in class io.netty.buffer.CompositeByteBuf
 
setBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.CompositeByteBuf
 
setBytes(int, ByteBuf) - Method in class io.netty.buffer.CompositeByteBuf
 
setBytes(int, ByteBuf, int) - Method in class io.netty.buffer.CompositeByteBuf
 
setBytes(int, byte[]) - Method in class io.netty.buffer.CompositeByteBuf
 
setBytes(int, byte[], int, int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
setBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
setBytes(int, ByteBuffer) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
setBytes(int, InputStream, int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
setBytes(int, ScatteringByteChannel, int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
setBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
setBytes(int, ByteBuf) - Method in class io.netty.buffer.EmptyByteBuf
 
setBytes(int, ByteBuf, int) - Method in class io.netty.buffer.EmptyByteBuf
 
setBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.EmptyByteBuf
 
setBytes(int, byte[]) - Method in class io.netty.buffer.EmptyByteBuf
 
setBytes(int, byte[], int, int) - Method in class io.netty.buffer.EmptyByteBuf
 
setBytes(int, ByteBuffer) - Method in class io.netty.buffer.EmptyByteBuf
 
setBytes(int, InputStream, int) - Method in class io.netty.buffer.EmptyByteBuf
 
setBytes(int, ScatteringByteChannel, int) - Method in class io.netty.buffer.EmptyByteBuf
 
setBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.EmptyByteBuf
 
setBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
setBytes(int, byte[], int, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
setBytes(int, ByteBuffer) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
setBytes(int, InputStream, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
setBytes(int, ScatteringByteChannel, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
setBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
setBytes(int, ByteBuf) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
setBytes(int, ByteBuf, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
setBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
setBytes(int, byte[]) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
setBytes(int, byte[], int, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
setBytes(int, ByteBuffer) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
setBytes(int, InputStream, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
setBytes(int, ScatteringByteChannel, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
setBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
setBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
setBytes(int, byte[], int, int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
setBytes(int, ByteBuffer) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
setBytes(int, InputStream, int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
setBytes(int, ScatteringByteChannel, int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
setBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
setBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
setBytes(int, byte[], int, int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
setBytes(int, ByteBuffer) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
setBytes(int, InputStream, int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
setBytes(int, ScatteringByteChannel, int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
setBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
setBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
setBytes(int, byte[], int, int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
setBytes(int, ByteBuffer) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
setBytes(int, InputStream, int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
setBytes(int, ScatteringByteChannel, int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
setBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
setCas(long) - Method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
setCas(long) - Method in interface io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Sets the CAS identifier.
setChar(int, int) - Method in class io.netty.buffer.AbstractByteBuf
 
setChar(int, int) - Method in class io.netty.buffer.ByteBuf
Sets the specified 2-byte UTF-16 character at the specified absolute index in this buffer.
setChar(int, int) - Method in class io.netty.buffer.CompositeByteBuf
 
setChar(int, int) - Method in class io.netty.buffer.EmptyByteBuf
 
setChar(int, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
setChar(K, char) - Method in class io.netty.handler.codec.DefaultHeaders
 
setChar(K, char) - Method in class io.netty.handler.codec.EmptyHeaders
 
setChar(K, char) - Method in interface io.netty.handler.codec.Headers
Set the name to value.
setCharSequence(int, CharSequence, Charset) - Method in class io.netty.buffer.AbstractByteBuf
 
setCharSequence(int, CharSequence, Charset) - Method in class io.netty.buffer.ByteBuf
Writes the specified CharSequence at the current writerIndex and increases the writerIndex by the written bytes.
setCharSequence(int, CharSequence, Charset) - Method in class io.netty.buffer.EmptyByteBuf
 
setCharSequence(int, CharSequence, Charset) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
setCheckInterval(long) - Method in class io.netty.handler.traffic.AbstractTrafficShapingHandler
 
setCloseNotifyFlushTimeout(long, TimeUnit) - Method in class io.netty.handler.ssl.SslHandler
Sets the timeout for flushing the close_notify that was triggered by closing the Channel.
setCloseNotifyFlushTimeoutMillis(long) - Method in class io.netty.handler.ssl.SslHandler
setCloseNotifyReadTimeout(long, TimeUnit) - Method in class io.netty.handler.ssl.SslHandler
Sets the timeout for receiving the response for the close_notify that was triggered by closing the Channel.
setCloseNotifyReadTimeoutMillis(long) - Method in class io.netty.handler.ssl.SslHandler
setCloseNotifyTimeout(long, TimeUnit) - Method in class io.netty.handler.ssl.SslHandler
setCloseNotifyTimeoutMillis(long) - Method in class io.netty.handler.ssl.SslHandler
setCode(DnsResponseCode) - Method in class io.netty.handler.codec.dns.DatagramDnsResponse
 
setCode(DnsResponseCode) - Method in class io.netty.handler.codec.dns.DefaultDnsResponse
 
setCode(DnsResponseCode) - Method in interface io.netty.handler.codec.dns.DnsResponse
Sets the response code for this message.
setConnectTimeoutMillis(int) - Method in interface io.netty.channel.ChannelConfig
Sets the connect timeout of the channel in milliseconds.
setConnectTimeoutMillis(int) - Method in class io.netty.channel.DefaultChannelConfig
 
setConnectTimeoutMillis(int) - Method in class io.netty.channel.epoll.EpollChannelConfig
 
setConnectTimeoutMillis(int) - Method in class io.netty.channel.epoll.EpollDatagramChannelConfig
 
setConnectTimeoutMillis(int) - Method in class io.netty.channel.epoll.EpollDomainSocketChannelConfig
 
setConnectTimeoutMillis(int) - Method in class io.netty.channel.epoll.EpollServerChannelConfig
 
setConnectTimeoutMillis(int) - Method in class io.netty.channel.epoll.EpollServerSocketChannelConfig
 
setConnectTimeoutMillis(int) - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
 
setConnectTimeoutMillis(int) - Method in class io.netty.channel.kqueue.KQueueChannelConfig
 
setConnectTimeoutMillis(int) - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
 
setConnectTimeoutMillis(int) - Method in class io.netty.channel.kqueue.KQueueDomainSocketChannelConfig
 
setConnectTimeoutMillis(int) - Method in class io.netty.channel.kqueue.KQueueServerChannelConfig
 
setConnectTimeoutMillis(int) - Method in class io.netty.channel.kqueue.KQueueServerSocketChannelConfig
 
setConnectTimeoutMillis(int) - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
 
setConnectTimeoutMillis(int) - Method in interface io.netty.channel.socket.DatagramChannelConfig
 
setConnectTimeoutMillis(int) - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
 
setConnectTimeoutMillis(int) - Method in class io.netty.channel.socket.DefaultServerSocketChannelConfig
 
setConnectTimeoutMillis(int) - Method in class io.netty.channel.socket.DefaultSocketChannelConfig
 
setConnectTimeoutMillis(int) - Method in class io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig
 
setConnectTimeoutMillis(int) - Method in class io.netty.channel.socket.oio.DefaultOioSocketChannelConfig
 
setConnectTimeoutMillis(int) - Method in interface io.netty.channel.socket.oio.OioServerSocketChannelConfig
 
setConnectTimeoutMillis(int) - Method in interface io.netty.channel.socket.oio.OioSocketChannelConfig
 
setConnectTimeoutMillis(int) - Method in interface io.netty.channel.socket.ServerSocketChannelConfig
 
setConnectTimeoutMillis(int) - Method in interface io.netty.channel.socket.SocketChannelConfig
 
setConnectTimeoutMillis(int) - Method in interface io.netty.channel.unix.DomainSocketChannelConfig
 
setCounterHashCode(IntegerHolder) - Method in class io.netty.util.internal.InternalThreadLocalMap
 
setCumulator(ByteToMessageDecoder.Cumulator) - Method in class io.netty.handler.codec.ByteToMessageDecoder
Set the ByteToMessageDecoder.Cumulator to use for cumulate the received ByteBufs.
setDataType(byte) - Method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
setDataType(byte) - Method in interface io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Sets the data type of the message.
setDecoderResult(DecoderResult) - Method in interface io.netty.handler.codec.DecoderResultProvider
Updates the result of decoding this object.
setDecoderResult(DecoderResult) - Method in class io.netty.handler.codec.memcache.AbstractMemcacheObject
 
setDecoderResult(DecoderResult) - Method in class io.netty.handler.codec.stomp.DefaultStompContentSubframe
 
setDecoderResult(DecoderResult) - Method in class io.netty.handler.codec.stomp.DefaultStompHeadersSubframe
 
setDefaultFactory(InternalLoggerFactory) - Static method in class io.netty.util.internal.logging.InternalLoggerFactory
Changes the default factory.
setDiscardAfterReads(int) - Method in class io.netty.handler.codec.ByteToMessageDecoder
Set the number of reads after which ByteBuf.discardSomeReadBytes() are called and so free up memory.
setDouble(int, double) - Method in class io.netty.buffer.AbstractByteBuf
 
setDouble(int, double) - Method in class io.netty.buffer.ByteBuf
Sets the specified 64-bit floating-point number at the specified absolute index in this buffer.
setDouble(int, double) - Method in class io.netty.buffer.CompositeByteBuf
 
setDouble(int, double) - Method in class io.netty.buffer.EmptyByteBuf
 
setDouble(int, double) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
setDouble(K, double) - Method in class io.netty.handler.codec.DefaultHeaders
 
setDouble(K, double) - Method in class io.netty.handler.codec.EmptyHeaders
 
setDouble(K, double) - Method in interface io.netty.handler.codec.Headers
Set the name to value.
setEnabled(boolean) - Static method in class io.netty.util.ResourceLeakDetector
Deprecated.
setEpollMode(EpollMode) - Method in class io.netty.channel.epoll.EpollChannelConfig
Set the EpollMode used.
setEpollMode(EpollMode) - Method in class io.netty.channel.epoll.EpollDatagramChannelConfig
 
setEpollMode(EpollMode) - Method in class io.netty.channel.epoll.EpollDomainSocketChannelConfig
 
setEpollMode(EpollMode) - Method in class io.netty.channel.epoll.EpollServerChannelConfig
 
setEpollMode(EpollMode) - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
 
setExtras(ByteBuf) - Method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
setExtras(ByteBuf) - Method in interface io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Sets the extras buffer on the message.
setFailure(Throwable) - Method in interface io.netty.channel.ChannelProgressivePromise
 
setFailure(Throwable) - Method in interface io.netty.channel.ChannelPromise
 
setFailure(Throwable) - Method in class io.netty.channel.DefaultChannelProgressivePromise
 
setFailure(Throwable) - Method in class io.netty.channel.DefaultChannelPromise
 
setFailure(Throwable) - Method in class io.netty.util.concurrent.DefaultProgressivePromise
 
setFailure(Throwable) - Method in class io.netty.util.concurrent.DefaultPromise
 
setFailure(Throwable) - Method in interface io.netty.util.concurrent.ProgressivePromise
 
setFailure(Throwable) - Method in interface io.netty.util.concurrent.Promise
Marks this future as a failure and notifies all listeners.
setFloat(int, float) - Method in class io.netty.buffer.AbstractByteBuf
 
setFloat(int, float) - Method in class io.netty.buffer.ByteBuf
Sets the specified 32-bit floating-point number at the specified absolute index in this buffer.
setFloat(int, float) - Method in class io.netty.buffer.CompositeByteBuf
 
setFloat(int, float) - Method in class io.netty.buffer.EmptyByteBuf
 
setFloat(int, float) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
setFloat(K, float) - Method in class io.netty.handler.codec.DefaultHeaders
 
setFloat(K, float) - Method in class io.netty.handler.codec.EmptyHeaders
 
setFloat(K, float) - Method in interface io.netty.handler.codec.Headers
Set the name to value.
setFreeBind(boolean) - Method in class io.netty.channel.epoll.EpollServerSocketChannelConfig
If true is used IP_FREEBIND is enabled, false for disable it.
setFutureListenerStackDepth(int) - Method in class io.netty.util.internal.InternalThreadLocalMap
 
setHandshakeTimeout(long, TimeUnit) - Method in class io.netty.handler.ssl.SslHandler
 
setHandshakeTimeoutMillis(long) - Method in class io.netty.handler.ssl.SslHandler
 
setId(int) - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
 
setId(int) - Method in class io.netty.handler.codec.dns.DatagramDnsQuery
 
setId(int) - Method in class io.netty.handler.codec.dns.DatagramDnsResponse
 
setId(int) - Method in class io.netty.handler.codec.dns.DefaultDnsQuery
 
setId(int) - Method in class io.netty.handler.codec.dns.DefaultDnsResponse
 
setId(int) - Method in interface io.netty.handler.codec.dns.DnsMessage
Sets the ID of this DNS message.
setId(int) - Method in interface io.netty.handler.codec.dns.DnsQuery
 
setId(int) - Method in interface io.netty.handler.codec.dns.DnsResponse
 
setIfAbsent(T) - Method in interface io.netty.util.Attribute
Atomically sets to the given value if this Attribute's value is null.
setIndex(int, int) - Method in class io.netty.buffer.AbstractByteBuf
 
setIndex(int, int) - Method in class io.netty.buffer.ByteBuf
Sets the readerIndex and writerIndex of this buffer in one shot.
setIndex(int, int) - Method in class io.netty.buffer.CompositeByteBuf
 
setIndex(int, int) - Method in class io.netty.buffer.EmptyByteBuf
 
setIndex(int, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
setIndexedVariable(int, Object) - Method in class io.netty.util.internal.InternalThreadLocalMap
 
setInitialSeedUniquifier(long) - Static method in class io.netty.util.internal.ThreadLocalRandom
 
setInt(int, int) - Method in class io.netty.buffer.AbstractByteBuf
 
setInt(int, int) - Method in class io.netty.buffer.ByteBuf
Sets the specified 32-bit integer at the specified absolute index in this buffer.
setInt(int, int) - Method in class io.netty.buffer.CompositeByteBuf
 
setInt(int, int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
setInt(int, int) - Method in class io.netty.buffer.EmptyByteBuf
 
setInt(int, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
setInt(int, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
setInt(int, int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
setInt(int, int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
setInt(K, int) - Method in class io.netty.handler.codec.DefaultHeaders
 
setInt(K, int) - Method in class io.netty.handler.codec.EmptyHeaders
 
setInt(K, int) - Method in interface io.netty.handler.codec.Headers
Set the name to value.
setInterface(InetAddress) - Method in class io.netty.channel.epoll.EpollDatagramChannelConfig
 
setInterface(InetAddress) - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
 
setInterface(InetAddress) - Method in interface io.netty.channel.socket.DatagramChannelConfig
Sets the address of the network interface used for multicast packets.
setInterface(InetAddress) - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
 
setIntLE(int, int) - Method in class io.netty.buffer.AbstractByteBuf
 
setIntLE(int, int) - Method in class io.netty.buffer.ByteBuf
Sets the specified 32-bit integer at the specified absolute index in this buffer with Little Endian byte order .
setIntLE(int, int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
setIntLE(int, int) - Method in class io.netty.buffer.EmptyByteBuf
 
setIntLE(int, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
setIntLE(int, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
setIntLE(int, int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
setIoRatio(int) - Method in class io.netty.channel.epoll.EpollEventLoopGroup
Sets the percentage of the desired amount of time spent for I/O in the child event loops.
setIoRatio(int) - Method in class io.netty.channel.kqueue.KQueueEventLoopGroup
Sets the percentage of the desired amount of time spent for I/O in the child event loops.
setIoRatio(int) - Method in class io.netty.channel.nio.NioEventLoop
Sets the percentage of the desired amount of time spent for I/O in the event loop.
setIoRatio(int) - Method in class io.netty.channel.nio.NioEventLoopGroup
Sets the percentage of the desired amount of time spent for I/O in the child event loops.
setIpTransparent(boolean) - Method in class io.netty.channel.epoll.EpollServerSocketChannelConfig
If true is used IP_TRANSPARENT is enabled, false for disable it.
setKeepAlive(boolean) - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
 
setKeepAlive(boolean) - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
 
setKeepAlive(boolean) - Method in class io.netty.channel.socket.DefaultSocketChannelConfig
 
setKeepAlive(boolean) - Method in class io.netty.channel.socket.oio.DefaultOioSocketChannelConfig
 
setKeepAlive(boolean) - Method in interface io.netty.channel.socket.oio.OioSocketChannelConfig
 
setKeepAlive(boolean) - Method in interface io.netty.channel.socket.SocketChannelConfig
setKeepAlive(boolean) - Method in class io.netty.channel.unix.Socket
 
setKey(ByteBuf) - Method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
setKey(ByteBuf) - Method in interface io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Sets the key of the document.
setLevel(ResourceLeakDetector.Level) - Static method in class io.netty.util.ResourceLeakDetector
Sets the resource leak detection level.
setLocalChannelReaderStackDepth(int) - Method in class io.netty.util.internal.InternalThreadLocalMap
 
setLong(int, long) - Method in class io.netty.buffer.AbstractByteBuf
 
setLong(int, long) - Method in class io.netty.buffer.ByteBuf
Sets the specified 64-bit long integer at the specified absolute index in this buffer.
setLong(int, long) - Method in class io.netty.buffer.CompositeByteBuf
 
setLong(int, long) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
setLong(int, long) - Method in class io.netty.buffer.EmptyByteBuf
 
setLong(int, long) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
setLong(int, long) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
setLong(int, long) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
setLong(int, long) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
setLong(K, long) - Method in class io.netty.handler.codec.DefaultHeaders
 
setLong(K, long) - Method in class io.netty.handler.codec.EmptyHeaders
 
setLong(K, long) - Method in interface io.netty.handler.codec.Headers
Set the name to value.
setLongLE(int, long) - Method in class io.netty.buffer.AbstractByteBuf
 
setLongLE(int, long) - Method in class io.netty.buffer.ByteBuf
Sets the specified 64-bit long integer at the specified absolute index in this buffer in Little Endian Byte Order.
setLongLE(int, long) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
setLongLE(int, long) - Method in class io.netty.buffer.EmptyByteBuf
 
setLongLE(int, long) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
setLongLE(int, long) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
setLongLE(int, long) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
setLoopbackModeDisabled(boolean) - Method in class io.netty.channel.epoll.EpollDatagramChannelConfig
 
setLoopbackModeDisabled(boolean) - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
 
setLoopbackModeDisabled(boolean) - Method in interface io.netty.channel.socket.DatagramChannelConfig
setLoopbackModeDisabled(boolean) - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
 
setMagic(byte) - Method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
setMagic(byte) - Method in interface io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Sets the magic byte.
setMaxCumulationBufferComponents(int) - Method in class io.netty.handler.codec.MessageAggregator
Sets the maximum number of components in the cumulation buffer.
setMaxDeviation(float, float, float) - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
 
setMaxGlobalWriteSize(long) - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
Note the change will be taken as best effort, meaning that all already scheduled traffics will not be changed, but only applied to new traffics.
So the expected usage of this method is to be used not too often, accordingly to the traffic shaping configuration.
setMaxGlobalWriteSize(long) - Method in class io.netty.handler.traffic.GlobalTrafficShapingHandler
Note the change will be taken as best effort, meaning that all already scheduled traffics will not be changed, but only applied to new traffics.
So the expected usage of this method is to be used not too often, accordingly to the traffic shaping configuration.
setMaxMessagesPerRead(int) - Method in interface io.netty.channel.ChannelConfig
Deprecated.
Use MaxMessagesRecvByteBufAllocator

Sets the maximum number of messages to read per read loop. If this value is greater than 1, an event loop might attempt to read multiple times to procure multiple messages.

setMaxMessagesPerRead(int) - Method in class io.netty.channel.DefaultChannelConfig
Deprecated.
setMaxMessagesPerRead(int) - Method in class io.netty.channel.epoll.EpollChannelConfig
Deprecated.
setMaxMessagesPerRead(int) - Method in class io.netty.channel.epoll.EpollDatagramChannelConfig
Deprecated.
setMaxMessagesPerRead(int) - Method in class io.netty.channel.epoll.EpollDomainSocketChannelConfig
Deprecated.
setMaxMessagesPerRead(int) - Method in class io.netty.channel.epoll.EpollServerChannelConfig
Deprecated.
setMaxMessagesPerRead(int) - Method in class io.netty.channel.epoll.EpollServerSocketChannelConfig
Deprecated.
setMaxMessagesPerRead(int) - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
Deprecated.
setMaxMessagesPerRead(int) - Method in class io.netty.channel.kqueue.KQueueChannelConfig
Deprecated.
setMaxMessagesPerRead(int) - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
Deprecated.
setMaxMessagesPerRead(int) - Method in class io.netty.channel.kqueue.KQueueDomainSocketChannelConfig
Deprecated.
setMaxMessagesPerRead(int) - Method in class io.netty.channel.kqueue.KQueueServerChannelConfig
Deprecated.
setMaxMessagesPerRead(int) - Method in class io.netty.channel.kqueue.KQueueServerSocketChannelConfig
Deprecated.
setMaxMessagesPerRead(int) - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
Deprecated.
setMaxMessagesPerRead(int) - Method in interface io.netty.channel.socket.DatagramChannelConfig
Deprecated.
setMaxMessagesPerRead(int) - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
Deprecated.
setMaxMessagesPerRead(int) - Method in class io.netty.channel.socket.DefaultServerSocketChannelConfig
Deprecated.
setMaxMessagesPerRead(int) - Method in class io.netty.channel.socket.DefaultSocketChannelConfig
Deprecated.
setMaxMessagesPerRead(int) - Method in class io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig
Deprecated.
setMaxMessagesPerRead(int) - Method in class io.netty.channel.socket.oio.DefaultOioSocketChannelConfig
Deprecated.
setMaxMessagesPerRead(int) - Method in interface io.netty.channel.socket.oio.OioServerSocketChannelConfig
Deprecated.
setMaxMessagesPerRead(int) - Method in interface io.netty.channel.socket.oio.OioSocketChannelConfig
Deprecated.
setMaxMessagesPerRead(int) - Method in interface io.netty.channel.socket.ServerSocketChannelConfig
Deprecated.
setMaxMessagesPerRead(int) - Method in interface io.netty.channel.socket.SocketChannelConfig
Deprecated.
setMaxMessagesPerRead(int) - Method in interface io.netty.channel.unix.DomainSocketChannelConfig
Deprecated.
setMaxTimeWait(long) - Method in class io.netty.handler.traffic.AbstractTrafficShapingHandler
Note the change will be taken as best effort, meaning that all already scheduled traffics will not be changed, but only applied to new traffics.
setMaxWriteDelay(long) - Method in class io.netty.handler.traffic.AbstractTrafficShapingHandler
Note the change will be taken as best effort, meaning that all already scheduled traffics will not be changed, but only applied to new traffics.
setMaxWriteSize(long) - Method in class io.netty.handler.traffic.AbstractTrafficShapingHandler
Note that this limit is a best effort on memory limitation to prevent Out Of Memory Exception.
setMedium(int, int) - Method in class io.netty.buffer.AbstractByteBuf
 
setMedium(int, int) - Method in class io.netty.buffer.ByteBuf
Sets the specified 24-bit medium integer at the specified absolute index in this buffer.
setMedium(int, int) - Method in class io.netty.buffer.CompositeByteBuf
 
setMedium(int, int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
setMedium(int, int) - Method in class io.netty.buffer.EmptyByteBuf
 
setMedium(int, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
setMedium(int, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
setMedium(int, int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
setMedium(int, int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
setMediumLE(int, int) - Method in class io.netty.buffer.AbstractByteBuf
 
setMediumLE(int, int) - Method in class io.netty.buffer.ByteBuf
Sets the specified 24-bit medium integer at the specified absolute index in this buffer in the Little Endian Byte Order.
setMediumLE(int, int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
setMediumLE(int, int) - Method in class io.netty.buffer.EmptyByteBuf
 
setMediumLE(int, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
setMediumLE(int, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
setMediumLE(int, int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
setMemory(byte[], int, long, byte) - Static method in class io.netty.util.internal.PlatformDependent
 
setMemory(long, long, byte) - Static method in class io.netty.util.internal.PlatformDependent
 
setMessageSizeEstimator(MessageSizeEstimator) - Method in interface io.netty.channel.ChannelConfig
Set the MessageSizeEstimator which is used for the channel to detect the size of a message.
setMessageSizeEstimator(MessageSizeEstimator) - Method in class io.netty.channel.DefaultChannelConfig
 
setMessageSizeEstimator(MessageSizeEstimator) - Method in class io.netty.channel.epoll.EpollChannelConfig
 
setMessageSizeEstimator(MessageSizeEstimator) - Method in class io.netty.channel.epoll.EpollDatagramChannelConfig
 
setMessageSizeEstimator(MessageSizeEstimator) - Method in class io.netty.channel.epoll.EpollDomainSocketChannelConfig
 
setMessageSizeEstimator(MessageSizeEstimator) - Method in class io.netty.channel.epoll.EpollServerChannelConfig
 
setMessageSizeEstimator(MessageSizeEstimator) - Method in class io.netty.channel.epoll.EpollServerSocketChannelConfig
 
setMessageSizeEstimator(MessageSizeEstimator) - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
 
setMessageSizeEstimator(MessageSizeEstimator) - Method in class io.netty.channel.kqueue.KQueueChannelConfig
 
setMessageSizeEstimator(MessageSizeEstimator) - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
 
setMessageSizeEstimator(MessageSizeEstimator) - Method in class io.netty.channel.kqueue.KQueueDomainSocketChannelConfig
 
setMessageSizeEstimator(MessageSizeEstimator) - Method in class io.netty.channel.kqueue.KQueueServerChannelConfig
 
setMessageSizeEstimator(MessageSizeEstimator) - Method in class io.netty.channel.kqueue.KQueueServerSocketChannelConfig
 
setMessageSizeEstimator(MessageSizeEstimator) - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
 
setMessageSizeEstimator(MessageSizeEstimator) - Method in interface io.netty.channel.socket.DatagramChannelConfig
 
setMessageSizeEstimator(MessageSizeEstimator) - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
 
setMessageSizeEstimator(MessageSizeEstimator) - Method in class io.netty.channel.socket.DefaultServerSocketChannelConfig
 
setMessageSizeEstimator(MessageSizeEstimator) - Method in class io.netty.channel.socket.DefaultSocketChannelConfig
 
setMessageSizeEstimator(MessageSizeEstimator) - Method in class io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig
 
setMessageSizeEstimator(MessageSizeEstimator) - Method in class io.netty.channel.socket.oio.DefaultOioSocketChannelConfig
 
setMessageSizeEstimator(MessageSizeEstimator) - Method in interface io.netty.channel.socket.oio.OioServerSocketChannelConfig
 
setMessageSizeEstimator(MessageSizeEstimator) - Method in interface io.netty.channel.socket.oio.OioSocketChannelConfig
 
setMessageSizeEstimator(MessageSizeEstimator) - Method in interface io.netty.channel.socket.ServerSocketChannelConfig
 
setMessageSizeEstimator(MessageSizeEstimator) - Method in interface io.netty.channel.socket.SocketChannelConfig
 
setMessageSizeEstimator(MessageSizeEstimator) - Method in interface io.netty.channel.unix.DomainSocketChannelConfig
 
setNetworkInterface(NetworkInterface) - Method in class io.netty.channel.epoll.EpollDatagramChannelConfig
 
setNetworkInterface(NetworkInterface) - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
 
setNetworkInterface(NetworkInterface) - Method in interface io.netty.channel.socket.DatagramChannelConfig
setNetworkInterface(NetworkInterface) - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
 
setObject(K, Object) - Method in class io.netty.handler.codec.DefaultHeaders
 
setObject(K, Iterable<?>) - Method in class io.netty.handler.codec.DefaultHeaders
 
setObject(K, Object...) - Method in class io.netty.handler.codec.DefaultHeaders
 
setObject(K, Object) - Method in class io.netty.handler.codec.EmptyHeaders
 
setObject(K, Iterable<?>) - Method in class io.netty.handler.codec.EmptyHeaders
 
setObject(K, Object...) - Method in class io.netty.handler.codec.EmptyHeaders
 
setObject(K, Object) - Method in interface io.netty.handler.codec.Headers
Sets a new header.
setObject(K, Iterable<?>) - Method in interface io.netty.handler.codec.Headers
Sets a header with the specified name and values.
setObject(K, Object...) - Method in interface io.netty.handler.codec.Headers
Sets a header with the specified name and values.
setOpaque(int) - Method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
setOpaque(int) - Method in interface io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Sets the opaque value.
setOpCode(DnsOpCode) - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
 
setOpCode(DnsOpCode) - Method in class io.netty.handler.codec.dns.DatagramDnsQuery
 
setOpCode(DnsOpCode) - Method in class io.netty.handler.codec.dns.DatagramDnsResponse
 
setOpCode(DnsOpCode) - Method in class io.netty.handler.codec.dns.DefaultDnsQuery
 
setOpCode(DnsOpCode) - Method in class io.netty.handler.codec.dns.DefaultDnsResponse
 
setOpCode(DnsOpCode) - Method in interface io.netty.handler.codec.dns.DnsMessage
Sets the opCode of this DNS message.
setOpCode(DnsOpCode) - Method in interface io.netty.handler.codec.dns.DnsQuery
 
setOpCode(DnsOpCode) - Method in interface io.netty.handler.codec.dns.DnsResponse
 
setOpcode(byte) - Method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
setOpcode(byte) - Method in interface io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Sets the opcode for the message.
setOption(ChannelOption<T>, T) - Method in interface io.netty.channel.ChannelConfig
Sets a configuration property with the specified name and value.
setOption(ChannelOption<T>, T) - Method in class io.netty.channel.DefaultChannelConfig
 
setOption(ChannelOption<T>, T) - Method in class io.netty.channel.epoll.EpollChannelConfig
 
setOption(ChannelOption<T>, T) - Method in class io.netty.channel.epoll.EpollDatagramChannelConfig
 
setOption(ChannelOption<T>, T) - Method in class io.netty.channel.epoll.EpollDomainSocketChannelConfig
 
setOption(ChannelOption<T>, T) - Method in class io.netty.channel.epoll.EpollServerChannelConfig
 
setOption(ChannelOption<T>, T) - Method in class io.netty.channel.epoll.EpollServerSocketChannelConfig
 
setOption(ChannelOption<T>, T) - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
 
setOption(ChannelOption<T>, T) - Method in class io.netty.channel.kqueue.KQueueChannelConfig
 
setOption(ChannelOption<T>, T) - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
 
setOption(ChannelOption<T>, T) - Method in class io.netty.channel.kqueue.KQueueDomainSocketChannelConfig
 
setOption(ChannelOption<T>, T) - Method in class io.netty.channel.kqueue.KQueueServerChannelConfig
 
setOption(ChannelOption<T>, T) - Method in class io.netty.channel.kqueue.KQueueServerSocketChannelConfig
 
setOption(ChannelOption<T>, T) - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
 
setOption(ChannelOption<T>, T) - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
 
setOption(ChannelOption<T>, T) - Method in class io.netty.channel.socket.DefaultServerSocketChannelConfig
 
setOption(ChannelOption<T>, T) - Method in class io.netty.channel.socket.DefaultSocketChannelConfig
 
setOption(ChannelOption<T>, T) - Method in class io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig
 
setOption(ChannelOption<T>, T) - Method in class io.netty.channel.socket.oio.DefaultOioSocketChannelConfig
 
setOptions(Map<ChannelOption<?>, ?>) - Method in interface io.netty.channel.ChannelConfig
Sets the configuration properties from the specified Map.
setOptions(Map<ChannelOption<?>, ?>) - Method in class io.netty.channel.DefaultChannelConfig
 
setOpWrite() - Method in class io.netty.channel.nio.AbstractNioByteChannel
 
setPerformancePreferences(int, int, int) - Method in class io.netty.channel.epoll.EpollServerChannelConfig
 
setPerformancePreferences(int, int, int) - Method in class io.netty.channel.epoll.EpollServerSocketChannelConfig
 
setPerformancePreferences(int, int, int) - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
 
setPerformancePreferences(int, int, int) - Method in class io.netty.channel.kqueue.KQueueServerChannelConfig
 
setPerformancePreferences(int, int, int) - Method in class io.netty.channel.kqueue.KQueueServerSocketChannelConfig
 
setPerformancePreferences(int, int, int) - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
 
setPerformancePreferences(int, int, int) - Method in class io.netty.channel.socket.DefaultServerSocketChannelConfig
 
setPerformancePreferences(int, int, int) - Method in class io.netty.channel.socket.DefaultSocketChannelConfig
 
setPerformancePreferences(int, int, int) - Method in class io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig
 
setPerformancePreferences(int, int, int) - Method in class io.netty.channel.socket.oio.DefaultOioSocketChannelConfig
 
setPerformancePreferences(int, int, int) - Method in interface io.netty.channel.socket.oio.OioServerSocketChannelConfig
 
setPerformancePreferences(int, int, int) - Method in interface io.netty.channel.socket.oio.OioSocketChannelConfig
 
setPerformancePreferences(int, int, int) - Method in interface io.netty.channel.socket.ServerSocketChannelConfig
Sets the performance preferences as specified in ServerSocket.setPerformancePreferences(int, int, int).
setPerformancePreferences(int, int, int) - Method in interface io.netty.channel.socket.SocketChannelConfig
Sets the performance preferences as specified in Socket.setPerformancePreferences(int, int, int).
setProgress(long, long) - Method in interface io.netty.channel.ChannelProgressivePromise
 
setProgress(long, long) - Method in class io.netty.channel.DefaultChannelProgressivePromise
 
setProgress(long, long) - Method in class io.netty.util.concurrent.DefaultProgressivePromise
 
setProgress(long, long) - Method in interface io.netty.util.concurrent.ProgressivePromise
Sets the current progress of the operation and notifies the listeners that implement GenericProgressiveFutureListener.
SETQ - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
setRcvAllocTransportProvidesGuess(boolean) - Method in class io.netty.channel.kqueue.KQueueChannelConfig
If this is true then the RecvByteBufAllocator.Handle#guess() will be overriden to always attempt to read as many bytes as kqueue says are available.
setRcvAllocTransportProvidesGuess(boolean) - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
 
setRcvAllocTransportProvidesGuess(boolean) - Method in class io.netty.channel.kqueue.KQueueDomainSocketChannelConfig
 
setRcvAllocTransportProvidesGuess(boolean) - Method in class io.netty.channel.kqueue.KQueueServerChannelConfig
 
setRcvAllocTransportProvidesGuess(boolean) - Method in class io.netty.channel.kqueue.KQueueServerSocketChannelConfig
 
setRcvAllocTransportProvidesGuess(boolean) - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
 
setReadChannelLimit(long) - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
 
setReadLimit(long) - Method in class io.netty.handler.traffic.AbstractTrafficShapingHandler
Note the change will be taken as best effort, meaning that all already scheduled traffics will not be changed, but only applied to new traffics.
setReadMode(DomainSocketReadMode) - Method in class io.netty.channel.epoll.EpollDomainSocketChannelConfig
 
setReadMode(DomainSocketReadMode) - Method in class io.netty.channel.kqueue.KQueueDomainSocketChannelConfig
 
setReadMode(DomainSocketReadMode) - Method in interface io.netty.channel.unix.DomainSocketChannelConfig
Change the DomainSocketReadMode for the channel.
setReadPending(boolean) - Method in class io.netty.channel.nio.AbstractNioChannel
Deprecated.
Use AbstractNioChannel.clearReadPending() if appropriate instead. No longer supported.
setReadPending(boolean) - Method in class io.netty.channel.oio.AbstractOioChannel
Deprecated.
Use AbstractOioChannel.clearReadPending() if appropriate instead. No longer supported.
setReadPending(boolean) - Method in class io.netty.channel.socket.nio.NioDatagramChannel
Deprecated.
setReadPending(boolean) - Method in class io.netty.channel.socket.oio.OioServerSocketChannel
Deprecated.
setReadPending(boolean) - Method in class io.netty.channel.socket.oio.OioSocketChannel
Deprecated.
setReceiveBufferSize(int) - Method in class io.netty.channel.epoll.EpollDatagramChannelConfig
 
setReceiveBufferSize(int) - Method in class io.netty.channel.epoll.EpollServerChannelConfig
 
setReceiveBufferSize(int) - Method in class io.netty.channel.epoll.EpollServerSocketChannelConfig
 
setReceiveBufferSize(int) - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
 
setReceiveBufferSize(int) - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
 
setReceiveBufferSize(int) - Method in class io.netty.channel.kqueue.KQueueServerChannelConfig
 
setReceiveBufferSize(int) - Method in class io.netty.channel.kqueue.KQueueServerSocketChannelConfig
 
setReceiveBufferSize(int) - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
 
setReceiveBufferSize(int) - Method in interface io.netty.channel.socket.DatagramChannelConfig
setReceiveBufferSize(int) - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
 
setReceiveBufferSize(int) - Method in class io.netty.channel.socket.DefaultServerSocketChannelConfig
 
setReceiveBufferSize(int) - Method in class io.netty.channel.socket.DefaultSocketChannelConfig
 
setReceiveBufferSize(int) - Method in class io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig
 
setReceiveBufferSize(int) - Method in class io.netty.channel.socket.oio.DefaultOioSocketChannelConfig
 
setReceiveBufferSize(int) - Method in interface io.netty.channel.socket.oio.OioServerSocketChannelConfig
 
setReceiveBufferSize(int) - Method in interface io.netty.channel.socket.oio.OioSocketChannelConfig
 
setReceiveBufferSize(int) - Method in interface io.netty.channel.socket.ServerSocketChannelConfig
setReceiveBufferSize(int) - Method in interface io.netty.channel.socket.SocketChannelConfig
setReceiveBufferSize(int) - Method in class io.netty.channel.unix.Socket
 
setRecord(DnsSection, DnsRecord) - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
 
setRecord(DnsSection, int, DnsRecord) - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
 
setRecord(DnsSection, DnsRecord) - Method in class io.netty.handler.codec.dns.DatagramDnsQuery
 
setRecord(DnsSection, DnsRecord) - Method in class io.netty.handler.codec.dns.DatagramDnsResponse
 
setRecord(DnsSection, DnsRecord) - Method in class io.netty.handler.codec.dns.DefaultDnsQuery
 
setRecord(DnsSection, DnsRecord) - Method in class io.netty.handler.codec.dns.DefaultDnsResponse
 
setRecord(DnsSection, DnsRecord) - Method in interface io.netty.handler.codec.dns.DnsMessage
Sets the specified section of this DNS message to the specified record, making it a single-record section.
setRecord(DnsSection, int, DnsRecord) - Method in interface io.netty.handler.codec.dns.DnsMessage
Sets the specified record at the specified index of the specified section of this DNS message.
setRecord(DnsSection, DnsRecord) - Method in interface io.netty.handler.codec.dns.DnsQuery
 
setRecord(DnsSection, DnsRecord) - Method in interface io.netty.handler.codec.dns.DnsResponse
 
setRecursionAvailable(boolean) - Method in class io.netty.handler.codec.dns.DatagramDnsResponse
 
setRecursionAvailable(boolean) - Method in class io.netty.handler.codec.dns.DefaultDnsResponse
 
setRecursionAvailable(boolean) - Method in interface io.netty.handler.codec.dns.DnsResponse
Set to true if DNS server can handle recursive queries.
setRecursionDesired(boolean) - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
 
setRecursionDesired(boolean) - Method in class io.netty.handler.codec.dns.DatagramDnsQuery
 
setRecursionDesired(boolean) - Method in class io.netty.handler.codec.dns.DatagramDnsResponse
 
setRecursionDesired(boolean) - Method in class io.netty.handler.codec.dns.DefaultDnsQuery
 
setRecursionDesired(boolean) - Method in class io.netty.handler.codec.dns.DefaultDnsResponse
 
setRecursionDesired(boolean) - Method in interface io.netty.handler.codec.dns.DnsMessage
Sets the RD (recursion desired} field of this DNS message.
setRecursionDesired(boolean) - Method in interface io.netty.handler.codec.dns.DnsQuery
 
setRecursionDesired(boolean) - Method in interface io.netty.handler.codec.dns.DnsResponse
 
setRecvByteBufAllocator(RecvByteBufAllocator) - Method in interface io.netty.channel.ChannelConfig
Set the RecvByteBufAllocator which is used for the channel to allocate receive buffers.
setRecvByteBufAllocator(RecvByteBufAllocator) - Method in class io.netty.channel.DefaultChannelConfig
 
setRecvByteBufAllocator(RecvByteBufAllocator) - Method in class io.netty.channel.epoll.EpollChannelConfig
 
setRecvByteBufAllocator(RecvByteBufAllocator) - Method in class io.netty.channel.epoll.EpollDatagramChannelConfig
 
setRecvByteBufAllocator(RecvByteBufAllocator) - Method in class io.netty.channel.epoll.EpollDomainSocketChannelConfig
 
setRecvByteBufAllocator(RecvByteBufAllocator) - Method in class io.netty.channel.epoll.EpollServerChannelConfig
 
setRecvByteBufAllocator(RecvByteBufAllocator) - Method in class io.netty.channel.epoll.EpollServerSocketChannelConfig
 
setRecvByteBufAllocator(RecvByteBufAllocator) - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
 
setRecvByteBufAllocator(RecvByteBufAllocator) - Method in class io.netty.channel.kqueue.KQueueChannelConfig
 
setRecvByteBufAllocator(RecvByteBufAllocator) - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
 
setRecvByteBufAllocator(RecvByteBufAllocator) - Method in class io.netty.channel.kqueue.KQueueDomainSocketChannelConfig
 
setRecvByteBufAllocator(RecvByteBufAllocator) - Method in class io.netty.channel.kqueue.KQueueServerChannelConfig
 
setRecvByteBufAllocator(RecvByteBufAllocator) - Method in class io.netty.channel.kqueue.KQueueServerSocketChannelConfig
 
setRecvByteBufAllocator(RecvByteBufAllocator) - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
 
setRecvByteBufAllocator(RecvByteBufAllocator) - Method in interface io.netty.channel.socket.DatagramChannelConfig
 
setRecvByteBufAllocator(RecvByteBufAllocator) - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
 
setRecvByteBufAllocator(RecvByteBufAllocator) - Method in class io.netty.channel.socket.DefaultServerSocketChannelConfig
 
setRecvByteBufAllocator(RecvByteBufAllocator) - Method in class io.netty.channel.socket.DefaultSocketChannelConfig
 
setRecvByteBufAllocator(RecvByteBufAllocator) - Method in class io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig
 
setRecvByteBufAllocator(RecvByteBufAllocator) - Method in class io.netty.channel.socket.oio.DefaultOioSocketChannelConfig
 
setRecvByteBufAllocator(RecvByteBufAllocator) - Method in interface io.netty.channel.socket.oio.OioServerSocketChannelConfig
 
setRecvByteBufAllocator(RecvByteBufAllocator) - Method in interface io.netty.channel.socket.oio.OioSocketChannelConfig
 
setRecvByteBufAllocator(RecvByteBufAllocator) - Method in interface io.netty.channel.socket.ServerSocketChannelConfig
 
setRecvByteBufAllocator(RecvByteBufAllocator) - Method in interface io.netty.channel.socket.SocketChannelConfig
 
setRecvByteBufAllocator(RecvByteBufAllocator) - Method in interface io.netty.channel.unix.DomainSocketChannelConfig
 
setRefCnt(int) - Method in class io.netty.buffer.AbstractReferenceCountedByteBuf
An unsafe operation intended for use by a subclass that sets the reference count of the buffer directly
setRefCnt(int) - Method in class io.netty.util.AbstractReferenceCounted
An unsafe operation intended for use by a subclass that sets the reference count of the buffer directly
setReserved(short) - Method in interface io.netty.handler.codec.memcache.binary.BinaryMemcacheRequest
Sets the reserved field value.
setReserved(short) - Method in class io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheRequest
 
setResourceLeakDetectorFactory(ResourceLeakDetectorFactory) - Static method in class io.netty.util.ResourceLeakDetectorFactory
Set the factory's singleton instance.
setReuseAddress(boolean) - Method in class io.netty.channel.epoll.EpollDatagramChannelConfig
 
setReuseAddress(boolean) - Method in class io.netty.channel.epoll.EpollServerChannelConfig
 
setReuseAddress(boolean) - Method in class io.netty.channel.epoll.EpollServerSocketChannelConfig
 
setReuseAddress(boolean) - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
 
setReuseAddress(boolean) - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
 
setReuseAddress(boolean) - Method in class io.netty.channel.kqueue.KQueueServerChannelConfig
 
setReuseAddress(boolean) - Method in class io.netty.channel.kqueue.KQueueServerSocketChannelConfig
 
setReuseAddress(boolean) - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
 
setReuseAddress(boolean) - Method in interface io.netty.channel.socket.DatagramChannelConfig
setReuseAddress(boolean) - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
 
setReuseAddress(boolean) - Method in class io.netty.channel.socket.DefaultServerSocketChannelConfig
 
setReuseAddress(boolean) - Method in class io.netty.channel.socket.DefaultSocketChannelConfig
 
setReuseAddress(boolean) - Method in class io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig
 
setReuseAddress(boolean) - Method in class io.netty.channel.socket.oio.DefaultOioSocketChannelConfig
 
setReuseAddress(boolean) - Method in interface io.netty.channel.socket.oio.OioServerSocketChannelConfig
 
setReuseAddress(boolean) - Method in interface io.netty.channel.socket.oio.OioSocketChannelConfig
 
setReuseAddress(boolean) - Method in interface io.netty.channel.socket.ServerSocketChannelConfig
setReuseAddress(boolean) - Method in interface io.netty.channel.socket.SocketChannelConfig
setReuseAddress(boolean) - Method in class io.netty.channel.unix.Socket
 
setReusePort(boolean) - Method in class io.netty.channel.epoll.EpollDatagramChannelConfig
Set the SO_REUSEPORT option on the underlying Channel.
setReusePort(boolean) - Method in class io.netty.channel.epoll.EpollServerSocketChannelConfig
Set the SO_REUSEPORT option on the underlying Channel.
setReusePort(boolean) - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
Set the SO_REUSEPORT option on the underlying Channel.
setReusePort(boolean) - Method in class io.netty.channel.kqueue.KQueueServerSocketChannelConfig
 
setReusePort(boolean) - Method in class io.netty.channel.unix.Socket
 
setSeed(long) - Method in class io.netty.util.internal.ThreadLocalRandom
Throws UnsupportedOperationException.
setSendBufferSize(int) - Method in class io.netty.channel.epoll.EpollDatagramChannelConfig
 
setSendBufferSize(int) - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
 
setSendBufferSize(int) - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
 
setSendBufferSize(int) - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
 
setSendBufferSize(int) - Method in interface io.netty.channel.socket.DatagramChannelConfig
setSendBufferSize(int) - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
 
setSendBufferSize(int) - Method in class io.netty.channel.socket.DefaultSocketChannelConfig
 
setSendBufferSize(int) - Method in class io.netty.channel.socket.oio.DefaultOioSocketChannelConfig
 
setSendBufferSize(int) - Method in interface io.netty.channel.socket.oio.OioSocketChannelConfig
 
setSendBufferSize(int) - Method in interface io.netty.channel.socket.SocketChannelConfig
setSendBufferSize(int) - Method in class io.netty.channel.unix.Socket
 
setShort(int, int) - Method in class io.netty.buffer.AbstractByteBuf
 
setShort(int, int) - Method in class io.netty.buffer.ByteBuf
Sets the specified 16-bit short integer at the specified absolute index in this buffer.
setShort(int, int) - Method in class io.netty.buffer.CompositeByteBuf
 
setShort(int, int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
setShort(int, int) - Method in class io.netty.buffer.EmptyByteBuf
 
setShort(int, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
setShort(int, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
setShort(int, int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
setShort(int, int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
setShort(K, short) - Method in class io.netty.handler.codec.DefaultHeaders
 
setShort(K, short) - Method in class io.netty.handler.codec.EmptyHeaders
 
setShort(K, short) - Method in interface io.netty.handler.codec.Headers
Set the name to value.
setShortLE(int, int) - Method in class io.netty.buffer.AbstractByteBuf
 
setShortLE(int, int) - Method in class io.netty.buffer.ByteBuf
Sets the specified 16-bit short integer at the specified absolute index in this buffer with the Little Endian Byte Order.
setShortLE(int, int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
setShortLE(int, int) - Method in class io.netty.buffer.EmptyByteBuf
 
setShortLE(int, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
setShortLE(int, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
setShortLE(int, int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
setSingleDecode(boolean) - Method in class io.netty.handler.codec.ByteToMessageDecoder
If set then only one message is decoded on each ByteToMessageDecoder.channelRead(ChannelHandlerContext, Object) call.
setSndLowAt(int) - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
 
setSoLinger(int) - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
 
setSoLinger(int) - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
 
setSoLinger(int) - Method in class io.netty.channel.socket.DefaultSocketChannelConfig
 
setSoLinger(int) - Method in class io.netty.channel.socket.oio.DefaultOioSocketChannelConfig
 
setSoLinger(int) - Method in interface io.netty.channel.socket.oio.OioSocketChannelConfig
 
setSoLinger(int) - Method in interface io.netty.channel.socket.SocketChannelConfig
setSoLinger(int) - Method in class io.netty.channel.unix.Socket
 
setSoTimeout(int) - Method in class io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig
 
setSoTimeout(int) - Method in class io.netty.channel.socket.oio.DefaultOioSocketChannelConfig
 
setSoTimeout(int) - Method in interface io.netty.channel.socket.oio.OioServerSocketChannelConfig
Sets the maximal time a operation on the underlying socket may block.
setSoTimeout(int) - Method in interface io.netty.channel.socket.oio.OioSocketChannelConfig
Sets the maximal time a operation on the underlying socket may block.
setStatus(short) - Method in interface io.netty.handler.codec.memcache.binary.BinaryMemcacheResponse
Sets the status of the response.
setStatus(short) - Method in class io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheResponse
 
setSuccess(Void) - Method in interface io.netty.channel.ChannelProgressivePromise
 
setSuccess() - Method in interface io.netty.channel.ChannelProgressivePromise
 
setSuccess(Void) - Method in interface io.netty.channel.ChannelPromise
 
setSuccess() - Method in interface io.netty.channel.ChannelPromise
 
setSuccess() - Method in class io.netty.channel.DefaultChannelProgressivePromise
 
setSuccess(Void) - Method in class io.netty.channel.DefaultChannelProgressivePromise
 
setSuccess() - Method in class io.netty.channel.DefaultChannelPromise
 
setSuccess(Void) - Method in class io.netty.channel.DefaultChannelPromise
 
setSuccess(V) - Method in class io.netty.util.concurrent.DefaultProgressivePromise
 
setSuccess(V) - Method in class io.netty.util.concurrent.DefaultPromise
 
setSuccess(V) - Method in interface io.netty.util.concurrent.ProgressivePromise
 
setSuccess(V) - Method in interface io.netty.util.concurrent.Promise
Marks this future as a success and notifies all listeners.
setTcpCork(boolean) - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
Set the TCP_CORK option on the socket.
setTcpDeferAccept(int) - Method in class io.netty.channel.epoll.EpollServerSocketChannelConfig
Set the TCP_DEFER_ACCEPT option on the socket.
setTcpFastopen(int) - Method in class io.netty.channel.epoll.EpollServerChannelConfig
Enables tcpFastOpen on the server channel.
setTcpKeepCnt(int) - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
Set the TCP_KEEPCNT option on the socket.
setTcpKeepCntl(int) - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
setTcpKeepIdle(int) - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
Set the TCP_KEEPIDLE option on the socket.
setTcpKeepIntvl(int) - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
Set the TCP_KEEPINTVL option on the socket.
setTcpMd5Sig(Map<InetAddress, byte[]>) - Method in class io.netty.channel.epoll.EpollServerSocketChannelConfig
Set the TCP_MD5SIG option on the socket.
setTcpMd5Sig(Map<InetAddress, byte[]>) - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
Set the TCP_MD5SIG option on the socket.
setTcpNoDelay(boolean) - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
 
setTcpNoDelay(boolean) - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
 
setTcpNoDelay(boolean) - Method in class io.netty.channel.socket.DefaultSocketChannelConfig
 
setTcpNoDelay(boolean) - Method in class io.netty.channel.socket.oio.DefaultOioSocketChannelConfig
 
setTcpNoDelay(boolean) - Method in interface io.netty.channel.socket.oio.OioSocketChannelConfig
 
setTcpNoDelay(boolean) - Method in interface io.netty.channel.socket.SocketChannelConfig
setTcpNoDelay(boolean) - Method in class io.netty.channel.unix.Socket
 
setTcpNoPush(boolean) - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
 
setTcpNotSentLowAt(long) - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
Set the TCP_NOTSENT_LOWAT option on the socket.
setTcpQuickAck(boolean) - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
Set the TCP_QUICKACK option on the socket.
setTcpUserTimeout(int) - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
Set the TCP_USER_TIMEOUT option on the socket.
setThreadLocalMap(InternalThreadLocalMap) - Method in class io.netty.util.concurrent.FastThreadLocalThread
Sets the internal data structure that keeps the thread-local variables bound to this thread.
setTimeMillis(K, long) - Method in class io.netty.handler.codec.DefaultHeaders
 
setTimeMillis(K, long) - Method in class io.netty.handler.codec.EmptyHeaders
 
setTimeMillis(K, long) - Method in interface io.netty.handler.codec.Headers
Set the name to value.
setTimeToLive(int) - Method in class io.netty.channel.epoll.EpollDatagramChannelConfig
 
setTimeToLive(int) - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
 
setTimeToLive(int) - Method in interface io.netty.channel.socket.DatagramChannelConfig
setTimeToLive(int) - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
 
setTotalBodyLength(int) - Method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
setTotalBodyLength(int) - Method in interface io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Sets the total body length.
setTrafficClass(int) - Method in class io.netty.channel.epoll.EpollDatagramChannelConfig
 
setTrafficClass(int) - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
 
setTrafficClass(int) - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
 
setTrafficClass(int) - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
 
setTrafficClass(int) - Method in interface io.netty.channel.socket.DatagramChannelConfig
setTrafficClass(int) - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
 
setTrafficClass(int) - Method in class io.netty.channel.socket.DefaultSocketChannelConfig
 
setTrafficClass(int) - Method in class io.netty.channel.socket.oio.DefaultOioSocketChannelConfig
 
setTrafficClass(int) - Method in interface io.netty.channel.socket.oio.OioSocketChannelConfig
 
setTrafficClass(int) - Method in interface io.netty.channel.socket.SocketChannelConfig
setTrafficClass(int) - Method in class io.netty.channel.unix.Socket
 
setTruncated(boolean) - Method in class io.netty.handler.codec.dns.DatagramDnsResponse
 
setTruncated(boolean) - Method in class io.netty.handler.codec.dns.DefaultDnsResponse
 
setTruncated(boolean) - Method in interface io.netty.handler.codec.dns.DnsResponse
Set to true if response has been truncated (usually happens for responses over 512 bytes).
setUncancellable() - Method in class io.netty.util.concurrent.DefaultPromise
 
setUncancellable() - Method in interface io.netty.util.concurrent.Promise
Make this future impossible to cancel.
setup() - Method in class io.netty.channel.unix.tests.SocketTest
 
setUserDefinedWritability(int, boolean) - Method in class io.netty.channel.ChannelOutboundBuffer
Sets a user-defined writability flag at the specified index.
setValue(V) - Method in class io.netty.handler.codec.DefaultHeaders.HeaderEntry
 
setValue(V) - Method in interface io.netty.util.collection.ByteObjectMap.PrimitiveEntry
Sets the value for this entry.
setValue(V) - Method in interface io.netty.util.collection.CharObjectMap.PrimitiveEntry
Sets the value for this entry.
setValue(V) - Method in interface io.netty.util.collection.IntObjectMap.PrimitiveEntry
Sets the value for this entry.
setValue(V) - Method in interface io.netty.util.collection.LongObjectMap.PrimitiveEntry
Sets the value for this entry.
setValue(V) - Method in interface io.netty.util.collection.ShortObjectMap.PrimitiveEntry
Sets the value for this entry.
setWriteBufferHighWaterMark(int) - Method in interface io.netty.channel.ChannelConfig
Sets the high water mark of the write buffer.
setWriteBufferHighWaterMark(int) - Method in class io.netty.channel.DefaultChannelConfig
 
setWriteBufferHighWaterMark(int) - Method in class io.netty.channel.epoll.EpollChannelConfig
Deprecated.
setWriteBufferHighWaterMark(int) - Method in class io.netty.channel.epoll.EpollDatagramChannelConfig
Deprecated.
setWriteBufferHighWaterMark(int) - Method in class io.netty.channel.epoll.EpollDomainSocketChannelConfig
Deprecated.
setWriteBufferHighWaterMark(int) - Method in class io.netty.channel.epoll.EpollServerChannelConfig
Deprecated.
setWriteBufferHighWaterMark(int) - Method in class io.netty.channel.epoll.EpollServerSocketChannelConfig
Deprecated.
setWriteBufferHighWaterMark(int) - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
Deprecated.
setWriteBufferHighWaterMark(int) - Method in class io.netty.channel.kqueue.KQueueChannelConfig
Deprecated.
setWriteBufferHighWaterMark(int) - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
Deprecated.
setWriteBufferHighWaterMark(int) - Method in class io.netty.channel.kqueue.KQueueDomainSocketChannelConfig
Deprecated.
setWriteBufferHighWaterMark(int) - Method in class io.netty.channel.kqueue.KQueueServerChannelConfig
Deprecated.
setWriteBufferHighWaterMark(int) - Method in class io.netty.channel.kqueue.KQueueServerSocketChannelConfig
Deprecated.
setWriteBufferHighWaterMark(int) - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
Deprecated.
setWriteBufferHighWaterMark(int) - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
 
setWriteBufferHighWaterMark(int) - Method in class io.netty.channel.socket.DefaultServerSocketChannelConfig
 
setWriteBufferHighWaterMark(int) - Method in class io.netty.channel.socket.DefaultSocketChannelConfig
 
setWriteBufferHighWaterMark(int) - Method in class io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig
 
setWriteBufferHighWaterMark(int) - Method in class io.netty.channel.socket.oio.DefaultOioSocketChannelConfig
 
setWriteBufferHighWaterMark(int) - Method in interface io.netty.channel.socket.oio.OioServerSocketChannelConfig
 
setWriteBufferHighWaterMark(int) - Method in interface io.netty.channel.socket.oio.OioSocketChannelConfig
 
setWriteBufferHighWaterMark(int) - Method in interface io.netty.channel.socket.ServerSocketChannelConfig
 
setWriteBufferHighWaterMark(int) - Method in interface io.netty.channel.unix.DomainSocketChannelConfig
Deprecated.
setWriteBufferLowWaterMark(int) - Method in interface io.netty.channel.ChannelConfig
Sets the low water mark of the write buffer.
setWriteBufferLowWaterMark(int) - Method in class io.netty.channel.DefaultChannelConfig
 
setWriteBufferLowWaterMark(int) - Method in class io.netty.channel.epoll.EpollChannelConfig
Deprecated.
setWriteBufferLowWaterMark(int) - Method in class io.netty.channel.epoll.EpollDatagramChannelConfig
Deprecated.
setWriteBufferLowWaterMark(int) - Method in class io.netty.channel.epoll.EpollDomainSocketChannelConfig
Deprecated.
setWriteBufferLowWaterMark(int) - Method in class io.netty.channel.epoll.EpollServerChannelConfig
Deprecated.
setWriteBufferLowWaterMark(int) - Method in class io.netty.channel.epoll.EpollServerSocketChannelConfig
Deprecated.
setWriteBufferLowWaterMark(int) - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
Deprecated.
setWriteBufferLowWaterMark(int) - Method in class io.netty.channel.kqueue.KQueueChannelConfig
Deprecated.
setWriteBufferLowWaterMark(int) - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
Deprecated.
setWriteBufferLowWaterMark(int) - Method in class io.netty.channel.kqueue.KQueueDomainSocketChannelConfig
Deprecated.
setWriteBufferLowWaterMark(int) - Method in class io.netty.channel.kqueue.KQueueServerChannelConfig
Deprecated.
setWriteBufferLowWaterMark(int) - Method in class io.netty.channel.kqueue.KQueueServerSocketChannelConfig
Deprecated.
setWriteBufferLowWaterMark(int) - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
Deprecated.
setWriteBufferLowWaterMark(int) - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
 
setWriteBufferLowWaterMark(int) - Method in class io.netty.channel.socket.DefaultServerSocketChannelConfig
 
setWriteBufferLowWaterMark(int) - Method in class io.netty.channel.socket.DefaultSocketChannelConfig
 
setWriteBufferLowWaterMark(int) - Method in class io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig
 
setWriteBufferLowWaterMark(int) - Method in class io.netty.channel.socket.oio.DefaultOioSocketChannelConfig
 
setWriteBufferLowWaterMark(int) - Method in interface io.netty.channel.socket.oio.OioServerSocketChannelConfig
 
setWriteBufferLowWaterMark(int) - Method in interface io.netty.channel.socket.oio.OioSocketChannelConfig
 
setWriteBufferLowWaterMark(int) - Method in interface io.netty.channel.socket.ServerSocketChannelConfig
 
setWriteBufferLowWaterMark(int) - Method in interface io.netty.channel.unix.DomainSocketChannelConfig
Deprecated.
setWriteBufferWaterMark(WriteBufferWaterMark) - Method in interface io.netty.channel.ChannelConfig
Set the WriteBufferWaterMark which is used for setting the high and low water mark of the write buffer.
setWriteBufferWaterMark(WriteBufferWaterMark) - Method in class io.netty.channel.DefaultChannelConfig
 
setWriteBufferWaterMark(WriteBufferWaterMark) - Method in class io.netty.channel.epoll.EpollChannelConfig
 
setWriteBufferWaterMark(WriteBufferWaterMark) - Method in class io.netty.channel.epoll.EpollDatagramChannelConfig
 
setWriteBufferWaterMark(WriteBufferWaterMark) - Method in class io.netty.channel.epoll.EpollDomainSocketChannelConfig
 
setWriteBufferWaterMark(WriteBufferWaterMark) - Method in class io.netty.channel.epoll.EpollServerChannelConfig
 
setWriteBufferWaterMark(WriteBufferWaterMark) - Method in class io.netty.channel.epoll.EpollServerSocketChannelConfig
 
setWriteBufferWaterMark(WriteBufferWaterMark) - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
 
setWriteBufferWaterMark(WriteBufferWaterMark) - Method in class io.netty.channel.kqueue.KQueueChannelConfig
 
setWriteBufferWaterMark(WriteBufferWaterMark) - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
 
setWriteBufferWaterMark(WriteBufferWaterMark) - Method in class io.netty.channel.kqueue.KQueueDomainSocketChannelConfig
 
setWriteBufferWaterMark(WriteBufferWaterMark) - Method in class io.netty.channel.kqueue.KQueueServerChannelConfig
 
setWriteBufferWaterMark(WriteBufferWaterMark) - Method in class io.netty.channel.kqueue.KQueueServerSocketChannelConfig
 
setWriteBufferWaterMark(WriteBufferWaterMark) - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
 
setWriteBufferWaterMark(WriteBufferWaterMark) - Method in interface io.netty.channel.socket.DatagramChannelConfig
 
setWriteBufferWaterMark(WriteBufferWaterMark) - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
 
setWriteBufferWaterMark(WriteBufferWaterMark) - Method in class io.netty.channel.socket.DefaultServerSocketChannelConfig
 
setWriteBufferWaterMark(WriteBufferWaterMark) - Method in class io.netty.channel.socket.DefaultSocketChannelConfig
 
setWriteBufferWaterMark(WriteBufferWaterMark) - Method in class io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig
 
setWriteBufferWaterMark(WriteBufferWaterMark) - Method in class io.netty.channel.socket.oio.DefaultOioSocketChannelConfig
 
setWriteBufferWaterMark(WriteBufferWaterMark) - Method in interface io.netty.channel.socket.oio.OioServerSocketChannelConfig
 
setWriteBufferWaterMark(WriteBufferWaterMark) - Method in interface io.netty.channel.socket.oio.OioSocketChannelConfig
 
setWriteBufferWaterMark(WriteBufferWaterMark) - Method in interface io.netty.channel.socket.ServerSocketChannelConfig
 
setWriteBufferWaterMark(WriteBufferWaterMark) - Method in interface io.netty.channel.socket.SocketChannelConfig
 
setWriteBufferWaterMark(WriteBufferWaterMark) - Method in interface io.netty.channel.unix.DomainSocketChannelConfig
 
setWriteChannelLimit(long) - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
 
setWriteLimit(long) - Method in class io.netty.handler.traffic.AbstractTrafficShapingHandler
Note the change will be taken as best effort, meaning that all already scheduled traffics will not be changed, but only applied to new traffics.
setWriteSpinCount(int) - Method in interface io.netty.channel.ChannelConfig
Sets the maximum loop count for a write operation until WritableByteChannel.write(ByteBuffer) returns a non-zero value.
setWriteSpinCount(int) - Method in class io.netty.channel.DefaultChannelConfig
 
setWriteSpinCount(int) - Method in class io.netty.channel.epoll.EpollChannelConfig
 
setWriteSpinCount(int) - Method in class io.netty.channel.epoll.EpollDatagramChannelConfig
 
setWriteSpinCount(int) - Method in class io.netty.channel.epoll.EpollDomainSocketChannelConfig
 
setWriteSpinCount(int) - Method in class io.netty.channel.epoll.EpollServerChannelConfig
 
setWriteSpinCount(int) - Method in class io.netty.channel.epoll.EpollServerSocketChannelConfig
 
setWriteSpinCount(int) - Method in class io.netty.channel.epoll.EpollSocketChannelConfig
 
setWriteSpinCount(int) - Method in class io.netty.channel.kqueue.KQueueChannelConfig
 
setWriteSpinCount(int) - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
 
setWriteSpinCount(int) - Method in class io.netty.channel.kqueue.KQueueDomainSocketChannelConfig
 
setWriteSpinCount(int) - Method in class io.netty.channel.kqueue.KQueueServerChannelConfig
 
setWriteSpinCount(int) - Method in class io.netty.channel.kqueue.KQueueServerSocketChannelConfig
 
setWriteSpinCount(int) - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
 
setWriteSpinCount(int) - Method in interface io.netty.channel.socket.DatagramChannelConfig
 
setWriteSpinCount(int) - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
 
setWriteSpinCount(int) - Method in class io.netty.channel.socket.DefaultServerSocketChannelConfig
 
setWriteSpinCount(int) - Method in class io.netty.channel.socket.DefaultSocketChannelConfig
 
setWriteSpinCount(int) - Method in class io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig
 
setWriteSpinCount(int) - Method in class io.netty.channel.socket.oio.DefaultOioSocketChannelConfig
 
setWriteSpinCount(int) - Method in interface io.netty.channel.socket.oio.OioServerSocketChannelConfig
 
setWriteSpinCount(int) - Method in interface io.netty.channel.socket.oio.OioSocketChannelConfig
 
setWriteSpinCount(int) - Method in interface io.netty.channel.socket.ServerSocketChannelConfig
 
setWriteSpinCount(int) - Method in interface io.netty.channel.socket.SocketChannelConfig
 
setWriteSpinCount(int) - Method in interface io.netty.channel.unix.DomainSocketChannelConfig
 
setZ(int) - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
 
setZ(int) - Method in class io.netty.handler.codec.dns.DatagramDnsQuery
 
setZ(int) - Method in class io.netty.handler.codec.dns.DatagramDnsResponse
 
setZ(int) - Method in class io.netty.handler.codec.dns.DefaultDnsQuery
 
setZ(int) - Method in class io.netty.handler.codec.dns.DefaultDnsResponse
 
setZ(int) - Method in interface io.netty.handler.codec.dns.DnsMessage
Sets the Z (reserved for future use) field of this DNS message.
setZ(int) - Method in interface io.netty.handler.codec.dns.DnsQuery
 
setZ(int) - Method in interface io.netty.handler.codec.dns.DnsResponse
 
setZero(int, int) - Method in class io.netty.buffer.AbstractByteBuf
 
setZero(int, int) - Method in class io.netty.buffer.ByteBuf
Fills this buffer with NUL (0x00) starting at the specified absolute index.
setZero(int, int) - Method in class io.netty.buffer.CompositeByteBuf
 
setZero(int, int) - Method in class io.netty.buffer.EmptyByteBuf
 
setZero(int, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
setZero(int, int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
ShortCollections - Class in io.netty.util.collection
Utilities for short-based primitive collections.
shortCommitHash() - Method in class io.netty.util.Version
 
ShortObjectHashMap<V> - Class in io.netty.util.collection
A hash map implementation of ShortObjectMap that uses open addressing for keys.
ShortObjectHashMap() - Constructor for class io.netty.util.collection.ShortObjectHashMap
 
ShortObjectHashMap(int) - Constructor for class io.netty.util.collection.ShortObjectHashMap
 
ShortObjectHashMap(int, float) - Constructor for class io.netty.util.collection.ShortObjectHashMap
 
ShortObjectMap<V> - Interface in io.netty.util.collection
Interface for a primitive map that uses shorts as keys.
ShortObjectMap.PrimitiveEntry<V> - Interface in io.netty.util.collection
A primitive entry in the map, provided by the iterator from ShortObjectMap.entries()
shuffled(Iterable<? extends InetSocketAddress>) - Static method in class io.netty.resolver.dns.DnsServerAddresses
Returns the DnsServerAddresses that yields the specified address in a shuffled order.
shuffled(InetSocketAddress...) - Static method in class io.netty.resolver.dns.DnsServerAddresses
Returns the DnsServerAddresses that yields the specified addresses in a shuffled order.
shutdown() - Method in class io.netty.channel.epoll.AbstractEpollStreamChannel
 
shutdown(ChannelPromise) - Method in class io.netty.channel.epoll.AbstractEpollStreamChannel
 
shutdown() - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel
 
shutdown(ChannelPromise) - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel
 
shutdown() - Method in interface io.netty.channel.socket.DuplexChannel
Will shutdown the input and output sides of this channel.
shutdown(ChannelPromise) - Method in interface io.netty.channel.socket.DuplexChannel
Will shutdown the input and output sides of this channel.
shutdown() - Method in class io.netty.channel.socket.nio.NioSocketChannel
 
shutdown(ChannelPromise) - Method in class io.netty.channel.socket.nio.NioSocketChannel
 
shutdown() - Method in class io.netty.channel.socket.oio.OioSocketChannel
 
shutdown(ChannelPromise) - Method in class io.netty.channel.socket.oio.OioSocketChannel
 
shutdown() - Method in class io.netty.channel.ThreadPerChannelEventLoopGroup
Deprecated.
shutdown() - Method in class io.netty.channel.unix.Socket
 
shutdown(boolean, boolean) - Method in class io.netty.channel.unix.Socket
 
shutdown() - Method in class io.netty.util.concurrent.AbstractEventExecutor
shutdown() - Method in class io.netty.util.concurrent.AbstractEventExecutorGroup
shutdown() - Method in interface io.netty.util.concurrent.EventExecutorGroup
shutdown() - Method in class io.netty.util.concurrent.GlobalEventExecutor
Deprecated.
shutdown() - Method in class io.netty.util.concurrent.ImmediateEventExecutor
Deprecated.
shutdown() - Method in class io.netty.util.concurrent.MultithreadEventExecutorGroup
Deprecated.
shutdown() - Method in class io.netty.util.concurrent.NonStickyEventExecutorGroup
 
shutdown() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
Deprecated.
shutdown() - Method in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor
 
shutdownGracefully(long, long, TimeUnit) - Method in class io.netty.channel.ThreadPerChannelEventLoopGroup
 
shutdownGracefully() - Method in class io.netty.util.concurrent.AbstractEventExecutor
 
shutdownGracefully() - Method in class io.netty.util.concurrent.AbstractEventExecutorGroup
 
shutdownGracefully() - Method in interface io.netty.util.concurrent.EventExecutorGroup
Shortcut method for EventExecutorGroup.shutdownGracefully(long, long, TimeUnit) with sensible default values.
shutdownGracefully(long, long, TimeUnit) - Method in interface io.netty.util.concurrent.EventExecutorGroup
Signals this executor that the caller wants the executor to be shut down.
shutdownGracefully(long, long, TimeUnit) - Method in class io.netty.util.concurrent.GlobalEventExecutor
 
shutdownGracefully(long, long, TimeUnit) - Method in class io.netty.util.concurrent.ImmediateEventExecutor
 
shutdownGracefully(long, long, TimeUnit) - Method in class io.netty.util.concurrent.MultithreadEventExecutorGroup
 
shutdownGracefully() - Method in class io.netty.util.concurrent.NonStickyEventExecutorGroup
 
shutdownGracefully(long, long, TimeUnit) - Method in class io.netty.util.concurrent.NonStickyEventExecutorGroup
 
shutdownGracefully(long, long, TimeUnit) - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
 
shutdownGracefully() - Method in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor
 
shutdownGracefully(long, long, TimeUnit) - Method in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor
 
shutdownInput() - Method in class io.netty.channel.epoll.AbstractEpollStreamChannel
 
shutdownInput(ChannelPromise) - Method in class io.netty.channel.epoll.AbstractEpollStreamChannel
 
shutdownInput() - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel
 
shutdownInput(ChannelPromise) - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel
 
shutdownInput() - Method in class io.netty.channel.nio.AbstractNioByteChannel
Shutdown the input side of the channel.
shutdownInput() - Method in class io.netty.channel.oio.AbstractOioByteChannel
Shutdown the input side of this channel.
shutdownInput() - Method in interface io.netty.channel.socket.DuplexChannel
 
shutdownInput(ChannelPromise) - Method in interface io.netty.channel.socket.DuplexChannel
Will shutdown the input and notify ChannelPromise.
shutdownInput() - Method in class io.netty.channel.socket.nio.NioSocketChannel
 
shutdownInput(ChannelPromise) - Method in class io.netty.channel.socket.nio.NioSocketChannel
 
shutdownInput() - Method in class io.netty.channel.socket.oio.OioSocketChannel
 
shutdownInput(ChannelPromise) - Method in class io.netty.channel.socket.oio.OioSocketChannel
 
shutdownNow() - Method in class io.netty.util.concurrent.AbstractEventExecutor
shutdownNow() - Method in class io.netty.util.concurrent.AbstractEventExecutorGroup
shutdownNow() - Method in interface io.netty.util.concurrent.EventExecutorGroup
shutdownNow() - Method in class io.netty.util.concurrent.NonStickyEventExecutorGroup
 
shutdownNow() - Method in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor
 
shutdownOutput() - Method in class io.netty.channel.epoll.AbstractEpollStreamChannel
 
shutdownOutput(ChannelPromise) - Method in class io.netty.channel.epoll.AbstractEpollStreamChannel
 
shutdownOutput() - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel
 
shutdownOutput(ChannelPromise) - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel
 
shutdownOutput() - Method in interface io.netty.channel.socket.DuplexChannel
 
shutdownOutput(ChannelPromise) - Method in interface io.netty.channel.socket.DuplexChannel
Will shutdown the output and notify ChannelPromise.
shutdownOutput() - Method in class io.netty.channel.socket.nio.NioSocketChannel
 
shutdownOutput(ChannelPromise) - Method in class io.netty.channel.socket.nio.NioSocketChannel
 
shutdownOutput() - Method in class io.netty.channel.socket.oio.OioSocketChannel
 
shutdownOutput(ChannelPromise) - Method in class io.netty.channel.socket.oio.OioSocketChannel
 
SIG - Static variable in class io.netty.handler.codec.dns.DnsRecordType
Signature record RFC 2535 Signature record used in SIG(0) (RFC 2931) and TKEY (RFC 2930).
Signal - Error in io.netty.util
A special Error which is used to signal some state or request by throwing it.
SIGNAL_SUCCESS - Static variable in class io.netty.handler.codec.DecoderResult
 
SIGNAL_UNFINISHED - Static variable in class io.netty.handler.codec.DecoderResult
 
SimpleChannelInboundHandler<I> - Class in io.netty.channel
ChannelInboundHandlerAdapter which allows to explicit only handle a specific type of messages.
SimpleChannelInboundHandler() - Constructor for class io.netty.channel.SimpleChannelInboundHandler
SimpleChannelInboundHandler(boolean) - Constructor for class io.netty.channel.SimpleChannelInboundHandler
Create a new instance which will try to detect the types to match out of the type parameter of the class.
SimpleChannelInboundHandler(Class<? extends I>) - Constructor for class io.netty.channel.SimpleChannelInboundHandler
SimpleChannelInboundHandler(Class<? extends I>, boolean) - Constructor for class io.netty.channel.SimpleChannelInboundHandler
Create a new instance
SimpleChannelPool - Class in io.netty.channel.pool
Simple ChannelPool implementation which will create new Channels if someone tries to acquire a Channel but none is in the pool atm.
SimpleChannelPool(Bootstrap, ChannelPoolHandler) - Constructor for class io.netty.channel.pool.SimpleChannelPool
Creates a new instance using the ChannelHealthChecker.ACTIVE.
SimpleChannelPool(Bootstrap, ChannelPoolHandler, ChannelHealthChecker) - Constructor for class io.netty.channel.pool.SimpleChannelPool
Creates a new instance.
SimpleChannelPool(Bootstrap, ChannelPoolHandler, ChannelHealthChecker, boolean) - Constructor for class io.netty.channel.pool.SimpleChannelPool
Creates a new instance.
simpleClassName(Object) - Static method in class io.netty.util.internal.StringUtil
simpleClassName(Class<?>) - Static method in class io.netty.util.internal.StringUtil
Generates a simplified name from a Class.
SimpleNameResolver<T> - Class in io.netty.resolver
A skeletal NameResolver implementation.
SimpleNameResolver(EventExecutor) - Constructor for class io.netty.resolver.SimpleNameResolver
 
SimpleStringRedisMessage - Class in io.netty.handler.codec.redis
Simple Strings of RESP.
SimpleStringRedisMessage(String) - Constructor for class io.netty.handler.codec.redis.SimpleStringRedisMessage
Creates a SimpleStringRedisMessage for the given content.
SimpleTrustManagerFactory - Class in io.netty.handler.ssl.util
Helps to implement a custom TrustManagerFactory.
SimpleTrustManagerFactory() - Constructor for class io.netty.handler.ssl.util.SimpleTrustManagerFactory
Creates a new instance.
SimpleTrustManagerFactory(String) - Constructor for class io.netty.handler.ssl.util.SimpleTrustManagerFactory
Creates a new instance.
SINGLE_EVENTEXECUTOR_PER_GROUP - Static variable in class io.netty.channel.ChannelOption
 
SingleThreadEventExecutor - Class in io.netty.util.concurrent
Abstract base class for OrderedEventExecutor's that execute all its submitted tasks in a single thread.
SingleThreadEventExecutor(EventExecutorGroup, ThreadFactory, boolean) - Constructor for class io.netty.util.concurrent.SingleThreadEventExecutor
Create a new instance
SingleThreadEventExecutor(EventExecutorGroup, ThreadFactory, boolean, int, RejectedExecutionHandler) - Constructor for class io.netty.util.concurrent.SingleThreadEventExecutor
Create a new instance
SingleThreadEventExecutor(EventExecutorGroup, Executor, boolean) - Constructor for class io.netty.util.concurrent.SingleThreadEventExecutor
Create a new instance
SingleThreadEventExecutor(EventExecutorGroup, Executor, boolean, int, RejectedExecutionHandler) - Constructor for class io.netty.util.concurrent.SingleThreadEventExecutor
Create a new instance
SingleThreadEventLoop - Class in io.netty.channel
Abstract base class for EventLoops that execute all its submitted tasks in a single thread.
SingleThreadEventLoop(EventLoopGroup, ThreadFactory, boolean) - Constructor for class io.netty.channel.SingleThreadEventLoop
 
SingleThreadEventLoop(EventLoopGroup, Executor, boolean) - Constructor for class io.netty.channel.SingleThreadEventLoop
 
SingleThreadEventLoop(EventLoopGroup, ThreadFactory, boolean, int, RejectedExecutionHandler) - Constructor for class io.netty.channel.SingleThreadEventLoop
 
SingleThreadEventLoop(EventLoopGroup, Executor, boolean, int, RejectedExecutionHandler) - Constructor for class io.netty.channel.SingleThreadEventLoop
 
singleton(InetSocketAddress) - Static method in class io.netty.resolver.dns.DnsServerAddresses
Returns the DnsServerAddresses that yields only a single address.
SingletonDnsServerAddressStreamProvider - Class in io.netty.resolver.dns
A DnsServerAddressStreamProvider which always uses a single DNS server for resolution.
SingletonDnsServerAddressStreamProvider(InetSocketAddress) - Constructor for class io.netty.resolver.dns.SingletonDnsServerAddressStreamProvider
Create a new instance.
size() - Method in class io.netty.channel.ChannelOutboundBuffer
Returns the number of flushed messages in this ChannelOutboundBuffer.
size() - Method in class io.netty.channel.group.DefaultChannelGroup
 
size(Object) - Method in interface io.netty.channel.MessageSizeEstimator.Handle
Calculate the size of the given message.
size() - Method in class io.netty.channel.PendingWriteQueue
Returns the number of pending write operations.
size() - Method in class io.netty.channel.pool.AbstractChannelPoolMap
Returns the number of ChannelPools currently in this AbstractChannelPoolMap.
size() - Method in class io.netty.channel.unix.IovArray
Returns the size in bytes
size() - Method in class io.netty.handler.codec.DefaultHeaders
 
size() - Method in class io.netty.handler.codec.EmptyHeaders
 
size() - Method in interface io.netty.handler.codec.Headers
Returns the number of headers in this object.
size() - Method in class io.netty.handler.codec.serialization.ObjectEncoderOutputStream
 
size() - Method in interface io.netty.resolver.dns.DnsServerAddressStream
Get the number of times DnsServerAddressStream.next() will return a distinct element before repeating or terminating.
size() - Method in class io.netty.util.collection.ByteObjectHashMap
 
size() - Method in class io.netty.util.collection.CharObjectHashMap
 
size() - Method in class io.netty.util.collection.IntObjectHashMap
 
size() - Method in class io.netty.util.collection.LongObjectHashMap
 
size() - Method in class io.netty.util.collection.ShortObjectHashMap
 
size() - Static method in class io.netty.util.concurrent.FastThreadLocal
Returns the number of thread local variables bound to the current thread.
size() - Method in class io.netty.util.internal.ConcurrentSet
 
size() - Method in class io.netty.util.internal.DefaultPriorityQueue
 
size() - Method in class io.netty.util.internal.EmptyPriorityQueue
 
size() - Method in class io.netty.util.internal.InternalThreadLocalMap
 
SIZEOF_JLONG - Static variable in class io.netty.channel.unix.Limits
 
sizeofEpollEvent() - Static method in class io.netty.channel.epoll.Native
 
skip(long) - Method in class io.netty.buffer.ByteBufInputStream
 
skip(long) - Method in class io.netty.handler.codec.serialization.ObjectDecoderInputStream
 
skipBytes(int) - Method in class io.netty.buffer.AbstractByteBuf
 
skipBytes(int) - Method in class io.netty.buffer.ByteBuf
Increases the current readerIndex by the specified length in this buffer.
skipBytes(int) - Method in class io.netty.buffer.ByteBufInputStream
 
skipBytes(int) - Method in class io.netty.buffer.CompositeByteBuf
 
skipBytes(int) - Method in class io.netty.buffer.EmptyByteBuf
 
skipBytes(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
skipBytes(int) - Method in class io.netty.handler.codec.serialization.ObjectDecoderInputStream
 
Slf4JLoggerFactory - Class in io.netty.util.internal.logging
Logger factory which creates a SLF4J logger.
Slf4JLoggerFactory() - Constructor for class io.netty.util.internal.logging.Slf4JLoggerFactory
Deprecated.
slice() - Method in class io.netty.buffer.AbstractByteBuf
 
slice(int, int) - Method in class io.netty.buffer.AbstractByteBuf
 
slice() - Method in class io.netty.buffer.ByteBuf
Returns a slice of this buffer's readable bytes.
slice(int, int) - Method in class io.netty.buffer.ByteBuf
Returns a slice of this buffer's sub-region.
slice(int, int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
slice() - Method in class io.netty.buffer.EmptyByteBuf
 
slice(int, int) - Method in class io.netty.buffer.EmptyByteBuf
 
slice(int, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
slice() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
slice(int, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
SlicedByteBuf - Class in io.netty.buffer
Deprecated.
Do not use.
SlicedByteBuf(ByteBuf, int, int) - Constructor for class io.netty.buffer.SlicedByteBuf
Deprecated.
 
slowDownFactor() - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
 
smallCacheSize() - Method in class io.netty.buffer.PooledByteBufAllocator
smallCacheSize() - Method in class io.netty.buffer.PooledByteBufAllocatorMetric
Return the size of the small cache.
smallSubpages() - Method in interface io.netty.buffer.PoolArenaMetric
Returns an unmodifiable List which holds PoolSubpageMetrics for small sub-pages.
SmtpCommand - Class in io.netty.handler.codec.smtp
The command part of a SmtpRequest.
SmtpContent - Interface in io.netty.handler.codec.smtp
Content that is sent after the DATA request.
SmtpRequest - Interface in io.netty.handler.codec.smtp
An SMTP request.
SmtpRequestEncoder - Class in io.netty.handler.codec.smtp
Encoder for SMTP requests.
SmtpRequestEncoder() - Constructor for class io.netty.handler.codec.smtp.SmtpRequestEncoder
 
SmtpRequests - Class in io.netty.handler.codec.smtp
Provides utility methods to create SmtpRequests.
SmtpResponse - Interface in io.netty.handler.codec.smtp
A SMTP response
SmtpResponseDecoder - Class in io.netty.handler.codec.smtp
Decoder for SMTP responses.
SmtpResponseDecoder(int) - Constructor for class io.netty.handler.codec.smtp.SmtpResponseDecoder
Creates a new instance that enforces the given maxLineLength.
Snappy - Class in io.netty.handler.codec.compression
Uncompresses an input ByteBuf encoded with Snappy compression into an output ByteBuf.
Snappy() - Constructor for class io.netty.handler.codec.compression.Snappy
 
SnappyFramedDecoder - Class in io.netty.handler.codec.compression
Deprecated.
Use SnappyFrameDecoder instead.
SnappyFramedDecoder() - Constructor for class io.netty.handler.codec.compression.SnappyFramedDecoder
Deprecated.
 
SnappyFrameDecoder - Class in io.netty.handler.codec.compression
Uncompresses a ByteBuf encoded with the Snappy framing format.
SnappyFrameDecoder() - Constructor for class io.netty.handler.codec.compression.SnappyFrameDecoder
Creates a new snappy-framed decoder with validation of checksums turned OFF.
SnappyFrameDecoder(boolean) - Constructor for class io.netty.handler.codec.compression.SnappyFrameDecoder
Creates a new snappy-framed decoder with validation of checksums as specified.
SnappyFramedEncoder - Class in io.netty.handler.codec.compression
Deprecated.
Use SnappyFrameEncoder instead.
SnappyFramedEncoder() - Constructor for class io.netty.handler.codec.compression.SnappyFramedEncoder
Deprecated.
 
SnappyFrameEncoder - Class in io.netty.handler.codec.compression
Compresses a ByteBuf using the Snappy framing format.
SnappyFrameEncoder() - Constructor for class io.netty.handler.codec.compression.SnappyFrameEncoder
 
sndCwnd() - Method in class io.netty.channel.epoll.EpollTcpInfo
 
sndMss() - Method in class io.netty.channel.epoll.EpollTcpInfo
 
sndSsthresh() - Method in class io.netty.channel.epoll.EpollTcpInfo
 
sndWscale() - Method in class io.netty.channel.epoll.EpollTcpInfo
 
SniHandler - Class in io.netty.handler.ssl
Enables SNI (Server Name Indication) extension for server side SSL.
SniHandler(Mapping<? super String, ? extends SslContext>) - Constructor for class io.netty.handler.ssl.SniHandler
Creates a SNI detection handler with configured SslContext maintained by Mapping
SniHandler(DomainNameMapping<? extends SslContext>) - Constructor for class io.netty.handler.ssl.SniHandler
Creates a SNI detection handler with configured SslContext maintained by DomainNameMapping
SniHandler(AsyncMapping<? super String, ? extends SslContext>) - Constructor for class io.netty.handler.ssl.SniHandler
Creates a SNI detection handler with configured SslContext maintained by AsyncMapping
SO_ACCEPTFILTER - Static variable in class io.netty.channel.kqueue.KQueueChannelOption
 
SO_BACKLOG - Static variable in class io.netty.channel.ChannelOption
 
SO_BROADCAST - Static variable in class io.netty.channel.ChannelOption
 
SO_KEEPALIVE - Static variable in class io.netty.channel.ChannelOption
 
SO_LINGER - Static variable in class io.netty.channel.ChannelOption
 
SO_RCVBUF - Static variable in class io.netty.channel.ChannelOption
 
SO_REUSEADDR - Static variable in class io.netty.channel.ChannelOption
 
SO_REUSEPORT - Static variable in class io.netty.channel.unix.UnixChannelOption
 
SO_SNDBUF - Static variable in class io.netty.channel.ChannelOption
 
SO_SNDLOWAT - Static variable in class io.netty.channel.kqueue.KQueueChannelOption
 
SO_TIMEOUT - Static variable in class io.netty.channel.ChannelOption
 
SO_TIMEOUT - Static variable in class io.netty.channel.oio.AbstractOioChannel
 
SOA - Static variable in class io.netty.handler.codec.dns.DnsRecordType
Start of [a zone of] authority record RFC 1035 and RFC 2308 Specifies authoritative information about a DNS zone, including the primary name server, the email of the domain administrator, the domain serial number, and several timers relating to refreshing the zone.
Socket - Class in io.netty.channel.unix
Provides a JNI bridge to native socket operations.
Socket(int) - Constructor for class io.netty.channel.unix.Socket
 
socket - Variable in class io.netty.channel.unix.tests.SocketTest
 
socketAddress(String, int) - Static method in class io.netty.util.internal.SocketUtils
 
SocketChannel - Interface in io.netty.channel.socket
A TCP/IP socket Channel.
SocketChannelConfig - Interface in io.netty.channel.socket
SocketTest<T extends Socket> - Class in io.netty.channel.unix.tests
 
SocketTest() - Constructor for class io.netty.channel.unix.tests.SocketTest
 
SocketUtils - Class in io.netty.util.internal
Provides socket operations with privileges enabled.
SocketWritableByteChannel - Class in io.netty.channel.unix
 
SocketWritableByteChannel(FileDescriptor) - Constructor for class io.netty.channel.unix.SocketWritableByteChannel
 
softCachingConcurrentResolver(ClassLoader) - Static method in class io.netty.handler.codec.serialization.ClassResolvers
agressive concurrent cache good for shared cache, when we're not worried about class unloading
softCachingResolver(ClassLoader) - Static method in class io.netty.handler.codec.serialization.ClassResolvers
agressive non-concurrent cache good for non-shared cache, when we're not worried about class unloading
SOMAXCONN - Static variable in class io.netty.util.NetUtil
The SOMAXCONN value of the current machine.
sourcePrefixLength() - Method in class io.netty.handler.codec.dns.DefaultDnsOptEcsRecord
 
sourcePrefixLength() - Method in interface io.netty.handler.codec.dns.DnsOptEcsRecord
Returns the leftmost number of significant bits of ADDRESS to be used for the lookup.
SPACE - Static variable in class io.netty.util.internal.StringUtil
 
SPDY_1 - Static variable in class io.netty.handler.ssl.ApplicationProtocolNames
"spdy/1": SPDY version 1
SPDY_2 - Static variable in class io.netty.handler.ssl.ApplicationProtocolNames
"spdy/2": SPDY version 2
SPDY_3 - Static variable in class io.netty.handler.ssl.ApplicationProtocolNames
"spdy/3": SPDY version 3
SPDY_3_1 - Static variable in class io.netty.handler.ssl.ApplicationProtocolNames
"spdy/3.1": SPDY version 3.1
SPF - Static variable in class io.netty.handler.codec.dns.DnsRecordType
Sender Policy Framework record RFC 4408 Specified as part of the SPF protocol as an alternative to of storing SPF data in TXT records.
splice(int, long, int, long, long) - Static method in class io.netty.channel.epoll.Native
 
spliceIn(FileDescriptor, RecvByteBufAllocator.Handle) - Method in class io.netty.channel.epoll.AbstractEpollStreamChannel.SpliceInTask
 
SpliceInTask(int, ChannelPromise) - Constructor for class io.netty.channel.epoll.AbstractEpollStreamChannel.SpliceInTask
 
spliceTo(AbstractEpollStreamChannel, int) - Method in class io.netty.channel.epoll.AbstractEpollStreamChannel
spliceTo(AbstractEpollStreamChannel, int, ChannelPromise) - Method in class io.netty.channel.epoll.AbstractEpollStreamChannel
spliceTo(FileDescriptor, int, int) - Method in class io.netty.channel.epoll.AbstractEpollStreamChannel
Splice from this AbstractEpollStreamChannel to another FileDescriptor.
spliceTo(FileDescriptor, int, int, ChannelPromise) - Method in class io.netty.channel.epoll.AbstractEpollStreamChannel
Splice from this AbstractEpollStreamChannel to another FileDescriptor.
split(String, int) - Method in class io.netty.util.AsciiString
Splits this string using the supplied regular expression expr.
split(char) - Method in class io.netty.util.AsciiString
Splits the specified String with the specified delimiter..
SRV - Static variable in class io.netty.handler.codec.dns.DnsRecordType
Service locator RFC 2782 Generalized service location record, used for newer protocols instead of creating protocol-specific records such as MX.
SSHFP - Static variable in class io.netty.handler.codec.dns.DnsRecordType
SSH Public Key Fingerprint record RFC 4255 Resource record for publishing SSH public host key fingerprints in the DNS System, in order to aid in verifying the authenticity of the host.
SSIZE_MAX - Static variable in class io.netty.channel.unix.Limits
 
SslCloseCompletionEvent - Class in io.netty.handler.ssl
Event that is fired once the close_notify was received or if an failure happens before it was received.
SslCloseCompletionEvent(Throwable) - Constructor for class io.netty.handler.ssl.SslCloseCompletionEvent
Creates a new event that indicates an close_notify was not received because of an previous error.
sslCloseFuture() - Method in class io.netty.handler.ssl.SslHandler
Return the Future that will get notified if the inbound of the SSLEngine is closed.
SslCompletionEvent - Class in io.netty.handler.ssl
 
sslContext() - Method in class io.netty.handler.ssl.SniHandler
 
SslContext - Class in io.netty.handler.ssl
A secure socket protocol implementation which acts as a factory for SSLEngine and SslHandler.
SslContext() - Constructor for class io.netty.handler.ssl.SslContext
Creates a new instance (startTls set to false).
SslContext(boolean) - Constructor for class io.netty.handler.ssl.SslContext
Creates a new instance.
SslContextBuilder - Class in io.netty.handler.ssl
Builder for configuring a new SslContext for creation.
sslContextProvider(Provider) - Method in class io.netty.handler.ssl.SslContextBuilder
The SSLContext Provider to use.
SslHandler - Class in io.netty.handler.ssl
Adds SSL · TLS and StartTLS support to a Channel.
SslHandler(SSLEngine) - Constructor for class io.netty.handler.ssl.SslHandler
Creates a new instance.
SslHandler(SSLEngine, boolean) - Constructor for class io.netty.handler.ssl.SslHandler
Creates a new instance.
SslHandler(SSLEngine, Executor) - Constructor for class io.netty.handler.ssl.SslHandler
Deprecated.
SslHandler(SSLEngine, boolean, Executor) - Constructor for class io.netty.handler.ssl.SslHandler
SslHandshakeCompletionEvent - Class in io.netty.handler.ssl
Event that is fired once the SSL handshake is complete, which may be because it was successful or there was an error.
SslHandshakeCompletionEvent(Throwable) - Constructor for class io.netty.handler.ssl.SslHandshakeCompletionEvent
Creates a new event that indicates an unsuccessful handshake.
sslProvider(SslProvider) - Method in class io.netty.handler.ssl.SslContextBuilder
The SslContext implementation to use.
SslProvider - Enum in io.netty.handler.ssl
An enumeration of SSL/TLS protocol providers.
stackTrace() - Method in interface io.netty.util.concurrent.ThreadProperties
 
stackTraceToString(Throwable) - Static method in class io.netty.util.internal.ThrowableUtil
Gets the stack trace from a Throwable as a String.
start() - Method in class io.netty.handler.traffic.GlobalChannelTrafficCounter
Start the monitoring process.
start() - Method in class io.netty.handler.traffic.TrafficCounter
Start the monitoring process.
start() - Method in class io.netty.util.HashedWheelTimer
Starts the background thread explicitly.
startOffset() - Method in class io.netty.handler.stream.ChunkedFile
Returns the offset in the file where the transfer began.
startOffset() - Method in class io.netty.handler.stream.ChunkedNioFile
Returns the offset in the file where the transfer began.
startsWith(CharSequence) - Method in class io.netty.util.AsciiString
Compares the specified string to this string to determine if the specified string is a prefix.
startsWith(CharSequence, int) - Method in class io.netty.util.AsciiString
Compares the specified string to this string, starting at the specified offset, to determine if the specified string is a prefix.
startTls(boolean) - Method in class io.netty.handler.ssl.SslContextBuilder
true if the first write request shouldn't be encrypted.
STAT - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
state() - Method in class io.netty.channel.epoll.EpollTcpInfo
 
state() - Method in class io.netty.handler.codec.ProtocolDetectionResult
state() - Method in class io.netty.handler.codec.ReplayingDecoder
Returns the current state of this decoder.
state(S) - Method in class io.netty.handler.codec.ReplayingDecoder
Sets the current state of this decoder.
state() - Method in class io.netty.handler.timeout.IdleStateEvent
Returns the idle state.
state() - Method in interface io.netty.util.concurrent.ThreadProperties
 
STATUS - Static variable in class io.netty.handler.codec.dns.DnsOpCode
The 'Status' DNS OpCode, as defined in RFC1035.
status() - Method in interface io.netty.handler.codec.memcache.binary.BinaryMemcacheResponse
Returns the status of the response.
status() - Method in class io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheResponse
 
StompCommand - Enum in io.netty.handler.codec.stomp
STOMP command
StompContentSubframe - Interface in io.netty.handler.codec.stomp
An STOMP chunk which is used for STOMP chunked transfer-encoding.
StompFrame - Interface in io.netty.handler.codec.stomp
Combines StompHeadersSubframe and LastStompContentSubframe into one frame.
StompHeaders - Interface in io.netty.handler.codec.stomp
The multimap data structure for the STOMP header names and values.
StompHeadersSubframe - Interface in io.netty.handler.codec.stomp
An interface that defines a StompFrame's command and headers.
StompSubframe - Interface in io.netty.handler.codec.stomp
Defines a common interface for all StompSubframe implementations.
StompSubframeAggregator - Class in io.netty.handler.codec.stomp
A ChannelHandler that aggregates an StompHeadersSubframe and its following StompContentSubframes into a single StompFrame.
StompSubframeAggregator(int) - Constructor for class io.netty.handler.codec.stomp.StompSubframeAggregator
Creates a new instance.
StompSubframeDecoder - Class in io.netty.handler.codec.stomp
StompSubframeDecoder() - Constructor for class io.netty.handler.codec.stomp.StompSubframeDecoder
 
StompSubframeDecoder(int, int) - Constructor for class io.netty.handler.codec.stomp.StompSubframeDecoder
 
StompSubframeEncoder - Class in io.netty.handler.codec.stomp
Encodes a StompFrame or a StompSubframe into a ByteBuf.
StompSubframeEncoder() - Constructor for class io.netty.handler.codec.stomp.StompSubframeEncoder
 
stop() - Method in class io.netty.handler.traffic.GlobalChannelTrafficCounter
Stop the monitoring process.
stop() - Method in class io.netty.handler.traffic.TrafficCounter
Stop the monitoring process.
stop() - Method in class io.netty.util.HashedWheelTimer
 
stop() - Method in interface io.netty.util.Timer
Releases all resources acquired by this Timer and cancels all tasks which were scheduled but not executed yet.
stream() - Method in class io.netty.resolver.dns.DnsServerAddresses
Starts a new infinite stream of DNS server addresses.
stringBuilder() - Method in class io.netty.util.internal.InternalThreadLocalMap
 
StringDecoder - Class in io.netty.handler.codec.string
Decodes a received ByteBuf into a String.
StringDecoder() - Constructor for class io.netty.handler.codec.string.StringDecoder
Creates a new instance with the current system character set.
StringDecoder(Charset) - Constructor for class io.netty.handler.codec.string.StringDecoder
Creates a new instance with the specified character set.
StringEncoder - Class in io.netty.handler.codec.string
Encodes the requested String into a ByteBuf.
StringEncoder() - Constructor for class io.netty.handler.codec.string.StringEncoder
Creates a new instance with the current system character set.
StringEncoder(Charset) - Constructor for class io.netty.handler.codec.string.StringEncoder
Creates a new instance with the specified character set.
StringUtil - Class in io.netty.util.internal
String utility class.
submit(Runnable) - Method in class io.netty.util.concurrent.AbstractEventExecutor
 
submit(Runnable, T) - Method in class io.netty.util.concurrent.AbstractEventExecutor
 
submit(Callable<T>) - Method in class io.netty.util.concurrent.AbstractEventExecutor
 
submit(Runnable) - Method in class io.netty.util.concurrent.AbstractEventExecutorGroup
 
submit(Runnable, T) - Method in class io.netty.util.concurrent.AbstractEventExecutorGroup
 
submit(Callable<T>) - Method in class io.netty.util.concurrent.AbstractEventExecutorGroup
 
submit(Runnable) - Method in interface io.netty.util.concurrent.EventExecutorGroup
 
submit(Runnable, T) - Method in interface io.netty.util.concurrent.EventExecutorGroup
 
submit(Callable<T>) - Method in interface io.netty.util.concurrent.EventExecutorGroup
 
submit(Runnable) - Method in class io.netty.util.concurrent.NonStickyEventExecutorGroup
 
submit(Runnable, T) - Method in class io.netty.util.concurrent.NonStickyEventExecutorGroup
 
submit(Callable<T>) - Method in class io.netty.util.concurrent.NonStickyEventExecutorGroup
 
submit(Runnable) - Method in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor
 
submit(Runnable, T) - Method in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor
 
submit(Callable<T>) - Method in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor
 
submitWrite(ChannelHandlerContext, Object, long, ChannelPromise) - Method in class io.netty.handler.traffic.AbstractTrafficShapingHandler
Deprecated.
submitWrite(ChannelHandlerContext, Object, long, long, long, ChannelPromise) - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
 
subscribe() - Static method in class io.netty.handler.codec.mqtt.MqttMessageBuilders
 
SUBSCRIPTION - Static variable in interface io.netty.handler.codec.stomp.StompHeaders
 
subSequence(int) - Method in class io.netty.util.AsciiString
Copies a range of characters into a new string.
subSequence(int, int) - Method in class io.netty.util.AsciiString
Copies a range of characters into a new string.
subSequence(int, int, boolean) - Method in class io.netty.util.AsciiString
Either copy or share a subset of underlying sub-sequence of bytes.
subSequence(int, int) - Method in class io.netty.util.internal.AppendableCharSequence
 
substring(int, int) - Method in class io.netty.util.internal.AppendableCharSequence
Create a new String from the given start to end.
substringAfter(String, char) - Static method in class io.netty.util.internal.StringUtil
Get the item after one char delim if the delim is found (else null).
subStringUnsafe(int, int) - Method in class io.netty.util.internal.AppendableCharSequence
Create a new String from the given start to end.
SucceededFuture<V> - Class in io.netty.util.concurrent
The CompleteFuture which is succeeded already.
SucceededFuture(EventExecutor, V) - Constructor for class io.netty.util.concurrent.SucceededFuture
Creates a new instance.
SUCCESS - Static variable in class io.netty.handler.codec.DecoderResult
 
SUCCESS - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseStatus
 
SUCCESS - Static variable in class io.netty.handler.ssl.SslCloseCompletionEvent
 
SUCCESS - Static variable in class io.netty.handler.ssl.SslHandshakeCompletionEvent
 
successAndRecycle() - Method in class io.netty.util.internal.PendingWrite
Mark the underlying Promise successfully and recycle this instance.
SupportedCipherSuiteFilter - Class in io.netty.handler.ssl
This class will filter all requested ciphers out that are not supported by the current SSLEngine.
supportedProtocols() - Method in class io.netty.handler.ssl.ApplicationProtocolConfig
The application level protocols supported.
SuppressForbidden - Annotation Type in io.netty.util
Annotation to suppress forbidden-apis errors inside a whole class, a method, or a field.
swapInt(int) - Static method in class io.netty.buffer.ByteBufUtil
Toggles the endianness of the specified 32-bit integer.
swapLong(long) - Static method in class io.netty.buffer.ByteBufUtil
Toggles the endianness of the specified 64-bit long integer.
swapMedium(int) - Static method in class io.netty.buffer.ByteBufUtil
Toggles the endianness of the specified 24-bit medium integer.
SwappedByteBuf - Class in io.netty.buffer
Deprecated.
use the Little Endian accessors, e.g. getShortLE, getIntLE instead.
SwappedByteBuf(ByteBuf) - Constructor for class io.netty.buffer.SwappedByteBuf
Deprecated.
 
swapShort(short) - Static method in class io.netty.buffer.ByteBufUtil
Toggles the endianness of the specified 16-bit short integer.
sync() - Method in interface io.netty.channel.ChannelFuture
 
sync() - Method in interface io.netty.channel.ChannelProgressiveFuture
 
sync() - Method in interface io.netty.channel.ChannelProgressivePromise
 
sync() - Method in interface io.netty.channel.ChannelPromise
 
sync() - Method in class io.netty.channel.DefaultChannelProgressivePromise
 
sync() - Method in class io.netty.channel.DefaultChannelPromise
 
sync() - Method in interface io.netty.channel.group.ChannelGroupFuture
 
sync() - Method in class io.netty.util.concurrent.CompleteFuture
 
sync() - Method in class io.netty.util.concurrent.DefaultProgressivePromise
 
sync() - Method in class io.netty.util.concurrent.DefaultPromise
 
sync() - Method in class io.netty.util.concurrent.FailedFuture
 
sync() - Method in interface io.netty.util.concurrent.Future
Waits for this future until it is done, and rethrows the cause of the failure if this future failed.
sync() - Method in interface io.netty.util.concurrent.ProgressiveFuture
 
sync() - Method in interface io.netty.util.concurrent.ProgressivePromise
 
sync() - Method in interface io.netty.util.concurrent.Promise
 
syncUninterruptibly() - Method in interface io.netty.channel.ChannelFuture
 
syncUninterruptibly() - Method in interface io.netty.channel.ChannelProgressiveFuture
 
syncUninterruptibly() - Method in interface io.netty.channel.ChannelProgressivePromise
 
syncUninterruptibly() - Method in interface io.netty.channel.ChannelPromise
 
syncUninterruptibly() - Method in class io.netty.channel.DefaultChannelProgressivePromise
 
syncUninterruptibly() - Method in class io.netty.channel.DefaultChannelPromise
 
syncUninterruptibly() - Method in interface io.netty.channel.group.ChannelGroupFuture
 
syncUninterruptibly() - Method in class io.netty.util.concurrent.CompleteFuture
 
syncUninterruptibly() - Method in class io.netty.util.concurrent.DefaultProgressivePromise
 
syncUninterruptibly() - Method in class io.netty.util.concurrent.DefaultPromise
 
syncUninterruptibly() - Method in class io.netty.util.concurrent.FailedFuture
 
syncUninterruptibly() - Method in interface io.netty.util.concurrent.Future
Waits for this future until it is done, and rethrows the cause of the failure if this future failed.
syncUninterruptibly() - Method in interface io.netty.util.concurrent.ProgressiveFuture
 
syncUninterruptibly() - Method in interface io.netty.util.concurrent.ProgressivePromise
 
syncUninterruptibly() - Method in interface io.netty.util.concurrent.Promise
 
SystemPropertyUtil - Class in io.netty.util.internal
A collection of utility methods to retrieve and parse the values of the Java system properties.

T

TA - Static variable in class io.netty.handler.codec.dns.DnsRecordType
DNSSEC Trust Authorities record N/A Part of a deployment proposal for DNSSEC without a signed DNS root.
TAB - Static variable in class io.netty.util.internal.StringUtil
 
takeTask() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
Take the next Runnable from the task queue and so will block if no task is currently present.
task() - Method in interface io.netty.util.Timeout
Returns the TimerTask which is associated with this handle.
TCP_CORK - Static variable in class io.netty.channel.epoll.EpollChannelOption
 
TCP_DEFER_ACCEPT - Static variable in class io.netty.channel.epoll.EpollChannelOption
 
TCP_FASTOPEN - Static variable in class io.netty.channel.epoll.EpollChannelOption
 
TCP_KEEPCNT - Static variable in class io.netty.channel.epoll.EpollChannelOption
 
TCP_KEEPIDLE - Static variable in class io.netty.channel.epoll.EpollChannelOption
 
TCP_KEEPINTVL - Static variable in class io.netty.channel.epoll.EpollChannelOption
 
TCP_MD5SIG - Static variable in class io.netty.channel.epoll.EpollChannelOption
 
TCP_MD5SIG_MAXKEYLEN - Static variable in class io.netty.channel.epoll.Native
 
TCP_NODELAY - Static variable in class io.netty.channel.ChannelOption
 
TCP_NOPUSH - Static variable in class io.netty.channel.kqueue.KQueueChannelOption
 
TCP_NOTSENT_LOWAT - Static variable in class io.netty.channel.epoll.EpollChannelOption
 
TCP_QUICKACK - Static variable in class io.netty.channel.epoll.EpollChannelOption
 
TCP_USER_TIMEOUT - Static variable in class io.netty.channel.epoll.EpollChannelOption
 
tcpInfo() - Method in class io.netty.channel.epoll.EpollSocketChannel
Returns the TCP_INFO for the current socket.
tcpInfo(EpollTcpInfo) - Method in class io.netty.channel.epoll.EpollSocketChannel
Updates and returns the TCP_INFO for the current socket.
tearDown() - Method in class io.netty.channel.unix.tests.SocketTest
 
terminationFuture() - Method in class io.netty.channel.ThreadPerChannelEventLoopGroup
 
terminationFuture() - Method in interface io.netty.util.concurrent.EventExecutorGroup
Returns the Future which is notified when all EventExecutors managed by this EventExecutorGroup have been terminated.
terminationFuture() - Method in class io.netty.util.concurrent.GlobalEventExecutor
 
terminationFuture() - Method in class io.netty.util.concurrent.ImmediateEventExecutor
 
terminationFuture() - Method in class io.netty.util.concurrent.MultithreadEventExecutorGroup
 
terminationFuture() - Method in class io.netty.util.concurrent.NonStickyEventExecutorGroup
 
terminationFuture() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
 
terminationFuture() - Method in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor
 
testDoubleCloseDoesNotThrow() - Method in class io.netty.channel.unix.tests.SocketTest
 
testKeepAlive() - Method in class io.netty.channel.unix.tests.SocketTest
 
testReceivedBufferSize() - Method in class io.netty.channel.unix.tests.SocketTest
 
testSendBufferSize() - Method in class io.netty.channel.unix.tests.SocketTest
 
testSoLinger() - Method in class io.netty.channel.unix.tests.SocketTest
 
testTcpNoDelay() - Method in class io.netty.channel.unix.tests.SocketTest
 
testTrafficClass() - Method in class io.netty.channel.unix.tests.SocketTest
 
ThreadDeathWatcher - Class in io.netty.util
Checks if a thread is alive periodically and runs a task when a thread dies.
threadGroup - Variable in class io.netty.util.concurrent.DefaultThreadFactory
 
threadLocalDirectBuffer() - Static method in class io.netty.buffer.ByteBufUtil
Returns a cached thread-local direct buffer, if available.
threadLocalMap() - Method in class io.netty.util.concurrent.FastThreadLocalThread
Returns the internal data structure that keeps the thread-local variables bound to this thread.
threadLocalRandom() - Static method in class io.netty.util.internal.PlatformDependent
Return a Random which is not-threadsafe and so can only be used from the same thread.
ThreadLocalRandom - Class in io.netty.util.internal
A random number generator isolated to the current thread.
ThreadPerChannelEventLoop - Class in io.netty.channel
SingleThreadEventLoop which is used to handle OIO Channel's.
ThreadPerChannelEventLoop(ThreadPerChannelEventLoopGroup) - Constructor for class io.netty.channel.ThreadPerChannelEventLoop
 
ThreadPerChannelEventLoopGroup - Class in io.netty.channel
An EventLoopGroup that creates one EventLoop per Channel.
ThreadPerChannelEventLoopGroup() - Constructor for class io.netty.channel.ThreadPerChannelEventLoopGroup
Create a new ThreadPerChannelEventLoopGroup with no limit in place.
ThreadPerChannelEventLoopGroup(int) - Constructor for class io.netty.channel.ThreadPerChannelEventLoopGroup
ThreadPerChannelEventLoopGroup(int, ThreadFactory, Object...) - Constructor for class io.netty.channel.ThreadPerChannelEventLoopGroup
ThreadPerChannelEventLoopGroup(int, Executor, Object...) - Constructor for class io.netty.channel.ThreadPerChannelEventLoopGroup
ThreadPerTaskExecutor - Class in io.netty.util.concurrent
 
ThreadPerTaskExecutor(ThreadFactory) - Constructor for class io.netty.util.concurrent.ThreadPerTaskExecutor
 
threadProperties() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
Returns the ThreadProperties of the Thread that powers the SingleThreadEventExecutor.
ThreadProperties - Interface in io.netty.util.concurrent
Expose details for a Thread.
ThrowableUtil - Class in io.netty.util.internal
 
throwException(Throwable) - Static method in class io.netty.util.internal.PlatformDependent
Raises an exception bypassing compiler checks for checked exceptions.
Timeout - Interface in io.netty.util
A handle associated with a TimerTask that is returned by a Timer.
TimeoutException - Exception in io.netty.handler.timeout
A TimeoutException when no data was either read or written within a certain period of time.
timer() - Method in interface io.netty.util.Timeout
Returns the Timer that created this handle.
Timer - Interface in io.netty.util
Schedules TimerTasks for one-time future execution in a background thread.
TimerTask - Interface in io.netty.util
A task which is executed after the delay specified with Timer.newTimeout(TimerTask, long, TimeUnit).
timeToLive() - Method in class io.netty.handler.codec.dns.AbstractDnsRecord
 
timeToLive() - Method in interface io.netty.handler.codec.dns.DnsQuestion
An unused property.
timeToLive() - Method in interface io.netty.handler.codec.dns.DnsRecord
Returns the time to live after reading for this resource record.
tinyCacheSize() - Method in class io.netty.buffer.PooledByteBufAllocator
tinyCacheSize() - Method in class io.netty.buffer.PooledByteBufAllocatorMetric
Return the size of the tiny cache.
tinySubpages() - Method in interface io.netty.buffer.PoolArenaMetric
Returns an unmodifiable List which holds PoolSubpageMetrics for tiny sub-pages.
TKEY - Static variable in class io.netty.handler.codec.dns.DnsRecordType
Secret key record RFC 2930 A method of providing keying material to be used with TSIG that is encrypted under the public key in an accompanying KEY RR..
TLSA - Static variable in class io.netty.handler.codec.dns.DnsRecordType
TLSA certificate association record RFC 6698 A record for DNS-based Authentication of Named Entities (DANE).
tmpdir() - Static method in class io.netty.util.internal.PlatformDependent
Returns the temporary directory.
toAddressString(InetAddress) - Static method in class io.netty.util.NetUtil
Returns the String representation of an InetAddress.
toAddressString(InetAddress, boolean) - Static method in class io.netty.util.NetUtil
Returns the String representation of an InetAddress.
toArray() - Method in class io.netty.channel.group.DefaultChannelGroup
 
toArray(T[]) - Method in class io.netty.channel.group.DefaultChannelGroup
 
toArray() - Method in class io.netty.util.internal.DefaultPriorityQueue
 
toArray(X[]) - Method in class io.netty.util.internal.DefaultPriorityQueue
 
toArray() - Method in class io.netty.util.internal.EmptyPriorityQueue
 
toArray(T1[]) - Method in class io.netty.util.internal.EmptyPriorityQueue
 
toByteArray() - Method in class io.netty.util.AsciiString
Converts this string to a byte array.
toByteArray(int, int) - Method in class io.netty.util.AsciiString
Converts a subset of this string to a byte array.
toByteIndex(int) - Method in class io.netty.buffer.CompositeByteBuf
 
toCharArray() - Method in class io.netty.util.AsciiString
Copies the characters in this string to a character array.
toCharArray(int, int) - Method in class io.netty.util.AsciiString
Copies the characters in this string to a character array.
toComponentIndex(int) - Method in class io.netty.buffer.CompositeByteBuf
Return the index for the given offset
toHexString(byte[]) - Static method in class io.netty.util.internal.StringUtil
Converts the specified byte array into a hexadecimal value.
toHexString(byte[], int, int) - Static method in class io.netty.util.internal.StringUtil
Converts the specified byte array into a hexadecimal value.
toHexString(T, byte[]) - Static method in class io.netty.util.internal.StringUtil
Converts the specified byte array into a hexadecimal value and appends it to the specified buffer.
toHexString(T, byte[], int, int) - Static method in class io.netty.util.internal.StringUtil
Converts the specified byte array into a hexadecimal value and appends it to the specified buffer.
toHexStringPadded(byte[]) - Static method in class io.netty.util.internal.StringUtil
Converts the specified byte array into a hexadecimal value.
toHexStringPadded(byte[], int, int) - Static method in class io.netty.util.internal.StringUtil
Converts the specified byte array into a hexadecimal value.
toHexStringPadded(T, byte[]) - Static method in class io.netty.util.internal.StringUtil
Converts the specified byte array into a hexadecimal value and appends it to the specified buffer.
toHexStringPadded(T, byte[], int, int) - Static method in class io.netty.util.internal.StringUtil
Converts the specified byte array into a hexadecimal value and appends it to the specified buffer.
toHintString() - Method in interface io.netty.util.ResourceLeakHint
Returns a human-readable message that potentially enables easier resource leak tracking.
toInternalLevel() - Method in enum io.netty.handler.logging.LogLevel
For internal use only.
toLeakAwareBuffer(ByteBuf) - Static method in class io.netty.buffer.AbstractByteBufAllocator
 
toLeakAwareBuffer(CompositeByteBuf) - Static method in class io.netty.buffer.AbstractByteBufAllocator
 
toLowerCase() - Method in class io.netty.util.AsciiString
Converts the characters in this string to lowercase, using the default Locale.
toMap() - Method in interface io.netty.channel.ChannelPipeline
Converts this pipeline into an ordered Map whose keys are handler names and whose values are handlers.
toMap() - Method in class io.netty.channel.DefaultChannelPipeline
 
TooLongFrameException - Exception in io.netty.handler.codec
An DecoderException which is thrown when the length of the frame decoded is greater than the allowed maximum.
TooLongFrameException() - Constructor for exception io.netty.handler.codec.TooLongFrameException
Creates a new instance.
TooLongFrameException(String, Throwable) - Constructor for exception io.netty.handler.codec.TooLongFrameException
Creates a new instance.
TooLongFrameException(String) - Constructor for exception io.netty.handler.codec.TooLongFrameException
Creates a new instance.
TooLongFrameException(Throwable) - Constructor for exception io.netty.handler.codec.TooLongFrameException
Creates a new instance.
topicName(String) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.PublishBuilder
 
topicName() - Method in class io.netty.handler.codec.mqtt.MqttPublishVariableHeader
 
topicName() - Method in class io.netty.handler.codec.mqtt.MqttTopicSubscription
 
topics() - Method in class io.netty.handler.codec.mqtt.MqttUnsubscribePayload
 
topicSubscriptions() - Method in class io.netty.handler.codec.mqtt.MqttSubscribePayload
 
toPoolName(Class<?>) - Static method in class io.netty.util.concurrent.DefaultThreadFactory
 
toSocketAddressString(InetSocketAddress) - Static method in class io.netty.util.NetUtil
Returns the String representation of an InetSocketAddress.
toSocketAddressString(String, int) - Static method in class io.netty.util.NetUtil
Returns the String representation of a host port combo.
toString() - Method in class io.netty.bootstrap.AbstractBootstrap
 
toString() - Method in class io.netty.bootstrap.AbstractBootstrapConfig
 
toString() - Method in class io.netty.bootstrap.BootstrapConfig
 
toString() - Method in class io.netty.bootstrap.ServerBootstrapConfig
 
toString(Charset) - Method in class io.netty.buffer.AbstractByteBuf
 
toString(int, int, Charset) - Method in class io.netty.buffer.AbstractByteBuf
 
toString() - Method in class io.netty.buffer.AbstractByteBuf
 
toString() - Method in class io.netty.buffer.AbstractByteBufAllocator
 
toString(Charset) - Method in class io.netty.buffer.ByteBuf
Decodes this buffer's readable bytes into a string with the specified character set name.
toString(int, int, Charset) - Method in class io.netty.buffer.ByteBuf
Decodes this buffer's sub-region into a string with the specified character set.
toString() - Method in class io.netty.buffer.ByteBuf
Returns the string representation of this buffer.
toString() - Method in class io.netty.buffer.CompositeByteBuf
 
toString() - Method in class io.netty.buffer.DefaultByteBufHolder
 
toString(Charset) - Method in class io.netty.buffer.EmptyByteBuf
 
toString(int, int, Charset) - Method in class io.netty.buffer.EmptyByteBuf
 
toString() - Method in class io.netty.buffer.EmptyByteBuf
 
toString() - Method in class io.netty.buffer.PooledByteBufAllocatorMetric
 
toString(Charset) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
toString(int, int, Charset) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
toString() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
toString() - Method in class io.netty.channel.AbstractChannel
Returns the String representation of this channel.
toString() - Method in class io.netty.channel.DefaultAddressedEnvelope
 
toString() - Method in class io.netty.channel.DefaultChannelId
 
toString() - Method in class io.netty.channel.DefaultChannelPipeline
Returns the String representation of this pipeline.
toString() - Method in class io.netty.channel.group.DefaultChannelGroup
 
toString() - Method in class io.netty.channel.kqueue.AcceptFilter
 
toString() - Method in class io.netty.channel.local.LocalAddress
 
toString() - Method in class io.netty.channel.ReflectiveChannelFactory
 
toString() - Method in class io.netty.channel.unix.DomainSocketAddress
 
toString() - Method in class io.netty.channel.unix.FileDescriptor
 
toString() - Method in class io.netty.channel.unix.PeerCredentials
 
toString() - Method in class io.netty.channel.unix.Socket
 
toString() - Method in class io.netty.channel.WriteBufferWaterMark
 
toString() - Method in class io.netty.handler.codec.DecoderResult
 
toString() - Method in class io.netty.handler.codec.DefaultHeaders.HeaderEntry
 
toString() - Method in class io.netty.handler.codec.DefaultHeaders
 
toString() - Method in class io.netty.handler.codec.dns.AbstractDnsOptPseudoRrRecord
 
toString() - Method in class io.netty.handler.codec.dns.AbstractDnsRecord
 
toString() - Method in class io.netty.handler.codec.dns.DefaultDnsOptEcsRecord
 
toString() - Method in class io.netty.handler.codec.dns.DefaultDnsPtrRecord
 
toString() - Method in class io.netty.handler.codec.dns.DefaultDnsQuery
 
toString() - Method in class io.netty.handler.codec.dns.DefaultDnsQuestion
 
toString() - Method in class io.netty.handler.codec.dns.DefaultDnsRawRecord
 
toString() - Method in class io.netty.handler.codec.dns.DefaultDnsResponse
 
toString() - Method in class io.netty.handler.codec.dns.DnsOpCode
 
toString() - Method in class io.netty.handler.codec.dns.DnsRecordType
 
toString() - Method in class io.netty.handler.codec.dns.DnsResponseCode
Returns a formatted error message for this DnsResponseCode.
toString() - Method in class io.netty.handler.codec.EmptyHeaders
 
toString() - Method in class io.netty.handler.codec.memcache.DefaultMemcacheContent
 
toString() - Method in class io.netty.handler.codec.mqtt.MqttConnAckVariableHeader
 
toString() - Method in class io.netty.handler.codec.mqtt.MqttConnectPayload
 
toString() - Method in class io.netty.handler.codec.mqtt.MqttConnectVariableHeader
 
toString() - Method in class io.netty.handler.codec.mqtt.MqttFixedHeader
 
toString() - Method in class io.netty.handler.codec.mqtt.MqttMessage
 
toString() - Method in class io.netty.handler.codec.mqtt.MqttMessageIdVariableHeader
 
toString() - Method in class io.netty.handler.codec.mqtt.MqttPublishVariableHeader
 
toString() - Method in class io.netty.handler.codec.mqtt.MqttSubAckPayload
 
toString() - Method in class io.netty.handler.codec.mqtt.MqttSubscribePayload
 
toString() - Method in class io.netty.handler.codec.mqtt.MqttTopicSubscription
 
toString() - Method in class io.netty.handler.codec.mqtt.MqttUnsubscribePayload
 
toString() - Method in class io.netty.handler.codec.redis.ArrayHeaderRedisMessage
 
toString() - Method in class io.netty.handler.codec.redis.ArrayRedisMessage
 
toString() - Method in class io.netty.handler.codec.redis.DefaultBulkStringRedisContent
 
toString() - Method in class io.netty.handler.codec.redis.ErrorRedisMessage
 
toString() - Method in class io.netty.handler.codec.redis.FullBulkStringRedisMessage
 
toString() - Method in class io.netty.handler.codec.redis.IntegerRedisMessage
 
toString() - Method in class io.netty.handler.codec.redis.SimpleStringRedisMessage
 
toString() - Method in class io.netty.handler.codec.smtp.DefaultSmtpRequest
 
toString() - Method in class io.netty.handler.codec.smtp.DefaultSmtpResponse
 
toString() - Method in class io.netty.handler.codec.smtp.SmtpCommand
 
toString() - Method in class io.netty.handler.codec.stomp.DefaultLastStompContentSubframe
 
toString() - Method in class io.netty.handler.codec.stomp.DefaultStompContentSubframe
 
toString() - Method in class io.netty.handler.codec.stomp.DefaultStompFrame
 
toString() - Method in class io.netty.handler.codec.stomp.DefaultStompHeadersSubframe
 
toString() - Method in class io.netty.handler.codec.string.LineSeparator
Return a hex dump of the line separator in UTF-8 encoding.
toString() - Method in class io.netty.handler.ssl.PemX509Certificate
 
toString() - Method in class io.netty.handler.ssl.SslCompletionEvent
 
toString() - Method in class io.netty.handler.traffic.AbstractTrafficShapingHandler
 
toString() - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
 
toString() - Method in class io.netty.handler.traffic.TrafficCounter
 
toString() - Method in class io.netty.resolver.dns.DefaultDnsCache
 
toString() - Method in class io.netty.resolver.dns.DnsCacheEntry
 
toString() - Method in class io.netty.resolver.dns.NoopDnsCache
 
toString() - Method in class io.netty.util.AbstractConstant
 
toString() - Method in class io.netty.util.AsciiString
Translates the entire byte string to a String.
toString(int) - Method in class io.netty.util.AsciiString
Translates the entire byte string to a String using the charset encoding.
toString(int, int) - Method in class io.netty.util.AsciiString
Translates the [start, end) range of this byte string to a String.
toString() - Method in class io.netty.util.collection.ByteObjectHashMap
 
toString() - Method in class io.netty.util.collection.CharObjectHashMap
 
toString() - Method in class io.netty.util.collection.IntObjectHashMap
 
toString() - Method in class io.netty.util.collection.LongObjectHashMap
 
toString() - Method in class io.netty.util.collection.ShortObjectHashMap
 
toString() - Method in class io.netty.util.concurrent.DefaultPromise
 
toString() - Method in class io.netty.util.DomainNameMapping
 
toString() - Method in class io.netty.util.internal.AppendableCharSequence
 
toString() - Method in class io.netty.util.internal.EmptyPriorityQueue
 
toString() - Method in class io.netty.util.internal.logging.AbstractInternalLogger
 
toString() - Method in error io.netty.util.Signal
 
toString() - Method in class io.netty.util.Version
 
toStringBuilder() - Method in class io.netty.util.concurrent.DefaultPromise
 
totalBodyLength() - Method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
totalBodyLength() - Method in interface io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Returns the total body length.
totalBytesRead() - Method in class io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator.MaxMessageHandle
 
totalPendingWriteBytes() - Method in class io.netty.channel.ChannelOutboundBuffer
 
totalRetrans() - Method in class io.netty.channel.epoll.EpollTcpInfo
 
touch() - Method in class io.netty.buffer.AbstractDerivedByteBuf
Deprecated.
 
touch(Object) - Method in class io.netty.buffer.AbstractDerivedByteBuf
Deprecated.
 
touch() - Method in class io.netty.buffer.AbstractReferenceCountedByteBuf
 
touch(Object) - Method in class io.netty.buffer.AbstractReferenceCountedByteBuf
 
touch() - Method in class io.netty.buffer.ByteBuf
 
touch(Object) - Method in class io.netty.buffer.ByteBuf
 
touch() - Method in interface io.netty.buffer.ByteBufHolder
 
touch(Object) - Method in interface io.netty.buffer.ByteBufHolder
 
touch() - Method in class io.netty.buffer.CompositeByteBuf
 
touch(Object) - Method in class io.netty.buffer.CompositeByteBuf
 
touch() - Method in class io.netty.buffer.DefaultByteBufHolder
 
touch(Object) - Method in class io.netty.buffer.DefaultByteBufHolder
 
touch() - Method in class io.netty.buffer.EmptyByteBuf
 
touch(Object) - Method in class io.netty.buffer.EmptyByteBuf
 
touch() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
touch(Object) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
touch() - Method in interface io.netty.channel.AddressedEnvelope
 
touch(Object) - Method in interface io.netty.channel.AddressedEnvelope
 
touch() - Method in class io.netty.channel.DefaultAddressedEnvelope
 
touch(Object) - Method in class io.netty.channel.DefaultAddressedEnvelope
 
touch() - Method in class io.netty.channel.DefaultFileRegion
 
touch(Object) - Method in class io.netty.channel.DefaultFileRegion
 
touch() - Method in interface io.netty.channel.FileRegion
 
touch(Object) - Method in interface io.netty.channel.FileRegion
 
touch() - Method in class io.netty.channel.socket.DatagramPacket
 
touch(Object) - Method in class io.netty.channel.socket.DatagramPacket
 
touch() - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
 
touch(Object) - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
 
touch() - Method in class io.netty.handler.codec.dns.DatagramDnsQuery
 
touch(Object) - Method in class io.netty.handler.codec.dns.DatagramDnsQuery
 
touch() - Method in class io.netty.handler.codec.dns.DatagramDnsResponse
 
touch(Object) - Method in class io.netty.handler.codec.dns.DatagramDnsResponse
 
touch() - Method in class io.netty.handler.codec.dns.DefaultDnsQuery
 
touch(Object) - Method in class io.netty.handler.codec.dns.DefaultDnsQuery
 
touch() - Method in class io.netty.handler.codec.dns.DefaultDnsRawRecord
 
touch(Object) - Method in class io.netty.handler.codec.dns.DefaultDnsRawRecord
 
touch() - Method in class io.netty.handler.codec.dns.DefaultDnsResponse
 
touch(Object) - Method in class io.netty.handler.codec.dns.DefaultDnsResponse
 
touch() - Method in interface io.netty.handler.codec.dns.DnsMessage
 
touch(Object) - Method in interface io.netty.handler.codec.dns.DnsMessage
 
touch() - Method in interface io.netty.handler.codec.dns.DnsQuery
 
touch(Object) - Method in interface io.netty.handler.codec.dns.DnsQuery
 
touch() - Method in interface io.netty.handler.codec.dns.DnsRawRecord
 
touch(Object) - Method in interface io.netty.handler.codec.dns.DnsRawRecord
 
touch() - Method in interface io.netty.handler.codec.dns.DnsResponse
 
touch(Object) - Method in interface io.netty.handler.codec.dns.DnsResponse
 
touch() - Method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
touch(Object) - Method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
touch() - Method in interface io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
 
touch(Object) - Method in interface io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
 
TOUCH - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
touch() - Method in interface io.netty.handler.codec.memcache.binary.BinaryMemcacheRequest
 
touch(Object) - Method in interface io.netty.handler.codec.memcache.binary.BinaryMemcacheRequest
 
touch() - Method in interface io.netty.handler.codec.memcache.binary.BinaryMemcacheResponse
 
touch(Object) - Method in interface io.netty.handler.codec.memcache.binary.BinaryMemcacheResponse
 
touch() - Method in class io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheRequest
 
touch(Object) - Method in class io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheRequest
 
touch() - Method in class io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheResponse
 
touch(Object) - Method in class io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheResponse
 
touch() - Method in class io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheRequest
 
touch(Object) - Method in class io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheRequest
 
touch() - Method in class io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheResponse
 
touch(Object) - Method in class io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheResponse
 
touch() - Method in interface io.netty.handler.codec.memcache.binary.FullBinaryMemcacheRequest
 
touch(Object) - Method in interface io.netty.handler.codec.memcache.binary.FullBinaryMemcacheRequest
 
touch() - Method in interface io.netty.handler.codec.memcache.binary.FullBinaryMemcacheResponse
 
touch(Object) - Method in interface io.netty.handler.codec.memcache.binary.FullBinaryMemcacheResponse
 
touch() - Method in class io.netty.handler.codec.memcache.DefaultLastMemcacheContent
 
touch(Object) - Method in class io.netty.handler.codec.memcache.DefaultLastMemcacheContent
 
touch() - Method in class io.netty.handler.codec.memcache.DefaultMemcacheContent
 
touch(Object) - Method in class io.netty.handler.codec.memcache.DefaultMemcacheContent
 
touch() - Method in interface io.netty.handler.codec.memcache.FullMemcacheMessage
 
touch(Object) - Method in interface io.netty.handler.codec.memcache.FullMemcacheMessage
 
touch() - Method in interface io.netty.handler.codec.memcache.LastMemcacheContent
 
touch(Object) - Method in interface io.netty.handler.codec.memcache.LastMemcacheContent
 
touch() - Method in interface io.netty.handler.codec.memcache.MemcacheContent
 
touch(Object) - Method in interface io.netty.handler.codec.memcache.MemcacheContent
 
touch() - Method in interface io.netty.handler.codec.memcache.MemcacheMessage
 
touch(Object) - Method in interface io.netty.handler.codec.memcache.MemcacheMessage
 
touch() - Method in class io.netty.handler.codec.mqtt.MqttPublishMessage
 
touch(Object) - Method in class io.netty.handler.codec.mqtt.MqttPublishMessage
 
touch(Object) - Method in class io.netty.handler.codec.redis.ArrayRedisMessage
 
touch() - Method in interface io.netty.handler.codec.redis.BulkStringRedisContent
 
touch(Object) - Method in interface io.netty.handler.codec.redis.BulkStringRedisContent
 
touch() - Method in class io.netty.handler.codec.redis.DefaultBulkStringRedisContent
 
touch(Object) - Method in class io.netty.handler.codec.redis.DefaultBulkStringRedisContent
 
touch() - Method in class io.netty.handler.codec.redis.DefaultLastBulkStringRedisContent
 
touch(Object) - Method in class io.netty.handler.codec.redis.DefaultLastBulkStringRedisContent
 
touch() - Method in class io.netty.handler.codec.redis.FullBulkStringRedisMessage
 
touch(Object) - Method in class io.netty.handler.codec.redis.FullBulkStringRedisMessage
 
touch() - Method in interface io.netty.handler.codec.redis.LastBulkStringRedisContent
 
touch(Object) - Method in interface io.netty.handler.codec.redis.LastBulkStringRedisContent
 
touch() - Method in class io.netty.handler.codec.smtp.DefaultLastSmtpContent
 
touch(Object) - Method in class io.netty.handler.codec.smtp.DefaultLastSmtpContent
 
touch() - Method in class io.netty.handler.codec.smtp.DefaultSmtpContent
 
touch(Object) - Method in class io.netty.handler.codec.smtp.DefaultSmtpContent
 
touch() - Method in interface io.netty.handler.codec.smtp.LastSmtpContent
 
touch(Object) - Method in interface io.netty.handler.codec.smtp.LastSmtpContent
 
touch() - Method in interface io.netty.handler.codec.smtp.SmtpContent
 
touch(Object) - Method in interface io.netty.handler.codec.smtp.SmtpContent
 
touch() - Method in class io.netty.handler.codec.stomp.DefaultLastStompContentSubframe
 
touch(Object) - Method in class io.netty.handler.codec.stomp.DefaultLastStompContentSubframe
 
touch() - Method in class io.netty.handler.codec.stomp.DefaultStompContentSubframe
 
touch(Object) - Method in class io.netty.handler.codec.stomp.DefaultStompContentSubframe
 
touch() - Method in class io.netty.handler.codec.stomp.DefaultStompFrame
 
touch(Object) - Method in class io.netty.handler.codec.stomp.DefaultStompFrame
 
touch() - Method in interface io.netty.handler.codec.stomp.LastStompContentSubframe
 
touch(Object) - Method in interface io.netty.handler.codec.stomp.LastStompContentSubframe
 
touch() - Method in interface io.netty.handler.codec.stomp.StompContentSubframe
 
touch(Object) - Method in interface io.netty.handler.codec.stomp.StompContentSubframe
 
touch() - Method in interface io.netty.handler.codec.stomp.StompFrame
 
touch(Object) - Method in interface io.netty.handler.codec.stomp.StompFrame
 
touch() - Method in class io.netty.handler.ssl.PemPrivateKey
 
touch(Object) - Method in class io.netty.handler.ssl.PemPrivateKey
 
touch() - Method in class io.netty.handler.ssl.PemX509Certificate
 
touch(Object) - Method in class io.netty.handler.ssl.PemX509Certificate
 
touch() - Method in class io.netty.util.AbstractReferenceCounted
 
touch() - Method in interface io.netty.util.ReferenceCounted
Records the current access location of this object for debugging purposes.
touch(Object) - Method in interface io.netty.util.ReferenceCounted
Records the current access location of this object with an additional arbitrary information for debugging purposes.
touch(T) - Static method in class io.netty.util.ReferenceCountUtil
Tries to call ReferenceCounted.touch() if the specified message implements ReferenceCounted.
touch(T, Object) - Static method in class io.netty.util.ReferenceCountUtil
Tries to call ReferenceCounted.touch(Object) if the specified message implements ReferenceCounted.
toUpperCase() - Method in class io.netty.util.AsciiString
Converts the characters in this string to uppercase, using the default Locale.
trace(Throwable) - Method in class io.netty.util.internal.logging.AbstractInternalLogger
 
trace(String) - Method in interface io.netty.util.internal.logging.InternalLogger
Log a message at the TRACE level.
trace(String, Object) - Method in interface io.netty.util.internal.logging.InternalLogger
Log a message at the TRACE level according to the specified format and argument.
trace(String, Object, Object) - Method in interface io.netty.util.internal.logging.InternalLogger
Log a message at the TRACE level according to the specified format and arguments.
trace(String, Object...) - Method in interface io.netty.util.internal.logging.InternalLogger
Log a message at the TRACE level according to the specified format and arguments.
trace(String, Throwable) - Method in interface io.netty.util.internal.logging.InternalLogger
Log an exception (throwable) at the TRACE level with an accompanying message.
trace(Throwable) - Method in interface io.netty.util.internal.logging.InternalLogger
Log an exception (throwable) at the TRACE level.
traceEnabled(boolean) - Method in class io.netty.resolver.dns.DnsNameResolverBuilder
Sets if this resolver should generate the detailed trace information in an exception message so that it is easier to understand the cause of resolution failure.
track(T) - Method in class io.netty.util.ResourceLeakDetector
Creates a new ResourceLeakTracker which is expected to be closed via ResourceLeakTracker.close(Object) when the related resource is deallocated.
trafficCounter - Variable in class io.netty.handler.traffic.AbstractTrafficShapingHandler
Traffic Counter
trafficCounter() - Method in class io.netty.handler.traffic.AbstractTrafficShapingHandler
 
TrafficCounter - Class in io.netty.handler.traffic
Counts the number of read and written bytes for rate-limiting traffic.
TrafficCounter(ScheduledExecutorService, String, long) - Constructor for class io.netty.handler.traffic.TrafficCounter
Constructor with the AbstractTrafficShapingHandler that hosts it, the ScheduledExecutorService to use, its name, the checkInterval between two computations in milliseconds.
TrafficCounter(AbstractTrafficShapingHandler, ScheduledExecutorService, String, long) - Constructor for class io.netty.handler.traffic.TrafficCounter
Constructor with the AbstractTrafficShapingHandler that hosts it, the Timer to use, its name, the checkInterval between two computations in millisecond.
TRANSACTION - Static variable in interface io.netty.handler.codec.stomp.StompHeaders
 
transfered() - Method in class io.netty.channel.DefaultFileRegion
Deprecated.
transfered() - Method in interface io.netty.channel.FileRegion
Deprecated.
transferred() - Method in class io.netty.channel.DefaultFileRegion
 
transferred() - Method in interface io.netty.channel.FileRegion
Returns the bytes which was transfered already.
transferredBytes() - Method in class io.netty.handler.stream.ChunkedNioStream
Returns the number of transferred bytes.
transferredBytes() - Method in class io.netty.handler.stream.ChunkedStream
Returns the number of transferred bytes.
transferTo(WritableByteChannel, long) - Method in class io.netty.channel.DefaultFileRegion
 
transferTo(WritableByteChannel, long) - Method in interface io.netty.channel.FileRegion
Transfers the content of this file region to the specified channel.
trim() - Method in class io.netty.util.AsciiString
Copies this string removing white space characters from the beginning and end of the string.
trimOws(CharSequence) - Static method in class io.netty.util.internal.StringUtil
Trim optional white-space characters from the specified value, according to RFC-7230.
TRUE_SUPPLIER - Static variable in interface io.netty.util.BooleanSupplier
A supplier which always returns true and never throws.
TRUE_SUPPLIER - Static variable in interface io.netty.util.UncheckedBooleanSupplier
A supplier which always returns true and never throws.
trustManager(File) - Method in class io.netty.handler.ssl.SslContextBuilder
Trusted certificates for verifying the remote endpoint's certificate.
trustManager(InputStream) - Method in class io.netty.handler.ssl.SslContextBuilder
Trusted certificates for verifying the remote endpoint's certificate.
trustManager(X509Certificate...) - Method in class io.netty.handler.ssl.SslContextBuilder
Trusted certificates for verifying the remote endpoint's certificate, null uses the system default.
trustManager(TrustManagerFactory) - Method in class io.netty.handler.ssl.SslContextBuilder
Trusted manager for verifying the remote endpoint's certificate.
tryCancel(Promise<?>, InternalLogger) - Static method in class io.netty.util.internal.PromiseNotificationUtil
Try to cancel the Promise and log if logger is not null in case this fails.
tryFailure(Throwable) - Method in class io.netty.util.concurrent.DefaultPromise
 
tryFailure(Throwable) - Method in interface io.netty.util.concurrent.Promise
Marks this future as a failure and notifies all listeners.
tryFailure(Promise<?>, Throwable, InternalLogger) - Static method in class io.netty.util.internal.PromiseNotificationUtil
Try to mark the Promise as failure and log if logger is not null in case this fails.
tryProgress(long, long) - Method in class io.netty.util.concurrent.DefaultProgressivePromise
 
tryProgress(long, long) - Method in interface io.netty.util.concurrent.ProgressivePromise
Tries to set the current progress of the operation and notifies the listeners that implement GenericProgressiveFutureListener.
trySetAccessible(AccessibleObject) - Static method in class io.netty.util.internal.ReflectionUtil
trySuccess() - Method in interface io.netty.channel.ChannelPromise
 
trySuccess() - Method in class io.netty.channel.DefaultChannelProgressivePromise
 
trySuccess() - Method in class io.netty.channel.DefaultChannelPromise
 
trySuccess(V) - Method in class io.netty.util.concurrent.DefaultPromise
 
trySuccess(V) - Method in interface io.netty.util.concurrent.Promise
Marks this future as a success and notifies all listeners.
trySuccess(Promise<? super V>, V, InternalLogger) - Static method in class io.netty.util.internal.PromiseNotificationUtil
Try to mark the Promise as success and log if logger is not null in case this fails.
TSIG - Static variable in class io.netty.handler.codec.dns.DnsRecordType
Transaction Signature record RFC 2845 Can be used to authenticate dynamic updates as coming from an approved client, or to authenticate responses as coming from an approved recursive name server similar to DNSSEC.
ttl(int, int) - Method in class io.netty.resolver.dns.DnsNameResolverBuilder
Sets the minimum and maximum TTL of the cached DNS resource records (in seconds).
TXT - Static variable in class io.netty.handler.codec.dns.DnsRecordType
Text record RFC 1035 Originally for arbitrary human-readable text in a DNS record.
type() - Method in class io.netty.handler.codec.dns.AbstractDnsRecord
 
type() - Method in interface io.netty.handler.codec.dns.DnsRecord
Returns the type of this resource record.
TypeParameterMatcher - Class in io.netty.util.internal
 
typeParameterMatcherFindCache() - Method in class io.netty.util.internal.InternalThreadLocalMap
 
typeParameterMatcherGetCache() - Method in class io.netty.util.internal.InternalThreadLocalMap
 

U

UDS_SUN_PATH_SIZE - Static variable in class io.netty.channel.unix.Socket
 
uid() - Method in class io.netty.channel.unix.PeerCredentials
 
UIO_MAX_IOV - Static variable in class io.netty.channel.unix.Limits
 
unacked() - Method in class io.netty.channel.epoll.EpollTcpInfo
 
UnaryPromiseNotifier<T> - Class in io.netty.util.concurrent
 
UnaryPromiseNotifier(Promise<? super T>) - Constructor for class io.netty.util.concurrent.UnaryPromiseNotifier
 
unavailabilityCause() - Static method in class io.netty.channel.epoll.Epoll
Returns the cause of unavailability of netty-transport-native-epoll.
unavailabilityCause() - Static method in class io.netty.channel.kqueue.KQueue
Returns the cause of unavailability of netty-transport-native-kqueue.
uncachedRedirectDnsServerStream(List<InetSocketAddress>) - Method in class io.netty.resolver.dns.DnsNameResolver
Provides the opportunity to sort the name servers before following a redirected DNS query.
UncheckedBooleanSupplier - Interface in io.netty.util
Represents a supplier of boolean-valued results which doesn't throw any checked exceptions.
unescapeCsv(CharSequence) - Static method in class io.netty.util.internal.StringUtil
Unescapes the specified escaped CSV field, if necessary according to RFC-4180.
unescapeCsvFields(CharSequence) - Static method in class io.netty.util.internal.StringUtil
Unescapes the specified escaped CSV fields according to RFC-4180.
UNFINISHED - Static variable in class io.netty.handler.codec.DecoderResult
 
UniqueIpFilter - Class in io.netty.handler.ipfilter
This class allows one to ensure that at all times for every IP address there is at most one Channel connected to the server.
UniqueIpFilter() - Constructor for class io.netty.handler.ipfilter.UniqueIpFilter
 
UNIX - Static variable in class io.netty.handler.codec.string.LineSeparator
The Unix line separator(LF)
UnixChannel - Interface in io.netty.channel.unix
Channel that expose operations that are only present on UNIX like systems.
UnixChannelOption<T> - Class in io.netty.channel.unix
 
UnixChannelOption() - Constructor for class io.netty.channel.unix.UnixChannelOption
 
UnixChannelUtil - Class in io.netty.channel.unix
 
UnixResolverDnsServerAddressStreamProvider - Class in io.netty.resolver.dns
Able to parse files such as /etc/resolv.conf and /etc/resolver to respect the system default domain servers.
UnixResolverDnsServerAddressStreamProvider(File, File...) - Constructor for class io.netty.resolver.dns.UnixResolverDnsServerAddressStreamProvider
Parse a file of the format /etc/resolv.conf which may contain the default DNS server to use, and also overrides for individual domains.
UnixResolverDnsServerAddressStreamProvider(String, String) - Constructor for class io.netty.resolver.dns.UnixResolverDnsServerAddressStreamProvider
Parse a file of the format /etc/resolv.conf which may contain the default DNS server to use, and also overrides for individual domains.
UnixTestUtils - Class in io.netty.channel.unix.tests
 
UNKNOWN_COMMAND - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseStatus
 
unknownStackTrace(T, Class<?>, String) - Static method in class io.netty.util.internal.ThrowableUtil
Set the StackTraceElement for the given Throwable, using the Class and method name.
unmodifiableBuffer(ByteBuf) - Static method in class io.netty.buffer.Unpooled
Deprecated.
unmodifiableBuffer(ByteBuf...) - Static method in class io.netty.buffer.Unpooled
Wrap the given ByteBufs in an unmodifiable ByteBuf.
unmodifiableMap(ByteObjectMap<V>) - Static method in class io.netty.util.collection.ByteCollections
Creates an unmodifiable wrapper around the given map.
unmodifiableMap(CharObjectMap<V>) - Static method in class io.netty.util.collection.CharCollections
Creates an unmodifiable wrapper around the given map.
unmodifiableMap(IntObjectMap<V>) - Static method in class io.netty.util.collection.IntCollections
Creates an unmodifiable wrapper around the given map.
unmodifiableMap(LongObjectMap<V>) - Static method in class io.netty.util.collection.LongCollections
Creates an unmodifiable wrapper around the given map.
unmodifiableMap(ShortObjectMap<V>) - Static method in class io.netty.util.collection.ShortCollections
Creates an unmodifiable wrapper around the given map.
UnorderedThreadPoolEventExecutor - Class in io.netty.util.concurrent
EventExecutor implementation which makes no guarantees about the ordering of task execution that are submitted because there may be multiple threads executing these tasks.
UnorderedThreadPoolEventExecutor(int) - Constructor for class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor
UnorderedThreadPoolEventExecutor(int, ThreadFactory) - Constructor for class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor
UnorderedThreadPoolEventExecutor(int, RejectedExecutionHandler) - Constructor for class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor
UnorderedThreadPoolEventExecutor(int, ThreadFactory, RejectedExecutionHandler) - Constructor for class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor
Unpooled - Class in io.netty.buffer
Creates a new ByteBuf by allocating new space or by wrapping or copying existing byte arrays, byte buffers and a string.
UnpooledByteBufAllocator - Class in io.netty.buffer
Simplistic ByteBufAllocator implementation that does not pool anything.
UnpooledByteBufAllocator(boolean) - Constructor for class io.netty.buffer.UnpooledByteBufAllocator
Create a new instance which uses leak-detection for direct buffers.
UnpooledByteBufAllocator(boolean, boolean) - Constructor for class io.netty.buffer.UnpooledByteBufAllocator
Create a new instance
UnpooledDirectByteBuf - Class in io.netty.buffer
A NIO ByteBuffer based buffer.
UnpooledDirectByteBuf(ByteBufAllocator, int, int) - Constructor for class io.netty.buffer.UnpooledDirectByteBuf
Creates a new direct buffer.
UnpooledDirectByteBuf(ByteBufAllocator, ByteBuffer, int) - Constructor for class io.netty.buffer.UnpooledDirectByteBuf
Creates a new direct buffer by wrapping the specified initial buffer.
UnpooledHeapByteBuf - Class in io.netty.buffer
Big endian Java heap buffer implementation.
UnpooledHeapByteBuf(ByteBufAllocator, int, int) - Constructor for class io.netty.buffer.UnpooledHeapByteBuf
Creates a new heap buffer with a newly allocated byte array.
UnpooledHeapByteBuf(ByteBufAllocator, byte[], int) - Constructor for class io.netty.buffer.UnpooledHeapByteBuf
Creates a new heap buffer with an existing byte array.
UnpooledUnsafeDirectByteBuf - Class in io.netty.buffer
A NIO ByteBuffer based buffer.
UnpooledUnsafeDirectByteBuf(ByteBufAllocator, int, int) - Constructor for class io.netty.buffer.UnpooledUnsafeDirectByteBuf
Creates a new direct buffer.
UnpooledUnsafeDirectByteBuf(ByteBufAllocator, ByteBuffer, int) - Constructor for class io.netty.buffer.UnpooledUnsafeDirectByteBuf
Creates a new direct buffer by wrapping the specified initial buffer.
unreleasableBuffer(ByteBuf) - Static method in class io.netty.buffer.Unpooled
Return a unreleasable view on the given ByteBuf which will just ignore release and retain calls.
unsafe() - Method in class io.netty.channel.AbstractChannel
 
unsafe() - Method in interface io.netty.channel.Channel
Returns an internal-use-only object that provides unsafe operations.
unsafe() - Method in class io.netty.channel.nio.AbstractNioChannel
 
UNSET - Static variable in class io.netty.util.internal.InternalThreadLocalMap
 
UnstableApi - Annotation Type in io.netty.util.internal
Indicates a public API that can change at any time (even in minor/bugfix releases).
unsubscribe() - Static method in class io.netty.handler.codec.mqtt.MqttMessageBuilders
 
unsupported() - Method in interface io.netty.handler.ssl.JdkApplicationProtocolNegotiator.ProtocolSelectionListener
Callback invoked to let the application know that the peer does not support this ApplicationProtocolNegotiator.
unsupported() - Method in interface io.netty.handler.ssl.JdkApplicationProtocolNegotiator.ProtocolSelector
Callback invoked to let the application know that the peer does not support this ApplicationProtocolNegotiator.
UnsupportedMessageTypeException - Exception in io.netty.handler.codec
Thrown if an unsupported message is received by an codec.
UnsupportedMessageTypeException(Object, Class<?>...) - Constructor for exception io.netty.handler.codec.UnsupportedMessageTypeException
 
UnsupportedMessageTypeException() - Constructor for exception io.netty.handler.codec.UnsupportedMessageTypeException
 
UnsupportedMessageTypeException(String, Throwable) - Constructor for exception io.netty.handler.codec.UnsupportedMessageTypeException
 
UnsupportedMessageTypeException(String) - Constructor for exception io.netty.handler.codec.UnsupportedMessageTypeException
 
UnsupportedMessageTypeException(Throwable) - Constructor for exception io.netty.handler.codec.UnsupportedMessageTypeException
 
UnsupportedValueConverter<V> - Class in io.netty.handler.codec
UnsupportedOperationException will be thrown from all ValueConverter methods.
unvoid() - Method in interface io.netty.channel.ChannelProgressivePromise
 
unvoid() - Method in interface io.netty.channel.ChannelPromise
Returns a new ChannelPromise if ChannelFuture.isVoid() returns true otherwise itself.
unvoid() - Method in class io.netty.channel.DefaultChannelProgressivePromise
 
unvoid() - Method in class io.netty.channel.DefaultChannelPromise
 
unwatch(Thread, Runnable) - Static method in class io.netty.util.ThreadDeathWatcher
Cancels the task scheduled via ThreadDeathWatcher.watch(Thread, Runnable).
unwrap() - Method in class io.netty.buffer.ByteBuf
Return the underlying buffer instance if this buffer is a wrapper of another buffer.
unwrap() - Method in class io.netty.buffer.CompositeByteBuf
 
unwrap() - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
unwrap() - Method in class io.netty.buffer.EmptyByteBuf
 
unwrap() - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
unwrap() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
unwrap() - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
unwrap() - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
unwrap() - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
UPDATE - Static variable in class io.netty.handler.codec.dns.DnsOpCode
The 'Update' DNS OpCode, as defined in RFC2136.
updateLastExecutionTime() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
Updates the internal timestamp that tells when a submitted task was executed most recently.
US_ASCII - Static variable in class io.netty.util.CharsetUtil
7-bit ASCII, as known as ISO646-US or the Basic Latin block of the Unicode character set
usage() - Method in interface io.netty.buffer.PoolChunkMetric
Return the percentage of the current usage of the chunk.
usedDirectMemory() - Method in interface io.netty.buffer.ByteBufAllocatorMetric
Returns the number of bytes of direct memory used by a ByteBufAllocator or -1 if unknown.
usedDirectMemory() - Method in class io.netty.buffer.PooledByteBufAllocatorMetric
 
usedHeapMemory() - Method in interface io.netty.buffer.ByteBufAllocatorMetric
Returns the number of bytes of heap memory used by a ByteBufAllocator or -1 if unknown.
usedHeapMemory() - Method in class io.netty.buffer.PooledByteBufAllocatorMetric
 
useDirectBufferNoCleaner() - Static method in class io.netty.util.internal.PlatformDependent
 
userDefinedWritabilityIndex() - Method in class io.netty.handler.traffic.AbstractTrafficShapingHandler
 
userDefinedWritabilityIndex() - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
 
userDefinedWritabilityIndex() - Method in class io.netty.handler.traffic.GlobalTrafficShapingHandler
 
userEventTriggered(ChannelHandlerContext, Object) - Method in interface io.netty.channel.ChannelInboundHandler
Gets called if an user event was triggered.
userEventTriggered(ChannelHandlerContext, Object) - Method in class io.netty.channel.ChannelInboundHandlerAdapter
userEventTriggered(ChannelHandlerContext, Object) - Method in class io.netty.channel.CombinedChannelDuplexHandler
 
userEventTriggered(ChannelHandlerContext, Object) - Method in class io.netty.handler.codec.ByteToMessageDecoder
 
userEventTriggered(ChannelHandlerContext, Object) - Method in class io.netty.handler.codec.DatagramPacketDecoder
 
userEventTriggered(ChannelHandlerContext, Object) - Method in class io.netty.handler.logging.LoggingHandler
 
userEventTriggered(ChannelHandlerContext, Object) - Method in class io.netty.handler.ssl.ApplicationProtocolNegotiationHandler
 
userName() - Method in class io.netty.handler.codec.mqtt.MqttConnectPayload
 
username(String) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
 
utf8MaxBytes(CharSequence) - Static method in class io.netty.buffer.ByteBufUtil
Returns max bytes length of UTF8 character sequence.
UTF_16 - Static variable in class io.netty.util.CharsetUtil
16-bit UTF (UCS Transformation Format) whose byte order is identified by an optional byte-order mark
UTF_16BE - Static variable in class io.netty.util.CharsetUtil
16-bit UTF (UCS Transformation Format) whose byte order is big-endian
UTF_16LE - Static variable in class io.netty.util.CharsetUtil
16-bit UTF (UCS Transformation Format) whose byte order is little-endian
UTF_8 - Static variable in class io.netty.util.CharsetUtil
8-bit UTF (UCS Transformation Format)

V

validate() - Method in class io.netty.bootstrap.AbstractBootstrap
Validate all the parameters.
validate() - Method in class io.netty.bootstrap.Bootstrap
 
validate() - Method in class io.netty.bootstrap.ServerBootstrap
 
validate(T) - Method in class io.netty.channel.ChannelOption
Validate the value which is set for the ChannelOption.
validate(ChannelOption<T>, T) - Method in class io.netty.channel.DefaultChannelConfig
 
validateName(K) - Method in interface io.netty.handler.codec.DefaultHeaders.NameValidator
Verify that name is valid.
value - Variable in class io.netty.handler.codec.DefaultHeaders.HeaderEntry
 
value() - Method in enum io.netty.handler.codec.mqtt.MqttMessageType
 
value() - Method in enum io.netty.handler.codec.mqtt.MqttQoS
 
value() - Method in class io.netty.handler.codec.redis.IntegerRedisMessage
Get long value of this IntegerRedisMessage.
value() - Method in enum io.netty.handler.codec.redis.RedisMessageType
Returns prefix byte for this type.
value() - Method in class io.netty.handler.codec.string.LineSeparator
Return the string value of this line separator.
value() - Method in interface io.netty.util.collection.ByteObjectMap.PrimitiveEntry
Gets the value for this entry.
value() - Method in interface io.netty.util.collection.CharObjectMap.PrimitiveEntry
Gets the value for this entry.
value() - Method in interface io.netty.util.collection.IntObjectMap.PrimitiveEntry
Gets the value for this entry.
value() - Method in interface io.netty.util.collection.LongObjectMap.PrimitiveEntry
Gets the value for this entry.
value() - Method in interface io.netty.util.collection.ShortObjectMap.PrimitiveEntry
Gets the value for this entry.
value - Variable in class io.netty.util.internal.IntegerHolder
 
value() - Method in interface io.netty.util.internal.LongCounter
 
valueConverter() - Method in class io.netty.handler.codec.DefaultHeaders
 
ValueConverter<T> - Interface in io.netty.handler.codec
Converts to/from a generic object to the type.
valueOf(String) - Static method in class io.netty.channel.ChannelOption
Returns the ChannelOption of the specified name.
valueOf(Class<?>, String) - Static method in class io.netty.channel.ChannelOption
valueOf(String) - Static method in enum io.netty.channel.epoll.EpollMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.netty.channel.pool.FixedChannelPool.AcquireTimeoutAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.netty.channel.socket.InternetProtocolFamily
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.netty.channel.unix.DomainSocketReadMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.netty.handler.codec.AsciiHeadersEncoder.NewlineType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.netty.handler.codec.AsciiHeadersEncoder.SeparatorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.netty.handler.codec.base64.Base64Dialect
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.netty.handler.codec.compression.ZlibWrapper
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in class io.netty.handler.codec.dns.DnsOpCode
Returns the DnsOpCode instance of the specified byte value.
valueOf(int) - Static method in class io.netty.handler.codec.dns.DnsRecordType
 
valueOf(String) - Static method in class io.netty.handler.codec.dns.DnsRecordType
 
valueOf(int) - Static method in class io.netty.handler.codec.dns.DnsResponseCode
Returns the DnsResponseCode that corresponds with the given responseCode.
valueOf(String) - Static method in enum io.netty.handler.codec.dns.DnsSection
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.netty.handler.codec.mqtt.MqttConnectReturnCode
Returns the enum constant of this type with the specified name.
valueOf(byte) - Static method in enum io.netty.handler.codec.mqtt.MqttConnectReturnCode
 
valueOf(String) - Static method in enum io.netty.handler.codec.mqtt.MqttMessageType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum io.netty.handler.codec.mqtt.MqttMessageType
 
valueOf(String) - Static method in enum io.netty.handler.codec.mqtt.MqttQoS
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum io.netty.handler.codec.mqtt.MqttQoS
 
valueOf(String) - Static method in enum io.netty.handler.codec.mqtt.MqttVersion
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.netty.handler.codec.ProtocolDetectionState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.netty.handler.codec.redis.RedisMessageType
Returns the enum constant of this type with the specified name.
valueOf(byte) - Static method in enum io.netty.handler.codec.redis.RedisMessageType
Return RedisMessageType for this type prefix byte.
valueOf(CharSequence) - Static method in class io.netty.handler.codec.smtp.SmtpCommand
Returns the SmtpCommand for the given command name.
valueOf(String) - Static method in enum io.netty.handler.codec.stomp.StompCommand
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.netty.handler.ipfilter.IpFilterRuleType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.netty.handler.logging.LogLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.netty.handler.ssl.ApplicationProtocolConfig.Protocol
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.netty.handler.ssl.ApplicationProtocolConfig.SelectedListenerFailureBehavior
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.netty.handler.ssl.ApplicationProtocolConfig.SelectorFailureBehavior
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.netty.handler.ssl.ClientAuth
Returns the enum constant of this type with the specified name.
valueOf(byte[]) - Static method in class io.netty.handler.ssl.PemPrivateKey
Creates a PemPrivateKey from raw byte[].
valueOf(ByteBuf) - Static method in class io.netty.handler.ssl.PemPrivateKey
Creates a PemPrivateKey from raw ByteBuf.
valueOf(byte[]) - Static method in class io.netty.handler.ssl.PemX509Certificate
Creates a PemX509Certificate from raw byte[].
valueOf(ByteBuf) - Static method in class io.netty.handler.ssl.PemX509Certificate
Creates a PemX509Certificate from raw ByteBuf.
valueOf(String) - Static method in enum io.netty.handler.ssl.SslProvider
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.netty.handler.timeout.IdleState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.netty.resolver.ResolvedAddressTypes
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in class io.netty.util.AttributeKey
Returns the singleton instance of the AttributeKey which has the specified name.
valueOf(Class<?>, String) - Static method in class io.netty.util.AttributeKey
 
valueOf(Class<?>, String) - Method in class io.netty.util.ConstantPool
valueOf(String) - Method in class io.netty.util.ConstantPool
Returns the Constant which is assigned to the specified name.
valueOf(String) - Static method in enum io.netty.util.internal.logging.InternalLogLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.netty.util.ResourceLeakDetector.Level
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in error io.netty.util.Signal
Returns the Signal of the specified name.
valueOf(Class<?>, String) - Static method in error io.netty.util.Signal
values() - Static method in enum io.netty.channel.epoll.EpollMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.netty.channel.pool.FixedChannelPool.AcquireTimeoutAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.netty.channel.socket.InternetProtocolFamily
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.netty.channel.unix.DomainSocketReadMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.netty.handler.codec.AsciiHeadersEncoder.NewlineType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.netty.handler.codec.AsciiHeadersEncoder.SeparatorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.netty.handler.codec.base64.Base64Dialect
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.netty.handler.codec.compression.ZlibWrapper
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.netty.handler.codec.dns.DnsSection
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.netty.handler.codec.mqtt.MqttConnectReturnCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.netty.handler.codec.mqtt.MqttMessageType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.netty.handler.codec.mqtt.MqttQoS
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.netty.handler.codec.mqtt.MqttVersion
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.netty.handler.codec.ProtocolDetectionState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.netty.handler.codec.redis.RedisMessageType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.netty.handler.codec.stomp.StompCommand
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.netty.handler.ipfilter.IpFilterRuleType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.netty.handler.logging.LogLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.netty.handler.ssl.ApplicationProtocolConfig.Protocol
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.netty.handler.ssl.ApplicationProtocolConfig.SelectedListenerFailureBehavior
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.netty.handler.ssl.ApplicationProtocolConfig.SelectorFailureBehavior
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.netty.handler.ssl.ClientAuth
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.netty.handler.ssl.SslProvider
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.netty.handler.timeout.IdleState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.netty.resolver.ResolvedAddressTypes
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in class io.netty.util.CharsetUtil
 
values() - Method in class io.netty.util.collection.ByteObjectHashMap
 
values() - Method in class io.netty.util.collection.CharObjectHashMap
 
values() - Method in class io.netty.util.collection.IntObjectHashMap
 
values() - Method in class io.netty.util.collection.LongObjectHashMap
 
values() - Method in class io.netty.util.collection.ShortObjectHashMap
 
values() - Static method in enum io.netty.util.internal.logging.InternalLogLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.netty.util.ResourceLeakDetector.Level
Returns an array containing the constants of this enum type, in the order they are declared.
variableHeader() - Method in class io.netty.handler.codec.mqtt.MqttConnAckMessage
 
variableHeader() - Method in class io.netty.handler.codec.mqtt.MqttConnectMessage
 
variableHeader() - Method in class io.netty.handler.codec.mqtt.MqttMessage
 
variableHeader() - Method in class io.netty.handler.codec.mqtt.MqttPubAckMessage
 
variableHeader() - Method in class io.netty.handler.codec.mqtt.MqttPublishMessage
 
variableHeader() - Method in class io.netty.handler.codec.mqtt.MqttSubAckMessage
 
variableHeader() - Method in class io.netty.handler.codec.mqtt.MqttSubscribeMessage
 
variableHeader() - Method in class io.netty.handler.codec.mqtt.MqttUnsubAckMessage
 
variableHeader() - Method in class io.netty.handler.codec.mqtt.MqttUnsubscribeMessage
 
verify(PublicKey) - Method in class io.netty.handler.ssl.PemX509Certificate
 
verify(PublicKey, String) - Method in class io.netty.handler.ssl.PemX509Certificate
 
version() - Method in class io.netty.handler.codec.dns.AbstractDnsOptPseudoRrRecord
 
version() - Method in interface io.netty.handler.codec.dns.DnsOptPseudoRecord
Returns the VERSION which is encoded into DnsRecord.timeToLive().
VERSION - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
version() - Method in class io.netty.handler.codec.mqtt.MqttConnectVariableHeader
 
VERSION - Static variable in interface io.netty.handler.codec.stomp.StompHeaders
 
Version - Class in io.netty.util
Retrieves the version information of available Netty artifacts.
voidPromise() - Method in class io.netty.channel.AbstractChannel.AbstractUnsafe
 
voidPromise() - Method in class io.netty.channel.AbstractChannel
 
voidPromise() - Method in interface io.netty.channel.Channel.Unsafe
Return a special ChannelPromise which can be reused and passed to the operations in Channel.Unsafe.
voidPromise() - Method in interface io.netty.channel.ChannelOutboundInvoker
Return a special ChannelPromise which can be reused for different operations.
voidPromise() - Method in class io.netty.channel.DefaultChannelPipeline
 
VRFY - Static variable in class io.netty.handler.codec.smtp.SmtpCommand
 
vrfy(CharSequence) - Static method in class io.netty.handler.codec.smtp.SmtpRequests
Creates a VRFY request.

W

wakesUpForTask(Runnable) - Method in class io.netty.channel.SingleThreadEventLoop
 
wakesUpForTask(Runnable) - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
 
wakeup(boolean) - Method in class io.netty.channel.nio.NioEventLoop
 
wakeup(boolean) - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
 
warn(Throwable) - Method in class io.netty.util.internal.logging.AbstractInternalLogger
 
warn(String) - Method in interface io.netty.util.internal.logging.InternalLogger
Log a message at the WARN level.
warn(String, Object) - Method in interface io.netty.util.internal.logging.InternalLogger
Log a message at the WARN level according to the specified format and argument.
warn(String, Object...) - Method in interface io.netty.util.internal.logging.InternalLogger
Log a message at the WARN level according to the specified format and arguments.
warn(String, Object, Object) - Method in interface io.netty.util.internal.logging.InternalLogger
Log a message at the WARN level according to the specified format and arguments.
warn(String, Throwable) - Method in interface io.netty.util.internal.logging.InternalLogger
Log an exception (throwable) at the WARN level with an accompanying message.
warn(Throwable) - Method in interface io.netty.util.internal.logging.InternalLogger
Log an exception (throwable) at the WARN level.
watch(Thread, Runnable) - Static method in class io.netty.util.ThreadDeathWatcher
Schedules the specified task to run when the specified thread dies.
weakCachingConcurrentResolver(ClassLoader) - Static method in class io.netty.handler.codec.serialization.ClassResolvers
non-agressive concurrent cache good for shared cache, when we're worried about class unloading
weakCachingResolver(ClassLoader) - Static method in class io.netty.handler.codec.serialization.ClassResolvers
non-agressive non-concurrent cache good for non-shared default cache
willFlag(boolean) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
 
willMessage() - Method in class io.netty.handler.codec.mqtt.MqttConnectPayload
willMessage(String) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
willMessage(byte[]) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
 
willMessageInBytes() - Method in class io.netty.handler.codec.mqtt.MqttConnectPayload
 
willQos() - Method in class io.netty.handler.codec.mqtt.MqttConnectVariableHeader
 
willQoS(MqttQoS) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
 
willRetain(boolean) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
 
willTopic() - Method in class io.netty.handler.codec.mqtt.MqttConnectPayload
 
willTopic(String) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
 
WINDOWS - Static variable in class io.netty.handler.codec.string.LineSeparator
The Windows line separator(CRLF)
WORKER_STATE_INIT - Static variable in class io.netty.util.HashedWheelTimer
 
WORKER_STATE_SHUTDOWN - Static variable in class io.netty.util.HashedWheelTimer
 
WORKER_STATE_STARTED - Static variable in class io.netty.util.HashedWheelTimer
 
wrappedBuffer(byte[]) - Static method in class io.netty.buffer.Unpooled
Creates a new big-endian buffer which wraps the specified array.
wrappedBuffer(byte[], int, int) - Static method in class io.netty.buffer.Unpooled
Creates a new big-endian buffer which wraps the sub-region of the specified array.
wrappedBuffer(ByteBuffer) - Static method in class io.netty.buffer.Unpooled
Creates a new buffer which wraps the specified NIO buffer's current slice.
wrappedBuffer(long, int, boolean) - Static method in class io.netty.buffer.Unpooled
Creates a new buffer which wraps the specified memory address.
wrappedBuffer(ByteBuf) - Static method in class io.netty.buffer.Unpooled
Creates a new buffer which wraps the specified buffer's readable bytes.
wrappedBuffer(byte[]...) - Static method in class io.netty.buffer.Unpooled
Creates a new big-endian composite buffer which wraps the specified arrays without copying them.
wrappedBuffer(ByteBuf...) - Static method in class io.netty.buffer.Unpooled
Creates a new big-endian composite buffer which wraps the readable bytes of the specified buffers without copying them.
wrappedBuffer(ByteBuffer...) - Static method in class io.netty.buffer.Unpooled
Creates a new big-endian composite buffer which wraps the slices of the specified NIO buffers without copying them.
wrappedBuffer(int, byte[]...) - Static method in class io.netty.buffer.Unpooled
Creates a new big-endian composite buffer which wraps the specified arrays without copying them.
wrappedBuffer(int, ByteBuf...) - Static method in class io.netty.buffer.Unpooled
Creates a new big-endian composite buffer which wraps the readable bytes of the specified buffers without copying them.
wrappedBuffer(int, ByteBuffer...) - Static method in class io.netty.buffer.Unpooled
Creates a new big-endian composite buffer which wraps the slices of the specified NIO buffers without copying them.
wrapperFactory() - Method in interface io.netty.handler.ssl.JdkApplicationProtocolNegotiator
wrapSslEngine(SSLEngine, JdkApplicationProtocolNegotiator, boolean) - Method in interface io.netty.handler.ssl.JdkApplicationProtocolNegotiator.SslEngineWrapperFactory
Abstract factory pattern for wrapping an SSLEngine object.
writableBytes() - Method in class io.netty.buffer.AbstractByteBuf
 
writableBytes() - Method in class io.netty.buffer.ByteBuf
Returns the number of writable bytes which is equal to (this.capacity - this.writerIndex).
writableBytes() - Method in class io.netty.buffer.EmptyByteBuf
 
writableBytes() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
write(byte[], int, int) - Method in class io.netty.buffer.ByteBufOutputStream
 
write(byte[]) - Method in class io.netty.buffer.ByteBufOutputStream
 
write(int) - Method in class io.netty.buffer.ByteBufOutputStream
 
write(Object, ChannelPromise) - Method in class io.netty.channel.AbstractChannel.AbstractUnsafe
 
write(Object) - Method in class io.netty.channel.AbstractChannel
 
write(Object, ChannelPromise) - Method in class io.netty.channel.AbstractChannel
 
write(Object, ChannelPromise) - Method in interface io.netty.channel.Channel.Unsafe
Schedules a write operation.
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class io.netty.channel.ChannelDuplexHandler
write(ChannelHandlerContext, Object, ChannelPromise) - Method in interface io.netty.channel.ChannelOutboundHandler
Called once a write operation is made.
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class io.netty.channel.ChannelOutboundHandlerAdapter
write(Object) - Method in interface io.netty.channel.ChannelOutboundInvoker
Request to write a message via this ChannelHandlerContext through the ChannelPipeline.
write(Object, ChannelPromise) - Method in interface io.netty.channel.ChannelOutboundInvoker
Request to write a message via this ChannelHandlerContext through the ChannelPipeline.
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class io.netty.channel.CombinedChannelDuplexHandler
 
write(Object) - Method in class io.netty.channel.DefaultChannelPipeline
 
write(Object, ChannelPromise) - Method in class io.netty.channel.DefaultChannelPipeline
 
write(Object) - Method in interface io.netty.channel.group.ChannelGroup
Writes the specified message to all Channels in this group.
write(Object, ChannelMatcher) - Method in interface io.netty.channel.group.ChannelGroup
Writes the specified message to all Channels in this group that are matched by the given ChannelMatcher.
write(Object, ChannelMatcher, boolean) - Method in interface io.netty.channel.group.ChannelGroup
Writes the specified message to all Channels in this group that are matched by the given ChannelMatcher.
write(Object) - Method in class io.netty.channel.group.DefaultChannelGroup
 
write(Object, ChannelMatcher) - Method in class io.netty.channel.group.DefaultChannelGroup
 
write(Object, ChannelMatcher, boolean) - Method in class io.netty.channel.group.DefaultChannelGroup
 
write(ByteBuffer, int, int) - Method in class io.netty.channel.unix.FileDescriptor
 
write(ByteBuffer) - Method in class io.netty.channel.unix.SocketWritableByteChannel
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class io.netty.handler.codec.ByteToMessageCodec
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class io.netty.handler.codec.MessageToByteEncoder
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class io.netty.handler.codec.MessageToMessageCodec
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class io.netty.handler.codec.MessageToMessageEncoder
 
write(int) - Method in class io.netty.handler.codec.serialization.ObjectEncoderOutputStream
 
write(byte[], int, int) - Method in class io.netty.handler.codec.serialization.ObjectEncoderOutputStream
 
write(byte[]) - Method in class io.netty.handler.codec.serialization.ObjectEncoderOutputStream
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class io.netty.handler.logging.LoggingHandler
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class io.netty.handler.ssl.AbstractSniHandler
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class io.netty.handler.ssl.SslHandler
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class io.netty.handler.stream.ChunkedWriteHandler
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class io.netty.handler.timeout.IdleStateHandler
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class io.netty.handler.timeout.WriteTimeoutHandler
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class io.netty.handler.traffic.AbstractTrafficShapingHandler
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
 
WRITE_BUFFER_HIGH_WATER_MARK - Static variable in class io.netty.channel.ChannelOption
WRITE_BUFFER_LOW_WATER_MARK - Static variable in class io.netty.channel.ChannelOption
WRITE_BUFFER_WATER_MARK - Static variable in class io.netty.channel.ChannelOption
 
WRITE_SPIN_COUNT - Static variable in class io.netty.channel.ChannelOption
 
writeAddress(long, int, int) - Method in class io.netty.channel.unix.FileDescriptor
 
writeAndFlush(Object) - Method in class io.netty.channel.AbstractChannel
 
writeAndFlush(Object, ChannelPromise) - Method in class io.netty.channel.AbstractChannel
 
writeAndFlush(Object, ChannelPromise) - Method in interface io.netty.channel.ChannelOutboundInvoker
writeAndFlush(Object) - Method in interface io.netty.channel.ChannelOutboundInvoker
writeAndFlush(Object, ChannelPromise) - Method in class io.netty.channel.DefaultChannelPipeline
 
writeAndFlush(Object) - Method in class io.netty.channel.DefaultChannelPipeline
 
writeAndFlush(Object) - Method in interface io.netty.channel.group.ChannelGroup
writeAndFlush(Object, ChannelMatcher) - Method in interface io.netty.channel.group.ChannelGroup
Shortcut for calling ChannelGroup.write(Object) and ChannelGroup.flush() and only act on Channels that are matched by the ChannelMatcher.
writeAndFlush(Object, ChannelMatcher, boolean) - Method in interface io.netty.channel.group.ChannelGroup
Shortcut for calling ChannelGroup.write(Object, ChannelMatcher, boolean) and ChannelGroup.flush() and only act on Channels that are matched by the ChannelMatcher.
writeAndFlush(Object) - Method in class io.netty.channel.group.DefaultChannelGroup
 
writeAndFlush(Object, ChannelMatcher) - Method in class io.netty.channel.group.DefaultChannelGroup
 
writeAndFlush(Object, ChannelMatcher, boolean) - Method in class io.netty.channel.group.DefaultChannelGroup
 
writeAscii(ByteBufAllocator, CharSequence) - Static method in class io.netty.buffer.ByteBufUtil
Encode a CharSequence in ASCII and write it to a ByteBuf allocated with alloc.
writeAscii(ByteBuf, CharSequence) - Static method in class io.netty.buffer.ByteBufUtil
Encode a CharSequence in ASCII and write it to a ByteBuf.
writeBoolean(boolean) - Method in class io.netty.buffer.AbstractByteBuf
 
writeBoolean(boolean) - Method in class io.netty.buffer.ByteBuf
Sets the specified boolean at the current writerIndex and increases the writerIndex by 1 in this buffer.
writeBoolean(boolean) - Method in class io.netty.buffer.ByteBufOutputStream
 
writeBoolean(boolean) - Method in class io.netty.buffer.CompositeByteBuf
 
writeBoolean(boolean) - Method in class io.netty.buffer.EmptyByteBuf
 
writeBoolean(boolean) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
writeBoolean(boolean) - Method in class io.netty.handler.codec.serialization.ObjectEncoderOutputStream
 
WriteBufferWaterMark - Class in io.netty.channel
WriteBufferWaterMark is used to set low water mark and high water mark for the write buffer.
WriteBufferWaterMark(int, int) - Constructor for class io.netty.channel.WriteBufferWaterMark
Create a new instance.
writeByte(int) - Method in class io.netty.buffer.AbstractByteBuf
 
writeByte(int) - Method in class io.netty.buffer.ByteBuf
Sets the specified byte at the current writerIndex and increases the writerIndex by 1 in this buffer.
writeByte(int) - Method in class io.netty.buffer.ByteBufOutputStream
 
writeByte(int) - Method in class io.netty.buffer.CompositeByteBuf
 
writeByte(int) - Method in class io.netty.buffer.EmptyByteBuf
 
writeByte(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
writeByte(int) - Method in class io.netty.handler.codec.serialization.ObjectEncoderOutputStream
 
writeBytes(byte[], int, int) - Method in class io.netty.buffer.AbstractByteBuf
 
writeBytes(byte[]) - Method in class io.netty.buffer.AbstractByteBuf
 
writeBytes(ByteBuf) - Method in class io.netty.buffer.AbstractByteBuf
 
writeBytes(ByteBuf, int) - Method in class io.netty.buffer.AbstractByteBuf
 
writeBytes(ByteBuf, int, int) - Method in class io.netty.buffer.AbstractByteBuf
 
writeBytes(ByteBuffer) - Method in class io.netty.buffer.AbstractByteBuf
 
writeBytes(InputStream, int) - Method in class io.netty.buffer.AbstractByteBuf
 
writeBytes(ScatteringByteChannel, int) - Method in class io.netty.buffer.AbstractByteBuf
 
writeBytes(FileChannel, long, int) - Method in class io.netty.buffer.AbstractByteBuf
 
writeBytes(ByteBuf) - Method in class io.netty.buffer.ByteBuf
Transfers the specified source buffer's data to this buffer starting at the current writerIndex until the source buffer becomes unreadable, and increases the writerIndex by the number of the transferred bytes.
writeBytes(ByteBuf, int) - Method in class io.netty.buffer.ByteBuf
Transfers the specified source buffer's data to this buffer starting at the current writerIndex and increases the writerIndex by the number of the transferred bytes (= length).
writeBytes(ByteBuf, int, int) - Method in class io.netty.buffer.ByteBuf
Transfers the specified source buffer's data to this buffer starting at the current writerIndex and increases the writerIndex by the number of the transferred bytes (= length).
writeBytes(byte[]) - Method in class io.netty.buffer.ByteBuf
Transfers the specified source array's data to this buffer starting at the current writerIndex and increases the writerIndex by the number of the transferred bytes (= src.length).
writeBytes(byte[], int, int) - Method in class io.netty.buffer.ByteBuf
Transfers the specified source array's data to this buffer starting at the current writerIndex and increases the writerIndex by the number of the transferred bytes (= length).
writeBytes(ByteBuffer) - Method in class io.netty.buffer.ByteBuf
Transfers the specified source buffer's data to this buffer starting at the current writerIndex until the source buffer's position reaches its limit, and increases the writerIndex by the number of the transferred bytes.
writeBytes(InputStream, int) - Method in class io.netty.buffer.ByteBuf
Transfers the content of the specified stream to this buffer starting at the current writerIndex and increases the writerIndex by the number of the transferred bytes.
writeBytes(ScatteringByteChannel, int) - Method in class io.netty.buffer.ByteBuf
Transfers the content of the specified channel to this buffer starting at the current writerIndex and increases the writerIndex by the number of the transferred bytes.
writeBytes(FileChannel, long, int) - Method in class io.netty.buffer.ByteBuf
Transfers the content of the specified channel starting at the given file position to this buffer starting at the current writerIndex and increases the writerIndex by the number of the transferred bytes.
writeBytes(String) - Method in class io.netty.buffer.ByteBufOutputStream
 
writeBytes(ByteBuf) - Method in class io.netty.buffer.CompositeByteBuf
 
writeBytes(ByteBuf, int) - Method in class io.netty.buffer.CompositeByteBuf
 
writeBytes(ByteBuf, int, int) - Method in class io.netty.buffer.CompositeByteBuf
 
writeBytes(byte[]) - Method in class io.netty.buffer.CompositeByteBuf
 
writeBytes(byte[], int, int) - Method in class io.netty.buffer.CompositeByteBuf
 
writeBytes(ByteBuffer) - Method in class io.netty.buffer.CompositeByteBuf
 
writeBytes(ByteBuf) - Method in class io.netty.buffer.EmptyByteBuf
 
writeBytes(ByteBuf, int) - Method in class io.netty.buffer.EmptyByteBuf
 
writeBytes(ByteBuf, int, int) - Method in class io.netty.buffer.EmptyByteBuf
 
writeBytes(byte[]) - Method in class io.netty.buffer.EmptyByteBuf
 
writeBytes(byte[], int, int) - Method in class io.netty.buffer.EmptyByteBuf
 
writeBytes(ByteBuffer) - Method in class io.netty.buffer.EmptyByteBuf
 
writeBytes(InputStream, int) - Method in class io.netty.buffer.EmptyByteBuf
 
writeBytes(ScatteringByteChannel, int) - Method in class io.netty.buffer.EmptyByteBuf
 
writeBytes(FileChannel, long, int) - Method in class io.netty.buffer.EmptyByteBuf
 
writeBytes(ByteBuf) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
writeBytes(ByteBuf, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
writeBytes(ByteBuf, int, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
writeBytes(byte[]) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
writeBytes(byte[], int, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
writeBytes(ByteBuffer) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
writeBytes(InputStream, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
writeBytes(ScatteringByteChannel, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
writeBytes(FileChannel, long, int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
writeBytes(String) - Method in class io.netty.handler.codec.serialization.ObjectEncoderOutputStream
 
writeChar(int) - Method in class io.netty.buffer.AbstractByteBuf
 
writeChar(int) - Method in class io.netty.buffer.ByteBuf
Sets the specified 2-byte UTF-16 character at the current writerIndex and increases the writerIndex by 2 in this buffer.
writeChar(int) - Method in class io.netty.buffer.ByteBufOutputStream
 
writeChar(int) - Method in class io.netty.buffer.CompositeByteBuf
 
writeChar(int) - Method in class io.netty.buffer.EmptyByteBuf
 
writeChar(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
writeChar(int) - Method in class io.netty.handler.codec.serialization.ObjectEncoderOutputStream
 
writeChars(String) - Method in class io.netty.buffer.ByteBufOutputStream
 
writeChars(String) - Method in class io.netty.handler.codec.serialization.ObjectEncoderOutputStream
 
writeCharSequence(CharSequence, Charset) - Method in class io.netty.buffer.AbstractByteBuf
 
writeCharSequence(CharSequence, Charset) - Method in class io.netty.buffer.ByteBuf
Writes the specified CharSequence at the current writerIndex and increases the writerIndex by the written bytes.
writeCharSequence(CharSequence, Charset) - Method in class io.netty.buffer.EmptyByteBuf
 
writeCharSequence(CharSequence, Charset) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
writeCounter() - Method in class io.netty.channel.ChannelFlushPromiseNotifier
Return the current write counter of this ChannelFlushPromiseNotifier
writeDouble(double) - Method in class io.netty.buffer.AbstractByteBuf
 
writeDouble(double) - Method in class io.netty.buffer.ByteBuf
Sets the specified 64-bit floating point number at the current writerIndex and increases the writerIndex by 8 in this buffer.
writeDouble(double) - Method in class io.netty.buffer.ByteBufOutputStream
 
writeDouble(double) - Method in class io.netty.buffer.CompositeByteBuf
 
writeDouble(double) - Method in class io.netty.buffer.EmptyByteBuf
 
writeDouble(double) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
writeDouble(double) - Method in class io.netty.handler.codec.serialization.ObjectEncoderOutputStream
 
writeFloat(float) - Method in class io.netty.buffer.AbstractByteBuf
 
writeFloat(float) - Method in class io.netty.buffer.ByteBuf
Sets the specified 32-bit floating point number at the current writerIndex and increases the writerIndex by 4 in this buffer.
writeFloat(float) - Method in class io.netty.buffer.ByteBufOutputStream
 
writeFloat(float) - Method in class io.netty.buffer.CompositeByteBuf
 
writeFloat(float) - Method in class io.netty.buffer.EmptyByteBuf
 
writeFloat(float) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
writeFloat(float) - Method in class io.netty.handler.codec.serialization.ObjectEncoderOutputStream
 
writeInbound(Object...) - Method in class io.netty.channel.embedded.EmbeddedChannel
Write messages to the inbound of this Channel.
writeInt(int) - Method in class io.netty.buffer.AbstractByteBuf
 
writeInt(int) - Method in class io.netty.buffer.ByteBuf
Sets the specified 32-bit integer at the current writerIndex and increases the writerIndex by 4 in this buffer.
writeInt(int) - Method in class io.netty.buffer.ByteBufOutputStream
 
writeInt(int) - Method in class io.netty.buffer.CompositeByteBuf
 
writeInt(int) - Method in class io.netty.buffer.EmptyByteBuf
 
writeInt(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
writeInt(int) - Method in class io.netty.handler.codec.serialization.ObjectEncoderOutputStream
 
writeIntLE(int) - Method in class io.netty.buffer.AbstractByteBuf
 
writeIntLE(int) - Method in class io.netty.buffer.ByteBuf
Sets the specified 32-bit integer at the current writerIndex in the Little Endian Byte Order and increases the writerIndex by 4 in this buffer.
writeIntLE(int) - Method in class io.netty.buffer.EmptyByteBuf
 
writeIntLE(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
writeLong(long) - Method in class io.netty.buffer.AbstractByteBuf
 
writeLong(long) - Method in class io.netty.buffer.ByteBuf
Sets the specified 64-bit long integer at the current writerIndex and increases the writerIndex by 8 in this buffer.
writeLong(long) - Method in class io.netty.buffer.ByteBufOutputStream
 
writeLong(long) - Method in class io.netty.buffer.CompositeByteBuf
 
writeLong(long) - Method in class io.netty.buffer.EmptyByteBuf
 
writeLong(long) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
writeLong(long) - Method in class io.netty.handler.codec.serialization.ObjectEncoderOutputStream
 
writeLongLE(long) - Method in class io.netty.buffer.AbstractByteBuf
 
writeLongLE(long) - Method in class io.netty.buffer.ByteBuf
Sets the specified 64-bit long integer at the current writerIndex in the Little Endian Byte Order and increases the writerIndex by 8 in this buffer.
writeLongLE(long) - Method in class io.netty.buffer.EmptyByteBuf
 
writeLongLE(long) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
writeMedium(int) - Method in class io.netty.buffer.AbstractByteBuf
 
writeMedium(int) - Method in class io.netty.buffer.ByteBuf
Sets the specified 24-bit medium integer at the current writerIndex and increases the writerIndex by 3 in this buffer.
writeMedium(int) - Method in class io.netty.buffer.CompositeByteBuf
 
writeMedium(int) - Method in class io.netty.buffer.EmptyByteBuf
 
writeMedium(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
writeMediumLE(int) - Method in class io.netty.buffer.AbstractByteBuf
 
writeMediumLE(int) - Method in class io.netty.buffer.ByteBuf
Sets the specified 24-bit medium integer at the current writerIndex in the Little Endian Byte Order and increases the writerIndex by 3 in this buffer.
writeMediumLE(int) - Method in class io.netty.buffer.EmptyByteBuf
 
writeMediumLE(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
writeObject(Object) - Method in class io.netty.handler.codec.serialization.ObjectEncoderOutputStream
 
writeOneInbound(Object) - Method in class io.netty.channel.embedded.EmbeddedChannel
Writes one message to the inbound of this Channel and does not flush it.
writeOneInbound(Object, ChannelPromise) - Method in class io.netty.channel.embedded.EmbeddedChannel
Writes one message to the inbound of this Channel and does not flush it.
writeOneOutbound(Object) - Method in class io.netty.channel.embedded.EmbeddedChannel
Writes one message to the outbound of this Channel and does not flush it.
writeOneOutbound(Object, ChannelPromise) - Method in class io.netty.channel.embedded.EmbeddedChannel
Writes one message to the outbound of this Channel and does not flush it.
writeOutbound(Object...) - Method in class io.netty.channel.embedded.EmbeddedChannel
Write messages to the outbound of this Channel.
WRITER_IDLE_STATE_EVENT - Static variable in class io.netty.handler.timeout.IdleStateEvent
 
writerIndex() - Method in class io.netty.buffer.AbstractByteBuf
 
writerIndex(int) - Method in class io.netty.buffer.AbstractByteBuf
 
writerIndex() - Method in class io.netty.buffer.ByteBuf
Returns the writerIndex of this buffer.
writerIndex(int) - Method in class io.netty.buffer.ByteBuf
Sets the writerIndex of this buffer.
writerIndex(int) - Method in class io.netty.buffer.CompositeByteBuf
 
writerIndex() - Method in class io.netty.buffer.EmptyByteBuf
 
writerIndex(int) - Method in class io.netty.buffer.EmptyByteBuf
 
writerIndex() - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
writerIndex(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
writeShort(int) - Method in class io.netty.buffer.AbstractByteBuf
 
writeShort(int) - Method in class io.netty.buffer.ByteBuf
Sets the specified 16-bit short integer at the current writerIndex and increases the writerIndex by 2 in this buffer.
writeShort(int) - Method in class io.netty.buffer.ByteBufOutputStream
 
writeShort(int) - Method in class io.netty.buffer.CompositeByteBuf
 
writeShort(int) - Method in class io.netty.buffer.EmptyByteBuf
 
writeShort(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
writeShort(int) - Method in class io.netty.handler.codec.serialization.ObjectEncoderOutputStream
 
writeShortLE(int) - Method in class io.netty.buffer.AbstractByteBuf
 
writeShortLE(int) - Method in class io.netty.buffer.ByteBuf
Sets the specified 16-bit short integer in the Little Endian Byte Order at the current writerIndex and increases the writerIndex by 2 in this buffer.
writeShortLE(int) - Method in class io.netty.buffer.EmptyByteBuf
 
writeShortLE(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
writeTimedOut(ChannelHandlerContext) - Method in class io.netty.handler.timeout.WriteTimeoutHandler
Is called when a write timeout was detected
WriteTimeoutException - Exception in io.netty.handler.timeout
A TimeoutException raised by WriteTimeoutHandler when no data was written within a certain period of time.
WriteTimeoutHandler - Class in io.netty.handler.timeout
Raises a WriteTimeoutException when a write operation cannot finish in a certain period of time.
WriteTimeoutHandler(int) - Constructor for class io.netty.handler.timeout.WriteTimeoutHandler
Creates a new instance.
WriteTimeoutHandler(long, TimeUnit) - Constructor for class io.netty.handler.timeout.WriteTimeoutHandler
Creates a new instance.
writeTimeToWait(long, long, long) - Method in class io.netty.handler.traffic.TrafficCounter
Deprecated.
writeTimeToWait(long, long, long, long) - Method in class io.netty.handler.traffic.TrafficCounter
Returns the time to wait (if any) for the given length message, using the given limitTraffic and the max wait time.
writeUTF(String) - Method in class io.netty.buffer.ByteBufOutputStream
 
writeUTF(String) - Method in class io.netty.handler.codec.serialization.ObjectEncoderOutputStream
 
writeUtf8(ByteBufAllocator, CharSequence) - Static method in class io.netty.buffer.ByteBufUtil
Encode a CharSequence in UTF-8 and write it to a ByteBuf allocated with alloc.
writeUtf8(ByteBuf, CharSequence) - Static method in class io.netty.buffer.ByteBufUtil
Encode a CharSequence in UTF-8 and write it to a ByteBuf.
writev(ByteBuffer[], int, int) - Method in class io.netty.channel.unix.FileDescriptor
 
writevAddresses(long, int) - Method in class io.netty.channel.unix.FileDescriptor
 
writeZero(int) - Method in class io.netty.buffer.AbstractByteBuf
 
writeZero(int) - Method in class io.netty.buffer.ByteBuf
Fills this buffer with NUL (0x00) starting at the current writerIndex and increases the writerIndex by the specified length.
writeZero(int) - Method in class io.netty.buffer.CompositeByteBuf
 
writeZero(int) - Method in class io.netty.buffer.EmptyByteBuf
 
writeZero(int) - Method in class io.netty.buffer.SwappedByteBuf
Deprecated.
 
writeZero(int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
writtenBytes() - Method in class io.netty.buffer.ByteBufOutputStream
Returns the number of written bytes by this stream so far.

X

XmlFrameDecoder - Class in io.netty.handler.codec.xml
A frame decoder for single separate XML based message streams.
XmlFrameDecoder(int) - Constructor for class io.netty.handler.codec.xml.XmlFrameDecoder
 

Y

YXDOMAIN - Static variable in class io.netty.handler.codec.dns.DnsResponseCode
The 'YXDomain' DNS RCODE (6), as defined in RFC2136.
YXRRSET - Static variable in class io.netty.handler.codec.dns.DnsResponseCode
The 'YXRRSet' DNS RCODE (7), as defined in RFC2136.

Z

z() - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
 
z() - Method in interface io.netty.handler.codec.dns.DnsMessage
Returns the Z (reserved for future use) field of this DNS message.
ZlibCodecFactory - Class in io.netty.handler.codec.compression
Creates a new ZlibEncoder and a new ZlibDecoder.
ZlibDecoder - Class in io.netty.handler.codec.compression
Decompresses a ByteBuf using the deflate algorithm.
ZlibDecoder() - Constructor for class io.netty.handler.codec.compression.ZlibDecoder
 
ZlibEncoder - Class in io.netty.handler.codec.compression
Compresses a ByteBuf using the deflate algorithm.
ZlibEncoder() - Constructor for class io.netty.handler.codec.compression.ZlibEncoder
 
ZlibWrapper - Enum in io.netty.handler.codec.compression
The container file formats that wrap the stream compressed by the DEFLATE algorithm.

_

_getByte(int) - Method in class io.netty.buffer.AbstractByteBuf
 
_getByte(int) - Method in class io.netty.buffer.CompositeByteBuf
 
_getByte(int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
_getByte(int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
_getByte(int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
_getByte(int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
_getByte(int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
_getInt(int) - Method in class io.netty.buffer.AbstractByteBuf
 
_getInt(int) - Method in class io.netty.buffer.CompositeByteBuf
 
_getInt(int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
_getInt(int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
_getInt(int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
_getInt(int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
_getInt(int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
_getIntLE(int) - Method in class io.netty.buffer.AbstractByteBuf
 
_getIntLE(int) - Method in class io.netty.buffer.CompositeByteBuf
 
_getIntLE(int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
_getIntLE(int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
_getIntLE(int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
_getIntLE(int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
_getIntLE(int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
_getLong(int) - Method in class io.netty.buffer.AbstractByteBuf
 
_getLong(int) - Method in class io.netty.buffer.CompositeByteBuf
 
_getLong(int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
_getLong(int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
_getLong(int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
_getLong(int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
_getLong(int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
_getLongLE(int) - Method in class io.netty.buffer.AbstractByteBuf
 
_getLongLE(int) - Method in class io.netty.buffer.CompositeByteBuf
 
_getLongLE(int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
_getLongLE(int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
_getLongLE(int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
_getLongLE(int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
_getLongLE(int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
_getShort(int) - Method in class io.netty.buffer.AbstractByteBuf
 
_getShort(int) - Method in class io.netty.buffer.CompositeByteBuf
 
_getShort(int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
_getShort(int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
_getShort(int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
_getShort(int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
_getShort(int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
_getShortLE(int) - Method in class io.netty.buffer.AbstractByteBuf
 
_getShortLE(int) - Method in class io.netty.buffer.CompositeByteBuf
 
_getShortLE(int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
_getShortLE(int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
_getShortLE(int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
_getShortLE(int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
_getShortLE(int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
_getUnsignedMedium(int) - Method in class io.netty.buffer.AbstractByteBuf
 
_getUnsignedMedium(int) - Method in class io.netty.buffer.CompositeByteBuf
 
_getUnsignedMedium(int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
_getUnsignedMedium(int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
_getUnsignedMedium(int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
_getUnsignedMedium(int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
_getUnsignedMedium(int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
_getUnsignedMediumLE(int) - Method in class io.netty.buffer.AbstractByteBuf
 
_getUnsignedMediumLE(int) - Method in class io.netty.buffer.CompositeByteBuf
 
_getUnsignedMediumLE(int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
_getUnsignedMediumLE(int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
_getUnsignedMediumLE(int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
_getUnsignedMediumLE(int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
_getUnsignedMediumLE(int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
_setByte(int, int) - Method in class io.netty.buffer.AbstractByteBuf
 
_setByte(int, int) - Method in class io.netty.buffer.CompositeByteBuf
 
_setByte(int, int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
_setByte(int, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
_setByte(int, int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
_setByte(int, int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
_setByte(int, int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
_setInt(int, int) - Method in class io.netty.buffer.AbstractByteBuf
 
_setInt(int, int) - Method in class io.netty.buffer.CompositeByteBuf
 
_setInt(int, int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
_setInt(int, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
_setInt(int, int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
_setInt(int, int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
_setInt(int, int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
_setIntLE(int, int) - Method in class io.netty.buffer.AbstractByteBuf
 
_setIntLE(int, int) - Method in class io.netty.buffer.CompositeByteBuf
 
_setIntLE(int, int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
_setIntLE(int, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
_setIntLE(int, int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
_setIntLE(int, int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
_setIntLE(int, int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
_setLong(int, long) - Method in class io.netty.buffer.AbstractByteBuf
 
_setLong(int, long) - Method in class io.netty.buffer.CompositeByteBuf
 
_setLong(int, long) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
_setLong(int, long) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
_setLong(int, long) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
_setLong(int, long) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
_setLong(int, long) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
_setLongLE(int, long) - Method in class io.netty.buffer.AbstractByteBuf
 
_setLongLE(int, long) - Method in class io.netty.buffer.CompositeByteBuf
 
_setLongLE(int, long) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
_setLongLE(int, long) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
_setLongLE(int, long) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
_setLongLE(int, long) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
_setLongLE(int, long) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
_setMedium(int, int) - Method in class io.netty.buffer.AbstractByteBuf
 
_setMedium(int, int) - Method in class io.netty.buffer.CompositeByteBuf
 
_setMedium(int, int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
_setMedium(int, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
_setMedium(int, int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
_setMedium(int, int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
_setMedium(int, int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
_setMediumLE(int, int) - Method in class io.netty.buffer.AbstractByteBuf
 
_setMediumLE(int, int) - Method in class io.netty.buffer.CompositeByteBuf
 
_setMediumLE(int, int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
_setMediumLE(int, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
_setMediumLE(int, int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
_setMediumLE(int, int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
_setMediumLE(int, int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
_setShort(int, int) - Method in class io.netty.buffer.AbstractByteBuf
 
_setShort(int, int) - Method in class io.netty.buffer.CompositeByteBuf
 
_setShort(int, int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
_setShort(int, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
_setShort(int, int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
_setShort(int, int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
_setShort(int, int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
_setShortLE(int, int) - Method in class io.netty.buffer.AbstractByteBuf
 
_setShortLE(int, int) - Method in class io.netty.buffer.CompositeByteBuf
 
_setShortLE(int, int) - Method in class io.netty.buffer.DuplicatedByteBuf
Deprecated.
 
_setShortLE(int, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
Deprecated.
 
_setShortLE(int, int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
 
_setShortLE(int, int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
 
_setShortLE(int, int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
 
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _ 
Skip navigation links

Copyright © 2008-2017 The Netty Project. All Rights Reserved.