- a - Variable in class io.netty.handler.codec.compression.Bzip2DivSufSort.StackEntry
-
- 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.
- a - Variable in class io.netty.resolver.dns.BiDnsQueryLifecycleObserver
-
- a - Variable in class io.netty.resolver.dns.BiDnsQueryLifecycleObserverFactory
-
- 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 java.net.SocketAddress> - Class in io.netty.resolver
-
- 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
-
- AbstractBinaryMemcacheDecoder(int) - Constructor for class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheDecoder
-
- AbstractBinaryMemcacheDecoder.State - Enum in io.netty.handler.codec.memcache.binary
-
Contains all states this decoder can possibly be in.
- AbstractBinaryMemcacheEncoder<M extends BinaryMemcacheMessage> - Class in io.netty.handler.codec.memcache.binary
-
- AbstractBinaryMemcacheEncoder() - Constructor for class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheEncoder
-
- AbstractBinaryMemcacheMessage - Class in io.netty.handler.codec.memcache.binary
-
- 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() - Constructor for class io.netty.bootstrap.AbstractBootstrap
-
- AbstractBootstrap(AbstractBootstrap<B, C>) - Constructor for class io.netty.bootstrap.AbstractBootstrap
-
- AbstractBootstrap.PendingRegistrationPromise - Class in io.netty.bootstrap
-
- AbstractBootstrapConfig<B extends AbstractBootstrap<B,C>,C extends Channel> - Class in io.netty.bootstrap
-
- 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
-
- 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
-
- 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.
- AbstractChannel.AnnotatedConnectException - Exception in io.netty.channel
-
- AbstractChannel.AnnotatedNoRouteToHostException - Exception in io.netty.channel
-
- AbstractChannel.AnnotatedSocketException - Exception in io.netty.channel
-
- AbstractChannel.CloseFuture - Class in io.netty.channel
-
- AbstractChannelHandlerContext - Class in io.netty.channel
-
- AbstractChannelHandlerContext(DefaultChannelPipeline, EventExecutor, String, boolean, boolean) - Constructor for class io.netty.channel.AbstractChannelHandlerContext
-
- AbstractChannelHandlerContext.AbstractWriteTask - Class in io.netty.channel
-
- AbstractChannelHandlerContext.WriteAndFlushTask - Class in io.netty.channel
-
- AbstractChannelHandlerContext.WriteTask - Class in io.netty.channel
-
- AbstractChannelPoolHandler - Class in io.netty.channel.pool
-
- AbstractChannelPoolHandler() - Constructor for class io.netty.channel.pool.AbstractChannelPoolHandler
-
- AbstractChannelPoolMap<K,P extends ChannelPool> - Class in io.netty.channel.pool
-
- AbstractChannelPoolMap() - Constructor for class io.netty.channel.pool.AbstractChannelPoolMap
-
- AbstractConstant<T extends AbstractConstant<T>> - Class in io.netty.util
-
- AbstractConstant(int, String) - Constructor for class io.netty.util.AbstractConstant
-
Creates a new instance.
- AbstractDerivedByteBuf - Class in io.netty.buffer
-
- AbstractDerivedByteBuf(int) - Constructor for class io.netty.buffer.AbstractDerivedByteBuf
-
Deprecated.
- AbstractDnsMessage - Class in io.netty.handler.codec.dns
-
- AbstractDnsMessage(int) - Constructor for class io.netty.handler.codec.dns.AbstractDnsMessage
-
- 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
-
- 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
-
- AbstractDnsRecord(String, DnsRecordType, long) - Constructor for class io.netty.handler.codec.dns.AbstractDnsRecord
-
- AbstractDnsRecord(String, DnsRecordType, int, long) - Constructor for class io.netty.handler.codec.dns.AbstractDnsRecord
-
Creates a new record.
- AbstractEventExecutor - Class in io.netty.util.concurrent
-
- 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
-
- AbstractEventExecutorGroup() - Constructor for class io.netty.util.concurrent.AbstractEventExecutorGroup
-
- AbstractEventLoop - Class in io.netty.channel
-
- AbstractEventLoop() - Constructor for class io.netty.channel.AbstractEventLoop
-
- AbstractEventLoop(EventLoopGroup) - Constructor for class io.netty.channel.AbstractEventLoop
-
- AbstractEventLoopGroup - Class in io.netty.channel
-
- 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
-
- AbstractIdleTask(ChannelHandlerContext) - Constructor for class io.netty.handler.timeout.IdleStateHandler.AbstractIdleTask
-
- AbstractInternalLogger - Class in io.netty.util.internal.logging
-
- AbstractInternalLogger(String) - Constructor for class io.netty.util.internal.logging.AbstractInternalLogger
-
Creates a new instance.
- AbstractKQueueChannel - Class in io.netty.channel.kqueue
-
- AbstractKQueueChannel(Channel, BsdSocket, boolean) - Constructor for class io.netty.channel.kqueue.AbstractKQueueChannel
-
- AbstractKQueueChannel(Channel, BsdSocket, boolean, boolean) - Constructor for class io.netty.channel.kqueue.AbstractKQueueChannel
-
- AbstractKQueueChannel.AbstractKQueueUnsafe - Class in io.netty.channel.kqueue
-
- AbstractKQueueServerChannel - Class in io.netty.channel.kqueue
-
- AbstractKQueueServerChannel(BsdSocket) - Constructor for class io.netty.channel.kqueue.AbstractKQueueServerChannel
-
- AbstractKQueueServerChannel(BsdSocket, boolean) - Constructor for class io.netty.channel.kqueue.AbstractKQueueServerChannel
-
- AbstractKQueueServerChannel.KQueueServerSocketUnsafe - Class in io.netty.channel.kqueue
-
- AbstractKQueueStreamChannel - Class in io.netty.channel.kqueue
-
- AbstractKQueueStreamChannel(Channel, BsdSocket, boolean) - Constructor for class io.netty.channel.kqueue.AbstractKQueueStreamChannel
-
- AbstractKQueueStreamChannel(BsdSocket) - Constructor for class io.netty.channel.kqueue.AbstractKQueueStreamChannel
-
- AbstractKQueueStreamChannel.KQueueSocketWritableByteChannel - Class in io.netty.channel.kqueue
-
- AbstractKQueueStreamChannel.KQueueStreamUnsafe - Class in io.netty.channel.kqueue
-
- AbstractKQueueUnsafe() - Constructor for class io.netty.channel.kqueue.AbstractKQueueChannel.AbstractKQueueUnsafe
-
- AbstractMemcacheObject - Class in io.netty.handler.codec.memcache
-
- AbstractMemcacheObject() - Constructor for class io.netty.handler.codec.memcache.AbstractMemcacheObject
-
- AbstractMemcacheObjectAggregator<H extends MemcacheMessage> - Class in io.netty.handler.codec.memcache
-
- 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
-
- AbstractMemcacheObjectEncoder() - Constructor for class io.netty.handler.codec.memcache.AbstractMemcacheObjectEncoder
-
- AbstractNioByteChannel - Class in io.netty.channel.nio
-
- 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
-
- AbstractNioMessageChannel(Channel, SelectableChannel, int) - Constructor for class io.netty.channel.nio.AbstractNioMessageChannel
-
- AbstractNioMessageChannel.NioMessageUnsafe - Class in io.netty.channel.nio
-
- AbstractNioUnsafe() - Constructor for class io.netty.channel.nio.AbstractNioChannel.AbstractNioUnsafe
-
- AbstractNotificationHandler<T> - Class in com.sun.nio.sctp
-
- AbstractNotificationHandler() - Constructor for class com.sun.nio.sctp.AbstractNotificationHandler
-
- 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
-
- AbstractOioChannel.DefaultOioUnsafe - Class in io.netty.channel.oio
-
- 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
-
- AbstractPooledDerivedByteBuf - Class in io.netty.buffer
-
Abstract base class for derived
ByteBuf
implementations.
- AbstractPooledDerivedByteBuf(Recycler.Handle<? extends AbstractPooledDerivedByteBuf>) - Constructor for class io.netty.buffer.AbstractPooledDerivedByteBuf
-
- AbstractPooledDerivedByteBuf.PooledNonRetainedDuplicateByteBuf - Class in io.netty.buffer
-
- AbstractPooledDerivedByteBuf.PooledNonRetainedSlicedByteBuf - Class in io.netty.buffer
-
- AbstractReferenceCounted - Class in io.netty.util
-
- 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 java.net.SocketAddress> - Class in io.netty.handler.ipfilter
-
This class provides the functionality to either accept or reject new
Channel
s
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
EventExecutor
s 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.
- AbstractServerChannel.DefaultServerUnsafe - Class in io.netty.channel
-
- AbstractSniHandler<T> - Class in io.netty.handler.ssl
-
- AbstractSniHandler() - Constructor for class io.netty.handler.ssl.AbstractSniHandler
-
- AbstractSocks4Message - Class in io.netty.handler.codec.socksx.v4
-
- AbstractSocks4Message() - Constructor for class io.netty.handler.codec.socksx.v4.AbstractSocks4Message
-
- AbstractSocks5Message - Class in io.netty.handler.codec.socksx.v5
-
- AbstractSocks5Message() - Constructor for class io.netty.handler.codec.socksx.v5.AbstractSocks5Message
-
- AbstractSocksMessage - Class in io.netty.handler.codec.socksx
-
- AbstractSocksMessage() - Constructor for class io.netty.handler.codec.socksx.AbstractSocksMessage
-
- AbstractStringRedisMessage - Class in io.netty.handler.codec.redis
-
Abstract class for Simple Strings or Errors.
- AbstractStringRedisMessage(String) - Constructor for class io.netty.handler.codec.redis.AbstractStringRedisMessage
-
- AbstractTrafficShapingHandler - Class in io.netty.handler.traffic
-
- 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.
- AbstractTrafficShapingHandler.ReopenReadTimerTask - Class in io.netty.handler.traffic
-
Class to implement setReadable at fix time
- AbstractUnpooledSlicedByteBuf - Class in io.netty.buffer
-
- AbstractUnpooledSlicedByteBuf(ByteBuf, int, int) - Constructor for class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- AbstractUnsafe() - Constructor for class io.netty.channel.AbstractChannel.AbstractUnsafe
-
- AbstractUnsafeSwappedByteBuf - Class in io.netty.buffer
-
- AbstractUnsafeSwappedByteBuf(AbstractByteBuf) - Constructor for class io.netty.buffer.AbstractUnsafeSwappedByteBuf
-
- AbstractWriteTask(Recycler.Handle<? extends AbstractChannelHandlerContext.AbstractWriteTask>) - Constructor for class io.netty.channel.AbstractChannelHandlerContext.AbstractWriteTask
-
- accelerationFactor - Variable in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
-
- accelerationFactor() - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
-
- accept() - Method in class com.sun.nio.sctp.SctpServerChannel
-
- accept(byte[]) - Method in class io.netty.channel.unix.Socket
-
- accept(int, byte[]) - Static 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
-
- acceptedAddress - Variable in class io.netty.channel.kqueue.AbstractKQueueServerChannel.KQueueServerSocketUnsafe
-
- 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.
- acceptInboundMessage(Object) - Method in class io.netty.handler.codec.sctp.SctpInboundByteStreamHandler
-
- acceptInboundMessage(SctpMessage) - Method in class io.netty.handler.codec.sctp.SctpInboundByteStreamHandler
-
- acceptInboundMessage(Object) - Method in class io.netty.handler.codec.sctp.SctpMessageToMessageDecoder
-
- acceptInProgress - Variable in class io.netty.channel.local.LocalServerChannel
-
- 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.ByteToMessageCodec.Encoder
-
- 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(Promise<Channel>) - Method in interface io.netty.channel.pool.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
-
- acquire0(Promise<Channel>) - Method in class io.netty.channel.pool.FixedChannelPool
-
- ACQUIRE_AND_RELEASE_ONLY - Static variable in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- acquired - Variable in class io.netty.channel.pool.FixedChannelPool.AcquireListener
-
- acquired() - Method in class io.netty.channel.pool.FixedChannelPool.AcquireListener
-
- acquiredChannelCount - Variable in class io.netty.channel.pool.FixedChannelPool
-
- acquireHealthyFromPoolOrNew(Promise<Channel>) - Method in class io.netty.channel.pool.SimpleChannelPool
-
Tries to retrieve healthy channel from the pool if any or creates a new channel otherwise.
- AcquireListener(Promise<Channel>) - Constructor for class io.netty.channel.pool.FixedChannelPool.AcquireListener
-
- AcquireTask(Promise<Channel>) - Constructor for class io.netty.channel.pool.FixedChannelPool.AcquireTask
-
- AcquireTimeoutAction() - Constructor for enum io.netty.channel.pool.FixedChannelPool.AcquireTimeoutAction
-
- acquireTimeoutNanos - Variable in class io.netty.channel.pool.FixedChannelPool
-
- activate(InputStream, OutputStream) - Method in class io.netty.channel.oio.OioByteStreamChannel
-
Activate this instance.
- active - Variable in class io.netty.channel.kqueue.AbstractKQueueChannel
-
- ACTIVE - Static variable in interface io.netty.channel.pool.ChannelHealthChecker
-
- activeBytesHuge - Variable in class io.netty.buffer.PoolArena
-
- activeChildren - Variable in class io.netty.channel.ThreadPerChannelEventLoopGroup
-
- activeOnOpen - Variable in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
-
- activeOnOpen - Variable in class io.netty.channel.socket.DefaultDatagramChannelConfig
-
- 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.
- AdaptiveRecvByteBufAllocator.HandleImpl - Class in io.netty.channel
-
- add(PoolChunk<T>) - Method in class io.netty.buffer.PoolChunkList
-
- add(PoolArena<?>, PoolChunk, long, int, PoolArena.SizeClass) - Method in class io.netty.buffer.PoolThreadCache
-
Add
PoolChunk
and
handle
to the cache if there is enough room.
- add(PoolChunk<T>, long) - Method in class io.netty.buffer.PoolThreadCache.MemoryRegionCache
-
Add to cache if not already full.
- add(ChannelPromise, int) - Method in class io.netty.channel.ChannelFlushPromiseNotifier
-
- add(ChannelPromise, long) - Method in class io.netty.channel.ChannelFlushPromiseNotifier
-
- 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(long) - Method in class io.netty.channel.kqueue.NativeLongArray
-
- add(SelectionKey) - Method in class io.netty.channel.nio.SelectedSelectionKeySet
-
- add(Object, ChannelPromise) - Method in class io.netty.channel.PendingWriteQueue
-
- add(ByteBuf) - Method in class io.netty.channel.unix.IovArray
-
- add(long, int, int) - Method in class io.netty.channel.unix.IovArray
-
- add(Object) - Method in class io.netty.handler.codec.CodecOutputList
-
- add(int, Object) - Method in class io.netty.handler.codec.CodecOutputList
-
- 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(String) - Method in class io.netty.handler.codec.HeadersUtils.CharSequenceDelegatingStringSet
-
- ADD - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
-
- add(DnsRecord) - Method in class io.netty.resolver.dns.DnsNameResolverContext.AuthoritativeNameServerList
-
- add(DnsQueryContext) - Method in class io.netty.resolver.dns.DnsQueryContextManager
-
- add(GenericFutureListener<? extends Future<?>>) - Method in class io.netty.util.concurrent.DefaultFutureListeners
-
- add(Promise<V>...) - Method in class io.netty.util.concurrent.PromiseAggregator
-
Deprecated.
Add the given
Promise
s to the aggregator.
- add(Promise) - Method in class io.netty.util.concurrent.PromiseCombiner
-
- 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
-
- 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(String, V) - Method in class io.netty.util.DomainNameMappingBuilder.ImmutableDomainNameMapping
-
Deprecated.
- 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(long) - Method in class io.netty.util.internal.PlatformDependent.AtomicLongCounter
-
- add(Object) - Method in class io.netty.util.internal.RecyclableArrayList
-
- add(int, Object) - Method in class io.netty.util.internal.RecyclableArrayList
-
- add(Recycler.DefaultHandle<?>) - Method in class io.netty.util.Recycler.WeakOrderQueue
-
- add0(PoolChunk<T>) - Method in class io.netty.buffer.PoolChunkList
-
- add0(int, int, K, V) - Method in class io.netty.handler.codec.DefaultHeaders
-
- ADD_COMPLETE - Static variable in class io.netty.channel.AbstractChannelHandlerContext
-
- ADD_PENDING - Static variable in class io.netty.channel.AbstractChannelHandlerContext
-
- addAfter(String, String, ChannelHandler) - Method in interface io.netty.channel.ChannelPipeline
-
- addAfter(EventExecutorGroup, String, String, ChannelHandler) - Method in interface io.netty.channel.ChannelPipeline
-
- addAfter(String, String, ChannelHandler) - Method in class io.netty.channel.DefaultChannelPipeline
-
- addAfter(EventExecutorGroup, String, String, ChannelHandler) - Method in class io.netty.channel.DefaultChannelPipeline
-
- addAfter0(AbstractChannelHandlerContext, AbstractChannelHandlerContext) - Static method in class io.netty.channel.DefaultChannelPipeline
-
- addAll(Collection<? extends String>) - Method in class io.netty.handler.codec.HeadersUtils.CharSequenceDelegatingStringSet
-
- addAll(Promise...) - Method in class io.netty.util.concurrent.PromiseCombiner
-
- 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
-
- addBefore(EventExecutorGroup, String, String, ChannelHandler) - Method in interface io.netty.channel.ChannelPipeline
-
- addBefore(String, String, ChannelHandler) - Method in class io.netty.channel.DefaultChannelPipeline
-
- addBefore(EventExecutorGroup, String, String, ChannelHandler) - Method in class io.netty.channel.DefaultChannelPipeline
-
- addBefore0(AbstractChannelHandlerContext, AbstractChannelHandlerContext) - Static 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.
- addCloseListener(ChannelFuture, ChannelPromise) - Static method in class io.netty.handler.ssl.SslHandler
-
- addComponent(ByteBuf) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- addComponent(int, ByteBuf) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- addComponent(boolean, ByteBuf) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- addComponent(boolean, int, ByteBuf) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- addComponent(ByteBuf) - Method in class io.netty.buffer.CompositeByteBuf
-
- 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
.
- addComponent(ByteBuf) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- addComponent(int, ByteBuf) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- addComponent(boolean, ByteBuf) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- addComponent(boolean, int, ByteBuf) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- addComponent0(boolean, int, ByteBuf) - Method in class io.netty.buffer.CompositeByteBuf
-
Precondition is that buffer != null
.
- addComponents(ByteBuf...) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- addComponents(Iterable<ByteBuf>) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- addComponents(int, ByteBuf...) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- addComponents(int, Iterable<ByteBuf>) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- addComponents(boolean, ByteBuf...) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- addComponents(boolean, Iterable<ByteBuf>) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- addComponents(ByteBuf...) - Method in class io.netty.buffer.CompositeByteBuf
-
- addComponents(Iterable<ByteBuf>) - Method in class io.netty.buffer.CompositeByteBuf
-
- addComponents(boolean, ByteBuf...) - Method in class io.netty.buffer.CompositeByteBuf
-
Add the given
ByteBuf
s and increase the
writerIndex
if
increaseWriterIndex
is
true
.
- addComponents(boolean, Iterable<ByteBuf>) - Method in class io.netty.buffer.CompositeByteBuf
-
Add the given
ByteBuf
s and increase the
writerIndex
if
increaseWriterIndex
is
true
.
- addComponents(int, ByteBuf...) - Method in class io.netty.buffer.CompositeByteBuf
-
Add the given
ByteBuf
s on the specific index
- addComponents(int, Iterable<ByteBuf>) - Method in class io.netty.buffer.CompositeByteBuf
-
Add the given
ByteBuf
s on the specific index
Be aware that this method does not increase the
writerIndex
of the
CompositeByteBuf
.
- addComponents(ByteBuf...) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- addComponents(Iterable<ByteBuf>) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- addComponents(int, ByteBuf...) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- addComponents(int, Iterable<ByteBuf>) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- addComponents(boolean, ByteBuf...) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- addComponents(boolean, Iterable<ByteBuf>) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- addComponents0(boolean, int, ByteBuf[], int, int) - Method in class io.netty.buffer.CompositeByteBuf
-
- addComponents0(boolean, int, Iterable<ByteBuf>) - Method in class io.netty.buffer.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.
- added - Variable in class io.netty.channel.ChannelHandlerAdapter
-
- addend - Static variable in class io.netty.util.internal.ThreadLocalRandom
-
- addFirst(String, ChannelHandler) - Method in interface io.netty.channel.ChannelPipeline
-
- addFirst(EventExecutorGroup, String, ChannelHandler) - Method in interface io.netty.channel.ChannelPipeline
-
- addFirst(ChannelHandler...) - Method in interface io.netty.channel.ChannelPipeline
-
- addFirst(EventExecutorGroup, ChannelHandler...) - Method in interface io.netty.channel.ChannelPipeline
-
- 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
-
- addFirst0(AbstractChannelHandlerContext) - 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
-
- addIfSupported(Set<String>, List<String>, String...) - Static method in class io.netty.handler.ssl.JdkSslContext
-
- 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.
- additionals - Variable in class io.netty.handler.codec.dns.AbstractDnsMessage
-
- additionals - Variable in class io.netty.resolver.dns.DnsNameResolverContext
-
- additionals - Variable in class io.netty.resolver.dns.DnsQueryContext
-
- addLast(String, ChannelHandler) - Method in interface io.netty.channel.ChannelPipeline
-
- addLast(EventExecutorGroup, String, ChannelHandler) - Method in interface io.netty.channel.ChannelPipeline
-
- addLast(ChannelHandler...) - Method in interface io.netty.channel.ChannelPipeline
-
- addLast(EventExecutorGroup, ChannelHandler...) - Method in interface io.netty.channel.ChannelPipeline
-
- 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
-
- addLast0(AbstractChannelHandlerContext) - 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.CompleteChannelFuture
-
- 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 Void>>) - Method in class io.netty.channel.group.DefaultChannelGroupFuture
-
- addListener(GenericFutureListener<? extends Future<? super Void>>) - Method in class io.netty.channel.group.VoidChannelGroupFuture
-
- addListener(GenericFutureListener<? extends Future<? super Void>>) - Method in class io.netty.channel.VoidChannelPromise
-
- 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
-
- addListener0(GenericFutureListener<? extends Future<? super V>>) - Method in class io.netty.util.concurrent.DefaultPromise
-
- 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.CompleteChannelFuture
-
- 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 Void>>...) - Method in class io.netty.channel.group.DefaultChannelGroupFuture
-
- addListeners(GenericFutureListener<? extends Future<? super Void>>...) - Method in class io.netty.channel.group.VoidChannelGroupFuture
-
- addListeners(GenericFutureListener<? extends Future<? super Void>>...) - Method in class io.netty.channel.VoidChannelPromise
-
- 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
-
- addNameServerToCache(DnsNameResolverContext.AuthoritativeNameServer, InetAddress, long) - Method in class io.netty.resolver.dns.DnsNameResolverContext
-
Add an authoritative nameserver to the cache if its not a root server.
- 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
-
- addr(int) - Method in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- addr(int) - Method in class io.netty.buffer.ReadOnlyUnsafeDirectByteBuf
-
- addr(int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
-
- addr(AbstractByteBuf, int) - Static method in class io.netty.buffer.UnsafeDirectSwappedByteBuf
-
- addRecord(DnsSection, DnsRecord) - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
-
- addRecord(int, DnsRecord) - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
-
- addRecord(DnsSection, int, DnsRecord) - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
-
- addRecord(int, 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 com.sun.nio.sctp.MessageInfo
-
- address - Variable in class io.netty.channel.unix.NativeInetAddress
-
- address() - Method in class io.netty.channel.unix.NativeInetAddress
-
- address(byte[], int, int) - Static method in class io.netty.channel.unix.NativeInetAddress
-
- address - Variable in class io.netty.handler.codec.dns.DefaultDnsOptEcsRecord
-
- 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 - Variable in class io.netty.resolver.dns.DnsCacheEntry
-
- address() - Method in class io.netty.resolver.dns.DnsCacheEntry
-
- address - Variable in class io.netty.resolver.dns.SingletonDnsServerAddresses
-
- 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.
- ADDRESS_FIELD_OFFSET - Static variable in class io.netty.util.internal.PlatformDependent0
-
- ADDRESS_SIZE - Static variable in class io.netty.channel.unix.IovArray
-
The size of an address which should be 8 for 64 bits and 4 for 32 bits.
- ADDRESS_SIZE - Static variable in class io.netty.util.internal.PlatformDependent
-
- ADDRESS_UNSUPPORTED - Static variable in class io.netty.handler.codec.socksx.v5.Socks5CommandStatus
-
- addressByName(String) - Static method in class io.netty.util.internal.SocketUtils
-
- addressDecoder - Variable in class io.netty.handler.codec.socksx.v5.Socks5CommandRequestDecoder
-
- addressDecoder - Variable in class io.netty.handler.codec.socksx.v5.Socks5CommandResponseDecoder
-
- AddressedEnvelope<M,A extends java.net.SocketAddress> - Interface in io.netty.channel
-
A message that wraps another message with a sender address and a recipient address.
- addressEncoder - Variable in class io.netty.handler.codec.socksx.v5.Socks5ClientEncoder
-
- addressEncoder() - Method in class io.netty.handler.codec.socksx.v5.Socks5ClientEncoder
-
- addressEncoder - Variable in class io.netty.handler.codec.socksx.v5.Socks5ServerEncoder
-
- addressEncoder() - Method in class io.netty.handler.codec.socksx.v5.Socks5ServerEncoder
-
- addresses - Variable in class io.netty.resolver.dns.DefaultDnsServerAddresses
-
- addresses - Variable in class io.netty.resolver.dns.SequentialDnsServerAddressStream
-
- addresses - Variable in class io.netty.resolver.dns.ShuffledDnsServerAddressStream
-
- addresses - Variable in class io.netty.resolver.dns.UniSequentialDnsServerAddressStreamProvider
-
- addressesFromNetworkInterface(NetworkInterface) - Static method in class io.netty.util.internal.SocketUtils
-
- addressFamily - Variable in enum io.netty.handler.codec.haproxy.HAProxyProxiedProtocol
-
- addressFamily() - Method in enum io.netty.handler.codec.haproxy.HAProxyProxiedProtocol
-
- AddressFamily(byte) - Constructor for enum io.netty.handler.codec.haproxy.HAProxyProxiedProtocol.AddressFamily
-
Creates a new instance
- addressNumber - Variable in enum io.netty.channel.socket.InternetProtocolFamily
-
- addressNumber() - Method in enum io.netty.channel.socket.InternetProtocolFamily
-
- AddressResolver<T extends java.net.SocketAddress> - Interface in io.netty.resolver
-
Resolves a possibility unresolved SocketAddress
.
- addressResolver - Variable in class io.netty.resolver.InetNameResolver
-
- AddressResolverGroup<T extends java.net.SocketAddress> - Class in io.netty.resolver
-
- 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.
- addressSize() - Static method in class io.netty.util.internal.PlatformDependent0
-
- addressSize0() - Static method in class io.netty.util.internal.PlatformDependent
-
- addressType - Variable in enum io.netty.channel.socket.InternetProtocolFamily
-
- addressType() - Method in enum io.netty.channel.socket.InternetProtocolFamily
-
Returns the address type of this protocol family.
- addressType - Variable in class io.netty.handler.codec.socks.SocksCmdRequest
-
- addressType() - Method in class io.netty.handler.codec.socks.SocksCmdRequest
-
- addressType - Variable in class io.netty.handler.codec.socks.SocksCmdRequestDecoder
-
- addressType - Variable in class io.netty.handler.codec.socks.SocksCmdResponse
-
- addressType() - Method in class io.netty.handler.codec.socks.SocksCmdResponse
-
- addressType - Variable in class io.netty.handler.codec.socks.SocksCmdResponseDecoder
-
- 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.GlobalEventExecutor
-
Add a task to the task queue, or throws a RejectedExecutionException
if this instance was shutdown
before.
- 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.
- addTaskWakesUp - Variable in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- 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.
- addTimeout(HashedWheelTimer.HashedWheelTimeout) - Method in class io.netty.util.HashedWheelTimer.HashedWheelBucket
-
- addTopicFilter(String) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.UnsubscribeBuilder
-
- addToPool(PoolSubpage<T>) - Method in class io.netty.buffer.PoolSubpage
-
- addToVariablesToRemove(InternalThreadLocalMap, FastThreadLocal<?>) - Static method in class io.netty.util.concurrent.FastThreadLocal
-
- addWriteTimeoutTask(WriteTimeoutHandler.WriteTimeoutTask) - Method in class io.netty.handler.timeout.WriteTimeoutHandler
-
- adjustMarkers(int) - Method in class io.netty.buffer.AbstractByteBuf
-
- adjustment - Variable in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- adjustment - Variable in class io.netty.buffer.PooledSlicedByteBuf
-
- ADLER32_UPDATE_METHOD - Static variable in class io.netty.handler.codec.compression.ByteBufChecksum
-
- AdvancedLeakAwareByteBuf - Class in io.netty.buffer
-
- AdvancedLeakAwareByteBuf(ByteBuf, ResourceLeakTracker<ByteBuf>) - Constructor for class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- AdvancedLeakAwareByteBuf(ByteBuf, ByteBuf, ResourceLeakTracker<ByteBuf>) - Constructor for class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- AdvancedLeakAwareCompositeByteBuf - Class in io.netty.buffer
-
- AdvancedLeakAwareCompositeByteBuf(CompositeByteBuf, ResourceLeakTracker<ByteBuf>) - Constructor for class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- AF_IPV4_BYTE - Static variable in class io.netty.handler.codec.haproxy.HAProxyConstants
-
- AF_IPV6_BYTE - Static variable in class io.netty.handler.codec.haproxy.HAProxyConstants
-
- AF_UNIX_BYTE - Static variable in class io.netty.handler.codec.haproxy.HAProxyConstants
-
- AF_UNSPEC_BYTE - Static variable in class io.netty.handler.codec.haproxy.HAProxyConstants
-
Address family byte constants
- 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.
- aggregatePromise - Variable in class io.netty.util.concurrent.PromiseAggregator
-
Deprecated.
- aggregatePromise - Variable in class io.netty.util.concurrent.PromiseCombiner
-
- AggregateState(int) - Constructor for class io.netty.handler.codec.redis.RedisArrayAggregator.AggregateState
-
- alignCapacity(int) - Method in class io.netty.buffer.PoolArena
-
- all() - Static method in class io.netty.channel.group.ChannelMatchers
-
- ALL_IDLE_STATE_EVENT - Static variable in class io.netty.handler.timeout.IdleStateEvent
-
- ALL_MATCHER - Static variable in class io.netty.channel.group.ChannelMatchers
-
- allAddressesByName(String) - Static method in class io.netty.util.internal.SocketUtils
-
- allIdleTimeNanos - Variable in class io.netty.handler.timeout.IdleStateHandler
-
- allIdleTimeout - Variable in class io.netty.handler.timeout.IdleStateHandler
-
- AllIdleTimeoutTask(ChannelHandlerContext) - Constructor for class io.netty.handler.timeout.IdleStateHandler.AllIdleTimeoutTask
-
- allLeaks - Variable in class io.netty.util.ResourceLeakDetector
-
the collection of active resources
- allLocalAddresses() - Method in class io.netty.channel.sctp.nio.NioSctpChannel
-
- allLocalAddresses() - Method in class io.netty.channel.sctp.nio.NioSctpServerChannel
-
- allLocalAddresses() - Method in class io.netty.channel.sctp.oio.OioSctpChannel
-
- allLocalAddresses() - Method in class io.netty.channel.sctp.oio.OioSctpServerChannel
-
- allLocalAddresses() - Method in interface io.netty.channel.sctp.SctpChannel
-
Return all local addresses of the SCTP channel.
- allLocalAddresses() - Method in interface io.netty.channel.sctp.SctpServerChannel
-
Return all local addresses of the SCTP server channel.
- allNames - Variable in class io.netty.handler.codec.HeadersUtils.DelegatingStringSet
-
- alloc() - Method in class io.netty.buffer.AbstractPooledDerivedByteBuf
-
- alloc() - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- alloc() - Method in class io.netty.buffer.ByteBuf
-
- alloc - Variable in class io.netty.buffer.CompositeByteBuf
-
- alloc() - Method in class io.netty.buffer.CompositeByteBuf
-
- alloc() - Method in class io.netty.buffer.DuplicatedByteBuf
-
Deprecated.
- alloc - Variable in class io.netty.buffer.EmptyByteBuf
-
- alloc() - Method in class io.netty.buffer.EmptyByteBuf
-
- alloc() - Method in class io.netty.buffer.FixedCompositeByteBuf
-
- alloc() - Method in class io.netty.buffer.PooledByteBuf
-
- alloc() - Method in class io.netty.buffer.ReadOnlyByteBuf
-
Deprecated.
- alloc() - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- alloc() - Method in class io.netty.buffer.SwappedByteBuf
-
Deprecated.
- ALLOC - Static variable in class io.netty.buffer.Unpooled
-
- alloc - Variable in class io.netty.buffer.UnpooledDirectByteBuf
-
- alloc() - Method in class io.netty.buffer.UnpooledDirectByteBuf
-
- alloc - Variable in class io.netty.buffer.UnpooledHeapByteBuf
-
- alloc() - Method in class io.netty.buffer.UnpooledHeapByteBuf
-
- alloc - Variable in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
-
- alloc() - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
-
- alloc() - Method in class io.netty.buffer.WrappedByteBuf
-
- alloc() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- alloc() - Method in class io.netty.channel.AbstractChannel
-
- alloc() - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- alloc() - Method in interface io.netty.channel.Channel
-
- alloc() - Method in interface io.netty.channel.ChannelHandlerContext
-
- alloc() - Method in class io.netty.channel.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- alloc() - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel.KQueueSocketWritableByteChannel
-
- alloc() - Method in class io.netty.channel.unix.SocketWritableByteChannel
-
- alloc() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- allocate(PoolThreadCache, int, int) - Method in class io.netty.buffer.PoolArena
-
- allocate(PoolThreadCache, PooledByteBuf<T>, int) - Method in class io.netty.buffer.PoolArena
-
- allocate(int) - Method in class io.netty.buffer.PoolChunk
-
- allocate(PooledByteBuf<T>, int, int) - Method in class io.netty.buffer.PoolChunkList
-
- allocate() - Method in class io.netty.buffer.PoolSubpage
-
Returns the bitmap index of the subpage allocation.
- allocate(PoolThreadCache.MemoryRegionCache<?>, PooledByteBuf, int) - Method in class io.netty.buffer.PoolThreadCache
-
- allocate(PooledByteBuf<T>, int) - Method in class io.netty.buffer.PoolThreadCache.MemoryRegionCache
-
Allocate something out of the cache if possible and remove the entry from the cache.
- allocate(ByteBufAllocator) - Method in class io.netty.channel.DefaultMaxBytesRecvByteBufAllocator.HandleImpl
-
- allocate(ByteBufAllocator) - Method in class io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator.MaxMessageHandle
-
- allocate(ByteBufAllocator) - Method in class io.netty.channel.kqueue.KQueueRecvByteAllocatorHandle
-
- 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.
- allocate(ChannelHandlerContext, int) - Method in class io.netty.handler.ssl.SslHandler
-
Always prefer a direct buffer when it's pooled, so that we reduce the number of memory copies
in OpenSslEngine
.
- allocate(Recycler.Stack<?>, Thread) - Static method in class io.netty.util.Recycler.WeakOrderQueue
-
- ALLOCATE_ARRAY_METHOD - Static variable in class io.netty.util.internal.PlatformDependent0
-
- allocateArray(int) - Method in class io.netty.buffer.UnpooledByteBufAllocator.InstrumentedUnpooledHeapByteBuf
-
- allocateArray(int) - Method in class io.netty.buffer.UnpooledByteBufAllocator.InstrumentedUnpooledUnsafeHeapByteBuf
-
- allocateArray(int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
-
- allocateArray(int) - Method in class io.netty.buffer.UnpooledUnsafeHeapByteBuf
-
- 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) - Static method in class io.netty.buffer.PoolArena.DirectArena
-
- allocateDirect(int) - Method in class io.netty.buffer.UnpooledByteBufAllocator.InstrumentedUnpooledDirectByteBuf
-
- allocateDirect(int) - Method in class io.netty.buffer.UnpooledByteBufAllocator.InstrumentedUnpooledUnsafeDirectByteBuf
-
- allocateDirect(int) - Method in class io.netty.buffer.UnpooledByteBufAllocator.InstrumentedUnpooledUnsafeNoCleanerDirectByteBuf
-
- 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.
- allocateDirect(int) - Method in class io.netty.buffer.UnpooledUnsafeNoCleanerDirectByteBuf
-
- allocateDirectNoCleaner(int) - Static method in class io.netty.util.internal.PlatformDependent
-
Allocate a new ByteBuffer
with the given capacity
.
- allocateDirectNoCleaner(int) - Static method in class io.netty.util.internal.PlatformDependent0
-
- allocateHuffmanCodeLengths(int[], int) - Static method in class io.netty.handler.codec.compression.Bzip2HuffmanAllocator
-
Allocates Canonical Huffman code lengths in place based on a sorted frequency array.
- allocateHuge(PooledByteBuf<T>, int) - Method in class io.netty.buffer.PoolArena
-
- allocateMemory(long) - Static method in class io.netty.util.internal.PlatformDependent
-
- allocateMemory(long) - Static method in class io.netty.util.internal.PlatformDependent0
-
- allocateNode(int) - Method in class io.netty.buffer.PoolChunk
-
Algorithm to allocate an index in memoryMap when we query for a free node
at depth d
- allocateNodeLengths(int[]) - Static method in class io.netty.handler.codec.compression.Bzip2HuffmanAllocator
-
A final allocation pass with no code length limit.
- allocateNodeLengthsWithRelocation(int[], int, int) - Static method in class io.netty.handler.codec.compression.Bzip2HuffmanAllocator
-
A final allocation pass that relocates nodes in order to achieve a maximum code length limit.
- allocateNormal(PooledByteBuf<T>, int, int) - Method in class io.netty.buffer.PoolArena
-
- allocateNormal(PoolArena<?>, PooledByteBuf<?>, int, int) - Method in class io.netty.buffer.PoolThreadCache
-
Try to allocate a small buffer out of the cache.
- allocateOutNetBuf(ChannelHandlerContext, int, int) - Method in class io.netty.handler.ssl.SslHandler
-
Allocates an outbound network buffer for SSLEngine.wrap(ByteBuffer, ByteBuffer)
which can encrypt
the specified amount of pending bytes.
- allocateRun(int) - Method in class io.netty.buffer.PoolChunk
-
Allocate a run of pages (>=1)
- allocateSmall(PoolArena<?>, PooledByteBuf<?>, int, int) - Method in class io.netty.buffer.PoolThreadCache
-
Try to allocate a small buffer out of the cache.
- allocateSubpage(int) - Method in class io.netty.buffer.PoolChunk
-
Create/ initialize a new PoolSubpage of normCapacity
Any PoolSubpage created/ initialized here is added to subpage pool in the PoolArena that owns this PoolChunk
- allocateTiny(PoolArena<?>, PooledByteBuf<?>, int, int) - Method in class io.netty.buffer.PoolThreadCache
-
Try to allocate a tiny buffer out of the cache.
- allocateUninitializedArray(int) - Static method in class io.netty.util.internal.PlatformDependent
-
- allocateUninitializedArray(int) - Static method in class io.netty.util.internal.PlatformDependent0
-
- allocations - Variable in class io.netty.buffer.PoolThreadCache
-
- allocations - Variable in class io.netty.buffer.PoolThreadCache.MemoryRegionCache
-
- allocationsHuge - Variable in class io.netty.buffer.PoolArena
-
- allocationsNormal - Variable in class io.netty.buffer.PoolArena
-
- allocationsSmall - Variable in class io.netty.buffer.PoolArena
-
- allocationsTiny - Variable in class io.netty.buffer.PoolArena
-
- allocator - Variable in class io.netty.buffer.FixedCompositeByteBuf
-
- allocator - Variable in class io.netty.buffer.PooledByteBuf
-
- allocator - Variable in class io.netty.buffer.PooledByteBufAllocatorMetric
-
- allocator - Variable in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- ALLOCATOR - Static variable in class io.netty.channel.ChannelOption
-
- allocator - Variable in class io.netty.channel.DefaultChannelConfig
-
- allocator - Variable in class io.netty.channel.local.PreferHeapByteBufAllocator
-
- allocBuffer(int) - Method in class io.netty.buffer.CompositeByteBuf
-
- allocHandle - Variable in class io.netty.channel.kqueue.AbstractKQueueChannel.AbstractKQueueUnsafe
-
- ALLOW_HALF_CLOSURE - Static variable in class io.netty.channel.ChannelOption
-
- allowedQueries - Variable in class io.netty.resolver.dns.DnsNameResolverContext
-
- allowGrowing - Variable in class io.netty.channel.kqueue.KQueueEventLoop
-
- allowHalfClosure - Variable in class io.netty.channel.kqueue.KQueueSocketChannelConfig
-
- allowHalfClosure - Variable in class io.netty.channel.socket.DefaultSocketChannelConfig
-
- allRemoteAddresses() - Method in class io.netty.channel.sctp.nio.NioSctpChannel
-
- allRemoteAddresses() - Method in class io.netty.channel.sctp.oio.OioSctpChannel
-
- allRemoteAddresses() - Method in interface io.netty.channel.sctp.SctpChannel
-
Return all remote addresses of the SCTP server channel.
- alphabet(Base64Dialect) - Static method in class io.netty.handler.codec.base64.Base64
-
- alphabet - Variable in enum io.netty.handler.codec.base64.Base64Dialect
-
- alphabetSize - Variable in class io.netty.handler.codec.compression.Bzip2HuffmanStageDecoder
-
The total number of codes (uniform for each table).
- alphabetSize - Variable in class io.netty.handler.codec.compression.Bzip2MTFAndRLE2StageEncoder
-
The encoded alphabet size.
- ALPN_WRAPPER - Static variable in class io.netty.handler.ssl.JdkAlpnApplicationProtocolNegotiator
-
- AlpnWrapper() - Constructor for class io.netty.handler.ssl.JdkAlpnApplicationProtocolNegotiator.AlpnWrapper
-
- alreadyReadChunkSize - Variable in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheDecoder
-
- alreadyReadChunkSize - Variable in class io.netty.handler.codec.stomp.StompSubframeDecoder
-
- 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.
- AnnotatedConnectException(ConnectException, SocketAddress) - Constructor for exception io.netty.channel.AbstractChannel.AnnotatedConnectException
-
- AnnotatedNoRouteToHostException(NoRouteToHostException, SocketAddress) - Constructor for exception io.netty.channel.AbstractChannel.AnnotatedNoRouteToHostException
-
- AnnotatedSocketException(SocketException, SocketAddress) - Constructor for exception io.netty.channel.AbstractChannel.AnnotatedSocketException
-
- answers - Variable in class io.netty.handler.codec.dns.AbstractDnsMessage
-
- 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.
- apn - Variable in class io.netty.handler.ssl.JdkSslContext
-
- apn - Variable in class io.netty.handler.ssl.SslContextBuilder
-
- 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(ByteBufAllocator, boolean, PemEncoded, int, ByteBuf) - Static method in class io.netty.handler.ssl.PemX509Certificate
-
- append(ByteBufAllocator, boolean, X509Certificate, int, ByteBuf) - Static method in class io.netty.handler.ssl.PemX509Certificate
-
Appends the
X509Certificate
value to the
ByteBuf
(last arg) and returns it.
- 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
-
- append0(Date, StringBuilder) - Method in class io.netty.handler.codec.DateFormatter
-
- AppendableCharSequence - Class in io.netty.util.internal
-
- AppendableCharSequence(int) - Constructor for class io.netty.util.internal.AppendableCharSequence
-
- AppendableCharSequence(char[]) - Constructor for class io.netty.util.internal.AppendableCharSequence
-
- appendAddresses(StringBuilder, DnsMessage) - Static method in class io.netty.handler.codec.dns.DnsMessageUtil
-
- appendAllRecords(StringBuilder, DnsMessage) - Static method in class io.netty.handler.codec.dns.DnsMessageUtil
-
- appendHexDumpField(StringBuilder, int, int) - Method in class io.netty.channel.DefaultChannelId
-
- appendHexDumpRowPrefix(StringBuilder, int, int) - Static method in class io.netty.buffer.ByteBufUtil.HexUtil
-
- appendHextet(StringBuilder, byte[], int) - Static method in class io.netty.handler.codec.socks.SocksCommonUtils
-
- appendMapping(StringBuilder, int) - Method in class io.netty.util.DomainNameMappingBuilder.ImmutableDomainNameMapping
-
- appendMapping(StringBuilder, String, String) - Static method in class io.netty.util.DomainNameMappingBuilder.ImmutableDomainNameMapping
-
- appendPartialContent(CompositeByteBuf, ByteBuf) - Static method in class io.netty.handler.codec.MessageAggregator
-
- appendPoolSubPages(StringBuilder, PoolSubpage<?>[]) - Static method in class io.netty.buffer.PoolArena
-
- 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
.
- appendPrettyHexDump(StringBuilder, ByteBuf, int, int) - Static method in class io.netty.buffer.ByteBufUtil.HexUtil
-
- APPENDQ - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
-
- appendQuery(StringBuilder, DnsQuery) - Static method in class io.netty.handler.codec.dns.DnsMessageUtil
-
- appendQueryHeader(StringBuilder, DnsQuery) - Static method in class io.netty.handler.codec.dns.DnsMessageUtil
-
- appendRecordClass(StringBuilder, int) - Static method in class io.netty.handler.codec.dns.DnsMessageUtil
-
- appendRecords(StringBuilder, DnsMessage, DnsSection) - Static method in class io.netty.handler.codec.dns.DnsMessageUtil
-
- appendResponse(StringBuilder, DnsResponse) - Static method in class io.netty.handler.codec.dns.DnsMessageUtil
-
- appendResponseHeader(StringBuilder, DnsResponse) - Static method in class io.netty.handler.codec.dns.DnsMessageUtil
-
- appendTrailingDot(String) - Static method in class io.netty.handler.codec.dns.AbstractDnsRecord
-
- appendZeroLeftPadded(int, StringBuilder) - Static method in class io.netty.handler.codec.DateFormatter
-
- APPLE_SND_LOW_AT_MAX - Static variable in class io.netty.channel.kqueue.BsdSocket
-
- applicationProtocol - Variable in class io.netty.handler.ssl.JdkSslSession
-
- applicationProtocol() - Method in class io.netty.handler.ssl.SslHandler
-
Returns the name of the current application-level protocol.
- ApplicationProtocolAccessor - Interface in io.netty.handler.ssl
-
Provides a way to get the application-level protocol name from ALPN or NPN.
- ApplicationProtocolConfig - Class in io.netty.handler.ssl
-
- 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.Protocol, ApplicationProtocolConfig.SelectorFailureBehavior, ApplicationProtocolConfig.SelectedListenerFailureBehavior, List<String>) - Constructor for class io.netty.handler.ssl.ApplicationProtocolConfig
-
Create a new instance.
- ApplicationProtocolConfig() - Constructor for class io.netty.handler.ssl.ApplicationProtocolConfig
-
- 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.
- ApplicationProtocolNames() - Constructor for class io.netty.handler.ssl.ApplicationProtocolNames
-
- ApplicationProtocolNegotiationHandler - Class in io.netty.handler.ssl
-
- 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.
- ApplicationProtocolUtil - Class in io.netty.handler.ssl
-
Utility class for application protocol common operations.
- ApplicationProtocolUtil() - Constructor for class io.netty.handler.ssl.ApplicationProtocolUtil
-
- arena - Variable in class io.netty.buffer.PoolChunk
-
- arena - Variable in class io.netty.buffer.PoolChunkList
-
- array() - Method in class io.netty.buffer.AbstractPooledDerivedByteBuf
-
- array() - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- 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.FixedCompositeByteBuf
-
- array() - Method in class io.netty.buffer.PooledDirectByteBuf
-
- array() - Method in class io.netty.buffer.PooledHeapByteBuf
-
- array() - Method in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- array() - Method in class io.netty.buffer.ReadOnlyByteBuf
-
Deprecated.
- array() - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- array() - Method in class io.netty.buffer.SwappedByteBuf
-
Deprecated.
- array() - Method in class io.netty.buffer.UnpooledDirectByteBuf
-
- array - Variable in class io.netty.buffer.UnpooledHeapByteBuf
-
- array() - Method in class io.netty.buffer.UnpooledHeapByteBuf
-
- array() - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
-
- array() - Method in class io.netty.buffer.WrappedByteBuf
-
- array() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- array - Variable in class io.netty.handler.codec.CodecOutputList
-
- array() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- 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.
- arrayFormat(String, Object[]) - Static method in class io.netty.util.internal.logging.MessageFormatter
-
- ArrayHeaderRedisMessage - Class in io.netty.handler.codec.redis
-
Header of Redis Array Message.
- ArrayHeaderRedisMessage(long) - Constructor for class io.netty.handler.codec.redis.ArrayHeaderRedisMessage
-
- arrayList() - Method in class io.netty.util.internal.InternalThreadLocalMap
-
- arrayList(int) - Method in class io.netty.util.internal.InternalThreadLocalMap
-
- arrayList - Variable in class io.netty.util.internal.UnpaddedInternalThreadLocalMap
-
- arrayOffset() - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- 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.FixedCompositeByteBuf
-
- arrayOffset() - Method in class io.netty.buffer.PooledDirectByteBuf
-
- arrayOffset() - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- arrayOffset() - Method in class io.netty.buffer.PooledHeapByteBuf
-
- arrayOffset() - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- arrayOffset() - Method in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- arrayOffset() - Method in class io.netty.buffer.ReadOnlyByteBuf
-
Deprecated.
- arrayOffset() - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- 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.buffer.WrappedByteBuf
-
- arrayOffset() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- arrayOffset() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- arrayOffset() - Method in class io.netty.util.AsciiString
-
- ArrayRedisMessage - Class in io.netty.handler.codec.redis
-
- ArrayRedisMessage() - Constructor for class io.netty.handler.codec.redis.ArrayRedisMessage
-
- ArrayRedisMessage(List<RedisMessage>) - Constructor for class io.netty.handler.codec.redis.ArrayRedisMessage
-
- artifactId - Variable in class io.netty.util.Version
-
- artifactId() - Method in class io.netty.util.Version
-
- artifactVersion - Variable in class io.netty.util.Version
-
- artifactVersion() - Method in class io.netty.util.Version
-
- asAddressResolver() - Method in class io.netty.resolver.InetNameResolver
-
- AsciiCaseInsensitiveCharEqualityComparator() - Constructor for class io.netty.util.AsciiString.AsciiCaseInsensitiveCharEqualityComparator
-
- asciiEncoder - Static variable in class io.netty.handler.codec.socks.SocksAuthRequest
-
- 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
.
- AsciiString.AsciiCaseInsensitiveCharEqualityComparator - Class in io.netty.util
-
- AsciiString.CharEqualityComparator - Interface in io.netty.util
-
- AsciiString.DefaultCharEqualityComparator - Class in io.netty.util
-
- AsciiString.GeneralCaseInsensitiveCharEqualityComparator - Class in io.netty.util
-
- 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
-
- asLongText() - Method in class io.netty.channel.embedded.EmbeddedChannelId
-
- asMap() - Method in class io.netty.util.DomainNameMapping
-
Returns a read-only Map
of the domain mapping patterns and their associated value objects.
- asMap() - Method in class io.netty.util.DomainNameMappingBuilder.ImmutableDomainNameMapping
-
- asReadOnly() - Method in class io.netty.buffer.AbstractByteBuf
-
- asReadOnly() - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- asReadOnly() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.SimpleLeakAwareByteBuf
-
- asReadOnly() - Method in class io.netty.buffer.SimpleLeakAwareCompositeByteBuf
-
- asReadOnly() - Method in class io.netty.buffer.SwappedByteBuf
-
Deprecated.
- asReadOnly() - Method in class io.netty.buffer.UnreleasableByteBuf
-
- asReadOnly() - Method in class io.netty.buffer.WrappedByteBuf
-
- asReadOnly() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- asReadOnly() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- assertEmpty() - Method in class io.netty.channel.PendingWriteQueue
-
- assertEventLoop() - Method in class io.netty.channel.AbstractChannel.AbstractUnsafe
-
- 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
-
- asShortText() - Method in class io.netty.channel.embedded.EmbeddedChannelId
-
- assignHuffmanCodeSymbols() - Method in class io.netty.handler.codec.compression.Bzip2HuffmanStageEncoder
-
Assigns Canonical Huffman codes based on the calculated lengths.
- Association - Class in com.sun.nio.sctp
-
- Association() - Constructor for class com.sun.nio.sctp.Association
-
- association() - Method in interface com.sun.nio.sctp.Notification
-
- association() - Method in class com.sun.nio.sctp.SctpChannel
-
- association() - Method in class io.netty.channel.sctp.nio.NioSctpChannel
-
- association() - Method in class io.netty.channel.sctp.oio.OioSctpChannel
-
- association() - Method in interface io.netty.channel.sctp.SctpChannel
-
Returns the underlying SCTP association.
- AssociationChangeNotification - Class in com.sun.nio.sctp
-
- AssociationChangeNotification() - Constructor for class com.sun.nio.sctp.AssociationChangeNotification
-
- AsyncMapping<IN,OUT> - Interface in io.netty.util
-
- AsyncMappingAdapter(Mapping<? super String, ? extends SslContext>) - Constructor for class io.netty.handler.ssl.SniHandler.AsyncMappingAdapter
-
- AtomicLongCounter() - Constructor for class io.netty.util.internal.PlatformDependent.AtomicLongCounter
-
- attemptBytesRead - Variable in class io.netty.channel.DefaultMaxBytesRecvByteBufAllocator.HandleImpl
-
- attemptedBytesRead(int) - Method in class io.netty.channel.DefaultMaxBytesRecvByteBufAllocator.HandleImpl
-
- attemptedBytesRead() - Method in class io.netty.channel.DefaultMaxBytesRecvByteBufAllocator.HandleImpl
-
- attemptedBytesRead - Variable in class io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator.MaxMessageHandle
-
- attemptedBytesRead() - Method in class io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator.MaxMessageHandle
-
- attemptedBytesRead(int) - Method in class io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator.MaxMessageHandle
-
- attemptedBytesRead(int) - Method in class io.netty.channel.kqueue.KQueueRecvByteAllocatorHandle
-
- attemptedBytesRead() - Method in class io.netty.channel.kqueue.KQueueRecvByteAllocatorHandle
-
- 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 class io.netty.channel.AbstractChannelHandlerContext
-
- attr(AttributeKey<T>) - Method in interface io.netty.channel.ChannelHandlerContext
-
- attr(AttributeKey<T>) - Method in class io.netty.channel.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- attr(AttributeKey<T>) - Method in interface io.netty.util.AttributeMap
-
- 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
-
- AttributeKey(int, String) - Constructor for class io.netty.util.AttributeKey
-
- AttributeMap - Interface in io.netty.util
-
- attributes - Variable in class io.netty.util.DefaultAttributeMap
-
- attrs - Variable in class io.netty.bootstrap.AbstractBootstrap
-
- attrs() - Method in class io.netty.bootstrap.AbstractBootstrap
-
- attrs() - Method in class io.netty.bootstrap.AbstractBootstrapConfig
-
Returns a copy of the configured attributes.
- attrs0() - Method in class io.netty.bootstrap.AbstractBootstrap
-
- 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
-
- authMethod - Variable in class io.netty.handler.codec.socksx.v5.DefaultSocks5InitialResponse
-
- authMethod() - Method in class io.netty.handler.codec.socksx.v5.DefaultSocks5InitialResponse
-
- authMethod() - Method in interface io.netty.handler.codec.socksx.v5.Socks5InitialResponse
-
Returns the METHOD
field of this response.
- authMethods - Variable in class io.netty.handler.codec.socksx.v5.DefaultSocks5InitialRequest
-
- authMethods() - Method in class io.netty.handler.codec.socksx.v5.DefaultSocks5InitialRequest
-
- authMethods() - Method in interface io.netty.handler.codec.socksx.v5.Socks5InitialRequest
-
Returns the list of desired authentication methods.
- authoritativeAnswer - Variable in class io.netty.handler.codec.dns.DefaultDnsResponse
-
- authoritativeDnsServerCache - Variable in class io.netty.resolver.dns.DnsNameResolver
-
- authoritativeDnsServerCache() - Method in class io.netty.resolver.dns.DnsNameResolver
-
Returns the cache used for authoritative DNS servers for a domain.
- authoritativeDnsServerCache - Variable in class io.netty.resolver.dns.DnsNameResolverBuilder
-
- authoritativeDnsServerCache(DnsCache) - Method in class io.netty.resolver.dns.DnsNameResolverBuilder
-
Sets the cache for authoritative NS servers
- AuthoritativeNameServer(int, String, String) - Constructor for class io.netty.resolver.dns.DnsNameResolverContext.AuthoritativeNameServer
-
- AuthoritativeNameServerList(String) - Constructor for class io.netty.resolver.dns.DnsNameResolverContext.AuthoritativeNameServerList
-
- authorities - Variable in class io.netty.handler.codec.dns.AbstractDnsMessage
-
- authScheme - Variable in class io.netty.handler.codec.socks.SocksInitResponse
-
- authScheme() - Method in class io.netty.handler.codec.socks.SocksInitResponse
-
- authSchemes - Variable in class io.netty.handler.codec.socks.SocksInitRequest
-
- authSchemes() - Method in class io.netty.handler.codec.socks.SocksInitRequest
-
- authStatus - Variable in class io.netty.handler.codec.socks.SocksAuthResponse
-
- authStatus() - Method in class io.netty.handler.codec.socks.SocksAuthResponse
-
- AUTO_CLOSE - Static variable in class io.netty.channel.ChannelOption
-
- AUTO_READ - Static variable in class io.netty.channel.ChannelOption
-
- autoClose - Variable in class io.netty.channel.DefaultChannelConfig
-
- autoRead - Variable in class io.netty.channel.DefaultChannelConfig
-
- AUTOREAD_UPDATER - Static variable in class io.netty.channel.DefaultChannelConfig
-
- autoReadCleared() - Method in class io.netty.channel.DefaultChannelConfig
-
- autoReadCleared() - Method in class io.netty.channel.kqueue.KQueueChannelConfig
-
- autoReadCleared() - Method in class io.netty.channel.sctp.nio.NioSctpChannel.NioSctpChannelConfig
-
- autoReadCleared() - Method in class io.netty.channel.sctp.nio.NioSctpServerChannel.NioSctpServerChannelConfig
-
- autoReadCleared() - Method in class io.netty.channel.sctp.oio.OioSctpChannel.OioSctpChannelConfig
-
- autoReadCleared() - Method in class io.netty.channel.sctp.oio.OioSctpServerChannel.OioSctpServerChannelConfig
-
- autoReadCleared() - Method in class io.netty.channel.socket.nio.NioDatagramChannelConfig
-
- autoReadCleared() - Method in class io.netty.channel.socket.nio.NioServerSocketChannel.NioServerSocketChannelConfig
-
- autoReadCleared() - Method in class io.netty.channel.socket.nio.NioSocketChannel.NioSocketChannelConfig
-
- autoReadCleared() - Method in class io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig
-
- autoReadCleared() - Method in class io.netty.channel.socket.oio.DefaultOioSocketChannelConfig
-
- autoRelease - Variable in class io.netty.channel.SimpleChannelInboundHandler
-
- 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
-
- AVAILABLE - Static variable in class io.netty.handler.ssl.JdkAlpnApplicationProtocolNegotiator
-
- availableProcessors() - Static method in class io.netty.util.NettyRuntime
-
Get the configured number of available processors.
- availableProcessors - Variable in class io.netty.util.NettyRuntime.AvailableProcessorsHolder
-
- availableProcessors() - Method in class io.netty.util.NettyRuntime.AvailableProcessorsHolder
-
Get the configured number of available processors.
- AvailableProcessorsHolder() - Constructor for class io.netty.util.NettyRuntime.AvailableProcessorsHolder
-
- availableSharedCapacity - Variable in class io.netty.util.Recycler.Stack
-
- availableSharedCapacity - Variable in class io.netty.util.Recycler.WeakOrderQueue
-
- availableSize() - Method in class io.netty.handler.codec.compression.Bzip2BlockCompressor
-
Gets available size of the current block.
- 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.CompleteChannelFuture
-
- 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.channel.group.DefaultChannelGroupFuture
-
- await() - Method in class io.netty.channel.group.VoidChannelGroupFuture
-
- await(long, TimeUnit) - Method in class io.netty.channel.group.VoidChannelGroupFuture
-
- await(long) - Method in class io.netty.channel.group.VoidChannelGroupFuture
-
- await() - Method in class io.netty.channel.VoidChannelPromise
-
- await(long, TimeUnit) - Method in class io.netty.channel.VoidChannelPromise
-
- await(long) - Method in class io.netty.channel.VoidChannelPromise
-
- 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
-
- await0(long, boolean) - Method in class io.netty.util.concurrent.DefaultPromise
-
- 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.embedded.EmbeddedEventLoop
-
- 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.NonStickyEventExecutorGroup.NonStickyOrderedEventExecutor
-
- 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.CompleteChannelFuture
-
- 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.channel.group.DefaultChannelGroupFuture
-
- awaitUninterruptibly() - Method in class io.netty.channel.group.VoidChannelGroupFuture
-
- awaitUninterruptibly(long, TimeUnit) - Method in class io.netty.channel.group.VoidChannelGroupFuture
-
- awaitUninterruptibly(long) - Method in class io.netty.channel.group.VoidChannelGroupFuture
-
- awaitUninterruptibly() - Method in class io.netty.channel.VoidChannelPromise
-
- awaitUninterruptibly(long, TimeUnit) - Method in class io.netty.channel.VoidChannelPromise
-
- awaitUninterruptibly(long) - Method in class io.netty.channel.VoidChannelPromise
-
- 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 - Variable in class io.netty.handler.codec.compression.Bzip2DivSufSort.StackEntry
-
- b - Variable in enum io.netty.handler.codec.socks.SocksAddressType
-
- b - Variable in enum io.netty.handler.codec.socks.SocksAuthScheme
-
- b - Variable in enum io.netty.handler.codec.socks.SocksAuthStatus
-
- b - Variable in enum io.netty.handler.codec.socks.SocksCmdStatus
-
- b - Variable in enum io.netty.handler.codec.socks.SocksCmdType
-
- b - Variable in enum io.netty.handler.codec.socks.SocksProtocolVersion
-
- b - Variable in enum io.netty.handler.codec.socks.SocksSubnegotiationVersion
-
- b - Variable in enum io.netty.handler.codec.socksx.SocksVersion
-
- b - Variable in class io.netty.resolver.dns.BiDnsQueryLifecycleObserver
-
- b - Variable in class io.netty.resolver.dns.BiDnsQueryLifecycleObserverFactory
-
- b2c(byte) - Static method in class io.netty.util.AsciiString
-
- b4 - Variable in class io.netty.handler.codec.base64.Base64.Decoder
-
- b4Posn - Variable in class io.netty.handler.codec.base64.Base64.Decoder
-
- backlog - Variable in class io.netty.channel.kqueue.KQueueServerChannelConfig
-
- backlog - Variable in class io.netty.channel.sctp.DefaultSctpServerChannelConfig
-
- backlog - Variable in class io.netty.channel.socket.DefaultServerSocketChannelConfig
-
- 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.
- Base64() - Constructor for class io.netty.handler.codec.base64.Base64
-
- Base64.Decoder - Class in io.netty.handler.codec.base64
-
- Base64Decoder - Class in io.netty.handler.codec.base64
-
- 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.
- Base64Dialect(byte[], byte[], boolean) - Constructor for enum io.netty.handler.codec.base64.Base64Dialect
-
- Base64Encoder - Class in io.netty.handler.codec.base64
-
- 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
-
- BASE_BLOCK_SIZE - Static variable in class io.netty.handler.codec.compression.Bzip2Constants
-
Base block size.
- 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
-
- BEGIN_CERT - Static variable in class io.netty.handler.ssl.PemX509Certificate
-
- BEGIN_PRIVATE_KEY - Static variable in class io.netty.handler.ssl.PemPrivateKey
-
- 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
-
- beginHandshake() - Method in class io.netty.handler.ssl.JdkSslEngine
-
- beginRead() - Method in class io.netty.channel.AbstractChannel.AbstractUnsafe
-
- beginRead() - Method in interface io.netty.channel.Channel.Unsafe
-
- 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
-
- BINARY_PREFIX - Static variable in class io.netty.handler.codec.haproxy.HAProxyMessageDecoder
-
Binary header prefix
- BINARY_PREFIX_LENGTH - Static variable in class io.netty.handler.codec.haproxy.HAProxyMessageDecoder
-
Binary header prefix length
- 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
-
- BinaryMemcacheClientCodec(int) - Constructor for class io.netty.handler.codec.memcache.binary.BinaryMemcacheClientCodec
-
- BinaryMemcacheClientCodec(int, boolean) - Constructor for class io.netty.handler.codec.memcache.binary.BinaryMemcacheClientCodec
-
- BinaryMemcacheClientCodec.Decoder - Class in io.netty.handler.codec.memcache.binary
-
- BinaryMemcacheClientCodec.Encoder - Class in io.netty.handler.codec.memcache.binary
-
- BinaryMemcacheMessage - Interface in io.netty.handler.codec.memcache.binary
-
- 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
-
- BinaryMemcacheOpcodes() - Constructor for class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
-
- BinaryMemcacheRequest - Interface in io.netty.handler.codec.memcache.binary
-
- 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
-
- 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
-
- BinaryMemcacheResponseStatus() - Constructor for class io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseStatus
-
- 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(SocketAddress) - Method in class com.sun.nio.sctp.SctpChannel
-
- bind(SocketAddress) - Method in class com.sun.nio.sctp.SctpServerChannel
-
- bind(SocketAddress, int) - Method in class com.sun.nio.sctp.SctpServerChannel
-
- bind() - Method in class io.netty.bootstrap.AbstractBootstrap
-
- bind(int) - Method in class io.netty.bootstrap.AbstractBootstrap
-
- bind(String, int) - Method in class io.netty.bootstrap.AbstractBootstrap
-
- bind(InetAddress, int) - Method in class io.netty.bootstrap.AbstractBootstrap
-
- bind(SocketAddress) - Method in class io.netty.bootstrap.AbstractBootstrap
-
- 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) - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- bind(SocketAddress, ChannelPromise) - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- bind(SocketAddress, ChannelPromise) - Method in interface io.netty.channel.Channel.Unsafe
-
- 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.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- bind(SocketAddress, ChannelPromise) - Method in class io.netty.channel.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- bind(SocketAddress) - Method in class io.netty.channel.DefaultChannelPipeline
-
- bind(SocketAddress, ChannelPromise) - Method in class io.netty.channel.DefaultChannelPipeline
-
- bind(ChannelHandlerContext, SocketAddress, ChannelPromise) - Method in class io.netty.channel.DefaultChannelPipeline.HeadContext
-
- bind(SocketAddress) - Method in class io.netty.channel.unix.Socket
-
- bind(int, byte[], int, int) - Static method in class io.netty.channel.unix.Socket
-
- bind(ChannelHandlerContext, SocketAddress, ChannelPromise) - Method in class io.netty.handler.codec.DatagramPacketEncoder
-
- BIND - Static variable in class io.netty.handler.codec.socksx.v4.Socks4CommandType
-
- BIND - Static variable in class io.netty.handler.codec.socksx.v5.Socks5CommandType
-
- 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
-
- bindAddress(InetAddress) - Method in class com.sun.nio.sctp.SctpChannel
-
- bindAddress(InetAddress) - Method in class com.sun.nio.sctp.SctpServerChannel
-
- bindAddress(InetAddress) - Method in class io.netty.channel.sctp.nio.NioSctpChannel
-
- bindAddress(InetAddress, ChannelPromise) - Method in class io.netty.channel.sctp.nio.NioSctpChannel
-
- bindAddress(InetAddress) - Method in class io.netty.channel.sctp.nio.NioSctpServerChannel
-
- bindAddress(InetAddress, ChannelPromise) - Method in class io.netty.channel.sctp.nio.NioSctpServerChannel
-
- bindAddress(InetAddress) - Method in class io.netty.channel.sctp.oio.OioSctpChannel
-
- bindAddress(InetAddress, ChannelPromise) - Method in class io.netty.channel.sctp.oio.OioSctpChannel
-
- bindAddress(InetAddress) - Method in class io.netty.channel.sctp.oio.OioSctpServerChannel
-
- bindAddress(InetAddress, ChannelPromise) - Method in class io.netty.channel.sctp.oio.OioSctpServerChannel
-
- bindAddress(InetAddress) - Method in interface io.netty.channel.sctp.SctpChannel
-
Bind a address to the already bound channel to enable multi-homing.
- bindAddress(InetAddress, ChannelPromise) - Method in interface io.netty.channel.sctp.SctpChannel
-
Bind a address to the already bound channel to enable multi-homing.
- bindAddress(InetAddress) - Method in interface io.netty.channel.sctp.SctpServerChannel
-
Bind a address to the already bound channel to enable multi-homing.
- bindAddress(InetAddress, ChannelPromise) - Method in interface io.netty.channel.sctp.SctpServerChannel
-
Bind a address to the already bound channel to enable multi-homing.
- bindDomainSocket(int, byte[]) - Static method in class io.netty.channel.unix.Socket
-
- BIT_MODE - Static variable in class io.netty.util.internal.PlatformDependent
-
- bitBuffer - Variable in class io.netty.handler.codec.compression.Bzip2BitReader
-
A buffer of bits read from the input stream that have not yet been returned.
- bitBuffer - Variable in class io.netty.handler.codec.compression.Bzip2BitWriter
-
A buffer of bits waiting to be written to the output stream.
- bitCount - Variable in class io.netty.handler.codec.compression.Bzip2BitReader
-
- bitCount - Variable in class io.netty.handler.codec.compression.Bzip2BitWriter
-
- bitmap - Variable in class io.netty.buffer.PoolSubpage
-
- bitmapIdx(long) - Static method in class io.netty.buffer.PoolChunk
-
- bitmapLength - Variable in class io.netty.buffer.PoolSubpage
-
- bitMode() - Static method in class io.netty.util.internal.PlatformDependent
-
Returns the bit mode of the current VM (usually 32 or 64.)
- bitMode0() - Static method in class io.netty.util.internal.PlatformDependent
-
- bitsToEncode(int) - Static method in class io.netty.handler.codec.compression.Snappy
-
Calculates the minimum number of bits required to encode a value.
- 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
-
- block - Variable in class io.netty.handler.codec.compression.Bzip2BlockCompressor
-
The RLE'd block data.
- BLOCK_HEADER_MAGIC_1 - Static variable in class io.netty.handler.codec.compression.Bzip2Constants
-
Block header magic number.
- BLOCK_HEADER_MAGIC_2 - Static variable in class io.netty.handler.codec.compression.Bzip2Constants
-
- BLOCK_TYPE_COMPRESSED - Static variable in class io.netty.handler.codec.compression.FastLz
-
- BLOCK_TYPE_NON_COMPRESSED - Static variable in class io.netty.handler.codec.compression.FastLz
-
- BLOCK_WITH_CHECKSUM - Static variable in class io.netty.handler.codec.compression.FastLz
-
- BLOCK_WITHOUT_CHECKSUM - Static variable in class io.netty.handler.codec.compression.FastLz
-
- blockCompressor - Variable in class io.netty.handler.codec.compression.Bzip2Encoder
-
The compressor for the current block.
- blockCRC - Variable in class io.netty.handler.codec.compression.Bzip2BlockDecompressor
-
The CRC of the current block as read from the block header.
- blockCRC - Variable in class io.netty.handler.codec.compression.Bzip2Decoder
-
The CRC of the current block as read from the block header.
- blockDecompressor - Variable in class io.netty.handler.codec.compression.Bzip2Decoder
-
The decompressor for the current block.
- 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
-
- blockLength - Variable in class io.netty.handler.codec.compression.Bzip2BlockCompressor
-
- blockLength() - Method in class io.netty.handler.codec.compression.Bzip2BlockDecompressor
-
- blockLengthLimit - Variable in class io.netty.handler.codec.compression.Bzip2BlockCompressor
-
A limit beyond which new data will not be accepted into the block.
- blockRandomised - Variable in class io.netty.handler.codec.compression.Bzip2BlockDecompressor
-
true
if the current block is randomised, otherwise false
.
- blockSize - Variable in class io.netty.handler.codec.compression.Bzip2Decoder
-
Always: in the range 0 ..
- blockValuesPresent - Variable in class io.netty.handler.codec.compression.Bzip2BlockCompressor
-
The values that are present within the RLE'd block data.
- bndAddr - Variable in class io.netty.handler.codec.socksx.v5.DefaultSocks5CommandResponse
-
- bndAddr() - Method in class io.netty.handler.codec.socksx.v5.DefaultSocks5CommandResponse
-
- bndAddr() - Method in interface io.netty.handler.codec.socksx.v5.Socks5CommandResponse
-
Returns the BND.ADDR
field of this response.
- bndAddrType - Variable in class io.netty.handler.codec.socksx.v5.DefaultSocks5CommandResponse
-
- bndAddrType() - Method in class io.netty.handler.codec.socksx.v5.DefaultSocks5CommandResponse
-
- bndAddrType() - Method in interface io.netty.handler.codec.socksx.v5.Socks5CommandResponse
-
Returns the address type of the BND.ADDR
field of this response.
- bndPort - Variable in class io.netty.handler.codec.socksx.v5.DefaultSocks5CommandResponse
-
- bndPort() - Method in class io.netty.handler.codec.socksx.v5.DefaultSocks5CommandResponse
-
- bndPort() - Method in interface io.netty.handler.codec.socksx.v5.Socks5CommandResponse
-
Returns the BND.PORT
field of this response.
- booleanArrayAppend(StringBuilder, boolean[]) - Static method in class io.netty.util.internal.logging.MessageFormatter
-
- 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
-
- Bootstrap() - Constructor for class io.netty.bootstrap.Bootstrap
-
- Bootstrap(Bootstrap) - Constructor for class io.netty.bootstrap.Bootstrap
-
- bootstrap - Variable in class io.netty.channel.pool.SimpleChannelPool
-
- 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
-
- BootstrapConfig(Bootstrap) - Constructor for class io.netty.bootstrap.BootstrapConfig
-
- boundChannels - Static variable in class io.netty.channel.local.LocalChannelRegistry
-
- breakLines(Base64Dialect) - Static method in class io.netty.handler.codec.base64.Base64
-
- breakLines - Variable in class io.netty.handler.codec.base64.Base64Encoder
-
- breakLinesByDefault - Variable in enum io.netty.handler.codec.base64.Base64Dialect
-
- BSD_SND_LOW_AT_MAX - Static variable in class io.netty.channel.kqueue.BsdSocket
-
- BsdSocket - Class in io.netty.channel.kqueue
-
A socket which provides access BSD native methods.
- BsdSocket(int) - Constructor for class io.netty.channel.kqueue.BsdSocket
-
- bubbleDown(int, T) - Method in class io.netty.util.internal.DefaultPriorityQueue
-
- bubbleUp(int, T) - Method in class io.netty.util.internal.DefaultPriorityQueue
-
- bucket - Variable in class io.netty.util.HashedWheelTimer.HashedWheelTimeout
-
- BUCKET_A_SIZE - Static variable in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- BUCKET_B(int, int) - Static method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- BUCKET_B_SIZE - Static variable in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- BUCKET_BSTAR(int, int) - Static method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- BUCKET_SIZE - Static variable in class io.netty.util.DefaultAttributeMap
-
- budget - Variable in class io.netty.handler.codec.compression.Bzip2DivSufSort.TRBudget
-
- buf - Variable in class io.netty.buffer.CompositeByteBuf.Component
-
- buf - Variable in class io.netty.buffer.FixedCompositeByteBuf.Component
-
- buf - Variable in class io.netty.buffer.SwappedByteBuf
-
Deprecated.
- buf - Variable in class io.netty.buffer.WrappedByteBuf
-
- buf - Variable in class io.netty.channel.ChannelOutboundBuffer.Entry
-
- buf - Variable in class io.netty.handler.codec.AsciiHeadersEncoder
-
- bufAndListenerPairs - Variable in class io.netty.channel.CoalescingBufferQueue
-
- 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 - Variable in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- buffer() - Method in interface io.netty.buffer.ByteBufAllocator
-
- 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 - Variable in class io.netty.buffer.ByteBufInputStream
-
- buffer - Variable in class io.netty.buffer.ByteBufOutputStream
-
- buffer() - Method in class io.netty.buffer.ByteBufOutputStream
-
Returns the buffer where this stream is writing data.
- buffer - Variable in class io.netty.buffer.DuplicatedByteBuf
-
Deprecated.
- buffer(int) - Method in class io.netty.buffer.FixedCompositeByteBuf
-
Return the
ByteBuf
stored at the given index of the array.
- buffer - Variable in class io.netty.buffer.ReadOnlyByteBuf
-
Deprecated.
- buffer - Variable in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- 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
.
- buffer - Variable in class io.netty.buffer.UnpooledDirectByteBuf
-
- buffer - Variable in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
-
- buffer() - Method in class io.netty.channel.local.PreferHeapByteBufAllocator
-
- buffer(int) - Method in class io.netty.channel.local.PreferHeapByteBufAllocator
-
- buffer(int, int) - Method in class io.netty.channel.local.PreferHeapByteBufAllocator
-
- buffer - Variable in class io.netty.channel.PendingWriteQueue
-
- buffer - Variable in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- buffers - Variable in class io.netty.buffer.FixedCompositeByteBuf
-
- bufferSize - Variable in class io.netty.channel.FixedRecvByteBufAllocator
-
- bufferSize - Variable in class io.netty.channel.FixedRecvByteBufAllocator.HandleImpl
-
- bufs - Variable in class io.netty.channel.ChannelOutboundBuffer.Entry
-
- 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
-
- 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
- buildAliasMap(DnsResponse) - Static method in class io.netty.resolver.dns.DnsNameResolverContext
-
- builder - Variable in class io.netty.util.DomainMappingBuilder
-
Deprecated.
- 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
-
- buildKeyManagerFactory(File, String, File, String, KeyManagerFactory) - Static method in class io.netty.handler.ssl.JdkSslContext
-
- buildKeyManagerFactory(X509Certificate[], PrivateKey, String, KeyManagerFactory) - Static method in class io.netty.handler.ssl.SslContext
-
- buildKeyManagerFactory(X509Certificate[], String, PrivateKey, String, KeyManagerFactory) - Static method in class io.netty.handler.ssl.SslContext
-
- buildKeyStore(X509Certificate[], PrivateKey, char[]) - Static method in class io.netty.handler.ssl.SslContext
-
Generates a new KeyStore
.
- buildTimeMillis - Variable in class io.netty.util.Version
-
- buildTimeMillis() - Method in class io.netty.util.Version
-
- buildTrustManagerFactory(File, TrustManagerFactory) - Static method in class io.netty.handler.ssl.SslContext
-
Deprecated.
- buildTrustManagerFactory(X509Certificate[], TrustManagerFactory) - Static method in class io.netty.handler.ssl.SslContext
-
- 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 - Variable in 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.
- bwt() - Method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
Performs a Burrows Wheeler Transform on the input array.
- bwtBlock - Variable in class io.netty.handler.codec.compression.Bzip2BlockCompressor
-
The Burrows Wheeler Transformed block data.
- bwtBlock - Variable in class io.netty.handler.codec.compression.Bzip2BlockDecompressor
-
The Burrows-Wheeler Transform processed data.
- bwtBlock - Variable in class io.netty.handler.codec.compression.Bzip2MTFAndRLE2StageEncoder
-
The Burrows-Wheeler transformed block.
- bwtBlockLength - Variable in class io.netty.handler.codec.compression.Bzip2BlockDecompressor
-
The actual length in bytes of the current block at the Inverse Burrows Wheeler Transform
stage (before final Run-Length Decoding).
- bwtByteCounts - Variable in class io.netty.handler.codec.compression.Bzip2BlockDecompressor
-
- bwtBytesDecoded - Variable in class io.netty.handler.codec.compression.Bzip2BlockDecompressor
-
The number of output bytes that have been decoded up to the Inverse Burrows Wheeler Transform stage.
- bwtCurrentMergedPointer - Variable in class io.netty.handler.codec.compression.Bzip2BlockDecompressor
-
The current merged pointer into the Burrow-Wheeler Transform array.
- bwtLength - Variable in class io.netty.handler.codec.compression.Bzip2MTFAndRLE2StageEncoder
-
- bwtMergedPointers - Variable in class io.netty.handler.codec.compression.Bzip2BlockDecompressor
-
At each position contains the union of :-
An output character (8 bits)
A pointer from each position to its successor (24 bits, left shifted 8 bits)
As the pointer cannot exceed the maximum block size of 900k, 24 bits is more than enough to
hold it; Folding the character data into the spare bits while performing the inverse BWT,
when both pieces of information are available, saves a large number of memory accesses in
the final decoding stages.
- bwtStartPointer - Variable in class io.netty.handler.codec.compression.Bzip2BlockDecompressor
-
Starting pointer into BWT for after untransform.
- bwtValuesPresent - Variable in class io.netty.handler.codec.compression.Bzip2MTFAndRLE2StageEncoder
-
At each position, true
if the byte value with that index is present within the block,
otherwise false
.
- BY_NAME - Static variable in class io.netty.handler.codec.dns.DnsRecordType
-
- BY_TYPE - Static variable in class io.netty.handler.codec.dns.DnsRecordType
-
- BYTE2CHAR - Static variable in class io.netty.buffer.ByteBufUtil.HexUtil
-
- BYTE2HEX - Static variable in class io.netty.buffer.ByteBufUtil.HexUtil
-
- BYTE2HEX_NOPAD - Static variable in class io.netty.util.internal.StringUtil
-
- BYTE2HEX_PAD - Static variable in class io.netty.util.internal.StringUtil
-
- BYTE_ARRAY_BASE_OFFSET - Static variable in class io.netty.util.internal.PlatformDependent
-
- BYTE_ARRAY_BASE_OFFSET - Static variable in class io.netty.util.internal.PlatformDependent0
-
- BYTE_MASK - Static variable in class io.netty.handler.codec.compression.Crc32c
-
- byteArrayAppend(StringBuilder, byte[]) - Static method in class io.netty.util.internal.logging.MessageFormatter
-
- byteArrayBaseOffset() - Static method in class io.netty.util.internal.PlatformDependent0
-
- byteArrayBaseOffset0() - Static method in class io.netty.util.internal.PlatformDependent
-
- 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
-
- ByteBufChecksum - Class in io.netty.handler.codec.compression
-
Checksum
implementation which can directly act on a
ByteBuf
.
- ByteBufChecksum() - Constructor for class io.netty.handler.codec.compression.ByteBufChecksum
-
- ByteBufChecksum.ReflectiveByteBufChecksum - Class in io.netty.handler.codec.compression
-
- ByteBufChecksum.SlowByteBufChecksum - Class in io.netty.handler.codec.compression
-
- byteBuffer - Variable in class io.netty.handler.stream.ChunkedNioStream
-
Associated ByteBuffer
- 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
-
- byteBufToErrors - Variable in class io.netty.handler.codec.redis.FixedRedisMessagePool
-
- byteBufToIntegers - Variable in class io.netty.handler.codec.redis.FixedRedisMessagePool
-
- byteBufToSimpleStrings - Variable in class io.netty.handler.codec.redis.FixedRedisMessagePool
-
- 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.
- ByteBufUtil() - Constructor for class io.netty.buffer.ByteBufUtil
-
- ByteBufUtil.HexUtil - Class in io.netty.buffer
-
- ByteBufUtil.ThreadLocalDirectByteBuf - Class in io.netty.buffer
-
- ByteBufUtil.ThreadLocalUnsafeDirectByteBuf - Class in io.netty.buffer
-
- byteChannel - Variable in class io.netty.channel.kqueue.AbstractKQueueStreamChannel
-
- ByteCollections - Class in io.netty.util.collection
-
Utilities for byte-based primitive collections.
- ByteCollections() - Constructor for class io.netty.util.collection.ByteCollections
-
- ByteCollections.EmptyMap - Class in io.netty.util.collection
-
An empty map.
- ByteCollections.UnmodifiableMap<V> - Class in io.netty.util.collection
-
- ByteCollections.UnmodifiableMap.EntryImpl - Class in io.netty.util.collection
-
Unmodifiable wrapper for an entry.
- ByteCollections.UnmodifiableMap.IteratorImpl - Class in io.netty.util.collection
-
Unmodifiable wrapper for an iterator.
- 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
-
- ByteObjectHashMap.EntrySet - Class in io.netty.util.collection
-
Set implementation for iterating over the entries of the map.
- ByteObjectHashMap.KeySet - Class in io.netty.util.collection
-
Set implementation for iterating over the keys.
- ByteObjectHashMap.MapEntry - Class in io.netty.util.collection
-
A single entry in the map.
- ByteObjectHashMap.MapIterator - Class in io.netty.util.collection
-
Iterator used by the Map
interface.
- ByteObjectHashMap.PrimitiveIterator - Class in io.netty.util.collection
-
Iterator over primitive entries.
- ByteObjectMap<V> - Interface in io.netty.util.collection
-
Interface for a primitive map that uses byte
s as keys.
- ByteObjectMap.PrimitiveEntry<V> - Interface in io.netty.util.collection
-
- byteOrder - Variable in class io.netty.handler.codec.LengthFieldBasedFrameDecoder
-
- byteOrder - Variable in class io.netty.handler.codec.LengthFieldPrepender
-
- BYTEPADDING - Static variable in class io.netty.buffer.ByteBufUtil.HexUtil
-
- 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 - Variable in class io.netty.channel.PendingWriteQueue
-
- bytes() - Method in class io.netty.channel.PendingWriteQueue
-
Returns the total number of bytes that are pending because of pending messages.
- bytes - Variable in class io.netty.handler.ssl.OpenSslJavaxX509Certificate
-
- bytes - Variable in class io.netty.handler.ssl.OpenSslX509Certificate
-
- 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.AdvancedLeakAwareByteBuf
-
- bytesBefore(int, byte) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- bytesBefore(int, int, byte) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- bytesBefore(byte) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- bytesBefore(int, byte) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- bytesBefore(int, int, byte) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.
- bytesBefore(byte) - Method in class io.netty.buffer.WrappedByteBuf
-
- bytesBefore(int, byte) - Method in class io.netty.buffer.WrappedByteBuf
-
- bytesBefore(int, int, byte) - Method in class io.netty.buffer.WrappedByteBuf
-
- bytesBefore(byte) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- bytesBefore(int, byte) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- bytesBefore(int, int, byte) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- bytesBefore(byte) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- bytesBefore(int, byte) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- bytesBefore(int, int, byte) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- bytesBeforeUnwritable() - Method in class io.netty.channel.AbstractChannel
-
- bytesBeforeUnwritable() - Method in interface io.netty.channel.Channel
-
- bytesBeforeUnwritable() - Method in class io.netty.channel.ChannelOutboundBuffer
-
- bytesBeforeWritable() - Method in class io.netty.channel.AbstractChannel
-
- bytesBeforeWritable() - Method in interface io.netty.channel.Channel
-
- bytesBeforeWritable() - Method in class io.netty.channel.ChannelOutboundBuffer
-
- bytesRealWriteFlowControl(long) - Method in class io.netty.handler.traffic.TrafficCounter
-
Computes counters for Real Write.
- bytesRecvFlowControl(long) - Method in class io.netty.handler.traffic.TrafficCounter
-
Computes counters for Read.
- bytesRemainingInVariablePart - Variable in class io.netty.handler.codec.mqtt.MqttDecoder
-
- bytesToDiscard - Variable in class io.netty.handler.codec.LengthFieldBasedFrameDecoder
-
- 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.
- bytesToRead - Variable in class io.netty.channel.DefaultMaxBytesRecvByteBufAllocator.HandleImpl
-
- bytesWriteFlowControl(long) - Method in class io.netty.handler.traffic.TrafficCounter
-
Computes counters for Write.
- byteToFind - Variable in class io.netty.util.ByteProcessor.IndexOfProcessor
-
- 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
-
- 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
- ByteToMessageCodec.Encoder - Class in io.netty.handler.codec
-
- ByteToMessageDecoder - Class in io.netty.handler.codec
-
- ByteToMessageDecoder() - Constructor for class io.netty.handler.codec.ByteToMessageDecoder
-
- ByteToMessageDecoder.Cumulator - Interface in io.netty.handler.codec
-
- byteToNotFind - Variable in class io.netty.util.ByteProcessor.IndexNotOfProcessor
-
- byteValue - Variable in class io.netty.handler.codec.dns.DnsOpCode
-
- byteValue() - Method in class io.netty.handler.codec.dns.DnsOpCode
-
- byteValue - Variable in enum io.netty.handler.codec.haproxy.HAProxyCommand
-
- byteValue() - Method in enum io.netty.handler.codec.haproxy.HAProxyCommand
-
Returns the byte value of this command.
- byteValue - Variable in enum io.netty.handler.codec.haproxy.HAProxyProtocolVersion
-
- byteValue() - Method in enum io.netty.handler.codec.haproxy.HAProxyProtocolVersion
-
Returns the byte value of this version.
- byteValue - Variable in enum io.netty.handler.codec.haproxy.HAProxyProxiedProtocol.AddressFamily
-
- byteValue() - Method in enum io.netty.handler.codec.haproxy.HAProxyProxiedProtocol.AddressFamily
-
Returns the byte value of this address family.
- byteValue - Variable in enum io.netty.handler.codec.haproxy.HAProxyProxiedProtocol
-
- byteValue() - Method in enum io.netty.handler.codec.haproxy.HAProxyProxiedProtocol
-
Returns the byte value of this protocol and address family.
- byteValue() - Method in enum io.netty.handler.codec.haproxy.HAProxyProxiedProtocol.TransportProtocol
-
Returns the byte value of this transport protocol.
- byteValue - Variable in enum io.netty.handler.codec.mqtt.MqttConnectReturnCode
-
- byteValue() - Method in enum io.netty.handler.codec.mqtt.MqttConnectReturnCode
-
- byteValue() - Method in enum io.netty.handler.codec.socks.SocksAddressType
-
- byteValue() - Method in enum io.netty.handler.codec.socks.SocksAuthScheme
-
- byteValue() - Method in enum io.netty.handler.codec.socks.SocksAuthStatus
-
- byteValue() - Method in enum io.netty.handler.codec.socks.SocksCmdStatus
-
- byteValue() - Method in enum io.netty.handler.codec.socks.SocksCmdType
-
- byteValue() - Method in enum io.netty.handler.codec.socks.SocksProtocolVersion
-
- byteValue() - Method in enum io.netty.handler.codec.socks.SocksSubnegotiationVersion
-
- byteValue() - Method in enum io.netty.handler.codec.socksx.SocksVersion
-
Returns the value of the version field, as defined in the protocol specification.
- byteValue - Variable in class io.netty.handler.codec.socksx.v4.Socks4CommandStatus
-
- byteValue() - Method in class io.netty.handler.codec.socksx.v4.Socks4CommandStatus
-
- byteValue - Variable in class io.netty.handler.codec.socksx.v4.Socks4CommandType
-
- byteValue() - Method in class io.netty.handler.codec.socksx.v4.Socks4CommandType
-
- byteValue - Variable in class io.netty.handler.codec.socksx.v5.Socks5AddressType
-
- byteValue() - Method in class io.netty.handler.codec.socksx.v5.Socks5AddressType
-
- byteValue - Variable in class io.netty.handler.codec.socksx.v5.Socks5AuthMethod
-
- byteValue() - Method in class io.netty.handler.codec.socksx.v5.Socks5AuthMethod
-
- byteValue - Variable in class io.netty.handler.codec.socksx.v5.Socks5CommandStatus
-
- byteValue() - Method in class io.netty.handler.codec.socksx.v5.Socks5CommandStatus
-
- byteValue - Variable in class io.netty.handler.codec.socksx.v5.Socks5CommandType
-
- byteValue() - Method in class io.netty.handler.codec.socksx.v5.Socks5CommandType
-
- byteValue - Variable in class io.netty.handler.codec.socksx.v5.Socks5PasswordAuthStatus
-
- byteValue() - Method in class io.netty.handler.codec.socksx.v5.Socks5PasswordAuthStatus
-
- Bzip2BitReader - Class in io.netty.handler.codec.compression
-
An bit reader that allows the reading of single bit booleans, bit strings of
arbitrary length (up to 32 bits), and bit aligned 32-bit integers.
- Bzip2BitReader() - Constructor for class io.netty.handler.codec.compression.Bzip2BitReader
-
- Bzip2BitWriter - Class in io.netty.handler.codec.compression
-
A bit writer that allows the writing of single bit booleans, unary numbers, bit strings
of arbitrary length (up to 32 bits), and bit aligned 32-bit integers.
- Bzip2BitWriter() - Constructor for class io.netty.handler.codec.compression.Bzip2BitWriter
-
- Bzip2BlockCompressor - Class in io.netty.handler.codec.compression
-
Compresses and writes a single Bzip2 block.
Block encoding consists of the following stages:
1.
- Bzip2BlockCompressor(Bzip2BitWriter, int) - Constructor for class io.netty.handler.codec.compression.Bzip2BlockCompressor
-
- Bzip2BlockDecompressor - Class in io.netty.handler.codec.compression
-
Reads and decompresses a single Bzip2 block.
Block decoding consists of the following stages:
1.
- Bzip2BlockDecompressor(int, int, boolean, int, Bzip2BitReader) - Constructor for class io.netty.handler.codec.compression.Bzip2BlockDecompressor
-
- Bzip2Constants - Class in io.netty.handler.codec.compression
-
- Bzip2Constants() - Constructor for class io.netty.handler.codec.compression.Bzip2Constants
-
- 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
-
- Bzip2Decoder.State - Enum in io.netty.handler.codec.compression
-
Current state of stream.
- Bzip2DivSufSort - Class in io.netty.handler.codec.compression
-
DivSufSort suffix array generator.
Based on
libdivsufsort 1.2.3 patched to support Bzip2.
This is a simple conversion of the original C with two minor bugfixes applied (see "BUGFIX"
comments within the class).
- Bzip2DivSufSort(byte[], int[], int) - Constructor for class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- Bzip2DivSufSort.PartitionResult - Class in io.netty.handler.codec.compression
-
- Bzip2DivSufSort.StackEntry - Class in io.netty.handler.codec.compression
-
- Bzip2DivSufSort.TRBudget - Class in io.netty.handler.codec.compression
-
- 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
.
- Bzip2Encoder.State - Enum in io.netty.handler.codec.compression
-
Current state of stream.
- Bzip2HuffmanAllocator - Class in io.netty.handler.codec.compression
-
An in-place, length restricted Canonical Huffman code length allocator.
Based on the algorithm proposed by R.
- Bzip2HuffmanAllocator() - Constructor for class io.netty.handler.codec.compression.Bzip2HuffmanAllocator
-
- Bzip2HuffmanStageDecoder - Class in io.netty.handler.codec.compression
-
A decoder for the Bzip2 Huffman coding stage.
- Bzip2HuffmanStageDecoder(Bzip2BitReader, int, int) - Constructor for class io.netty.handler.codec.compression.Bzip2HuffmanStageDecoder
-
- Bzip2HuffmanStageEncoder - Class in io.netty.handler.codec.compression
-
An encoder for the Bzip2 Huffman encoding stage.
- Bzip2HuffmanStageEncoder(Bzip2BitWriter, char[], int, int, int[]) - Constructor for class io.netty.handler.codec.compression.Bzip2HuffmanStageEncoder
-
- Bzip2MoveToFrontTable - Class in io.netty.handler.codec.compression
-
A 256 entry Move To Front transform.
- Bzip2MoveToFrontTable() - Constructor for class io.netty.handler.codec.compression.Bzip2MoveToFrontTable
-
- Bzip2MTFAndRLE2StageEncoder - Class in io.netty.handler.codec.compression
-
An encoder for the Bzip2 Move To Front Transform and Run-Length Encoding[2] stages.
Although conceptually these two stages are separate, it is computationally efficient to perform
them in one pass.
- Bzip2MTFAndRLE2StageEncoder(int[], int, boolean[]) - Constructor for class io.netty.handler.codec.compression.Bzip2MTFAndRLE2StageEncoder
-
- Bzip2Rand - Class in io.netty.handler.codec.compression
-
Random numbers for decompress Bzip2 blocks.
- Bzip2Rand() - Constructor for class io.netty.handler.codec.compression.Bzip2Rand
-
- c - Variable in class io.netty.handler.codec.compression.Bzip2DivSufSort.StackEntry
-
- 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 - Variable in class io.netty.buffer.PooledByteBuf
-
- cache(PoolArena<?>, int, PoolArena.SizeClass) - Method in class io.netty.buffer.PoolThreadCache
-
- cache(PoolThreadCache.MemoryRegionCache<T>[], int) - Static method in class io.netty.buffer.PoolThreadCache
-
- 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
-
- cachedEntries(String) - Method in class io.netty.resolver.dns.DefaultDnsCache
-
- cacheDisabled(ClassLoader) - Static method in class io.netty.handler.codec.serialization.ClassResolvers
-
cache disabled
- cachedStackTrace - Variable in exception io.netty.util.ResourceLeakException
-
Deprecated.
- cacheForNormal(PoolArena<?>, int) - Method in class io.netty.buffer.PoolThreadCache
-
- cacheForSmall(PoolArena<?>, int) - Method in class io.netty.buffer.PoolThreadCache
-
- cacheForTiny(PoolArena<?>, int) - Method in class io.netty.buffer.PoolThreadCache
-
- cacheFromJava(String) - Static method in class io.netty.handler.ssl.CipherSuiteConverter
-
- cacheFromOpenSsl(String) - Static method in class io.netty.handler.ssl.CipherSuiteConverter
-
- CachingClassResolver - Class in io.netty.handler.codec.serialization
-
- CachingClassResolver(ClassResolver, Map<String, Class<?>>) - Constructor for class io.netty.handler.codec.serialization.CachingClassResolver
-
- cal - Variable in class io.netty.handler.codec.DateFormatter
-
- calcMaxSize(int) - Method in class io.netty.util.collection.ByteObjectHashMap
-
Calculates the maximum size allowed before rehashing.
- calcMaxSize(int) - Method in class io.netty.util.collection.CharObjectHashMap
-
Calculates the maximum size allowed before rehashing.
- calcMaxSize(int) - Method in class io.netty.util.collection.IntObjectHashMap
-
Calculates the maximum size allowed before rehashing.
- calcMaxSize(int) - Method in class io.netty.util.collection.LongObjectHashMap
-
Calculates the maximum size allowed before rehashing.
- calcMaxSize(int) - Method in class io.netty.util.collection.ShortObjectHashMap
-
Calculates the maximum size allowed before rehashing.
- CALCULATE_THRESHOLD - Static variable in class io.netty.buffer.AbstractByteBufAllocator
-
- calculateAndWriteChecksum(ByteBuf, ByteBuf) - Static method in class io.netty.handler.codec.compression.SnappyFrameEncoder
-
Calculates and writes the 4-byte checksum to the output buffer
- calculateChecksum(ByteBuf) - Static method in class io.netty.handler.codec.compression.Snappy
-
Computes the CRC32C checksum of the supplied data and performs the "mask" operation
on the computed checksum
- calculateChecksum(ByteBuf, int, int) - Static method in class io.netty.handler.codec.compression.Snappy
-
Computes the CRC32C checksum of the supplied data and performs the "mask" operation
on the computed checksum
- calculateEcsAddressLength(int, int) - Static method in class io.netty.handler.codec.dns.DefaultDnsRecordEncoder
-
- calculateMaxCapacity(int, int) - Static method in class io.netty.buffer.PoolChunkList
-
Calculates the maximum capacity of a buffer that will ever be possible to allocate out of the
PoolChunk
s
that belong to the
PoolChunkList
with the given
minUsage
and
maxUsage
settings.
- 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.
- calculateNewCapacity(int, int) - Method in class io.netty.channel.local.PreferHeapByteBufAllocator
-
- calculateOutputBufferLength(int) - Static method in class io.netty.handler.codec.compression.FastLz
-
The output buffer must be at least 6% larger than the input buffer and can not be smaller than 66 bytes.
- calculateSize(Object) - Method in class io.netty.handler.traffic.AbstractTrafficShapingHandler
-
Calculate the size of the given Object
.
- calculateStrategy(IntSupplier, boolean) - Method in class io.netty.channel.DefaultSelectStrategy
-
- calculateStrategy(IntSupplier, boolean) - Method in interface io.netty.channel.SelectStrategy
-
The
SelectStrategy
can be used to steer the outcome of a potential select
call.
- calculateWrapBufferCapacity(SslHandler, int, int) - Method in enum io.netty.handler.ssl.SslHandler.SslEngineType
-
- CALENDAR_MONTH_TO_SHORT_NAME - Static variable in class io.netty.handler.codec.DateFormatter
-
- call() - Method in class io.netty.util.concurrent.PromiseTask.RunnableAdapter
-
- 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
-
- callHandlerAdded0(AbstractChannelHandlerContext) - Method in class io.netty.channel.DefaultChannelPipeline
-
- callHandlerAddedForAllHandlers() - Method in class io.netty.channel.DefaultChannelPipeline
-
- callHandlerCallbackLater(AbstractChannelHandlerContext, boolean) - Method in class io.netty.channel.DefaultChannelPipeline
-
- callHandlerRemoved0(AbstractChannelHandlerContext) - Method in class io.netty.channel.DefaultChannelPipeline
-
- CAN_ENABLE_TCP_NODELAY_BY_DEFAULT - Static variable in class io.netty.util.internal.PlatformDependent
-
- cancel() - Method in class io.netty.channel.ChannelOutboundBuffer.Entry
-
- cancel(boolean) - Method in class io.netty.channel.group.VoidChannelGroupFuture
-
- cancel(SelectionKey) - Method in class io.netty.channel.nio.NioEventLoop
-
- cancel(boolean) - Method in class io.netty.channel.VoidChannelPromise
-
- 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(boolean) - Method in class io.netty.util.concurrent.ScheduledFutureTask
-
- cancel() - Method in class io.netty.util.HashedWheelTimer.HashedWheelTimeout
-
- cancel() - Method in interface io.netty.util.Timeout
-
Attempts to cancel the
TimerTask
associated with this handle.
- cancelExpiration(List<DnsCacheEntry>) - Static method in class io.netty.resolver.dns.DefaultDnsCache
-
- cancelExpiration() - Method in class io.netty.resolver.dns.DnsCacheEntry
-
- CANCELLATION_CAUSE_HOLDER - Static variable in class io.netty.util.concurrent.DefaultPromise
-
- cancelled - Variable in class io.netty.channel.ChannelOutboundBuffer.Entry
-
- cancelledKeys - Variable in class io.netty.channel.nio.NioEventLoop
-
- cancelledTimeouts - Variable in class io.netty.util.HashedWheelTimer
-
- cancelScheduledFlush() - Method in class io.netty.handler.flush.FlushConsolidationHandler
-
- cancelScheduledTasks() - Method in class io.netty.channel.embedded.EmbeddedEventLoop
-
- cancelScheduledTasks() - Method in class io.netty.util.concurrent.AbstractScheduledEventExecutor
-
Cancel all scheduled tasks.
- cancelWithoutRemove(boolean) - Method in class io.netty.util.concurrent.ScheduledFutureTask
-
- 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.
- canExecuteExecutable(File) - Static method in class io.netty.util.internal.NativeLibraryLoader.NoexecVolumeDetector
-
- capacity(int) - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- capacity(int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- capacity(int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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 - Variable in class io.netty.buffer.FixedCompositeByteBuf
-
- capacity() - Method in class io.netty.buffer.FixedCompositeByteBuf
-
- capacity(int) - Method in class io.netty.buffer.FixedCompositeByteBuf
-
- capacity() - Method in class io.netty.buffer.PooledByteBuf
-
- capacity(int) - Method in class io.netty.buffer.PooledByteBuf
-
- capacity() - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- capacity(int) - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- capacity() - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- capacity(int) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- 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.ReadOnlyByteBufferBuf
-
- capacity(int) - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- 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 - Variable in class io.netty.buffer.UnpooledDirectByteBuf
-
- 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.UnpooledSlicedByteBuf
-
- capacity - Variable in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
-
- capacity() - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
-
- capacity(int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
-
- capacity(int) - Method in class io.netty.buffer.UnpooledUnsafeNoCleanerDirectByteBuf
-
- capacity() - Method in class io.netty.buffer.WrappedByteBuf
-
- capacity(int) - Method in class io.netty.buffer.WrappedByteBuf
-
- capacity() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- capacity(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- capacity - Variable in class io.netty.channel.kqueue.KQueueEventArray
-
- capacity() - Method in class io.netty.channel.kqueue.KQueueEventArray
-
Return the capacity of the
KQueueEventArray
which represent the maximum number of
kevent
s
that can be stored in it.
- capacity - Variable in class io.netty.channel.kqueue.NativeLongArray
-
- CAPACITY - Static variable in class io.netty.channel.unix.IovArray
-
The needed memory to hold up to IOV_MAX
iov entries, where IOV_MAX
signified
the maximum number of iovec
structs that can be passed to writev(...)
.
- capacity() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- capacity(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- CARRIAGE_RETURN - Static variable in class io.netty.util.internal.StringUtil
-
- cas - Variable in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
-
- 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
-
- casState(int, int) - Method in class io.netty.channel.unix.FileDescriptor
-
- cast(Promise<?>) - Static method in class io.netty.resolver.dns.DnsNameResolver
-
- castRecord(Object) - Static method in class io.netty.handler.codec.dns.AbstractDnsMessage
-
- cause - Variable in class io.netty.channel.FailedChannelFuture
-
- cause() - Method in class io.netty.channel.FailedChannelFuture
-
- cause() - Method in interface io.netty.channel.group.ChannelGroupFuture
-
- cause() - Method in class io.netty.channel.group.DefaultChannelGroupFuture
-
- cause() - Method in class io.netty.channel.group.VoidChannelGroupFuture
-
- cause() - Method in class io.netty.channel.SucceededChannelFuture
-
- cause() - Method in class io.netty.channel.VoidChannelPromise
-
- cause - Variable in class io.netty.handler.codec.DecoderResult
-
- cause() - Method in class io.netty.handler.codec.DecoderResult
-
- cause - Variable in class io.netty.handler.ssl.SslCompletionEvent
-
- cause() - Method in class io.netty.handler.ssl.SslCompletionEvent
-
- cause - Variable in class io.netty.resolver.dns.DnsCacheEntry
-
- cause() - Method in class io.netty.resolver.dns.DnsCacheEntry
-
- cause() - Method in class io.netty.util.concurrent.DefaultPromise
-
- cause - Variable in class io.netty.util.concurrent.DefaultPromise.CauseHolder
-
- cause - Variable in class io.netty.util.concurrent.FailedFuture
-
- 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 - Variable in class io.netty.util.concurrent.PromiseCombiner
-
- cause() - Method in class io.netty.util.concurrent.SucceededFuture
-
- CauseHolder(Throwable) - Constructor for class io.netty.util.concurrent.DefaultPromise.CauseHolder
-
- CERT - Static variable in class io.netty.handler.codec.dns.DnsRecordType
-
Certificate record RFC 4398 Stores PKIX, SPKI, PGP, etc.
- cert - Variable in class io.netty.handler.ssl.util.SelfSignedCertificate
-
- cert() - Method in class io.netty.handler.ssl.util.SelfSignedCertificate
-
Returns the generated X.509 certificate.
- CERT_PATTERN - Static variable in class io.netty.handler.ssl.PemReader
-
- certificate - Variable in class io.netty.handler.ssl.util.SelfSignedCertificate
-
- 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 - Variable in class io.netty.channel.nio.AbstractNioChannel
-
- ch() - Method in interface io.netty.channel.nio.AbstractNioChannel.NioUnsafe
-
Return underlying SelectableChannel
- ch - Variable in class io.netty.channel.sctp.oio.OioSctpChannel
-
- ch - Variable in class io.netty.channel.ThreadPerChannelEventLoop
-
- ch - Variable in class io.netty.resolver.dns.DnsNameResolver
-
- chance - Variable in class io.netty.handler.codec.compression.Bzip2DivSufSort.TRBudget
-
- changeList - Variable in class io.netty.channel.kqueue.KQueueEventLoop
-
- channel(Class<? extends C>) - Method in class io.netty.bootstrap.AbstractBootstrap
-
The
Class
which is used to create
Channel
instances from.
- channel() - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- 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
-
- channel - Variable in class io.netty.channel.ChannelOutboundBuffer
-
- 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.CoalescingBufferQueue
-
- channel() - Method in class io.netty.channel.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- channel - Variable in class io.netty.channel.CompleteChannelFuture
-
- channel() - Method in class io.netty.channel.CompleteChannelFuture
-
- channel - Variable in class io.netty.channel.DefaultChannelConfig
-
- channel - Variable in class io.netty.channel.DefaultChannelPipeline
-
- channel() - Method in class io.netty.channel.DefaultChannelPipeline
-
- channel - Variable in class io.netty.channel.DefaultChannelProgressivePromise
-
- channel() - Method in class io.netty.channel.DefaultChannelProgressivePromise
-
- channel - Variable in class io.netty.channel.DefaultChannelPromise
-
- channel() - Method in class io.netty.channel.DefaultChannelPromise
-
- channel - Variable in class io.netty.channel.group.ChannelMatchers.InstanceMatcher
-
- channel - Variable in class io.netty.channel.kqueue.KQueueChannelConfig
-
- channel(int) - Method in class io.netty.channel.kqueue.KQueueEventArray
-
- channel - Variable in class io.netty.channel.kqueue.KQueueServerChannelConfig
-
- channel - Variable in class io.netty.channel.kqueue.KQueueSocketChannelConfig
-
- channel - Variable in class io.netty.channel.VoidChannelPromise
-
- channel() - Method in class io.netty.channel.VoidChannelPromise
-
- Channel.Unsafe - Interface in io.netty.channel
-
Unsafe operations that should never be called from user-code.
- CHANNEL_CLOSED - Static variable in class io.netty.handler.ssl.SslHandler
-
- CHANNEL_DEFAULT_USER_DEFINED_WRITABILITY_INDEX - Static variable in class io.netty.handler.traffic.AbstractTrafficShapingHandler
-
Default value for Channel UserDefinedWritability index
- CHANNEL_OUTBOUND_BUFFER_ENTRY_OVERHEAD - Static variable in class io.netty.channel.ChannelOutboundBuffer
-
- channelAccepted(ChannelHandlerContext, T) - Method in class io.netty.handler.ipfilter.AbstractRemoteAddressFilter
-
- 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
-
- channelActive(ChannelHandlerContext) - Method in interface io.netty.channel.ChannelInboundHandler
-
- 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.channel.DefaultChannelPipeline.HeadContext
-
- channelActive(ChannelHandlerContext) - Method in class io.netty.channel.DefaultChannelPipeline.TailContext
-
- 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
-
- channelActive(ChannelHandlerContext) - Method in class io.netty.resolver.dns.DnsNameResolver.DnsResponseHandler
-
- channelActivePromise - Variable in class io.netty.resolver.dns.DnsNameResolver.DnsResponseHandler
-
- ChannelConfig - Interface in io.netty.channel
-
A set of configuration properties of a
Channel
.
- channelCreated(Channel) - Method in interface io.netty.channel.pool.ChannelPoolHandler
-
- ChannelDuplexHandler - Class in io.netty.channel
-
- 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 - Variable in class io.netty.bootstrap.AbstractBootstrap
-
- channelFactory(ChannelFactory<? extends C>) - Method in class io.netty.bootstrap.AbstractBootstrap
-
- channelFactory(ChannelFactory<? extends C>) - Method in class io.netty.bootstrap.AbstractBootstrap
-
- channelFactory() - Method in class io.netty.bootstrap.AbstractBootstrap
-
- 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
-
- ChannelFactory<T extends Channel> - Interface in io.netty.channel
-
- channelFactory - Variable in class io.netty.resolver.dns.DnsAddressResolverGroup
-
- channelFactory - Variable in class io.netty.resolver.dns.DnsNameResolverBuilder
-
- channelFactory(ChannelFactory<? extends DatagramChannel>) - Method in class io.netty.resolver.dns.DnsNameResolverBuilder
-
- 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
-
- ChannelFlushPromiseNotifier.DefaultFlushCheckpoint - Class in io.netty.channel
-
- ChannelFlushPromiseNotifier.FlushCheckpoint - Interface in io.netty.channel
-
- ChannelFuture - Interface in io.netty.channel
-
The result of an asynchronous
Channel
I/O operation.
- channelFuture - Variable in class io.netty.resolver.dns.DnsNameResolver
-
- ChannelFutureListener - Interface in io.netty.channel
-
- ChannelGroup - Interface in io.netty.channel.group
-
A thread-safe
Set
that contains open
Channel
s and provides
various bulk operations on them.
- ChannelGroupException - Exception in io.netty.channel.group
-
- ChannelGroupException(Collection<Map.Entry<Channel, Throwable>>) - Constructor for exception io.netty.channel.group.ChannelGroupException
-
- ChannelGroupFuture - Interface in io.netty.channel.group
-
- ChannelGroupFutureListener - Interface in io.netty.channel.group
-
- 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
ChannelPipeline
s multiple times
without a race condition.
- ChannelHandlerAdapter - Class in io.netty.channel
-
- ChannelHandlerAdapter() - Constructor for class io.netty.channel.ChannelHandlerAdapter
-
- ChannelHandlerContext - Interface in io.netty.channel
-
- ChannelHealthChecker - Interface in io.netty.channel.pool
-
- 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
-
- channelIdle(ChannelHandlerContext, IdleStateEvent) - Method in class io.netty.handler.timeout.ReadTimeoutHandler
-
- channelInactive(ChannelHandlerContext) - Method in interface io.netty.channel.ChannelInboundHandler
-
- 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.channel.DefaultChannelPipeline.HeadContext
-
- channelInactive(ChannelHandlerContext) - Method in class io.netty.channel.DefaultChannelPipeline.TailContext
-
- 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.memcache.binary.BinaryMemcacheClientCodec.Decoder
-
- 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
-
- 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
-
- ChannelInitializer() - Constructor for class io.netty.channel.ChannelInitializer
-
- channelInputClosed(ChannelHandlerContext, boolean) - Method in class io.netty.handler.codec.ByteToMessageDecoder
-
- channelInputClosed(ChannelHandlerContext, List<Object>) - Method in class io.netty.handler.codec.ByteToMessageDecoder
-
Called when the input of the channel was closed which may be because it changed to inactive or because of
ChannelInputShutdownEvent
.
- channelInputClosed(ChannelHandlerContext, List<Object>) - Method in class io.netty.handler.codec.ReplayingDecoder
-
- ChannelInputShutdownEvent - Class in io.netty.channel.socket
-
- ChannelInputShutdownEvent() - Constructor for class io.netty.channel.socket.ChannelInputShutdownEvent
-
- 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.
- ChannelInputShutdownReadComplete() - Constructor for class io.netty.channel.socket.ChannelInputShutdownReadComplete
-
- ChannelMatcher - Interface in io.netty.channel.group
-
- ChannelMatchers - Class in io.netty.channel.group
-
Helper class which provides often used
ChannelMatcher
implementations.
- ChannelMatchers() - Constructor for class io.netty.channel.group.ChannelMatchers
-
- ChannelMatchers.ClassMatcher - Class in io.netty.channel.group
-
- ChannelMatchers.CompositeMatcher - Class in io.netty.channel.group
-
- ChannelMatchers.InstanceMatcher - Class in io.netty.channel.group
-
- ChannelMatchers.InvertMatcher - Class in io.netty.channel.group
-
- 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
-
- ChannelOption(int, String) - Constructor for class io.netty.channel.ChannelOption
-
- 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(AbstractChannel) - Constructor for class io.netty.channel.ChannelOutboundBuffer
-
- ChannelOutboundBuffer.Entry - Class in io.netty.channel
-
- ChannelOutboundBuffer.MessageProcessor - Interface in io.netty.channel
-
- ChannelOutboundHandler - Interface in io.netty.channel
-
- ChannelOutboundHandlerAdapter - Class in io.netty.channel
-
- ChannelOutboundHandlerAdapter() - Constructor for class io.netty.channel.ChannelOutboundHandlerAdapter
-
- ChannelOutboundInvoker - Interface in io.netty.channel
-
- ChannelPipeline - Interface in io.netty.channel
-
A list of
ChannelHandler
s which handles or intercepts inbound events and outbound operations of a
Channel
.
- ChannelPipelineException - Exception in io.netty.channel
-
- 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
-
- 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
-
- ChannelPromiseAggregator - Class in io.netty.channel
-
- 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
- channelQueues - Variable in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
-
All queues per channel
- channelQueues - Variable in class io.netty.handler.traffic.GlobalTrafficShapingHandler
-
All queues per channel
- channelRead(ChannelHandlerContext, Object) - Method in class io.netty.bootstrap.ServerBootstrap.ServerBootstrapAcceptor
-
- 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.DefaultChannelPipeline.HeadContext
-
- channelRead(ChannelHandlerContext, Object) - Method in class io.netty.channel.DefaultChannelPipeline.TailContext
-
- 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.haproxy.HAProxyMessageDecoder
-
- 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
-
- channelRead(ChannelHandlerContext, Object) - Method in class io.netty.resolver.dns.DnsNameResolver.DnsResponseHandler
-
- 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
-
- 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.channel.DefaultChannelPipeline.HeadContext
-
- channelReadComplete(ChannelHandlerContext) - Method in class io.netty.channel.DefaultChannelPipeline.TailContext
-
- 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
-
- 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.channel.DefaultChannelPipeline.HeadContext
-
- channelRegistered(ChannelHandlerContext) - Method in class io.netty.channel.DefaultChannelPipeline.TailContext
-
- 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
-
- 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
-
- channelTrafficCounter - Variable in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler.PerChannel
-
- 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.
- ChannelTrafficShapingHandler.ToSend - Class in io.netty.handler.traffic
-
- channelType(Class<? extends DatagramChannel>) - Method in class io.netty.resolver.dns.DnsNameResolverBuilder
-
- channelUnregistered(ChannelHandlerContext) - Method in interface io.netty.channel.ChannelInboundHandler
-
- channelUnregistered(ChannelHandlerContext) - Method in class io.netty.channel.ChannelInboundHandlerAdapter
-
- channelUnregistered(ChannelHandlerContext) - Method in class io.netty.channel.CombinedChannelDuplexHandler
-
- channelUnregistered(ChannelHandlerContext) - Method in class io.netty.channel.DefaultChannelPipeline.HeadContext
-
- channelUnregistered(ChannelHandlerContext) - Method in class io.netty.channel.DefaultChannelPipeline.TailContext
-
- 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.channel.DefaultChannelPipeline.HeadContext
-
- channelWritabilityChanged(ChannelHandlerContext) - Method in class io.netty.channel.DefaultChannelPipeline.TailContext
-
- 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
-
- CHAR_BUFFERS - Static variable in class io.netty.buffer.ByteBufUtil
-
- charArrayAppend(StringBuilder, char[]) - Static method in class io.netty.util.internal.logging.MessageFormatter
-
- 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.
- CharCollections() - Constructor for class io.netty.util.collection.CharCollections
-
- CharCollections.EmptyMap - Class in io.netty.util.collection
-
An empty map.
- CharCollections.UnmodifiableMap<V> - Class in io.netty.util.collection
-
- CharCollections.UnmodifiableMap.EntryImpl - Class in io.netty.util.collection
-
Unmodifiable wrapper for an entry.
- CharCollections.UnmodifiableMap.IteratorImpl - Class in io.netty.util.collection
-
Unmodifiable wrapper for an iterator.
- 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
-
- CharObjectHashMap.EntrySet - Class in io.netty.util.collection
-
Set implementation for iterating over the entries of the map.
- CharObjectHashMap.KeySet - Class in io.netty.util.collection
-
Set implementation for iterating over the keys.
- CharObjectHashMap.MapEntry - Class in io.netty.util.collection
-
A single entry in the map.
- CharObjectHashMap.MapIterator - Class in io.netty.util.collection
-
Iterator used by the Map
interface.
- CharObjectHashMap.PrimitiveIterator - Class in io.netty.util.collection
-
Iterator over primitive entries.
- CharObjectMap<V> - Interface in io.netty.util.collection
-
Interface for a primitive map that uses char
s as keys.
- CharObjectMap.PrimitiveEntry<V> - Interface in io.netty.util.collection
-
- chars - Variable in class io.netty.util.internal.AppendableCharSequence
-
- CharSequenceDelegatingStringSet(Set<CharSequence>) - Constructor for class io.netty.handler.codec.HeadersUtils.CharSequenceDelegatingStringSet
-
- CharSequenceValueConverter - Class in io.netty.handler.codec
-
Converts to/from native types, general Object
, and CharSequence
s.
- CharSequenceValueConverter() - Constructor for class io.netty.handler.codec.CharSequenceValueConverter
-
- charset - Variable in class io.netty.handler.codec.string.LineEncoder
-
- charset - Variable in class io.netty.handler.codec.string.StringDecoder
-
- charset - Variable in class io.netty.handler.codec.string.StringEncoder
-
- charsetDecoderCache() - Method in class io.netty.util.internal.InternalThreadLocalMap
-
- charsetDecoderCache - Variable in class io.netty.util.internal.UnpaddedInternalThreadLocalMap
-
- charsetEncoderCache() - Method in class io.netty.util.internal.InternalThreadLocalMap
-
- charsetEncoderCache - Variable in class io.netty.util.internal.UnpaddedInternalThreadLocalMap
-
- CHARSETS - Static variable in class io.netty.util.CharsetUtil
-
- CharsetUtil - Class in io.netty.util
-
A utility class that provides various common operations and constants
related with Charset
and its relevant classes.
- CharsetUtil() - Constructor for class io.netty.util.CharsetUtil
-
- checkAccessible - Static variable in class io.netty.buffer.AbstractByteBuf
-
- checkAddAllowed() - Method in class io.netty.util.concurrent.PromiseCombiner
-
- checkAdded() - Method in class io.netty.channel.CombinedChannelDuplexHandler
-
- checkAddress(String, HAProxyProxiedProtocol.AddressFamily) - Static method in class io.netty.handler.codec.haproxy.HAProxyMessage
-
Validate an address (IPv4, IPv6, Unix Socket)
- checkAvailable(int) - Method in class io.netty.buffer.ByteBufInputStream
-
- checkByte(byte, byte) - Static method in class io.netty.handler.codec.compression.SnappyFrameDecoder
-
- checkChecksum(ByteBufChecksum, ByteBuf, int) - Static method in class io.netty.handler.codec.compression.CompressionUtil
-
- checkClientTrusted(X509Certificate[], String) - Method in class io.netty.handler.ssl.util.X509TrustManagerWrapper
-
- checkClientTrusted(X509Certificate[], String, Socket) - Method in class io.netty.handler.ssl.util.X509TrustManagerWrapper
-
- checkClientTrusted(X509Certificate[], String, SSLEngine) - Method in class io.netty.handler.ssl.util.X509TrustManagerWrapper
-
- checkComponentIndex(int) - Method in class io.netty.buffer.CompositeByteBuf
-
- checkComponentIndex(int, int) - Method in class io.netty.buffer.CompositeByteBuf
-
- checkCRC() - Method in class io.netty.handler.codec.compression.Bzip2BlockDecompressor
-
Verify and return the block CRC.
- checkDeadLock() - Method in class io.netty.channel.DefaultChannelProgressivePromise
-
- checkDeadLock() - Method in class io.netty.channel.DefaultChannelPromise
-
- checkDeadLock() - Method in class io.netty.channel.group.DefaultChannelGroupFuture
-
- checkDeadLock() - Method in class io.netty.handler.ssl.SslHandler.LazyChannelPromise
-
- checkDeadLock() - Method in class io.netty.util.concurrent.DefaultPromise
-
- checkDeadLock() - Method in class io.netty.util.concurrent.ImmediateEventExecutor.ImmediateProgressivePromise
-
- checkDeadLock() - Method in class io.netty.util.concurrent.ImmediateEventExecutor.ImmediatePromise
-
- checkDstIndex(int, int, int, int) - Method in class io.netty.buffer.AbstractByteBuf
-
- checkDuplicateName(String) - Method in class io.netty.channel.DefaultChannelPipeline
-
- checkEOF(FileRegion) - Static method in class io.netty.channel.oio.OioByteStreamChannel
-
- checkException(ChannelPromise) - Method in class io.netty.channel.embedded.EmbeddedChannel
-
Checks for the presence of an Exception
.
- 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
-
- checkIndex(int) - Method in class io.netty.buffer.EmptyByteBuf
-
- checkIndex(int, int) - Method in class io.netty.buffer.EmptyByteBuf
-
- checkIndex(int) - Method in class io.netty.handler.codec.CodecOutputList
-
- checkIndex(int, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- checkIndex0(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 - Variable in class io.netty.handler.traffic.TrafficCounter
-
Delay between two captures
- checkInterval() - Method in class io.netty.handler.traffic.TrafficCounter
-
- checkJavaVersion() - Static method in class io.netty.channel.socket.nio.NioDatagramChannel
-
- checkLength(int) - Method in class io.netty.buffer.EmptyByteBuf
-
- checkMaxBytesPerReadPair(int, int) - Static method in class io.netty.channel.DefaultMaxBytesRecvByteBufAllocator
-
- checkMultiplicity(ChannelHandler) - Static method in class io.netty.channel.DefaultChannelPipeline
-
- 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.
- checkNotifyWaiters() - Method in class io.netty.util.concurrent.DefaultPromise
-
- checkNotNull(T, String) - Static method in class io.netty.util.internal.ObjectUtil
-
Checks that the given argument is not null.
- checkNotNullAndNotEmpty(String) - Static method in class io.netty.util.ConstantPool
-
- checkNullElements(Collection<?>) - Static method in class io.netty.util.internal.RecyclableArrayList
-
- checkOpen(boolean) - Method in class io.netty.channel.embedded.EmbeddedChannel
-
Returns
true
if the
Channel
is open and records optionally
an
Exception
if it isn't.
- checkpoint - Variable in class io.netty.channel.ChannelFlushPromiseNotifier.DefaultFlushCheckpoint
-
- checkpoint - Variable in class io.netty.channel.DefaultChannelProgressivePromise
-
- checkpoint - Variable in class io.netty.channel.DefaultChannelPromise
-
- checkpoint - Variable in class io.netty.handler.codec.ReplayingDecoder
-
- 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.
- checkPort(int) - Static method in class io.netty.handler.codec.haproxy.HAProxyMessage
-
Validate a UDP/TCP port
- 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.
- checkQuestion(int, DnsRecord) - Static method in class io.netty.handler.codec.dns.AbstractDnsMessage
-
- 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.
- checkReadableBytes(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- checkReadableBytes0(int) - Method in class io.netty.buffer.AbstractByteBuf
-
- checkResolvable(InetSocketAddress) - Static method in class io.netty.channel.kqueue.AbstractKQueueChannel
-
- checkServerTrusted(X509Certificate[], String) - Method in class io.netty.handler.ssl.util.X509TrustManagerWrapper
-
- checkServerTrusted(X509Certificate[], String, Socket) - Method in class io.netty.handler.ssl.util.X509TrustManagerWrapper
-
- checkServerTrusted(X509Certificate[], String, SSLEngine) - Method in class io.netty.handler.ssl.util.X509TrustManagerWrapper
-
- checkSize() - Method in class io.netty.channel.kqueue.KQueueEventArray
-
- checkSize() - Method in class io.netty.channel.kqueue.NativeLongArray
-
- checkSliceOutOfBounds(int, int, ByteBuf) - Static method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- checkSniHostnameMatch(Collection<?>, String) - Static method in class io.netty.handler.ssl.Java8SslUtils
-
- checkSrcIndex(int, int, int, int) - Method in class io.netty.buffer.AbstractByteBuf
-
- checksum - Variable in class io.netty.handler.codec.compression.ByteBufChecksum.SlowByteBufChecksum
-
- checksum - Variable in class io.netty.handler.codec.compression.FastLzFrameDecoder
-
Underlying checksum calculator in use.
- checksum - Variable in class io.netty.handler.codec.compression.FastLzFrameEncoder
-
Underlying checksum calculator in use.
- CHECKSUM_OFFSET - Static variable in class io.netty.handler.codec.compression.FastLz
-
- checkValidity() - Method in class io.netty.handler.ssl.OpenSslJavaxX509Certificate
-
- checkValidity(Date) - Method in class io.netty.handler.ssl.OpenSslJavaxX509Certificate
-
- checkValidity() - Method in class io.netty.handler.ssl.OpenSslX509Certificate
-
- checkValidity(Date) - Method in class io.netty.handler.ssl.OpenSslX509Certificate
-
- 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.AbstractTrafficShapingHandler
-
Method overridden in GTSH to take into account specific timer for the channel.
- checkWaitReadTime(ChannelHandlerContext, long, long) - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
-
- checkWaitReadTime(ChannelHandlerContext, long, long) - Method in class io.netty.handler.traffic.GlobalTrafficShapingHandler
-
- checkWriteSuspend(ChannelHandlerContext, long, long) - Method in class io.netty.handler.traffic.AbstractTrafficShapingHandler
-
Check the writability according to delay and size for the channel.
- childArgs - Variable in class io.netty.channel.ThreadPerChannelEventLoopGroup
-
- childAttr(AttributeKey<T>, T) - Method in class io.netty.bootstrap.ServerBootstrap
-
- childAttrs - Variable in class io.netty.bootstrap.ServerBootstrap
-
- childAttrs() - Method in class io.netty.bootstrap.ServerBootstrap
-
- childAttrs - Variable in class io.netty.bootstrap.ServerBootstrap.ServerBootstrapAcceptor
-
- childAttrs() - Method in class io.netty.bootstrap.ServerBootstrapConfig
-
Returns a copy of the configured attributes which will be used for the child channels.
- childExecutor(EventExecutorGroup) - Method in class io.netty.channel.DefaultChannelPipeline
-
- childExecutors - Variable in class io.netty.channel.DefaultChannelPipeline
-
- childGroup - Variable in class io.netty.bootstrap.ServerBootstrap
-
- childGroup() - Method in class io.netty.bootstrap.ServerBootstrap
-
- childGroup - Variable in class io.netty.bootstrap.ServerBootstrap.ServerBootstrapAcceptor
-
- 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 - Variable in class io.netty.bootstrap.ServerBootstrap
-
- childHandler(ChannelHandler) - Method in class io.netty.bootstrap.ServerBootstrap
-
- childHandler() - Method in class io.netty.bootstrap.ServerBootstrap
-
- childHandler - Variable in class io.netty.bootstrap.ServerBootstrap.ServerBootstrapAcceptor
-
- 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.
- childListener - Variable in class io.netty.channel.group.DefaultChannelGroupFuture
-
- 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 - Variable in class io.netty.bootstrap.ServerBootstrap
-
- childOptions() - Method in class io.netty.bootstrap.ServerBootstrap
-
- childOptions - Variable in class io.netty.bootstrap.ServerBootstrap.ServerBootstrapAcceptor
-
- childOptions() - Method in class io.netty.bootstrap.ServerBootstrapConfig
-
Returns a copy of the configured options which will be used for the child channels.
- children - Variable in class io.netty.handler.codec.redis.ArrayRedisMessage
-
- children() - Method in class io.netty.handler.codec.redis.ArrayRedisMessage
-
Get children of this Arrays.
- children - Variable in class io.netty.handler.codec.redis.RedisArrayAggregator.AggregateState
-
- children - Variable in class io.netty.util.concurrent.MultithreadEventExecutorGroup
-
- childTerminationListener - Variable in class io.netty.channel.ThreadPerChannelEventLoopGroup
-
- chooser - Variable in class io.netty.util.concurrent.MultithreadEventExecutorGroup
-
- chunk - Variable in class io.netty.buffer.PooledByteBuf
-
- chunk - Variable in class io.netty.buffer.PoolSubpage
-
- chunk - Variable in class io.netty.buffer.PoolThreadCache.MemoryRegionCache.Entry
-
- 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
-
- 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
-
- ChunkedWriteHandler.PendingWrite - Class in io.netty.handler.stream
-
- chunkLength - Variable in class io.netty.handler.codec.compression.FastLzFrameDecoder
-
Length of current received chunk of data.
- chunkListMetrics - Variable in class io.netty.buffer.PoolArena
-
- chunkLists() - Method in class io.netty.buffer.PoolArena
-
- chunkLists() - Method in interface io.netty.buffer.PoolArenaMetric
-
- chunkSize - Variable in class io.netty.buffer.PoolArena
-
- chunkSize - Variable in class io.netty.buffer.PoolChunk
-
- chunkSize() - Method in class io.netty.buffer.PoolChunk
-
- 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 - Variable in class io.netty.buffer.PooledByteBufAllocator
-
- chunkSize() - Method in class io.netty.buffer.PooledByteBufAllocator
-
- chunkSize() - Method in class io.netty.buffer.PooledByteBufAllocatorMetric
-
Return the chunk size for an arena.
- chunkSize - Variable in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheDecoder
-
- chunkSize - Variable in class io.netty.handler.stream.ChunkedFile
-
- chunkSize - Variable in class io.netty.handler.stream.ChunkedNioFile
-
- chunkSize - Variable in class io.netty.handler.stream.ChunkedNioStream
-
- chunkSize - Variable in class io.netty.handler.stream.ChunkedStream
-
- ChunkType() - Constructor for enum io.netty.handler.codec.compression.SnappyFrameDecoder.ChunkType
-
- cipherFilter - Variable in class io.netty.handler.ssl.SslContextBuilder
-
- ciphers - Variable in class io.netty.handler.ssl.SslContextBuilder
-
- 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.
- CipherSuiteConverter - Class in io.netty.handler.ssl
-
Converts a Java cipher suite string to an OpenSSL cipher suite string and vice versa.
- CipherSuiteConverter() - Constructor for class io.netty.handler.ssl.CipherSuiteConverter
-
- 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 - Variable in class io.netty.handler.ssl.JdkSslContext
-
- 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
- classCache - Variable in class io.netty.handler.codec.serialization.CachingClassResolver
-
- classLoader - Variable in class io.netty.handler.codec.serialization.ClassLoaderClassResolver
-
- ClassLoaderClassResolver - Class in io.netty.handler.codec.serialization
-
- ClassLoaderClassResolver(ClassLoader) - Constructor for class io.netty.handler.codec.serialization.ClassLoaderClassResolver
-
- ClassMatcher(Class<? extends Channel>) - Constructor for class io.netty.channel.group.ChannelMatchers.ClassMatcher
-
- ClassResolver - Interface in io.netty.handler.codec.serialization
-
- classResolver - Variable in class io.netty.handler.codec.serialization.CompactObjectInputStream
-
- classResolver - Variable in class io.netty.handler.codec.serialization.ObjectDecoder
-
- classResolver - Variable in class io.netty.handler.codec.serialization.ObjectDecoderInputStream
-
- ClassResolvers - Class in io.netty.handler.codec.serialization
-
- ClassResolvers() - Constructor for class io.netty.handler.codec.serialization.ClassResolvers
-
- classToByteArray(Class<?>) - Static method in class io.netty.util.internal.NativeLibraryLoader
-
Load the helper Class
as a byte array, to be redefined in specified ClassLoader
.
- clazz - Variable in class io.netty.channel.group.ChannelMatchers.ClassMatcher
-
- clazz - Variable in class io.netty.channel.ReflectiveChannelFactory
-
- CLEAN_METHOD - Static variable in class io.netty.util.internal.CleanerJava6
-
- cleanArray() - Method in class io.netty.channel.kqueue.KQueueEventLoop
-
- Cleaner - Interface in io.netty.util.internal
-
Allows to free direct ByteBuffer
s.
- CLEANER - Static variable in class io.netty.util.internal.PlatformDependent
-
- CLEANER_FIELD_OFFSET - Static variable in class io.netty.util.internal.CleanerJava6
-
- CleanerJava6 - Class in io.netty.util.internal
-
Allows to free direct ByteBuffer
by using Cleaner.
- CleanerJava6() - Constructor for class io.netty.util.internal.CleanerJava6
-
- CleanerJava9 - Class in io.netty.util.internal
-
Provide a way to clean a ByteBuffer on Java9+.
- CleanerJava9() - Constructor for class io.netty.util.internal.CleanerJava9
-
- cleanSession - Variable in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
-
- cleanSession(boolean) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
-
- cleanup() - Method in class io.netty.channel.kqueue.KQueueEventLoop
-
- cleanup() - Method in class io.netty.channel.nio.NioEventLoop
-
- cleanup() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
Do nothing, sub-classes may override
- CLEANUP_INTERVAL - Static variable in class io.netty.channel.nio.NioEventLoop
-
- 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.buffer.WrappedByteBuf
-
- clear() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- clear() - Method in class io.netty.channel.group.DefaultChannelGroup
-
- clear() - Method in class io.netty.channel.kqueue.KQueueEventArray
-
- clear() - Method in class io.netty.channel.kqueue.NativeLongArray
-
- clear() - Method in class io.netty.channel.unix.IovArray
-
- clear() - Method in class io.netty.handler.codec.CodecOutputList
-
- 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(int) - 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.handler.codec.HeadersUtils.DelegatingStringSet
-
- clear() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- clear() - Method in class io.netty.handler.codec.serialization.ReferenceMap
-
- 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.ByteCollections.EmptyMap
-
- clear() - Method in class io.netty.util.collection.ByteCollections.UnmodifiableMap
-
- clear() - Method in class io.netty.util.collection.ByteObjectHashMap
-
- clear() - Method in class io.netty.util.collection.ByteObjectHashMap.KeySet
-
- clear() - Method in class io.netty.util.collection.CharCollections.EmptyMap
-
- clear() - Method in class io.netty.util.collection.CharCollections.UnmodifiableMap
-
- clear() - Method in class io.netty.util.collection.CharObjectHashMap
-
- clear() - Method in class io.netty.util.collection.CharObjectHashMap.KeySet
-
- clear() - Method in class io.netty.util.collection.IntCollections.EmptyMap
-
- clear() - Method in class io.netty.util.collection.IntCollections.UnmodifiableMap
-
- clear() - Method in class io.netty.util.collection.IntObjectHashMap
-
- clear() - Method in class io.netty.util.collection.IntObjectHashMap.KeySet
-
- clear() - Method in class io.netty.util.collection.LongCollections.EmptyMap
-
- clear() - Method in class io.netty.util.collection.LongCollections.UnmodifiableMap
-
- clear() - Method in class io.netty.util.collection.LongObjectHashMap
-
- clear() - Method in class io.netty.util.collection.LongObjectHashMap.KeySet
-
- clear() - Method in class io.netty.util.collection.ShortCollections.EmptyMap
-
- clear() - Method in class io.netty.util.collection.ShortCollections.UnmodifiableMap
-
- clear() - Method in class io.netty.util.collection.ShortObjectHashMap
-
- clear() - Method in class io.netty.util.collection.ShortObjectHashMap.KeySet
-
- 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
-
- clearCache() - Static method in class io.netty.handler.ssl.CipherSuiteConverter
-
Clears the cache for testing purpose.
- clearNioBuffers() - Method in class io.netty.channel.ChannelOutboundBuffer
-
- clearOpWrite() - Method in class io.netty.channel.nio.AbstractNioByteChannel
-
- clearReadFilter() - Method in class io.netty.channel.kqueue.AbstractKQueueChannel
-
- clearReadFilter0() - Method in class io.netty.channel.kqueue.AbstractKQueueChannel.AbstractKQueueUnsafe
-
- 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
.
- clearReadPending0() - Method in class io.netty.channel.nio.AbstractNioChannel
-
- clearReadPending0() - Method in class io.netty.channel.socket.nio.NioDatagramChannel
-
- clearReadPending0() - Method in class io.netty.channel.socket.oio.OioServerSocketChannel
-
- clearReadPending0() - Method in class io.netty.channel.socket.oio.OioSocketChannel
-
- clearReadPendingRunnable - Variable in class io.netty.channel.nio.AbstractNioChannel
-
- clearReadPendingRunnable - Variable in class io.netty.channel.oio.AbstractOioChannel
-
- clearTimeouts(Set<Timeout>) - Method in class io.netty.util.HashedWheelTimer.HashedWheelBucket
-
Clear this bucket and return all not expired / cancelled
Timeout
s.
- clearUserDefinedWritability(int) - Method in class io.netty.channel.ChannelOutboundBuffer
-
- ClientAuth - Enum in io.netty.handler.ssl
-
Indicates the state of the SSLEngine
with respect to client authentication.
- ClientAuth() - Constructor for enum io.netty.handler.ssl.ClientAuth
-
- clientAuth - Variable in class io.netty.handler.ssl.JdkSslContext
-
- clientAuth - Variable in class io.netty.handler.ssl.SslContextBuilder
-
- clientAuth(ClientAuth) - Method in class io.netty.handler.ssl.SslContextBuilder
-
Sets the client authentication mode.
- clientBitField - Variable in class io.netty.handler.codec.haproxy.HAProxySSLTLV
-
- clientId - Variable in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
-
- clientId(String) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
-
- clientIdentifier - Variable in class io.netty.handler.codec.mqtt.MqttConnectPayload
-
- 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(ChannelPromise, Throwable, ClosedChannelException, boolean) - 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() - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- close(ChannelPromise) - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- close(ChannelPromise) - Method in interface io.netty.channel.Channel.Unsafe
-
- close(ChannelHandlerContext, ChannelPromise) - Method in class io.netty.channel.ChannelDuplexHandler
-
- CLOSE - Static variable in interface io.netty.channel.ChannelFutureListener
-
- close(ClosedChannelException) - Method in class io.netty.channel.ChannelOutboundBuffer
-
- 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.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- close(ChannelPromise) - Method in class io.netty.channel.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- close() - Method in class io.netty.channel.DefaultChannelPipeline
-
- close(ChannelPromise) - Method in class io.netty.channel.DefaultChannelPipeline
-
- close(ChannelHandlerContext, ChannelPromise) - Method in class io.netty.channel.DefaultChannelPipeline.HeadContext
-
- 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
-
- close(ChannelMatcher) - Method in interface io.netty.channel.group.ChannelGroup
-
- 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.nio.SelectedSelectionKeySetSelector
-
- 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(int) - Static method in class io.netty.channel.unix.FileDescriptor
-
- close() - Method in class io.netty.channel.unix.SocketWritableByteChannel
-
- close(ByteBuf) - Method in class io.netty.handler.codec.compression.Bzip2BlockCompressor
-
Compresses and writes out the block.
- close() - Method in class io.netty.handler.codec.compression.Bzip2Encoder
-
- close(ChannelPromise) - Method in class io.netty.handler.codec.compression.Bzip2Encoder
-
- 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(ChannelPromise) - Method in class io.netty.handler.codec.compression.ZlibEncoder
-
- 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
-
- 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.dns.InflightNameResolver
-
- 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() - Method in class io.netty.util.ResourceLeakDetector.DefaultResourceLeak
-
- close(T) - Method in class io.netty.util.ResourceLeakDetector.DefaultResourceLeak
-
- close(T) - Method in interface io.netty.util.ResourceLeakTracker
-
- CLOSE_CLOSED_CHANNEL_EXCEPTION - Static variable in class io.netty.channel.AbstractChannel
-
- CLOSE_ON_FAILURE - Static variable in interface io.netty.channel.ChannelFutureListener
-
- closeAfterContinueResponse(Object) - Method in class io.netty.handler.codec.memcache.AbstractMemcacheObjectAggregator
-
- closeAfterContinueResponse(Object) - Method in class io.netty.handler.codec.MessageAggregator
-
- closeAfterContinueResponse(Object) - Method in class io.netty.handler.codec.redis.RedisBulkStringAggregator
-
- closeAfterContinueResponse(Object) - Method in class io.netty.handler.codec.stomp.StompSubframeAggregator
-
- closeAll() - Method in class io.netty.channel.kqueue.KQueueEventLoop
-
- closeAll() - Method in class io.netty.channel.nio.NioEventLoop
-
- closeAndFail(Channel, Throwable, Promise<?>) - Static method in class io.netty.channel.pool.SimpleChannelPool
-
- closeBlock(ByteBuf) - Method in class io.netty.handler.codec.compression.Bzip2Encoder
-
- closeChannel(Channel) - Static method in class io.netty.channel.pool.SimpleChannelPool
-
- closed - Variable in class io.netty.buffer.ByteBufInputStream
-
- closed - Variable in class io.netty.channel.group.DefaultChannelGroup
-
- closed - Variable in class io.netty.channel.pool.FixedChannelPool
-
- closed - Variable in class io.netty.handler.stream.ChunkedStream
-
- closed - Variable in class io.netty.handler.timeout.ReadTimeoutHandler
-
- closed - Variable in class io.netty.handler.timeout.WriteTimeoutHandler
-
- CLOSED_IN - Static variable in class io.netty.channel.oio.OioByteStreamChannel
-
- CLOSED_OUT - Static variable in class io.netty.channel.oio.OioByteStreamChannel
-
- 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 - Variable in class io.netty.channel.AbstractChannel
-
- closeFuture() - Method in class io.netty.channel.AbstractChannel
-
- CloseFuture(AbstractChannel) - Constructor for class io.netty.channel.AbstractChannel.CloseFuture
-
- 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
-
- closeInbound() - Method in class io.netty.handler.ssl.JdkSslEngine
-
- closeInput(ChunkedInput<?>) - Static method in class io.netty.handler.stream.ChunkedWriteHandler
-
- closeLeak() - Method in class io.netty.buffer.SimpleLeakAwareByteBuf
-
- closeLeak(ByteBuf) - Method in class io.netty.buffer.SimpleLeakAwareCompositeByteBuf
-
- closeNotifyFlushTimeoutMillis - Variable in class io.netty.handler.ssl.SslHandler
-
- closeNotifyReadTimeoutMillis - Variable in class io.netty.handler.ssl.SslHandler
-
- closeOnRead(ChannelPipeline) - Method in class io.netty.channel.nio.AbstractNioByteChannel.NioByteUnsafe
-
- closeOnRead(ChannelPipeline) - Method in class io.netty.channel.oio.AbstractOioByteChannel
-
- closeOnReadError(Throwable) - Method in class io.netty.channel.nio.AbstractNioMessageChannel
-
- closeOnReadError(Throwable) - Method in class io.netty.channel.socket.nio.NioDatagramChannel
-
- closeOutbound() - Method in class io.netty.handler.ssl.JdkSslEngine
-
- closeOutboundAndChannel(ChannelHandlerContext, ChannelPromise, boolean) - Method in class io.netty.handler.ssl.SslHandler
-
- closeQuietly(Closeable) - Static method in class io.netty.util.internal.NativeLibraryLoader
-
- closeSelector(String, Selector) - Static method in class io.netty.channel.sctp.oio.OioSctpChannel
-
- cmdStatus - Variable in class io.netty.handler.codec.socks.SocksCmdResponse
-
- cmdStatus() - Method in class io.netty.handler.codec.socks.SocksCmdResponse
-
- cmdStatus - Variable in class io.netty.handler.codec.socks.SocksCmdResponseDecoder
-
- cmdType - Variable in class io.netty.handler.codec.socks.SocksCmdRequest
-
- cmdType() - Method in class io.netty.handler.codec.socks.SocksCmdRequest
-
- cmdType - Variable in class io.netty.handler.codec.socks.SocksCmdRequestDecoder
-
- 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.
- CNAME_NOT_FOUND_QUERY_FAILED_EXCEPTION - Static variable in class io.netty.resolver.dns.DnsNameResolverContext
-
- 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 - Variable in class io.netty.handler.codec.dns.DefaultDnsResponse
-
- 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 - Variable in class io.netty.handler.codec.dns.DnsResponseCode
-
- code - Variable in class io.netty.handler.codec.smtp.DefaultSmtpResponse
-
- code() - Method in class io.netty.handler.codec.smtp.DefaultSmtpResponse
-
- code() - Method in interface io.netty.handler.codec.smtp.SmtpResponse
-
Returns the response code.
- codeBases - Variable in class io.netty.handler.codec.compression.Bzip2HuffmanStageDecoder
-
An array of values for each Huffman table that must be subtracted from the numerical value of
a Huffman code of a given bit length to give its canonical code index.
- 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.
- CodecOutputList - Class in io.netty.handler.codec
-
Special AbstractList
implementation which is used within our codec base classes.
- CodecOutputList(Recycler.Handle<CodecOutputList>) - Constructor for class io.netty.handler.codec.CodecOutputList
-
- codeLimits - Variable in class io.netty.handler.codec.compression.Bzip2HuffmanStageDecoder
-
An array of values for each Huffman table that gives the highest numerical value of a Huffman
code of a given bit length.
- codeSymbols - Variable in class io.netty.handler.codec.compression.Bzip2HuffmanStageDecoder
-
A mapping for each Huffman table from canonical code index to output symbol.
- COLON - Static variable in class io.netty.handler.codec.stomp.StompConstants
-
- com.sun.nio.sctp - package com.sun.nio.sctp
-
This package is only included to let SCTP also compile on non-unix operation systems.
- 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.
- CombinedChannelDuplexHandler.DelegatingChannelHandlerContext - Class in io.netty.channel
-
- CombinedIterator<E> - Class in io.netty.channel.group
-
- CombinedIterator(Iterator<E>, Iterator<E>) - Constructor for class io.netty.channel.group.CombinedIterator
-
- COMMA - Static variable in class io.netty.util.internal.StringUtil
-
- command - Variable in class io.netty.handler.codec.haproxy.HAProxyMessage
-
- command() - Method in class io.netty.handler.codec.haproxy.HAProxyMessage
-
- command - Variable in class io.netty.handler.codec.smtp.DefaultSmtpRequest
-
- command() - Method in class io.netty.handler.codec.smtp.DefaultSmtpRequest
-
- command() - Method in interface io.netty.handler.codec.smtp.SmtpRequest
-
- 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.
- COMMAND_LOCAL_BYTE - Static variable in class io.netty.handler.codec.haproxy.HAProxyConstants
-
Command byte constants
- COMMAND_MASK - Static variable in enum io.netty.handler.codec.haproxy.HAProxyCommand
-
The command is specified in the lowest 4 bits of the protocol version and command byte
- COMMAND_PROXY_BYTE - Static variable in class io.netty.handler.codec.haproxy.HAProxyConstants
-
- COMMAND_UNSUPPORTED - Static variable in class io.netty.handler.codec.socksx.v5.Socks5CommandStatus
-
- COMMANDS - Static variable in class io.netty.handler.codec.smtp.SmtpCommand
-
- commitTimeMillis - Variable in class io.netty.util.Version
-
- commitTimeMillis() - Method in class io.netty.util.Version
-
- CommonsLogger - Class in io.netty.util.internal.logging
-
- CommonsLogger(Log, String) - Constructor for class io.netty.util.internal.logging.CommonsLogger
-
Deprecated.
- CommonsLoggerFactory - Class in io.netty.util.internal.logging
-
- CommonsLoggerFactory() - Constructor for class io.netty.util.internal.logging.CommonsLoggerFactory
-
- commonSuffixOfLength(String, String, int) - Static method in class io.netty.util.internal.StringUtil
-
Checks if two strings have the same suffix of specified length
- CompactObjectInputStream - Class in io.netty.handler.codec.serialization
-
- CompactObjectInputStream(InputStream, ClassResolver) - Constructor for class io.netty.handler.codec.serialization.CompactObjectInputStream
-
- CompactObjectOutputStream - Class in io.netty.handler.codec.serialization
-
- CompactObjectOutputStream(OutputStream) - Constructor for class io.netty.handler.codec.serialization.CompactObjectOutputStream
-
- comparator - Variable in class io.netty.util.internal.DefaultPriorityQueue
-
- compare(ByteBuf, ByteBuf) - Static method in class io.netty.buffer.ByteBufUtil
-
- 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.
- compareAddresses(byte[], byte[]) - Static method in class io.netty.util.internal.MacAddressUtil
-
- compareAddresses(InetAddress, InetAddress) - Static method in class io.netty.util.internal.MacAddressUtil
-
- 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.
- compareAndSetState(int, int) - Method in class io.netty.util.HashedWheelTimer.HashedWheelTimeout
-
- 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(ByteBuf) - Method in class io.netty.buffer.WrappedByteBuf
-
- compareTo(ByteBuf) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- compareTo(Channel) - Method in class io.netty.channel.AbstractChannel
-
- compareTo(ChannelId) - Method in class io.netty.channel.DefaultChannelId
-
- compareTo(ChannelId) - Method in class io.netty.channel.embedded.EmbeddedChannelId
-
- 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(ByteBuf) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- compareTo(Socks4CommandStatus) - Method in class io.netty.handler.codec.socksx.v4.Socks4CommandStatus
-
- compareTo(Socks4CommandType) - Method in class io.netty.handler.codec.socksx.v4.Socks4CommandType
-
- compareTo(Socks5AddressType) - Method in class io.netty.handler.codec.socksx.v5.Socks5AddressType
-
- compareTo(Socks5AuthMethod) - Method in class io.netty.handler.codec.socksx.v5.Socks5AuthMethod
-
- compareTo(Socks5CommandStatus) - Method in class io.netty.handler.codec.socksx.v5.Socks5CommandStatus
-
- compareTo(Socks5CommandType) - Method in class io.netty.handler.codec.socksx.v5.Socks5CommandType
-
- compareTo(Socks5PasswordAuthStatus) - Method in class io.netty.handler.codec.socksx.v5.Socks5PasswordAuthStatus
-
- 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(Delayed) - Method in class io.netty.util.concurrent.ScheduledFutureTask
-
- compareTo(Delayed) - Method in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor.RunnableScheduledFutureTask
-
- compareTo(Signal) - Method in error io.netty.util.Signal
-
- compareUintBigEndian(ByteBuf, ByteBuf, int, int, int) - Static method in class io.netty.buffer.ByteBufUtil
-
- compareUintBigEndianA(ByteBuf, ByteBuf, int, int, int) - Static method in class io.netty.buffer.ByteBufUtil
-
- compareUintBigEndianB(ByteBuf, ByteBuf, int, int, int) - Static method in class io.netty.buffer.ByteBufUtil
-
- compareUintLittleEndian(ByteBuf, ByteBuf, int, int, int) - Static method in class io.netty.buffer.ByteBufUtil
-
- 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.
- CompleteChannelFuture - Class in io.netty.channel
-
- CompleteChannelFuture(Channel, EventExecutor) - Constructor for class io.netty.channel.CompleteChannelFuture
-
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
- Component(ByteBuf) - Constructor for class io.netty.buffer.CompositeByteBuf.Component
-
- Component(int, int, ByteBuf) - Constructor for class io.netty.buffer.FixedCompositeByteBuf.Component
-
- component(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- componentAtOffset(int) - Method in class io.netty.buffer.CompositeByteBuf
-
Return the
ByteBuf
on the specified index
- componentAtOffset(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- components - Variable in class io.netty.buffer.CompositeByteBuf
-
- compose(ByteBuf, ByteBuf) - Method in class io.netty.channel.CoalescingBufferQueue
-
Compose the current buffer with another.
- compose(ChannelMatcher...) - Static method in class io.netty.channel.group.ChannelMatchers
-
- COMPOSITE_CUMULATOR - Static variable in class io.netty.handler.codec.ByteToMessageDecoder
-
- 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
-
- 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.
- compositeBuffer() - Method in class io.netty.channel.local.PreferHeapByteBufAllocator
-
- compositeBuffer(int) - Method in class io.netty.channel.local.PreferHeapByteBufAllocator
-
- 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, ByteBuf[], int, int) - Constructor for class io.netty.buffer.CompositeByteBuf
-
- CompositeByteBuf(ByteBufAllocator, boolean, int, Iterable<ByteBuf>) - Constructor for class io.netty.buffer.CompositeByteBuf
-
- CompositeByteBuf(ByteBufAllocator) - Constructor for class io.netty.buffer.CompositeByteBuf
-
- CompositeByteBuf.Component - Class in io.netty.buffer
-
- CompositeByteBuf.CompositeByteBufIterator - Class in io.netty.buffer
-
- CompositeByteBufIterator() - Constructor for class io.netty.buffer.CompositeByteBuf.CompositeByteBufIterator
-
- 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
-
- 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
-
- compositeDirectBuffer() - Method in class io.netty.channel.local.PreferHeapByteBufAllocator
-
- compositeDirectBuffer(int) - Method in class io.netty.channel.local.PreferHeapByteBufAllocator
-
- 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
-
- 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
-
- compositeHeapBuffer() - Method in class io.netty.channel.local.PreferHeapByteBufAllocator
-
- compositeHeapBuffer(int) - Method in class io.netty.channel.local.PreferHeapByteBufAllocator
-
- CompositeMatcher(ChannelMatcher...) - Constructor for class io.netty.channel.group.ChannelMatchers.CompositeMatcher
-
- CompositeNameResolver<T> - Class in io.netty.resolver
-
- CompositeNameResolver(EventExecutor, NameResolver<T>...) - Constructor for class io.netty.resolver.CompositeNameResolver
-
- compress(byte[], int, int, byte[], int, int) - Static method in class io.netty.handler.codec.compression.FastLz
-
Compress a block of data in the input buffer and returns the size of compressed block.
- CompressionException - Exception in io.netty.handler.codec.compression
-
- 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.
- CompressionUtil - Class in io.netty.handler.codec.compression
-
- CompressionUtil() - Constructor for class io.netty.handler.codec.compression.CompressionUtil
-
- computeBalancedWait(float, float, long) - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
-
- computeDate() - Method in class io.netty.handler.codec.DateFormatter
-
- computeDeviationCumulativeBytes() - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
-
- computeRemoteAddr(InetSocketAddress, InetSocketAddress) - Static method in class io.netty.channel.kqueue.KQueueSocketChannel
-
- 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
-
- config - Variable in class io.netty.bootstrap.Bootstrap
-
- config() - Method in class io.netty.bootstrap.Bootstrap
-
- config - Variable in class io.netty.bootstrap.ServerBootstrap
-
- config() - Method in class io.netty.bootstrap.ServerBootstrap
-
- config() - Method in interface io.netty.channel.Channel
-
Returns the configuration of this channel.
- config - Variable in class io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator.MaxMessageHandle
-
- config - Variable in class io.netty.channel.embedded.EmbeddedChannel
-
- config() - Method in class io.netty.channel.embedded.EmbeddedChannel
-
- config() - Method in class io.netty.channel.kqueue.AbstractKQueueChannel
-
- config - Variable in class io.netty.channel.kqueue.KQueueDatagramChannel
-
- config() - Method in class io.netty.channel.kqueue.KQueueDatagramChannel
-
- config - Variable in class io.netty.channel.kqueue.KQueueDomainSocketChannel
-
- config() - Method in class io.netty.channel.kqueue.KQueueDomainSocketChannel
-
- config - Variable in class io.netty.channel.kqueue.KQueueServerDomainSocketChannel
-
- config() - Method in class io.netty.channel.kqueue.KQueueServerDomainSocketChannel
-
- config - Variable in class io.netty.channel.kqueue.KQueueServerSocketChannel
-
- config() - Method in class io.netty.channel.kqueue.KQueueServerSocketChannel
-
- config - Variable in class io.netty.channel.kqueue.KQueueSocketChannel
-
- config() - Method in class io.netty.channel.kqueue.KQueueSocketChannel
-
- config - Variable in class io.netty.channel.local.LocalChannel
-
- config() - Method in class io.netty.channel.local.LocalChannel
-
- config - Variable in class io.netty.channel.local.LocalServerChannel
-
- config() - Method in class io.netty.channel.local.LocalServerChannel
-
- config - Variable in class io.netty.channel.sctp.nio.NioSctpChannel
-
- config() - Method in class io.netty.channel.sctp.nio.NioSctpChannel
-
- config - Variable in class io.netty.channel.sctp.nio.NioSctpServerChannel
-
- config() - Method in class io.netty.channel.sctp.nio.NioSctpServerChannel
-
- config - Variable in class io.netty.channel.sctp.oio.OioSctpChannel
-
- config() - Method in class io.netty.channel.sctp.oio.OioSctpChannel
-
- config - Variable in class io.netty.channel.sctp.oio.OioSctpServerChannel
-
- config() - Method in class io.netty.channel.sctp.oio.OioSctpServerChannel
-
- config() - Method in interface io.netty.channel.sctp.SctpChannel
-
- config() - Method in interface io.netty.channel.sctp.SctpServerChannel
-
- config() - Method in interface io.netty.channel.socket.DatagramChannel
-
- config - Variable in class io.netty.channel.socket.nio.NioDatagramChannel
-
- config() - Method in class io.netty.channel.socket.nio.NioDatagramChannel
-
- config - Variable in class io.netty.channel.socket.nio.NioServerSocketChannel
-
- config() - Method in class io.netty.channel.socket.nio.NioServerSocketChannel
-
- config - Variable in class io.netty.channel.socket.nio.NioSocketChannel
-
- config() - Method in class io.netty.channel.socket.nio.NioSocketChannel
-
- config - Variable in class io.netty.channel.socket.oio.OioDatagramChannel
-
- config() - Method in class io.netty.channel.socket.oio.OioDatagramChannel
-
- config - Variable in class io.netty.channel.socket.oio.OioServerSocketChannel
-
- config() - Method in class io.netty.channel.socket.oio.OioServerSocketChannel
-
- config - Variable in class io.netty.channel.socket.oio.OioSocketChannel
-
- 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
-
- config - Variable in class io.netty.handler.flow.FlowControlHandler
-
- config - Variable in class io.netty.handler.ssl.OpenSslDefaultApplicationProtocolNegotiator
-
- 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.
- configureAndWrapEngine(SSLEngine) - Method in class io.netty.handler.ssl.JdkSslContext
-
- 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
-
- ConnAckBuilder() - Constructor for class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnAckBuilder
-
- connect(SocketAddress) - Method in class com.sun.nio.sctp.SctpChannel
-
- 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) - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- connect(SocketAddress, SocketAddress) - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- connect(SocketAddress, ChannelPromise) - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- connect(SocketAddress, SocketAddress, ChannelPromise) - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- connect(SocketAddress, SocketAddress, ChannelPromise) - Method in class io.netty.channel.AbstractServerChannel.DefaultServerUnsafe
-
- connect(SocketAddress, SocketAddress, ChannelPromise) - Method in interface io.netty.channel.Channel.Unsafe
-
- 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.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- connect(SocketAddress, SocketAddress) - Method in class io.netty.channel.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- connect(SocketAddress, ChannelPromise) - Method in class io.netty.channel.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- connect(SocketAddress, SocketAddress, ChannelPromise) - Method in class io.netty.channel.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- 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(ChannelHandlerContext, SocketAddress, SocketAddress, ChannelPromise) - Method in class io.netty.channel.DefaultChannelPipeline.HeadContext
-
- connect(SocketAddress, SocketAddress, ChannelPromise) - Method in class io.netty.channel.embedded.EmbeddedChannel.DefaultUnsafe
-
- connect(SocketAddress, SocketAddress, ChannelPromise) - Method in class io.netty.channel.kqueue.AbstractKQueueServerChannel.KQueueServerSocketUnsafe
-
- connect(SocketAddress, SocketAddress, ChannelPromise) - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel.KQueueStreamUnsafe
-
- connect(SocketAddress, SocketAddress, ChannelPromise) - Method in class io.netty.channel.kqueue.KQueueDatagramChannel.KQueueDatagramChannelUnsafe
-
- connect(SocketAddress, SocketAddress, ChannelPromise) - Method in class io.netty.channel.local.LocalChannel.LocalUnsafe
-
- connect(SocketAddress, SocketAddress, ChannelPromise) - Method in class io.netty.channel.nio.AbstractNioChannel.AbstractNioUnsafe
-
- connect(SocketAddress, SocketAddress, ChannelPromise) - Method in class io.netty.channel.oio.AbstractOioChannel.DefaultOioUnsafe
-
- connect(SocketAddress) - Method in class io.netty.channel.unix.Socket
-
- connect(int, byte[], int, int) - Static 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 - Static variable in class io.netty.handler.codec.socksx.v4.Socks4CommandType
-
- CONNECT - Static variable in class io.netty.handler.codec.socksx.v5.Socks5CommandType
-
- 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_REFUSED_EXCEPTION - Static variable in class io.netty.channel.unix.Socket
-
- CONNECT_TIMEOUT_MILLIS - Static variable in class io.netty.channel.ChannelOption
-
- ConnectBuilder() - Constructor for class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
-
- connectChannel(Bootstrap) - Method in class io.netty.channel.pool.SimpleChannelPool
-
- connectDomainSocket(int, byte[]) - Static method in class io.netty.channel.unix.Socket
-
- connected - Variable in class io.netty.channel.kqueue.KQueueDatagramChannel
-
- connected - Variable in class io.netty.handler.ipfilter.UniqueIpFilter
-
- CONNECTION_REFUSED - Static variable in class io.netty.handler.codec.socksx.v5.Socks5CommandStatus
-
- CONNECTION_RESET_EXCEPTION_SENDMSG - Static variable in class io.netty.channel.unix.Socket
-
- CONNECTION_RESET_SHUTDOWN_EXCEPTION - Static variable in class io.netty.channel.unix.Socket
-
- connectPromise - Variable in class io.netty.channel.kqueue.AbstractKQueueStreamChannel
-
- connectPromise - Variable in class io.netty.channel.local.LocalChannel
-
- connectPromise - Variable in class io.netty.channel.nio.AbstractNioChannel
-
The future of the current connection attempt.
- connectReturnCode - Variable in class io.netty.handler.codec.mqtt.MqttConnAckVariableHeader
-
- connectReturnCode() - Method in class io.netty.handler.codec.mqtt.MqttConnAckVariableHeader
-
- connectSelector - Variable in class io.netty.channel.sctp.oio.OioSctpChannel
-
- 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
-
- connectTimeoutFuture - Variable in class io.netty.channel.kqueue.AbstractKQueueStreamChannel
-
- connectTimeoutFuture - Variable in class io.netty.channel.nio.AbstractNioChannel
-
- connectTimeoutMillis - Variable in class io.netty.channel.DefaultChannelConfig
-
- consolidate() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- consolidate(int, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- consolidate() - Method in class io.netty.buffer.CompositeByteBuf
-
- consolidate(int, int) - Method in class io.netty.buffer.CompositeByteBuf
-
- consolidate() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- consolidate(int, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- consolidateIfNeeded() - Method in class io.netty.buffer.CompositeByteBuf
-
This should only be called as last operation from a method as this may adjust the underlying
array of components and so affect the index etc.
- consolidateWhenNoReadInProgress - Variable in class io.netty.handler.flush.FlushConsolidationHandler
-
- Constant<T extends Constant<T>> - Interface in io.netty.util
-
A singleton which is safe to compare via the ==
operator.
- constant - Variable in error io.netty.util.Signal
-
- ConstantPool<T extends Constant<T>> - Class in io.netty.util
-
- ConstantPool() - Constructor for class io.netty.util.ConstantPool
-
- constants - Variable in class io.netty.util.ConstantPool
-
- ConstantTimeUtils - Class in io.netty.util.internal
-
- ConstantTimeUtils() - Constructor for class io.netty.util.internal.ConstantTimeUtils
-
- constructBWT(int[], int[]) - Method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- contains(Object) - Method in class io.netty.channel.group.DefaultChannelGroup
-
- contains(Object) - Method in class io.netty.channel.nio.SelectedSelectionKeySet
-
- 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(Object) - Method in class io.netty.handler.codec.HeadersUtils.DelegatingStringSet
-
- 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(CharSequence, CharSequence, AsciiString.CharEqualityComparator) - Static method in class io.netty.util.AsciiString
-
- contains(Object) - Method in class io.netty.util.collection.ByteObjectHashMap.KeySet
-
- contains(Object) - Method in class io.netty.util.collection.CharObjectHashMap.KeySet
-
- contains(Object) - Method in class io.netty.util.collection.IntObjectHashMap.KeySet
-
- contains(Object) - Method in class io.netty.util.collection.LongObjectHashMap.KeySet
-
- contains(Object) - Method in class io.netty.util.collection.ShortObjectHashMap.KeySet
-
- contains(Object) - Method in class io.netty.util.internal.ConcurrentSet
-
- contains(Object) - Method in class io.netty.util.internal.DefaultPriorityQueue
-
- contains(PriorityQueueNode, int) - 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.handler.codec.HeadersUtils.DelegatingStringSet
-
- containsAll(Collection<?>) - Method in class io.netty.util.internal.EmptyPriorityQueue
-
- containsAllContentEqualsIgnoreCase(Collection<CharSequence>, Collection<CharSequence>) - Static method in class io.netty.util.AsciiString
-
- 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
-
- 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(Object) - Method in class io.netty.handler.codec.serialization.ReferenceMap
-
- containsKey(Object) - Method in class io.netty.util.collection.ByteCollections.EmptyMap
-
- containsKey(byte) - Method in class io.netty.util.collection.ByteCollections.EmptyMap
-
- containsKey(byte) - Method in class io.netty.util.collection.ByteCollections.UnmodifiableMap
-
- containsKey(Object) - Method in class io.netty.util.collection.ByteCollections.UnmodifiableMap
-
- 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(Object) - Method in class io.netty.util.collection.CharCollections.EmptyMap
-
- containsKey(char) - Method in class io.netty.util.collection.CharCollections.EmptyMap
-
- containsKey(char) - Method in class io.netty.util.collection.CharCollections.UnmodifiableMap
-
- containsKey(Object) - Method in class io.netty.util.collection.CharCollections.UnmodifiableMap
-
- 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(Object) - Method in class io.netty.util.collection.IntCollections.EmptyMap
-
- containsKey(int) - Method in class io.netty.util.collection.IntCollections.EmptyMap
-
- containsKey(int) - Method in class io.netty.util.collection.IntCollections.UnmodifiableMap
-
- containsKey(Object) - Method in class io.netty.util.collection.IntCollections.UnmodifiableMap
-
- 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(Object) - Method in class io.netty.util.collection.LongCollections.EmptyMap
-
- containsKey(long) - Method in class io.netty.util.collection.LongCollections.EmptyMap
-
- containsKey(long) - Method in class io.netty.util.collection.LongCollections.UnmodifiableMap
-
- containsKey(Object) - Method in class io.netty.util.collection.LongCollections.UnmodifiableMap
-
- 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(Object) - Method in class io.netty.util.collection.ShortCollections.EmptyMap
-
- containsKey(short) - Method in class io.netty.util.collection.ShortCollections.EmptyMap
-
- containsKey(short) - Method in class io.netty.util.collection.ShortCollections.UnmodifiableMap
-
- containsKey(Object) - Method in class io.netty.util.collection.ShortCollections.UnmodifiableMap
-
- 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.handler.codec.serialization.ReferenceMap
-
- containsValue(Object) - Method in class io.netty.util.collection.ByteCollections.EmptyMap
-
- containsValue(Object) - Method in class io.netty.util.collection.ByteCollections.UnmodifiableMap
-
- containsValue(Object) - Method in class io.netty.util.collection.ByteObjectHashMap
-
- containsValue(Object) - Method in class io.netty.util.collection.CharCollections.EmptyMap
-
- containsValue(Object) - Method in class io.netty.util.collection.CharCollections.UnmodifiableMap
-
- containsValue(Object) - Method in class io.netty.util.collection.CharObjectHashMap
-
- containsValue(Object) - Method in class io.netty.util.collection.IntCollections.EmptyMap
-
- containsValue(Object) - Method in class io.netty.util.collection.IntCollections.UnmodifiableMap
-
- containsValue(Object) - Method in class io.netty.util.collection.IntObjectHashMap
-
- containsValue(Object) - Method in class io.netty.util.collection.LongCollections.EmptyMap
-
- containsValue(Object) - Method in class io.netty.util.collection.LongCollections.UnmodifiableMap
-
- containsValue(Object) - Method in class io.netty.util.collection.LongObjectHashMap
-
- containsValue(Object) - Method in class io.netty.util.collection.ShortCollections.EmptyMap
-
- containsValue(Object) - Method in class io.netty.util.collection.ShortCollections.UnmodifiableMap
-
- containsValue(Object) - Method in class io.netty.util.collection.ShortObjectHashMap
-
- content() - Method in interface io.netty.buffer.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 - Variable in class io.netty.handler.codec.dns.DefaultDnsRawRecord
-
- content() - Method in class io.netty.handler.codec.dns.DefaultDnsRawRecord
-
- content - Variable in class io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheRequest
-
- content() - Method in class io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheRequest
-
- content - Variable in class io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheResponse
-
- content() - Method in class io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheResponse
-
- content - Variable in class io.netty.handler.codec.memcache.DefaultMemcacheContent
-
- content() - Method in class io.netty.handler.codec.memcache.DefaultMemcacheContent
-
- content() - Method in class io.netty.handler.codec.mqtt.MqttPublishMessage
-
- content - Variable in class io.netty.handler.codec.redis.AbstractStringRedisMessage
-
- content() - Method in class io.netty.handler.codec.redis.AbstractStringRedisMessage
-
- content() - Method in class io.netty.handler.codec.redis.RedisDecoder.ToPositiveLongProcessor
-
- content - Variable in class io.netty.handler.codec.stomp.DefaultStompFrame
-
- content() - Method in class io.netty.handler.codec.stomp.DefaultStompFrame
-
- content - Variable in class io.netty.handler.ssl.PemPrivateKey
-
- content() - Method in class io.netty.handler.ssl.PemPrivateKey
-
- content - Variable in class io.netty.handler.ssl.PemValue
-
- content() - Method in class io.netty.handler.ssl.PemValue
-
- content - Variable in class io.netty.handler.ssl.PemX509Certificate
-
- 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.
- contentExpected - Variable in class io.netty.handler.codec.smtp.SmtpCommand
-
- contentExpected - Variable in class io.netty.handler.codec.smtp.SmtpRequestEncoder
-
- contentLength(Object) - Static method in class io.netty.handler.codec.memcache.AbstractMemcacheObjectEncoder
-
Determine the content length of the given object.
- contentLength - Variable in class io.netty.handler.codec.stomp.StompSubframeDecoder
-
- contentToString() - Method in class io.netty.buffer.DefaultByteBufHolder
-
- 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.
- context - Variable in class io.netty.handler.ssl.SniHandler.Selection
-
- context0(String) - Method in class io.netty.channel.DefaultChannelPipeline
-
- 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.DefaultMaxBytesRecvByteBufAllocator.HandleImpl
-
- continueReading(UncheckedBooleanSupplier) - Method in class io.netty.channel.DefaultMaxBytesRecvByteBufAllocator.HandleImpl
-
- continueReading() - Method in class io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator.MaxMessageHandle
-
- continueReading(UncheckedBooleanSupplier) - Method in class io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator.MaxMessageHandle
-
- continueReading(UncheckedBooleanSupplier) - Method in class io.netty.channel.kqueue.KQueueRecvByteAllocatorHandle
-
- continueReading() - Method in class io.netty.channel.kqueue.KQueueRecvByteAllocatorHandle
-
- continueReading() - Method in class io.netty.channel.RecvByteBufAllocator.DelegatingHandle
-
- continueReading(UncheckedBooleanSupplier) - Method in interface io.netty.channel.RecvByteBufAllocator.ExtendedHandle
-
- continueReading() - Method in interface io.netty.channel.RecvByteBufAllocator.Handle
-
Deprecated.
Determine if the current read loop should should continue.
- continueResponseWriteListener - Variable in class io.netty.handler.codec.MessageAggregator
-
- convert(InternetProtocolFamily) - Static method in class io.netty.channel.socket.nio.ProtocolFamilyConverter
-
- 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
-
- convertWrapperType(ZlibWrapper) - Static method in class io.netty.handler.codec.compression.ZlibUtil
-
- 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
.
- copiedBuffer(CharBuffer, Charset) - Static method in class io.netty.buffer.Unpooled
-
- copiedMap(Map<K, V>) - Static method in class io.netty.bootstrap.AbstractBootstrap
-
- copy() - Method in class io.netty.buffer.AbstractByteBuf
-
- copy(int, int) - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- copy() - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- copy(int, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- copy() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- copy(int, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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
-
- copy(AsciiString, ByteBuf) - Static method in class io.netty.buffer.ByteBufUtil
-
- copy(AsciiString, int, ByteBuf, int, int) - Static method in class io.netty.buffer.ByteBufUtil
-
- copy(AsciiString, int, ByteBuf, int) - Static method in class io.netty.buffer.ByteBufUtil
-
- copy(int, int) - Method in class io.netty.buffer.CompositeByteBuf
-
- copy() - Method in class io.netty.buffer.DefaultByteBufHolder
-
- 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.FixedCompositeByteBuf
-
- copy(int, int) - Method in class io.netty.buffer.PooledDirectByteBuf
-
- copy(int, int) - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- copy(int, int) - Method in class io.netty.buffer.PooledHeapByteBuf
-
- copy(int, int) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- copy(int, int) - Method in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- copy(int, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
-
Deprecated.
- copy(int, int) - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- copy(int, int) - Method in class io.netty.buffer.ReadOnlyUnsafeDirectByteBuf
-
- 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(AbstractByteBuf, long, int, int) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- copy() - Method in class io.netty.buffer.WrappedByteBuf
-
- copy(int, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- copy() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- copy(int, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- copy() - Method in class io.netty.channel.sctp.SctpMessage
-
- 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.haproxy.HAProxyTLV
-
- 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.ReplayingDecoderByteBuf
-
- copy(int, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- 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 interface io.netty.handler.ssl.PemEncoded
-
- copy() - Method in class io.netty.handler.ssl.PemPrivateKey
-
- copy() - Method in class io.netty.handler.ssl.PemValue
-
- 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.
- COPY_1_BYTE_OFFSET - Static variable in class io.netty.handler.codec.compression.Snappy
-
- COPY_2_BYTE_OFFSET - Static variable in class io.netty.handler.codec.compression.Snappy
-
- COPY_4_BYTE_OFFSET - Static variable in class io.netty.handler.codec.compression.Snappy
-
- 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
-
- copyMemory(long, long, long) - Static method in class io.netty.util.internal.PlatformDependent0
-
- copyMemory(Object, long, Object, long, long) - Static method in class io.netty.util.internal.PlatformDependent0
-
- 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(int, int, int, ByteBuf) - Method in class io.netty.buffer.CompositeByteBuf
-
- copyTo(CoalescingBufferQueue) - Method in class io.netty.channel.CoalescingBufferQueue
-
Copy all pending entries in this queue into the destination queue.
- corrupted - Variable in class io.netty.handler.codec.compression.SnappyFrameDecoder
-
- 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 - Variable in class io.netty.channel.ChannelOutboundBuffer.Entry
-
- count - Variable in class io.netty.channel.DefaultFileRegion
-
- count() - Method in class io.netty.channel.DefaultFileRegion
-
- count() - Method in interface io.netty.channel.FileRegion
-
Returns the number of bytes to transfer.
- count - Variable in class io.netty.channel.unix.IovArray
-
- 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(int) - 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.
- count - Variable in class io.netty.resolver.dns.DnsNameResolverContext.AuthoritativeNameServerList
-
- counter - Variable in class io.netty.handler.traffic.GlobalChannelTrafficCounter.MixedTrafficMonitoringTask
-
The associated TrafficCounter
- counterHashCode() - Method in class io.netty.util.internal.InternalThreadLocalMap
-
- counterHashCode - Variable in class io.netty.util.internal.UnpaddedInternalThreadLocalMap
-
- CR - Static variable in class io.netty.handler.codec.stomp.StompConstants
-
- crc - Variable in class io.netty.handler.codec.compression.Bzip2BlockCompressor
-
CRC builder for the block.
- crc() - Method in class io.netty.handler.codec.compression.Bzip2BlockCompressor
-
Gets the CRC of the completed block.
- crc - Variable in class io.netty.handler.codec.compression.Bzip2BlockDecompressor
-
Calculates the block CRC from the fully decoded bytes of the block.
- crc - Variable in class io.netty.handler.codec.compression.Crc32
-
The current CRC.
- crc - Variable in class io.netty.handler.codec.compression.Crc32c
-
- crc - Variable in class io.netty.handler.codec.compression.JdkZlibDecoder
-
- crc - Variable in class io.netty.handler.codec.compression.JdkZlibEncoder
-
- Crc32 - Class in io.netty.handler.codec.compression
-
A CRC32 calculator.
- Crc32() - Constructor for class io.netty.handler.codec.compression.Crc32
-
- CRC32_UPDATE_METHOD - Static variable in class io.netty.handler.codec.compression.ByteBufChecksum
-
- Crc32c - Class in io.netty.handler.codec.compression
-
Implements CRC32-C as defined in:
"Optimization of Cyclic Redundancy-CHeck Codes with 24 and 32 Parity Bits",
IEEE Transactions on Communications 41(6): 883-892 (1993).
- Crc32c() - Constructor for class io.netty.handler.codec.compression.Crc32c
-
- crc32c(int, int) - Static method in class io.netty.handler.codec.compression.Crc32c
-
- crc32Table - Static variable in class io.netty.handler.codec.compression.Crc32
-
A static CRC lookup table.
- CRC_TABLE - Static variable in class io.netty.handler.codec.compression.Crc32c
-
- create(int, int) - Static method in class com.sun.nio.sctp.SctpStandardSocketOptions.InitMaxStreams
-
- createByteArrayFromIpAddressString(String) - Static method in class io.netty.util.NetUtil
-
Creates an byte[] based on an ipAddressString.
- createGlobalTrafficCounter(ScheduledExecutorService) - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
-
Create the global TrafficCounter
- createGlobalTrafficCounter(ScheduledExecutorService) - Method in class io.netty.handler.traffic.GlobalTrafficShapingHandler
-
Create the global TrafficCounter.
- createHuffmanDecodingTables() - Method in class io.netty.handler.codec.compression.Bzip2HuffmanStageDecoder
-
Constructs Huffman decoding tables from lists of Canonical Huffman code lengths.
- createNormalCaches(int, int, PoolArena<T>) - Static method in class io.netty.buffer.PoolThreadCache
-
- createOrThrow(String) - Method in class io.netty.util.ConstantPool
-
Creates constant by name or throws exception.
- createOutgoing(Association, SocketAddress, int) - Static method in class com.sun.nio.sctp.MessageInfo
-
- createSubPageCaches(int, int, PoolArena.SizeClass) - Static method in class io.netty.buffer.PoolThreadCache
-
- createWheel(int) - Static method in class io.netty.util.HashedWheelTimer
-
- creationRecord - Variable in class io.netty.util.ResourceLeakDetector.DefaultResourceLeak
-
- CRLF - Static variable in class io.netty.handler.codec.smtp.SmtpRequestEncoder
-
- CSV_NUMBER_ESCAPE_CHARACTERS - Static variable in class io.netty.util.internal.StringUtil
-
2 - Quote character at beginning and end.
- ctx - Variable in class io.netty.channel.AbstractChannelHandlerContext.AbstractWriteTask
-
- ctx - Variable in class io.netty.channel.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- ctx - Variable in class io.netty.channel.DefaultChannelPipeline.PendingHandlerCallback
-
- ctx - Variable in class io.netty.channel.PendingWriteQueue
-
- ctx - Variable in class io.netty.handler.codec.compression.Bzip2Encoder
-
- ctx() - Method in class io.netty.handler.codec.compression.Bzip2Encoder
-
- ctx - Variable in class io.netty.handler.codec.compression.JdkZlibEncoder
-
- ctx() - Method in class io.netty.handler.codec.compression.JdkZlibEncoder
-
- ctx - Variable in class io.netty.handler.codec.compression.JZlibEncoder
-
- ctx() - Method in class io.netty.handler.codec.compression.JZlibEncoder
-
- ctx - Variable in class io.netty.handler.codec.MessageAggregator
-
- ctx() - Method in class io.netty.handler.codec.MessageAggregator
-
- ctx - Variable in class io.netty.handler.flush.FlushConsolidationHandler
-
- ctx - Variable in class io.netty.handler.ssl.DelegatingSslContext
-
- ctx - Variable in class io.netty.handler.ssl.SslHandler
-
- ctx - Variable in class io.netty.handler.stream.ChunkedWriteHandler
-
- ctx - Variable in class io.netty.handler.timeout.IdleStateHandler.AbstractIdleTask
-
- ctx - Variable in class io.netty.handler.timeout.WriteTimeoutHandler.WriteTimeoutTask
-
- ctx - Variable in class io.netty.handler.traffic.AbstractTrafficShapingHandler.ReopenReadTimerTask
-
- cumulate(ByteBufAllocator, ByteBuf, ByteBuf) - Method in interface io.netty.handler.codec.ByteToMessageDecoder.Cumulator
-
Cumulate the given
ByteBuf
s and return the
ByteBuf
that holds the cumulated bytes.
- cumulation - Variable in class io.netty.handler.codec.ByteToMessageDecoder
-
- cumulativeReadBytes - Variable in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
-
Maximum cumulative read bytes for one channel among all (as long as channels stay the same)
- cumulativeReadBytes - Variable in class io.netty.handler.traffic.TrafficCounter
-
Long life read bytes
- cumulativeReadBytes() - Method in class io.netty.handler.traffic.TrafficCounter
-
- cumulativeWrittenBytes - Variable in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
-
Maximum cumulative writing bytes for one channel among all (as long as channels stay the same)
- cumulativeWrittenBytes - Variable in class io.netty.handler.traffic.TrafficCounter
-
Long life written bytes
- cumulativeWrittenBytes() - Method in class io.netty.handler.traffic.TrafficCounter
-
- cumulator - Variable in class io.netty.handler.codec.ByteToMessageDecoder
-
- cumulator - Variable in enum io.netty.handler.ssl.SslHandler.SslEngineType
-
- 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 - Variable in class io.netty.handler.codec.DefaultHeaders.HeaderIterator
-
- current() - Static method in class io.netty.handler.ssl.util.ThreadLocalInsecureRandom
-
- current() - Method in interface io.netty.util.internal.PlatformDependent.ThreadLocalRandomProvider
-
- current() - Static method in class io.netty.util.internal.ThreadLocalRandom
-
Returns the current thread's ThreadLocalRandom
.
- CURRENT_SPI - Static variable in class io.netty.handler.ssl.util.SimpleTrustManagerFactory
-
- currentAlpha - Variable in class io.netty.handler.codec.compression.Bzip2HuffmanStageDecoder
-
- currentChecksum - Variable in class io.netty.handler.codec.compression.FastLzFrameDecoder
-
Checksum value of current received chunk of data which has checksum.
- currentGroup - Variable in class io.netty.handler.codec.compression.Bzip2HuffmanStageDecoder
-
- currentIterator - Variable in class io.netty.channel.group.CombinedIterator
-
- currentLength - Variable in class io.netty.handler.codec.compression.Bzip2HuffmanStageDecoder
-
- currentMessage - Variable in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheDecoder
-
- currentMessage - Variable in class io.netty.handler.codec.MessageAggregator
-
- 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 - Variable in class io.netty.handler.traffic.TrafficCounter
-
Current read bytes
- currentReadBytes() - Method in class io.netty.handler.traffic.TrafficCounter
-
- currentSelector - Variable in class io.netty.handler.codec.compression.Bzip2HuffmanStageDecoder
-
- currentState - Variable in class io.netty.handler.codec.compression.Bzip2Decoder
-
- currentState - Variable in class io.netty.handler.codec.compression.Bzip2Encoder
-
- currentState - Variable in class io.netty.handler.codec.compression.FastLzFrameDecoder
-
- currentTable - Variable in class io.netty.handler.codec.compression.Bzip2HuffmanStageDecoder
-
The Huffman table for the current group.
- currentWrite - Variable in class io.netty.handler.stream.ChunkedWriteHandler
-
- currentWrittenBytes - Variable in class io.netty.handler.traffic.TrafficCounter
-
Current written bytes
- currentWrittenBytes() - Method in class io.netty.handler.traffic.TrafficCounter
-
- cursor - Variable in class io.netty.util.Recycler.Stack
-
- customClassConstructor - Variable in class io.netty.util.ResourceLeakDetectorFactory.DefaultResourceLeakDetectorFactory
-
- customClassConstructor(String) - Static method in class io.netty.util.ResourceLeakDetectorFactory.DefaultResourceLeakDetectorFactory
-
- d - Variable in class io.netty.handler.codec.compression.Bzip2DivSufSort.StackEntry
-
- daemon - Variable in class io.netty.util.concurrent.DefaultThreadFactory
-
- data - Variable in class io.netty.buffer.DefaultByteBufHolder
-
- data - Variable in class io.netty.channel.DefaultChannelId
-
- data(int) - Method in class io.netty.channel.kqueue.KQueueEventArray
-
- DATA - Static variable in class io.netty.handler.codec.smtp.SmtpCommand
-
- DATA - Static variable in class io.netty.handler.codec.smtp.SmtpRequests
-
- data() - Static method in class io.netty.handler.codec.smtp.SmtpRequests
-
Creates a DATA
request.
- DATA_CMD - Static variable in class io.netty.handler.codec.smtp.SmtpCommand
-
- DATAGRAM_CHANNEL_ACTIVE_ON_REGISTRATION - Static variable in class io.netty.channel.ChannelOption
-
Deprecated.
- datagramChannel - Variable in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
-
- DatagramChannel - Interface in io.netty.channel.socket
-
- DatagramChannelConfig - Interface in io.netty.channel.socket
-
- DatagramDnsQuery - Class in io.netty.handler.codec.dns
-
- DatagramDnsQuery(InetSocketAddress, InetSocketAddress, int) - Constructor for class io.netty.handler.codec.dns.DatagramDnsQuery
-
- 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
-
- 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
-
- 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
-
- DatagramDnsResponse(InetSocketAddress, InetSocketAddress, int) - Constructor for class io.netty.handler.codec.dns.DatagramDnsResponse
-
- DatagramDnsResponse(InetSocketAddress, InetSocketAddress, int, DnsOpCode) - Constructor for class io.netty.handler.codec.dns.DatagramDnsResponse
-
- 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
-
- 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
-
- 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
-
- DatagramPacketDecoder(MessageToMessageDecoder<ByteBuf>) - Constructor for class io.netty.handler.codec.DatagramPacketDecoder
-
- DatagramPacketEncoder<M> - Class in io.netty.handler.codec
-
- DatagramPacketEncoder(MessageToMessageEncoder<? super M>) - Constructor for class io.netty.handler.codec.DatagramPacketEncoder
-
- 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.
- DatagramSocketAddress(String, int, int) - Constructor for class io.netty.channel.unix.DatagramSocketAddress
-
- dataType - Variable in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
-
- 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".
- DateFormatter() - Constructor for class io.netty.handler.codec.DateFormatter
-
- DAY_OF_WEEK_TO_SHORT_NAME - Static variable in class io.netty.handler.codec.DateFormatter
-
- dayOfMonth - Variable in class io.netty.handler.codec.DateFormatter
-
- dayOfMonthFound - Variable in class io.netty.handler.codec.DateFormatter
-
- deadline - Variable in class io.netty.util.HashedWheelTimer.HashedWheelTimeout
-
- deadlineNanos - Variable in class io.netty.util.concurrent.ScheduledFutureTask
-
- deadlineNanos(long) - Static method in class io.netty.util.concurrent.ScheduledFutureTask
-
- deadlineNanos() - Method in class io.netty.util.concurrent.ScheduledFutureTask
-
- deallocate() - Method in class io.netty.buffer.AbstractPooledDerivedByteBuf
-
- deallocate() - Method in class io.netty.buffer.AbstractReferenceCountedByteBuf
-
- deallocate() - Method in class io.netty.buffer.ByteBufUtil.ThreadLocalDirectByteBuf
-
- deallocate() - Method in class io.netty.buffer.ByteBufUtil.ThreadLocalUnsafeDirectByteBuf
-
- deallocate() - Method in class io.netty.buffer.CompositeByteBuf
-
- deallocate() - Method in class io.netty.buffer.FixedCompositeByteBuf
-
- deallocate() - Method in class io.netty.buffer.PooledByteBuf
-
- deallocate() - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- 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.buffer.WrappedCompositeByteBuf
-
- 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.handler.ssl.PemValue
-
- deallocate() - Method in class io.netty.util.AbstractReferenceCounted
-
- deallocationsHuge - Variable in class io.netty.buffer.PoolArena
-
- deallocationsNormal - Variable in class io.netty.buffer.PoolArena
-
- deallocationsSmall - Variable in class io.netty.buffer.PoolArena
-
- deallocationsTiny - Variable in class io.netty.buffer.PoolArena
-
- deathWatchThread - Variable in class io.netty.buffer.PoolThreadCache
-
- debug(Throwable) - Method in class io.netty.util.internal.logging.AbstractInternalLogger
-
- debug(String) - Method in class io.netty.util.internal.logging.CommonsLogger
-
Deprecated.
Delegates to the Log.debug(Object)
method of the underlying
Log
instance.
- debug(String, Object) - Method in class io.netty.util.internal.logging.CommonsLogger
-
Deprecated.
Delegates to the Log.debug(Object)
method of the underlying
Log
instance.
- debug(String, Object, Object) - Method in class io.netty.util.internal.logging.CommonsLogger
-
Deprecated.
Delegates to the Log.debug(Object)
method of the underlying
Log
instance.
- debug(String, Object...) - Method in class io.netty.util.internal.logging.CommonsLogger
-
Deprecated.
Delegates to the Log.debug(Object)
method of the underlying
Log
instance.
- debug(String, Throwable) - Method in class io.netty.util.internal.logging.CommonsLogger
-
Deprecated.
Delegates to the Log.debug(Object, Throwable)
method of
the underlying Log
instance.
- 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.
- debug(String) - Method in class io.netty.util.internal.logging.JdkLogger
-
Log a message object at level FINE.
- debug(String, Object) - Method in class io.netty.util.internal.logging.JdkLogger
-
Log a message at level FINE according to the specified format and argument.
- debug(String, Object, Object) - Method in class io.netty.util.internal.logging.JdkLogger
-
Log a message at level FINE according to the specified format and
arguments.
- debug(String, Object...) - Method in class io.netty.util.internal.logging.JdkLogger
-
Log a message at level FINE according to the specified format and
arguments.
- debug(String, Throwable) - Method in class io.netty.util.internal.logging.JdkLogger
-
Log an exception (throwable) at level FINE with an accompanying message.
- debug(String) - Method in class io.netty.util.internal.logging.Log4JLogger
-
Log a message object at level DEBUG.
- debug(String, Object) - Method in class io.netty.util.internal.logging.Log4JLogger
-
Log a message at level DEBUG according to the specified format and
argument.
- debug(String, Object, Object) - Method in class io.netty.util.internal.logging.Log4JLogger
-
Log a message at level DEBUG according to the specified format and
arguments.
- debug(String, Object...) - Method in class io.netty.util.internal.logging.Log4JLogger
-
Log a message at level DEBUG according to the specified format and
arguments.
- debug(String, Throwable) - Method in class io.netty.util.internal.logging.Log4JLogger
-
Log an exception (throwable) at level DEBUG with an accompanying message.
- debug(String) - Method in class io.netty.util.internal.logging.Slf4JLogger
-
- debug(String, Object) - Method in class io.netty.util.internal.logging.Slf4JLogger
-
- debug(String, Object, Object) - Method in class io.netty.util.internal.logging.Slf4JLogger
-
- debug(String, Object...) - Method in class io.netty.util.internal.logging.Slf4JLogger
-
- debug(String, Throwable) - Method in class io.netty.util.internal.logging.Slf4JLogger
-
- decideZlibOrNone - Variable in class io.netty.handler.codec.compression.JdkZlibDecoder
-
- decimalDigit(String, int) - Static method in class io.netty.util.NetUtil
-
- decodabet(Base64Dialect) - Static method in class io.netty.handler.codec.base64.Base64
-
- decodabet - Variable in class io.netty.handler.codec.base64.Base64.Decoder
-
- decodabet - Variable in enum io.netty.handler.codec.base64.Base64Dialect
-
- 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(ByteBuf, int, int, ByteBufAllocator, Base64Dialect) - Method in class io.netty.handler.codec.base64.Base64.Decoder
-
- 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.haproxy.HAProxyMessageDecoder
-
- 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, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.memcache.binary.BinaryMemcacheClientCodec.Decoder
-
- 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, SctpMessage, List<Object>) - Method in class io.netty.handler.codec.sctp.SctpInboundByteStreamHandler
-
- decode(ChannelHandlerContext, SctpMessage, List<Object>) - Method in class io.netty.handler.codec.sctp.SctpMessageCompletionHandler
-
- 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.socks.SocksAuthRequestDecoder
-
- decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.socks.SocksAuthResponseDecoder
-
- decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.socks.SocksCmdRequestDecoder
-
- decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.socks.SocksCmdResponseDecoder
-
- decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.socks.SocksInitRequestDecoder
-
- decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.socks.SocksInitResponseDecoder
-
- decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.socksx.SocksPortUnificationServerHandler
-
- decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.socksx.v4.Socks4ClientDecoder
-
- decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.socksx.v4.Socks4ServerDecoder
-
- decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.socksx.v5.Socks5CommandRequestDecoder
-
- decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.socksx.v5.Socks5CommandResponseDecoder
-
- decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.socksx.v5.Socks5InitialRequestDecoder
-
- decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.socksx.v5.Socks5InitialResponseDecoder
-
- decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.socksx.v5.Socks5PasswordAuthRequestDecoder
-
- decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.socksx.v5.Socks5PasswordAuthResponseDecoder
-
- 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
-
- decode4to3(byte[], ByteBuf, int, byte[]) - Static method in class io.netty.handler.codec.base64.Base64.Decoder
-
- decodeAddress(Socks5AddressType, ByteBuf) - Method in interface io.netty.handler.codec.socksx.v5.Socks5AddressDecoder
-
Decodes a SOCKS5 address field into its string representation.
- decodeBulkString(ByteBuf, List<Object>) - Method in class io.netty.handler.codec.redis.RedisDecoder
-
- decodeBulkStringContent(ByteBuf, List<Object>) - Method in class io.netty.handler.codec.redis.RedisDecoder
-
- decodeBulkStringEndOfLine(ByteBuf, List<Object>) - Method in class io.netty.handler.codec.redis.RedisDecoder
-
- decodeByte(byte, ByteBuf, int) - Method in class io.netty.handler.codec.json.JsonObjectDecoder
-
- decodeByteArray(ByteBuf) - Static method in class io.netty.handler.codec.mqtt.MqttDecoder
-
- decodeConnAckVariableHeader(ByteBuf) - Static method in class io.netty.handler.codec.mqtt.MqttDecoder
-
- decodeConnectionPayload(ByteBuf, MqttConnectVariableHeader) - Static method in class io.netty.handler.codec.mqtt.MqttDecoder
-
- decodeConnectionVariableHeader(ByteBuf) - Static method in class io.netty.handler.codec.mqtt.MqttDecoder
-
- decodeCopyWith1ByteOffset(byte, ByteBuf, ByteBuf, int) - Static method in class io.netty.handler.codec.compression.Snappy
-
Reads a compressed reference offset and length from the supplied input
buffer, seeks back to the appropriate place in the input buffer and
writes the found data to the supplied output stream.
- decodeCopyWith2ByteOffset(byte, ByteBuf, ByteBuf, int) - Static method in class io.netty.handler.codec.compression.Snappy
-
Reads a compressed reference offset and length from the supplied input
buffer, seeks back to the appropriate place in the input buffer and
writes the found data to the supplied output stream.
- decodeCopyWith4ByteOffset(byte, ByteBuf, ByteBuf, int) - Static method in class io.netty.handler.codec.compression.Snappy
-
Reads a compressed reference offset and length from the supplied input
buffer, seeks back to the appropriate place in the input buffer and
writes the found data to the supplied output stream.
- decodedBufferSize(int) - Static method in class io.netty.handler.codec.base64.Base64
-
- decodeDomainName(ByteBuf) - Static method in class io.netty.resolver.dns.DnsNameResolverContext
-
- decodeFixedHeader(ByteBuf) - Static method in class io.netty.handler.codec.mqtt.MqttDecoder
-
Decodes the fixed header.
- decodeHeader(ByteBuf) - Static method in class io.netty.handler.codec.haproxy.HAProxyMessage
-
Decodes a version 2, binary proxy protocol header.
- decodeHeader(String) - Static method in class io.netty.handler.codec.haproxy.HAProxyMessage
-
Decodes a version 1, human-readable proxy protocol header.
- decodeHeader(ByteBuf) - Method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheDecoder
-
- 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
-
- decodeHexDump(CharSequence, int, int) - Static method in class io.netty.buffer.ByteBufUtil
-
- decodeHexDump(CharSequence, int, int) - Static method in class io.netty.util.internal.StringUtil
-
- decodeHexDump(CharSequence) - Static method in class io.netty.util.internal.StringUtil
-
- decodeHexNibble(char) - Static method in class io.netty.util.internal.StringUtil
-
Helper to decode half of a hexadecimal number from a string.
- decodeHuffmanData(Bzip2HuffmanStageDecoder) - Method in class io.netty.handler.codec.compression.Bzip2BlockDecompressor
-
Reads the Huffman encoded data from the input stream, performs Run-Length Decoding and
applies the Move To Front transform to reconstruct the Burrows-Wheeler Transform array.
- decodeIdn - Variable in class io.netty.resolver.dns.DnsNameResolver
-
- decodeIdn - Variable in class io.netty.resolver.dns.DnsNameResolverBuilder
-
- decodeIdn(boolean) - Method in class io.netty.resolver.dns.DnsNameResolverBuilder
-
Set if domain / host names should be decoded to unicode when received.
- decodeInline(ByteBuf, List<Object>) - Method in class io.netty.handler.codec.redis.RedisDecoder
-
- decodeInt(byte[], int) - Static method in class io.netty.channel.unix.NativeInetAddress
-
- 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
-
- decodeLength(ByteBuf, List<Object>) - Method in class io.netty.handler.codec.redis.RedisDecoder
-
- decodeLine(ChannelHandlerContext, ByteBuf) - Method in class io.netty.handler.codec.haproxy.HAProxyMessageDecoder
-
Create a frame out of the
ByteBuf
and return it.
- decodeLiteral(byte, ByteBuf, ByteBuf) - Static method in class io.netty.handler.codec.compression.Snappy
-
Reads a literal from the input buffer directly to the output buffer.
- decodeMessageId(ByteBuf) - Static method in class io.netty.handler.codec.mqtt.MqttDecoder
-
- decodeMessageIdVariableHeader(ByteBuf) - Static method in class io.netty.handler.codec.mqtt.MqttDecoder
-
- decodeMsbLsb(ByteBuf) - Static method in class io.netty.handler.codec.mqtt.MqttDecoder
-
- decodeMsbLsb(ByteBuf, int, int) - Static method in class io.netty.handler.codec.mqtt.MqttDecoder
-
- 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.
- decodeNextBWTByte() - Method in class io.netty.handler.codec.compression.Bzip2BlockDecompressor
-
Decodes a byte from the Burrows-Wheeler Transform stage.
- decodePayload(ByteBuf, MqttMessageType, int, Object) - Static method in class io.netty.handler.codec.mqtt.MqttDecoder
-
Decodes the payload.
- decodePublishPayload(ByteBuf, int) - Static method in class io.netty.handler.codec.mqtt.MqttDecoder
-
- decodePublishVariableHeader(ByteBuf, MqttFixedHeader) - Static method in class io.netty.handler.codec.mqtt.MqttDecoder
-
- 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.
- decodeQuestions(DnsQuery, ByteBuf, int) - Method in class io.netty.handler.codec.dns.DatagramDnsQueryDecoder
-
- decodeQuestions(DnsResponse, ByteBuf, int) - Method in class io.netty.handler.codec.dns.DatagramDnsResponseDecoder
-
- Decoder() - Constructor for class io.netty.handler.codec.base64.Base64.Decoder
-
- decoder - Variable in class io.netty.handler.codec.ByteToMessageCodec
-
- decoder - Variable in class io.netty.handler.codec.DatagramPacketDecoder
-
- Decoder(int) - Constructor for class io.netty.handler.codec.memcache.binary.BinaryMemcacheClientCodec.Decoder
-
- decoder - Variable in class io.netty.handler.codec.MessageToMessageCodec
-
- DECODER - Static variable in class io.netty.resolver.dns.DnsNameResolver
-
- 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
-
- decodeRecord(ByteBuf) - Method in interface io.netty.handler.codec.dns.DnsRecordDecoder
-
Decodes a DNS record into its object representation.
- decodeRecords(DnsQuery, DnsSection, ByteBuf, int) - Method in class io.netty.handler.codec.dns.DatagramDnsQueryDecoder
-
- decodeRecords(DnsResponse, DnsSection, ByteBuf, int) - Method in class io.netty.handler.codec.dns.DatagramDnsResponseDecoder
-
- decodeRedisArrayHeader(ArrayHeaderRedisMessage) - Method in class io.netty.handler.codec.redis.RedisArrayAggregator
-
- decodeRemovalReentryProtection(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.ByteToMessageDecoder
-
Decode the from one
ByteBuf
to an other.
- DecoderException - Exception in io.netty.handler.codec
-
- 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 - Variable in class io.netty.handler.codec.memcache.AbstractMemcacheObject
-
- decoderResult() - Method in class io.netty.handler.codec.memcache.AbstractMemcacheObject
-
- decoderResult - Variable in class io.netty.handler.codec.mqtt.MqttMessage
-
- decoderResult() - Method in class io.netty.handler.codec.mqtt.MqttMessage
-
- decoderResult - Variable in class io.netty.handler.codec.socksx.AbstractSocksMessage
-
- decoderResult() - Method in class io.netty.handler.codec.socksx.AbstractSocksMessage
-
- decoderResult - Variable in class io.netty.handler.codec.stomp.DefaultStompContentSubframe
-
- 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.
- DecoderState() - Constructor for enum io.netty.handler.codec.mqtt.MqttDecoder.DecoderState
-
- decodeState - Variable in class io.netty.handler.codec.ByteToMessageDecoder
-
- decodeString(ByteBuf, int, int, Charset) - Static method in class io.netty.buffer.ByteBufUtil
-
- decodeString(CharsetDecoder, ByteBuffer, CharBuffer) - Static method in class io.netty.buffer.ByteBufUtil
-
- decodeString(ByteBuf) - Static method in class io.netty.handler.codec.mqtt.MqttDecoder
-
- decodeString(ByteBuf, int, int) - Static method in class io.netty.handler.codec.mqtt.MqttDecoder
-
- decodeStruct(ChannelHandlerContext, ByteBuf) - Method in class io.netty.handler.codec.haproxy.HAProxyMessageDecoder
-
Create a frame out of the
ByteBuf
and return it.
- decodeSubackPayload(ByteBuf, int) - Static method in class io.netty.handler.codec.mqtt.MqttDecoder
-
- decodeSubscribePayload(ByteBuf, int) - Static method in class io.netty.handler.codec.mqtt.MqttDecoder
-
- decodeType(ByteBuf) - Method in class io.netty.handler.codec.redis.RedisDecoder
-
- decodeUnsubscribePayload(ByteBuf, int) - Static method in class io.netty.handler.codec.mqtt.MqttDecoder
-
- decodeVariableHeader(ByteBuf, MqttFixedHeader) - Static method in class io.netty.handler.codec.mqtt.MqttDecoder
-
Decodes the variable header (if any)
- decodeWasNull - Variable in class io.netty.handler.codec.ByteToMessageDecoder
-
- decompose(int, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- decompose(int, int) - Method in class io.netty.buffer.CompositeByteBuf
-
- decompose(int, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- decompress(byte[], int, int, byte[], int, int) - Static method in class io.netty.handler.codec.compression.FastLz
-
Decompress a block of compressed data and returns the size of the decompressed block.
- DecompressionException - Exception in io.netty.handler.codec.compression
-
- 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
-
- decreaseNow - Variable in class io.netty.channel.AdaptiveRecvByteBufAllocator.HandleImpl
-
- DECREMENT - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
-
- decrement() - Method in interface io.netty.util.internal.LongCounter
-
- decrement() - Method in class io.netty.util.internal.PlatformDependent.AtomicLongCounter
-
- decrement - Variable in class io.netty.util.ReferenceCountUtil.ReleasingTask
-
- decrementAndRunTaskQueue() - Method in class io.netty.channel.pool.FixedChannelPool
-
- decrementDirect(int) - Method in class io.netty.buffer.UnpooledByteBufAllocator
-
- decrementHeap(int) - Method in class io.netty.buffer.UnpooledByteBufAllocator
-
- decrementMemoryCounter(int) - Static method in class io.netty.util.internal.PlatformDependent
-
- decrementPendingOutboundBytes(long) - Method in class io.netty.channel.ChannelOutboundBuffer
-
Decrement the pending bytes which will be written at some point.
- decrementPendingOutboundBytes(long, boolean, boolean) - Method in class io.netty.channel.ChannelOutboundBuffer
-
- DECREMENTQ - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
-
- decWaiters() - Method in class io.netty.util.concurrent.DefaultPromise
-
- deeplyAppendParameter(StringBuilder, Object, Set<Object[]>) - Static method in class io.netty.util.internal.logging.MessageFormatter
-
- 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
-
- 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 interface io.netty.handler.codec.socksx.v5.Socks5AddressDecoder
-
- DEFAULT - Static variable in interface io.netty.handler.codec.socksx.v5.Socks5AddressEncoder
-
- DEFAULT - Static variable in class io.netty.handler.codec.socksx.v5.Socks5ClientEncoder
-
- DEFAULT - Static variable in class io.netty.handler.codec.socksx.v5.Socks5ServerEncoder
-
- 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_ACCELERATION - Static variable in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
-
- DEFAULT_ALLOCATOR - Static variable in class io.netty.buffer.ByteBufUtil
-
- DEFAULT_ARRAY_LIST_INITIAL_CAPACITY - Static variable in class io.netty.util.internal.InternalThreadLocalMap
-
- DEFAULT_CACHE_TRIM_INTERVAL - Static variable in class io.netty.buffer.PooledByteBufAllocator
-
- 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_CHUNK_SIZE - Static variable in class io.netty.handler.codec.stomp.StompSubframeDecoder
-
- DEFAULT_CHUNK_SIZE - Static variable in class io.netty.handler.stream.ChunkedStream
-
- DEFAULT_CIPHERS - Static variable in class io.netty.handler.ssl.JdkSslContext
-
- DEFAULT_CONNECT_TIMEOUT - Static variable in class io.netty.channel.DefaultChannelConfig
-
- DEFAULT_DEVIATION - Static variable in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
-
- DEFAULT_DIRECT_MEMORY_CACHE_ALIGNMENT - Static variable in class io.netty.buffer.PooledByteBufAllocator
-
- DEFAULT_DNS_SERVER_ADDRESS_STREAM_PROVIDER - Static variable in class io.netty.resolver.dns.DnsServerAddressStreamProviders
-
- DEFAULT_ERRORS - Static variable in class io.netty.handler.codec.redis.FixedRedisMessagePool
-
- DEFAULT_EVENT_LOOP_THREADS - Static variable in class io.netty.channel.MultithreadEventLoopGroup
-
- DEFAULT_HIGH_WATER_MARK - Static variable in class io.netty.channel.WriteBufferWaterMark
-
- DEFAULT_INITIAL - Static variable in class io.netty.channel.AdaptiveRecvByteBufAllocator
-
- DEFAULT_INITIAL_CAPACITY - Static variable in class io.netty.buffer.AbstractByteBufAllocator
-
- DEFAULT_INITIAL_CAPACITY - Static variable in class io.netty.util.internal.RecyclableArrayList
-
- DEFAULT_INITIAL_MAX_CAPACITY_PER_THREAD - Static variable in class io.netty.util.Recycler
-
- DEFAULT_JDK_MEM_LEVEL - Static variable in class io.netty.handler.codec.compression.ZlibCodecFactory
-
- DEFAULT_JDK_WINDOW_SIZE - Static variable in class io.netty.handler.codec.compression.ZlibCodecFactory
-
- DEFAULT_LEVEL - Static variable in class io.netty.handler.logging.LoggingHandler
-
- DEFAULT_LEVEL - Static variable in class io.netty.resolver.dns.TraceDnsQueryLifeCycleObserverFactory
-
- DEFAULT_LEVEL - Static variable in class io.netty.util.ResourceLeakDetector
-
- DEFAULT_LIST_SIZE - Static variable in class io.netty.handler.ssl.ApplicationProtocolUtil
-
- 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_LOGGER - Static variable in class io.netty.resolver.dns.TraceDnsQueryLifeCycleObserverFactory
-
- DEFAULT_LOW_WATER_MARK - Static variable in class io.netty.channel.WriteBufferWaterMark
-
- DEFAULT_MAX_BYTES_IN_MESSAGE - Static variable in class io.netty.handler.codec.mqtt.MqttDecoder
-
- DEFAULT_MAX_CACHED_BUFFER_CAPACITY - Static variable in class io.netty.buffer.PooledByteBufAllocator
-
- DEFAULT_MAX_CAPACITY - Static variable in class io.netty.buffer.AbstractByteBufAllocator
-
- DEFAULT_MAX_CAPACITY_PER_THREAD - Static variable in class io.netty.util.Recycler
-
- DEFAULT_MAX_CHUNK_SIZE - Static variable in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheDecoder
-
- DEFAULT_MAX_COMPONENTS - Static variable in class io.netty.buffer.AbstractByteBufAllocator
-
- DEFAULT_MAX_COMPOSITEBUFFER_COMPONENTS - Static variable in class io.netty.handler.codec.MessageAggregator
-
- DEFAULT_MAX_LINE_LENGTH - Static variable in class io.netty.handler.codec.stomp.StompSubframeDecoder
-
- DEFAULT_MAX_MPSC_CAPACITY - Static variable in class io.netty.util.internal.PlatformDependent
-
- DEFAULT_MAX_ORDER - Static variable in class io.netty.buffer.PooledByteBufAllocator
-
- DEFAULT_MAX_PENDING_EXECUTOR_TASKS - Static variable in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- DEFAULT_MAX_PENDING_TASKS - Static variable in class io.netty.channel.SingleThreadEventLoop
-
- DEFAULT_MAX_RECORDS - Static variable in class io.netty.util.ResourceLeakDetector
-
- DEFAULT_MAX_SIZE - Static variable in class io.netty.handler.traffic.AbstractTrafficShapingHandler
-
Default max size to not exceed in buffer (write only).
- 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).
- DEFAULT_MAXIMUM - Static variable in class io.netty.channel.AdaptiveRecvByteBufAllocator
-
- DEFAULT_MINIMUM - Static variable in class io.netty.channel.AdaptiveRecvByteBufAllocator
-
- DEFAULT_MSG_SIZE_ESTIMATOR - Static variable in class io.netty.channel.DefaultChannelConfig
-
- DEFAULT_NAME_SERVER_ARRAY - Static variable in class io.netty.resolver.dns.DefaultDnsServerAddressStreamProvider
-
- DEFAULT_NAME_SERVER_LIST - Static variable in class io.netty.resolver.dns.DefaultDnsServerAddressStreamProvider
-
- DEFAULT_NAME_SERVERS - Static variable in class io.netty.resolver.dns.DefaultDnsServerAddressStreamProvider
-
- DEFAULT_NDOTS - Static variable in class io.netty.resolver.dns.DnsNameResolver
-
- DEFAULT_NDOTS - Static variable in class io.netty.resolver.dns.UnixResolverDnsServerAddressStreamProvider
-
- DEFAULT_NORMAL_CACHE_SIZE - Static variable in class io.netty.buffer.PooledByteBufAllocator
-
- DEFAULT_NOT_AFTER - Static variable in class io.netty.handler.ssl.util.SelfSignedCertificate
-
The maximum possible value in X.509 specification: 9999-12-31 23:59:59
- DEFAULT_NOT_BEFORE - Static variable in class io.netty.handler.ssl.util.SelfSignedCertificate
-
Current time minus 1 year, just in case software clock goes back due to time synchronization
- DEFAULT_NUM_DIRECT_ARENA - Static variable in class io.netty.buffer.PooledByteBufAllocator
-
- DEFAULT_NUM_ELEMENTS - Static variable in class io.netty.handler.flow.FlowControlHandler.RecyclableArrayDeque
-
A value of 2
should be a good choice for most scenarios.
- DEFAULT_NUM_HEAP_ARENA - Static variable in class io.netty.buffer.PooledByteBufAllocator
-
- DEFAULT_PAGE_SIZE - Static variable in class io.netty.buffer.PooledByteBufAllocator
-
- DEFAULT_PROTOCOLS - Static variable in class io.netty.handler.ssl.JdkSslContext
-
- DEFAULT_RCVBUF_ALLOCATOR - Static variable in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
-
- DEFAULT_RESOLVE_ADDRESS_TYPES - Static variable in class io.netty.resolver.dns.DnsNameResolver
-
- DEFAULT_RESOLVER - Static variable in class io.netty.bootstrap.Bootstrap
-
- DEFAULT_SAMPLING_INTERVAL - Static variable in class io.netty.util.ResourceLeakDetector
-
- DEFAULT_SEARCH_DOMAINS - Static variable in class io.netty.resolver.dns.DnsNameResolver
-
- DEFAULT_SELECTOR_PROVIDER - Static variable in class io.netty.channel.socket.nio.NioDatagramChannel
-
- DEFAULT_SELECTOR_PROVIDER - Static variable in class io.netty.channel.socket.nio.NioServerSocketChannel
-
- DEFAULT_SELECTOR_PROVIDER - Static variable in class io.netty.channel.socket.nio.NioSocketChannel
-
- DEFAULT_SHUTDOWN_QUIET_PERIOD - Static variable in class io.netty.util.concurrent.AbstractEventExecutor
-
- DEFAULT_SHUTDOWN_TIMEOUT - Static variable in class io.netty.util.concurrent.AbstractEventExecutor
-
- DEFAULT_SIMPLE_STRINGS - Static variable in class io.netty.handler.codec.redis.FixedRedisMessagePool
-
- DEFAULT_SLOWDOWN - Static variable in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
-
- DEFAULT_SMALL_CACHE_SIZE - Static variable in class io.netty.buffer.PooledByteBufAllocator
-
- DEFAULT_SSL_ENGINE_WRAPPER_FACTORY - Static variable in class io.netty.handler.ssl.JdkDefaultApplicationProtocolNegotiator
-
- DEFAULT_TINY_CACHE_SIZE - Static variable in class io.netty.buffer.PooledByteBufAllocator
-
- DEFAULT_USE_CACHE_FOR_ALL_THREADS - Static variable in class io.netty.buffer.PooledByteBufAllocator
-
- defaultAddressArray() - Static method in class io.netty.resolver.dns.DefaultDnsServerAddressStreamProvider
-
- DefaultAddressedEnvelope<M,A extends java.net.SocketAddress> - Class in io.netty.channel
-
- 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
-
- defaultAddresses() - Static method in class io.netty.resolver.dns.DnsServerAddresses
-
- 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
-
- DefaultAddressResolverGroup - Class in io.netty.resolver
-
- DefaultAddressResolverGroup() - Constructor for class io.netty.resolver.DefaultAddressResolverGroup
-
- DefaultAttribute(DefaultAttributeMap.DefaultAttribute<?>, AttributeKey<T>) - Constructor for class io.netty.util.DefaultAttributeMap.DefaultAttribute
-
- DefaultAttribute() - Constructor for class io.netty.util.DefaultAttributeMap.DefaultAttribute
-
- 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
-
- DefaultAttributeMap.DefaultAttribute<T> - Class in io.netty.util
-
- DefaultBinaryMemcacheRequest - Class in io.netty.handler.codec.memcache.binary
-
- DefaultBinaryMemcacheRequest() - Constructor for class io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheRequest
-
- DefaultBinaryMemcacheRequest(ByteBuf) - Constructor for class io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheRequest
-
- DefaultBinaryMemcacheRequest(ByteBuf, ByteBuf) - Constructor for class io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheRequest
-
- DefaultBinaryMemcacheResponse - Class in io.netty.handler.codec.memcache.binary
-
- DefaultBinaryMemcacheResponse() - Constructor for class io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheResponse
-
- DefaultBinaryMemcacheResponse(ByteBuf) - Constructor for class io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheResponse
-
- DefaultBinaryMemcacheResponse(ByteBuf, ByteBuf) - Constructor for class io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheResponse
-
- DefaultBulkStringRedisContent - Class in io.netty.handler.codec.redis
-
- DefaultBulkStringRedisContent(ByteBuf) - Constructor for class io.netty.handler.codec.redis.DefaultBulkStringRedisContent
-
- DefaultByteBufHolder - Class in io.netty.buffer
-
- DefaultByteBufHolder(ByteBuf) - Constructor for class io.netty.buffer.DefaultByteBufHolder
-
- DefaultChannelConfig - Class in io.netty.channel
-
- 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
-
- DefaultChannelGroup(EventExecutor) - Constructor for class io.netty.channel.group.DefaultChannelGroup
-
- DefaultChannelGroup(String, EventExecutor) - Constructor for class io.netty.channel.group.DefaultChannelGroup
-
- DefaultChannelGroup(EventExecutor, boolean) - Constructor for class io.netty.channel.group.DefaultChannelGroup
-
- DefaultChannelGroup(String, EventExecutor, boolean) - Constructor for class io.netty.channel.group.DefaultChannelGroup
-
- DefaultChannelGroupFuture - Class in io.netty.channel.group
-
- DefaultChannelGroupFuture(ChannelGroup, Collection<ChannelFuture>, EventExecutor) - Constructor for class io.netty.channel.group.DefaultChannelGroupFuture
-
Creates a new instance.
- DefaultChannelGroupFuture(ChannelGroup, Map<Channel, ChannelFuture>, EventExecutor) - Constructor for class io.netty.channel.group.DefaultChannelGroupFuture
-
- DefaultChannelGroupFuture.DefaultEntry<K,V> - Class in io.netty.channel.group
-
- DefaultChannelHandlerContext - Class in io.netty.channel
-
- DefaultChannelHandlerContext(DefaultChannelPipeline, EventExecutor, String, ChannelHandler) - Constructor for class io.netty.channel.DefaultChannelHandlerContext
-
- DefaultChannelId - Class in io.netty.channel
-
- DefaultChannelId() - Constructor for class io.netty.channel.DefaultChannelId
-
- DefaultChannelPipeline - Class in io.netty.channel
-
- DefaultChannelPipeline(Channel) - Constructor for class io.netty.channel.DefaultChannelPipeline
-
- DefaultChannelPipeline.HeadContext - Class in io.netty.channel
-
- DefaultChannelPipeline.PendingHandlerAddedTask - Class in io.netty.channel
-
- DefaultChannelPipeline.PendingHandlerCallback - Class in io.netty.channel
-
- DefaultChannelPipeline.PendingHandlerRemovedTask - Class in io.netty.channel
-
- DefaultChannelPipeline.TailContext - Class in io.netty.channel
-
- DefaultChannelProgressivePromise - Class in io.netty.channel
-
- 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
-
- 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.
- DefaultCharEqualityComparator() - Constructor for class io.netty.util.AsciiString.DefaultCharEqualityComparator
-
- defaultClassLoader(ClassLoader) - Static method in class io.netty.handler.codec.serialization.ClassResolvers
-
- 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
-
- 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
-
- 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
-
- DefaultDnsQuery(int) - Constructor for class io.netty.handler.codec.dns.DefaultDnsQuery
-
- DefaultDnsQuery(int, DnsOpCode) - Constructor for class io.netty.handler.codec.dns.DefaultDnsQuery
-
Creates a new instance.
- DefaultDnsQuestion - Class in io.netty.handler.codec.dns
-
- DefaultDnsQuestion(String, DnsRecordType) - Constructor for class io.netty.handler.codec.dns.DefaultDnsQuestion
-
- 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
-
- 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
-
- DefaultDnsRecordDecoder() - Constructor for class io.netty.handler.codec.dns.DefaultDnsRecordDecoder
-
Creates a new instance.
- DefaultDnsRecordEncoder - Class in io.netty.handler.codec.dns
-
- DefaultDnsRecordEncoder() - Constructor for class io.netty.handler.codec.dns.DefaultDnsRecordEncoder
-
Creates a new instance.
- DefaultDnsResponse - Class in io.netty.handler.codec.dns
-
- DefaultDnsResponse(int) - Constructor for class io.netty.handler.codec.dns.DefaultDnsResponse
-
- DefaultDnsResponse(int, DnsOpCode) - Constructor for class io.netty.handler.codec.dns.DefaultDnsResponse
-
- DefaultDnsResponse(int, DnsOpCode, DnsResponseCode) - Constructor for class io.netty.handler.codec.dns.DefaultDnsResponse
-
Creates a new instance.
- DefaultDnsServerAddresses - Class in io.netty.resolver.dns
-
- DefaultDnsServerAddresses(String, InetSocketAddress[]) - Constructor for class io.netty.resolver.dns.DefaultDnsServerAddresses
-
- DefaultDnsServerAddressStreamProvider - Class in io.netty.resolver.dns
-
- DefaultDnsServerAddressStreamProvider() - Constructor for class io.netty.resolver.dns.DefaultDnsServerAddressStreamProvider
-
- DefaultEntry(K, V) - Constructor for class io.netty.channel.group.DefaultChannelGroupFuture.DefaultEntry
-
- DefaultEventExecutor - Class in io.netty.util.concurrent
-
- 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
.
- DefaultEventExecutorChooserFactory() - Constructor for class io.netty.util.concurrent.DefaultEventExecutorChooserFactory
-
- DefaultEventExecutorChooserFactory.GenericEventExecutorChooser - Class in io.netty.util.concurrent
-
- DefaultEventExecutorChooserFactory.PowerOfTwoEventExecutorChooser - Class in io.netty.util.concurrent
-
- DefaultEventExecutorGroup - Class in io.netty.util.concurrent
-
- 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
-
- 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
- defaultFactory - Static variable in class io.netty.util.internal.logging.InternalLoggerFactory
-
- 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
.
- DefaultFlushCheckpoint(long, ChannelPromise) - Constructor for class io.netty.channel.ChannelFlushPromiseNotifier.DefaultFlushCheckpoint
-
- DefaultFullBinaryMemcacheRequest - Class in io.netty.handler.codec.memcache.binary
-
- DefaultFullBinaryMemcacheRequest(ByteBuf, ByteBuf) - Constructor for class io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheRequest
-
- DefaultFullBinaryMemcacheRequest(ByteBuf, ByteBuf, ByteBuf) - Constructor for class io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheRequest
-
- DefaultFullBinaryMemcacheResponse - Class in io.netty.handler.codec.memcache.binary
-
- DefaultFullBinaryMemcacheResponse(ByteBuf, ByteBuf) - Constructor for class io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheResponse
-
- DefaultFullBinaryMemcacheResponse(ByteBuf, ByteBuf, ByteBuf) - Constructor for class io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheResponse
-
- DefaultFutureListeners - Class in io.netty.util.concurrent
-
- DefaultFutureListeners(GenericFutureListener<? extends Future<?>>, GenericFutureListener<? extends Future<?>>) - Constructor for class io.netty.util.concurrent.DefaultFutureListeners
-
- DefaultHandle(Recycler.Stack<?>) - Constructor for class io.netty.util.Recycler.DefaultHandle
-
- DefaultHeaders<K,V,T extends Headers<K,V,T>> - Class in io.netty.handler.codec
-
- 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.HeaderIterator - 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
-
- DefaultHostsFileEntriesResolver() - Constructor for class io.netty.resolver.DefaultHostsFileEntriesResolver
-
- DefaultHostsFileEntriesResolver(HostsFileEntries) - Constructor for class io.netty.resolver.DefaultHostsFileEntriesResolver
-
- DefaultLastBulkStringRedisContent - Class in io.netty.handler.codec.redis
-
- DefaultLastBulkStringRedisContent(ByteBuf) - Constructor for class io.netty.handler.codec.redis.DefaultLastBulkStringRedisContent
-
- DefaultLastMemcacheContent - Class in io.netty.handler.codec.memcache
-
- 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
-
- DefaultLastStompContentSubframe(ByteBuf) - Constructor for class io.netty.handler.codec.stomp.DefaultLastStompContentSubframe
-
- defaultMachineId() - Static method in class io.netty.util.internal.MacAddressUtil
-
- 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
-
- DefaultMaxBytesRecvByteBufAllocator.HandleImpl - Class in io.netty.channel
-
- defaultMaxMessagesPerRead - Variable in class io.netty.channel.ChannelMetadata
-
- defaultMaxMessagesPerRead() - Method in class io.netty.channel.ChannelMetadata
-
- DefaultMaxMessagesRecvByteBufAllocator - Class in io.netty.channel
-
- DefaultMaxMessagesRecvByteBufAllocator() - Constructor for class io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator
-
- DefaultMaxMessagesRecvByteBufAllocator(int) - Constructor for class io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator
-
- DefaultMaxMessagesRecvByteBufAllocator.MaxMessageHandle - Class in io.netty.channel
-
- defaultMaxOrder() - Static method in class io.netty.buffer.PooledByteBufAllocator
-
Default maximum order - System Property: io.netty.allocator.maxOrder - default 11
- defaultMaybeMoreDataSupplier - Variable in class io.netty.channel.kqueue.KQueueRecvByteAllocatorHandle
-
- defaultMaybeMoreSupplier - Variable in class io.netty.channel.DefaultMaxBytesRecvByteBufAllocator.HandleImpl
-
- defaultMaybeMoreSupplier - Variable in class io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator.MaxMessageHandle
-
- DefaultMemcacheContent - Class in io.netty.handler.codec.memcache
-
- 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
-
- DefaultMessageSizeEstimator(int) - Constructor for class io.netty.channel.DefaultMessageSizeEstimator
-
Create a new instance
- DefaultMessageSizeEstimator.HandleImpl - Class in io.netty.channel
-
- 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
-
- defaultNameServerAddresses - Variable in class io.netty.resolver.dns.UnixResolverDnsServerAddressStreamProvider
-
- 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
-
- DefaultOioServerSocketChannelConfig(ServerSocketChannel, ServerSocket) - Constructor for class io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig
-
Deprecated.
- DefaultOioServerSocketChannelConfig(OioServerSocketChannel, ServerSocket) - Constructor for class io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig
-
- DefaultOioSocketChannelConfig - Class in io.netty.channel.socket.oio
-
- DefaultOioSocketChannelConfig(SocketChannel, Socket) - Constructor for class io.netty.channel.socket.oio.DefaultOioSocketChannelConfig
-
Deprecated.
- DefaultOioSocketChannelConfig(OioSocketChannel, Socket) - Constructor for class io.netty.channel.socket.oio.DefaultOioSocketChannelConfig
-
- DefaultOioUnsafe() - Constructor for class io.netty.channel.oio.AbstractOioChannel.DefaultOioUnsafe
-
- 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
-
- DefaultPriorityQueue.PriorityQueueIterator - Class in io.netty.util.internal
-
- defaultProcessId() - Static method in class io.netty.channel.DefaultChannelId
-
- 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
-
- DefaultPromise.CauseHolder - Class in io.netty.util.concurrent
-
- defaultProvider() - Static method in class io.netty.handler.ssl.SslContext
-
- DefaultResourceLeak(Object) - Constructor for class io.netty.util.ResourceLeakDetector.DefaultResourceLeak
-
- DefaultResourceLeakDetectorFactory() - Constructor for class io.netty.util.ResourceLeakDetectorFactory.DefaultResourceLeakDetectorFactory
-
- DefaultRunnableDecorator(Runnable) - Constructor for class io.netty.util.concurrent.DefaultThreadFactory.DefaultRunnableDecorator
-
- DefaultSctpChannelConfig - Class in io.netty.channel.sctp
-
- DefaultSctpChannelConfig(SctpChannel, SctpChannel) - Constructor for class io.netty.channel.sctp.DefaultSctpChannelConfig
-
- DefaultSctpServerChannelConfig - Class in io.netty.channel.sctp
-
- DefaultSctpServerChannelConfig(SctpServerChannel, SctpServerChannel) - Constructor for class io.netty.channel.sctp.DefaultSctpServerChannelConfig
-
Creates a new instance.
- DefaultSelectStrategy - Class in io.netty.channel
-
Default select strategy.
- DefaultSelectStrategy() - Constructor for class io.netty.channel.DefaultSelectStrategy
-
- DefaultSelectStrategyFactory - Class in io.netty.channel
-
Factory which uses the default select strategy.
- DefaultSelectStrategyFactory() - Constructor for class io.netty.channel.DefaultSelectStrategyFactory
-
- 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
-
- DefaultServerSocketChannelConfig(ServerSocketChannel, ServerSocket) - Constructor for class io.netty.channel.socket.DefaultServerSocketChannelConfig
-
Creates a new instance.
- DefaultServerUnsafe() - Constructor for class io.netty.channel.AbstractServerChannel.DefaultServerUnsafe
-
- 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
-
- 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.
- DefaultSmtpRequest(SmtpCommand, List<CharSequence>) - Constructor for class io.netty.handler.codec.smtp.DefaultSmtpRequest
-
- DefaultSmtpResponse - Class in io.netty.handler.codec.smtp
-
- 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.
- DefaultSmtpResponse(int, List<CharSequence>) - Constructor for class io.netty.handler.codec.smtp.DefaultSmtpResponse
-
- DefaultSocketChannelConfig - Class in io.netty.channel.socket
-
- DefaultSocketChannelConfig(SocketChannel, Socket) - Constructor for class io.netty.channel.socket.DefaultSocketChannelConfig
-
Creates a new instance.
- DefaultSocks4CommandRequest - Class in io.netty.handler.codec.socksx.v4
-
- DefaultSocks4CommandRequest(Socks4CommandType, String, int) - Constructor for class io.netty.handler.codec.socksx.v4.DefaultSocks4CommandRequest
-
Creates a new instance.
- DefaultSocks4CommandRequest(Socks4CommandType, String, int, String) - Constructor for class io.netty.handler.codec.socksx.v4.DefaultSocks4CommandRequest
-
Creates a new instance.
- DefaultSocks4CommandResponse - Class in io.netty.handler.codec.socksx.v4
-
- DefaultSocks4CommandResponse(Socks4CommandStatus) - Constructor for class io.netty.handler.codec.socksx.v4.DefaultSocks4CommandResponse
-
Creates a new instance.
- DefaultSocks4CommandResponse(Socks4CommandStatus, String, int) - Constructor for class io.netty.handler.codec.socksx.v4.DefaultSocks4CommandResponse
-
Creates a new instance.
- DefaultSocks5CommandRequest - Class in io.netty.handler.codec.socksx.v5
-
- DefaultSocks5CommandRequest(Socks5CommandType, Socks5AddressType, String, int) - Constructor for class io.netty.handler.codec.socksx.v5.DefaultSocks5CommandRequest
-
- DefaultSocks5CommandResponse - Class in io.netty.handler.codec.socksx.v5
-
- DefaultSocks5CommandResponse(Socks5CommandStatus, Socks5AddressType) - Constructor for class io.netty.handler.codec.socksx.v5.DefaultSocks5CommandResponse
-
- DefaultSocks5CommandResponse(Socks5CommandStatus, Socks5AddressType, String, int) - Constructor for class io.netty.handler.codec.socksx.v5.DefaultSocks5CommandResponse
-
- DefaultSocks5InitialRequest - Class in io.netty.handler.codec.socksx.v5
-
- DefaultSocks5InitialRequest(Socks5AuthMethod...) - Constructor for class io.netty.handler.codec.socksx.v5.DefaultSocks5InitialRequest
-
- DefaultSocks5InitialRequest(Iterable<Socks5AuthMethod>) - Constructor for class io.netty.handler.codec.socksx.v5.DefaultSocks5InitialRequest
-
- DefaultSocks5InitialResponse - Class in io.netty.handler.codec.socksx.v5
-
- DefaultSocks5InitialResponse(Socks5AuthMethod) - Constructor for class io.netty.handler.codec.socksx.v5.DefaultSocks5InitialResponse
-
- DefaultSocks5PasswordAuthRequest - Class in io.netty.handler.codec.socksx.v5
-
- DefaultSocks5PasswordAuthRequest(String, String) - Constructor for class io.netty.handler.codec.socksx.v5.DefaultSocks5PasswordAuthRequest
-
- DefaultSocks5PasswordAuthResponse - Class in io.netty.handler.codec.socksx.v5
-
- DefaultSocks5PasswordAuthResponse(Socks5PasswordAuthStatus) - Constructor for class io.netty.handler.codec.socksx.v5.DefaultSocks5PasswordAuthResponse
-
- DefaultStompContentSubframe - Class in io.netty.handler.codec.stomp
-
- DefaultStompContentSubframe(ByteBuf) - Constructor for class io.netty.handler.codec.stomp.DefaultStompContentSubframe
-
- DefaultStompFrame - Class in io.netty.handler.codec.stomp
-
- 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
-
- 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
-
- DefaultThreadFactory.DefaultRunnableDecorator - Class in io.netty.util.concurrent
-
- DefaultThreadProperties(Thread) - Constructor for class io.netty.util.concurrent.SingleThreadEventExecutor.DefaultThreadProperties
-
- defaultTinyCacheSize() - Static method in class io.netty.buffer.PooledByteBufAllocator
-
Default tiny cache size - System Property: io.netty.allocator.tinyCacheSize - default 512
- DefaultUnsafe() - Constructor for class io.netty.channel.embedded.EmbeddedChannel.DefaultUnsafe
-
- defaultValue - Variable in class io.netty.util.DomainNameMapping
-
- defaultValue - Variable in class io.netty.util.DomainNameMappingBuilder
-
- deflate(ByteBuf) - Method in class io.netty.handler.codec.compression.JdkZlibEncoder
-
- deflater - Variable in class io.netty.handler.codec.compression.JdkZlibEncoder
-
- deflaterException(Deflater, String, int) - Static method in class io.netty.handler.codec.compression.ZlibUtil
-
- DELAYED_RECYCLED - Static variable in class io.netty.util.Recycler
-
- DELAYED_RUNNABLES - Static variable in class io.netty.util.concurrent.ImmediateEventExecutor
-
A Runnable will be queued if we are executing a Runnable.
- delayNanos() - Method in class io.netty.util.concurrent.ScheduledFutureTask
-
- delayNanos(long) - Method in class io.netty.util.concurrent.ScheduledFutureTask
-
- 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 - Variable in class io.netty.channel.kqueue.KQueueRecvByteAllocatorHandle
-
- delegate - Variable in class io.netty.channel.nio.SelectedSelectionKeySetSelector
-
- delegate - Variable in class io.netty.channel.RecvByteBufAllocator.DelegatingHandle
-
- delegate() - Method in class io.netty.channel.RecvByteBufAllocator.DelegatingHandle
-
- delegate - Variable in class io.netty.handler.codec.serialization.CachingClassResolver
-
- delegate - Variable in class io.netty.handler.codec.serialization.ReferenceMap
-
- delegate - Variable in class io.netty.handler.ssl.util.X509TrustManagerWrapper
-
- delegate - Variable in class io.netty.resolver.dns.InflightNameResolver
-
- delegatedTaskExecutor - Variable in class io.netty.handler.ssl.SslHandler
-
- DelegatingChannelHandlerContext(ChannelHandlerContext, ChannelHandler) - Constructor for class io.netty.channel.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- 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
-
- DelegatingStringSet(Set<T>) - Constructor for class io.netty.handler.codec.HeadersUtils.DelegatingStringSet
-
- 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.
- DELETE_NATIVE_LIB_AFTER_LOADING - Static variable in class io.netty.util.internal.NativeLibraryLoader
-
- deleteGlobalRefs(long, long) - Static method in class io.netty.channel.kqueue.KQueueEventArray
-
- deleteJniChannelPointers() - Method in class io.netty.channel.kqueue.KQueueEventLoop
-
- DELETEQ - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
-
- DELIM_STR - Static variable in class io.netty.util.internal.logging.MessageFormatter
-
- DELIMITER_LENGTH - Static variable in class io.netty.handler.codec.haproxy.HAProxyMessageDecoder
-
Version 1 header delimiter is always '\r\n' per spec
- DelimiterBasedFrameDecoder - Class in io.netty.handler.codec
-
A decoder that splits the received
ByteBuf
s 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 - Static variable in class io.netty.handler.codec.DateFormatter
-
- delimiters - Variable in class io.netty.handler.codec.DelimiterBasedFrameDecoder
-
- Delimiters - Class in io.netty.handler.codec
-
- Delimiters() - Constructor for class io.netty.handler.codec.Delimiters
-
- DELTA_BADVAL - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseStatus
-
- depth(int) - Method in class io.netty.buffer.PoolChunk
-
- depthMap - Variable in class io.netty.buffer.PoolChunk
-
- depths - Variable in class io.netty.handler.codec.redis.RedisArrayAggregator
-
- deque - Variable in class io.netty.channel.pool.SimpleChannelPool
-
- dequeue(ChannelHandlerContext, int) - Method in class io.netty.handler.flow.FlowControlHandler
-
Dequeues one or many (or none) messages depending on the channel's auto
reading state and returns the number of messages that were consumed from
the internal queue.
- deregister(ChannelPromise) - Method in class io.netty.channel.AbstractChannel.AbstractUnsafe
-
- deregister(ChannelPromise, boolean) - 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() - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- deregister(ChannelPromise) - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- deregister(ChannelPromise) - Method in interface io.netty.channel.Channel.Unsafe
-
- 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() - Method in class io.netty.channel.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- deregister(ChannelPromise) - Method in class io.netty.channel.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- 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(ChannelHandlerContext, ChannelPromise) - Method in class io.netty.channel.DefaultChannelPipeline.HeadContext
-
- deregister() - Method in interface io.netty.channel.group.ChannelGroup
-
- deregister(ChannelMatcher) - Method in interface io.netty.channel.group.ChannelGroup
-
- 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
-
- dest - Variable in class io.netty.handler.codec.base64.Base64.Decoder
-
- DESTINATION - Static variable in interface io.netty.handler.codec.stomp.StompHeaders
-
- destinationAddress - Variable in class io.netty.handler.codec.haproxy.HAProxyMessage
-
- destinationAddress() - Method in class io.netty.handler.codec.haproxy.HAProxyMessage
-
Returns the human-readable destination address of this
HAProxyMessage
.
- destinationPort - Variable in class io.netty.handler.codec.haproxy.HAProxyMessage
-
- destinationPort() - Method in class io.netty.handler.codec.haproxy.HAProxyMessage
-
- destroy() - Method in class io.netty.buffer.PoolChunk
-
- destroy(PoolArena<T>) - Method in class io.netty.buffer.PoolChunkList
-
- destroy() - Method in class io.netty.buffer.PoolSubpage
-
- destroy() - Method in class io.netty.channel.DefaultChannelPipeline
-
Removes all handlers from the pipeline one by one from tail (exclusive) to head (exclusive) to trigger
handlerRemoved().
- destroy() - Method in class io.netty.handler.flow.FlowControlHandler
-
Releases all messages and destroys the Queue
.
- destroy() - Method in class io.netty.handler.ssl.PemPrivateKey
-
NOTE: This is a JDK8 interface/method.
- destroy() - Method in class io.netty.handler.timeout.IdleStateHandler
-
- destroy() - Static method in class io.netty.util.concurrent.FastThreadLocal
-
- destroy() - Static method in class io.netty.util.internal.InternalThreadLocalMap
-
- destroyChunk(PoolChunk<T>) - Method in class io.netty.buffer.PoolArena
-
- destroyChunk(PoolChunk<ByteBuffer>) - Method in class io.netty.buffer.PoolArena.DirectArena
-
- destroyChunk(PoolChunk<byte[]>) - Method in class io.netty.buffer.PoolArena.HeapArena
-
- destroyDown(Thread, AbstractChannelHandlerContext, boolean) - Method in class io.netty.channel.DefaultChannelPipeline
-
- destroyPoolChunkLists(PoolChunkList<T>...) - Method in class io.netty.buffer.PoolArena
-
- destroyPoolSubPages(PoolSubpage<?>[]) - Static method in class io.netty.buffer.PoolArena
-
- destroyUp(AbstractChannelHandlerContext, boolean) - Method in class io.netty.channel.DefaultChannelPipeline
-
- details - Variable in class io.netty.handler.codec.smtp.DefaultSmtpResponse
-
- 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.
- details - Variable in class io.netty.handler.codec.smtp.SmtpResponseDecoder
-
- detected(T) - Static method in class io.netty.handler.codec.ProtocolDetectionResult
-
- detectedProtocol() - Method in class io.netty.handler.codec.ProtocolDetectionResult
-
- DETECTION_RESULT_V1 - Static variable in class io.netty.handler.codec.haproxy.HAProxyMessageDecoder
-
- DETECTION_RESULT_V2 - Static variable in class io.netty.handler.codec.haproxy.HAProxyMessageDecoder
-
- detectProtocol(ByteBuf) - Static method in class io.netty.handler.codec.haproxy.HAProxyMessageDecoder
-
- 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.
- dialect - Variable in class io.netty.handler.codec.base64.Base64Decoder
-
- dialect - Variable in class io.netty.handler.codec.base64.Base64Encoder
-
- dictionary - Variable in class io.netty.handler.codec.compression.JdkZlibDecoder
-
- dictionary - Variable in class io.netty.handler.codec.compression.JZlibDecoder
-
- direct - Variable in class io.netty.buffer.CompositeByteBuf
-
- direct - Variable in class io.netty.buffer.FixedCompositeByteBuf
-
- DIRECT_BUFFER_CONSTRUCTOR - Static variable in class io.netty.util.internal.PlatformDependent0
-
- DIRECT_BUFFER_PREFERRED - Static variable in class io.netty.util.internal.PlatformDependent
-
- DIRECT_MEMORY_COUNTER - Static variable in class io.netty.util.internal.PlatformDependent
-
- DIRECT_MEMORY_LIMIT - Static variable in class io.netty.util.internal.PlatformDependent
-
- DirectArena(PooledByteBufAllocator, int, int, int, int, int) - Constructor for class io.netty.buffer.PoolArena.DirectArena
-
- directArena - Variable in class io.netty.buffer.PoolThreadCache
-
- directArenaMetrics - Variable in class io.netty.buffer.PooledByteBufAllocator
-
- directArenas - Variable in class io.netty.buffer.PooledByteBufAllocator
-
- directArenas() - Method in class io.netty.buffer.PooledByteBufAllocator
-
- directArenas() - Method in class io.netty.buffer.PooledByteBufAllocatorMetric
-
Return a
List
of all direct
PoolArenaMetric
s 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
-
- 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() - Method in class io.netty.channel.local.PreferHeapByteBufAllocator
-
- directBuffer(int) - Method in class io.netty.channel.local.PreferHeapByteBufAllocator
-
- directBuffer(int, int) - Method in class io.netty.channel.local.PreferHeapByteBufAllocator
-
- directBuffer(long, int) - Static method in class io.netty.util.internal.PlatformDependent
-
- directBufferAddress(ByteBuffer) - Static method in class io.netty.util.internal.PlatformDependent
-
- directBufferAddress(ByteBuffer) - Static method in class io.netty.util.internal.PlatformDependent0
-
- 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.
- directByDefault - Variable in class io.netty.buffer.AbstractByteBufAllocator
-
- directCounter - Variable in class io.netty.buffer.UnpooledByteBufAllocator.UnpooledByteBufAllocatorMetric
-
- directMemoryCacheAlignment - Variable in class io.netty.buffer.PoolArena
-
- directMemoryCacheAlignmentMask - Variable in class io.netty.buffer.PoolArena
-
- DISABLE_KEYSET_OPTIMIZATION - Static variable in class io.netty.channel.nio.NioEventLoop
-
- DISABLED - Static variable in class io.netty.handler.ssl.ApplicationProtocolConfig
-
The configuration that disables application protocol negotiation.
- disableLeakDetector - Variable in class io.netty.buffer.UnpooledByteBufAllocator
-
- discard(Throwable) - Method in class io.netty.handler.stream.ChunkedWriteHandler
-
- discardAfterReads - Variable in class io.netty.handler.codec.ByteToMessageDecoder
-
- discardedBytes - Variable in class io.netty.handler.codec.haproxy.HAProxyMessageDecoder
-
Number of discarded bytes
- discardedBytes - Variable in class io.netty.handler.codec.LineBasedFrameDecoder
-
- discarding - Variable in class io.netty.handler.codec.haproxy.HAProxyMessageDecoder
-
true
if we're discarding input because we're already over maxLength
- discarding - Variable in class io.netty.handler.codec.LineBasedFrameDecoder
-
True if we're discarding input because we're already over maxLength.
- discardingTooLongFrame - Variable in class io.netty.handler.codec.DelimiterBasedFrameDecoder
-
- discardingTooLongFrame - Variable in class io.netty.handler.codec.LengthFieldBasedFrameDecoder
-
- discardMarks() - Method in class io.netty.buffer.AbstractByteBuf
-
- discardReadBytes() - Method in class io.netty.buffer.AbstractByteBuf
-
- discardReadBytes() - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- discardReadBytes() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.FixedCompositeByteBuf
-
- discardReadBytes() - Method in class io.netty.buffer.ReadOnlyByteBuf
-
Deprecated.
- discardReadBytes() - Method in class io.netty.buffer.SwappedByteBuf
-
Deprecated.
- discardReadBytes() - Method in class io.netty.buffer.WrappedByteBuf
-
- discardReadBytes() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- discardReadBytes() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- discardReadComponents() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- discardReadComponents() - Method in class io.netty.buffer.CompositeByteBuf
-
Discard all
ByteBuf
s which are read.
- discardReadComponents() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- discardSomeReadBytes() - Method in class io.netty.buffer.AbstractByteBuf
-
- discardSomeReadBytes() - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- discardSomeReadBytes() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.buffer.WrappedByteBuf
-
- discardSomeReadBytes() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- discardSomeReadBytes() - Method in class io.netty.handler.codec.ByteToMessageDecoder
-
- discardSomeReadBytes() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- 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() - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- disconnect(ChannelPromise) - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- disconnect(ChannelPromise) - Method in interface io.netty.channel.Channel.Unsafe
-
- 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() - Method in class io.netty.channel.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- disconnect(ChannelPromise) - Method in class io.netty.channel.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- 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(ChannelHandlerContext, ChannelPromise) - Method in class io.netty.channel.DefaultChannelPipeline.HeadContext
-
- 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
Channel
s in this group from their remote peers.
- disconnect(ChannelMatcher) - Method in interface io.netty.channel.group.ChannelGroup
-
Disconnects all
Channel
s 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.
- DNS_PORT - Static variable in class io.netty.resolver.dns.DefaultDnsServerAddressStreamProvider
-
- 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
-
- DnsCacheEntry(String, InetAddress) - Constructor for class io.netty.resolver.dns.DnsCacheEntry
-
- DnsCacheEntry(String, Throwable) - Constructor for class io.netty.resolver.dns.DnsCacheEntry
-
- DnsCacheIterable(List<DnsCacheEntry>) - Constructor for class io.netty.resolver.dns.DnsNameResolverContext.DnsCacheIterable
-
- dnsClass - Variable in class io.netty.handler.codec.dns.AbstractDnsRecord
-
- 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
-
- DnsMessageUtil - Class in io.netty.handler.codec.dns
-
Provides some utility methods for DNS message implementations.
- DnsMessageUtil() - Constructor for class io.netty.handler.codec.dns.DnsMessageUtil
-
- DnsNameResolver - Class in io.netty.resolver.dns
-
- 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.
- DnsNameResolver.DnsResponseHandler - Class in io.netty.resolver.dns
-
- DnsNameResolver.ListResolverContext - Class in io.netty.resolver.dns
-
- DnsNameResolver.SingleResolverContext - Class in io.netty.resolver.dns
-
- DnsNameResolverBuilder - Class in io.netty.resolver.dns
-
- DnsNameResolverBuilder(EventLoop) - Constructor for class io.netty.resolver.dns.DnsNameResolverBuilder
-
Creates a new builder.
- DnsNameResolverContext<T> - Class in io.netty.resolver.dns
-
- DnsNameResolverContext(DnsNameResolver, String, DnsRecord[], DnsCache, DnsServerAddressStream) - Constructor for class io.netty.resolver.dns.DnsNameResolverContext
-
- DnsNameResolverContext.AuthoritativeNameServer - Class in io.netty.resolver.dns
-
- DnsNameResolverContext.AuthoritativeNameServerList - Class in io.netty.resolver.dns
-
Holds the closed DNS Servers for a domain.
- DnsNameResolverContext.DnsCacheIterable - Class in io.netty.resolver.dns
-
- DnsNameResolverContext.SearchDomainUnknownHostException - Exception in io.netty.resolver.dns
-
- 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) - Constructor for class io.netty.handler.codec.dns.DnsOpCode
-
- DnsOpCode(int, String) - Constructor for class io.netty.handler.codec.dns.DnsOpCode
-
- DnsOptEcsRecord - Interface in io.netty.handler.codec.dns
-
- DnsOptPseudoRecord - Interface in io.netty.handler.codec.dns
-
- DnsPtrRecord - Interface in io.netty.handler.codec.dns
-
- DnsQuery - Interface in io.netty.handler.codec.dns
-
A DNS query message.
- DnsQueryContext - Class in io.netty.resolver.dns
-
- DnsQueryContext(DnsNameResolver, InetSocketAddress, DnsQuestion, DnsRecord[], Promise<AddressedEnvelope<DnsResponse, InetSocketAddress>>) - Constructor for class io.netty.resolver.dns.DnsQueryContext
-
- DnsQueryContextManager - Class in io.netty.resolver.dns
-
- DnsQueryContextManager() - Constructor for class io.netty.resolver.dns.DnsQueryContextManager
-
- DnsQueryLifecycleObserver - Interface in io.netty.resolver.dns
-
This interface provides visibility into individual DNS queries.
- dnsQueryLifecycleObserverFactory - Variable in class io.netty.resolver.dns.DnsNameResolver
-
- dnsQueryLifecycleObserverFactory() - Method in class io.netty.resolver.dns.DnsNameResolver
-
- dnsQueryLifecycleObserverFactory - Variable in class io.netty.resolver.dns.DnsNameResolverBuilder
-
- 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
-
- 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) - Constructor for class io.netty.handler.codec.dns.DnsRecordType
-
- DnsRecordType(int, String) - Constructor for class io.netty.handler.codec.dns.DnsRecordType
-
- dnsRedirectPort(InetAddress) - Method in class io.netty.resolver.dns.DnsNameResolver
-
- 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) - Constructor for class io.netty.handler.codec.dns.DnsResponseCode
-
- DnsResponseCode(int, String) - Constructor for class io.netty.handler.codec.dns.DnsResponseCode
-
- DnsResponseHandler(Promise<Channel>) - Constructor for class io.netty.resolver.dns.DnsNameResolver.DnsResponseHandler
-
- DnsSection - Enum in io.netty.handler.codec.dns
-
- DnsSection() - Constructor for enum io.netty.handler.codec.dns.DnsSection
-
- dnsServerAddress - Variable in class io.netty.resolver.dns.TraceDnsQueryLifecycleObserver
-
- DnsServerAddresses - Class in io.netty.resolver.dns
-
- DnsServerAddresses() - Constructor for class io.netty.resolver.dns.DnsServerAddresses
-
- DnsServerAddressStream - Interface in io.netty.resolver.dns
-
An infinite stream of DNS server addresses.
- dnsServerAddressStreamProvider - Variable in class io.netty.resolver.dns.DnsNameResolver
-
- dnsServerAddressStreamProvider - Variable in class io.netty.resolver.dns.DnsNameResolverBuilder
-
- DnsServerAddressStreamProvider - Interface in io.netty.resolver.dns
-
- DnsServerAddressStreamProviders - Class in io.netty.resolver.dns
-
- DnsServerAddressStreamProviders() - Constructor for class io.netty.resolver.dns.DnsServerAddressStreamProviders
-
- DO_CLOSE_CLOSED_CHANNEL_EXCEPTION - Static variable in class io.netty.channel.kqueue.AbstractKQueueStreamChannel
-
- DO_CLOSE_CLOSED_CHANNEL_EXCEPTION - Static variable in class io.netty.channel.local.LocalChannel
-
- DO_CLOSE_CLOSED_CHANNEL_EXCEPTION - Static variable in class io.netty.channel.nio.AbstractNioChannel
-
- DO_WRITE_CLOSED_CHANNEL_EXCEPTION - Static variable in class io.netty.channel.local.LocalChannel
-
- 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.kqueue.AbstractKQueueChannel
-
- 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.bootstrap.AbstractBootstrap
-
- 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.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.sctp.nio.NioSctpChannel
-
- doBind(SocketAddress) - Method in class io.netty.channel.sctp.nio.NioSctpServerChannel
-
- doBind(SocketAddress) - Method in class io.netty.channel.sctp.oio.OioSctpChannel
-
- doBind(SocketAddress) - Method in class io.netty.channel.sctp.oio.OioSctpServerChannel
-
- 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
-
- doBind0(ChannelFuture, Channel, SocketAddress, ChannelPromise) - Static method in class io.netty.bootstrap.AbstractBootstrap
-
- doBind0(SocketAddress) - Method in class io.netty.channel.socket.nio.NioDatagramChannel
-
- doBind0(SocketAddress) - Method in class io.netty.channel.socket.nio.NioSocketChannel
-
- doClose() - Method in class io.netty.channel.AbstractChannel
-
- doClose() - Method in class io.netty.channel.embedded.EmbeddedChannel
-
- doClose() - Method in class io.netty.channel.kqueue.AbstractKQueueChannel
-
- 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.sctp.nio.NioSctpChannel
-
- doClose() - Method in class io.netty.channel.sctp.nio.NioSctpServerChannel
-
- doClose() - Method in class io.netty.channel.sctp.oio.OioSctpChannel
-
- doClose() - Method in class io.netty.channel.sctp.oio.OioSctpServerChannel
-
- 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
-
- doClose0(ChannelPromise) - Method in class io.netty.channel.AbstractChannel.AbstractUnsafe
-
- doConnect(SocketAddress, SocketAddress, ChannelPromise) - Static method in class io.netty.bootstrap.Bootstrap
-
- 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.sctp.nio.NioSctpChannel
-
- doConnect(SocketAddress, SocketAddress) - Method in class io.netty.channel.sctp.nio.NioSctpServerChannel
-
- doConnect(SocketAddress, SocketAddress) - Method in class io.netty.channel.sctp.oio.OioSctpChannel
-
- doConnect(SocketAddress, SocketAddress) - Method in class io.netty.channel.sctp.oio.OioSctpServerChannel
-
- 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
-
- doDeregister() - Method in class io.netty.channel.kqueue.AbstractKQueueChannel
-
- 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.kqueue.AbstractKQueueChannel
-
- 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.sctp.nio.NioSctpChannel
-
- doDisconnect() - Method in class io.netty.channel.sctp.nio.NioSctpServerChannel
-
- doDisconnect() - Method in class io.netty.channel.sctp.oio.OioSctpChannel
-
- doDisconnect() - Method in class io.netty.channel.sctp.oio.OioSctpServerChannel
-
- 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
-
- doEncode(ByteBufAllocator, MqttMessage) - Static method in class io.netty.handler.codec.mqtt.MqttEncoder
-
This is the main encoding method.
- doFinishConnect() - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel.KQueueStreamUnsafe
-
- doFinishConnect() - Method in class io.netty.channel.kqueue.KQueueSocketChannel.KQueueSocketChannelUnsafe
-
- doFinishConnect() - Method in class io.netty.channel.nio.AbstractNioChannel
-
Finish the connect
- doFinishConnect() - Method in class io.netty.channel.sctp.nio.NioSctpChannel
-
- doFinishConnect() - Method in class io.netty.channel.sctp.nio.NioSctpServerChannel
-
- 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
-
- doFlush(ChannelHandlerContext) - Method in class io.netty.handler.stream.ChunkedWriteHandler
-
- doHealthCheck(Channel, Promise<Channel>) - Method in class io.netty.channel.pool.SimpleChannelPool
-
- doHealthCheckOnRelease(Channel, Promise<Void>) - Method in class io.netty.channel.pool.SimpleChannelPool
-
- doIsResolved(T) - Method in class io.netty.resolver.AbstractAddressResolver
-
- doIsResolved(InetSocketAddress) - Method in class io.netty.resolver.InetSocketAddressResolver
-
- doIsResolved(SocketAddress) - Method in class io.netty.resolver.NoopAddressResolver
-
- DOMAIN - Static variable in class io.netty.handler.codec.socksx.v5.Socks5AddressType
-
- DOMAIN_ROW_LABEL - Static variable in class io.netty.resolver.dns.UnixResolverDnsServerAddressStreamProvider
-
- DOMAIN_SOCKET_READ_MODE - Static variable in class io.netty.channel.unix.UnixChannelOption
-
- DOMAIN_ZEROED - Static variable in class io.netty.handler.codec.socks.SocksCmdResponse
-
- DomainMappingBuilder<V> - Class in io.netty.util
-
- 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
- domainName - Variable in class io.netty.resolver.dns.DnsNameResolverContext.AuthoritativeNameServer
-
- domainName() - Method in class io.netty.resolver.dns.DnsNameResolverContext.AuthoritativeNameServer
-
- 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
-
- DomainNameMapping(int, V) - Constructor for class io.netty.util.DomainNameMapping
-
- DomainNameMapping(Map<String, V>, V) - Constructor for class io.netty.util.DomainNameMapping
-
- DomainNameMappingBuilder<V> - Class in io.netty.util
-
- 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
- DomainNameMappingBuilder.ImmutableDomainNameMapping<V> - Class in io.netty.util
-
Immutable mapping from domain name pattern to its associated value object.
- domainNamePatterns - Variable in class io.netty.util.DomainNameMappingBuilder.ImmutableDomainNameMapping
-
- DomainSocketAddress - Class in io.netty.channel.unix
-
- 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
-
- DomainSocketChannelConfig - Interface in io.netty.channel.unix
-
- DomainSocketReadMode - Enum in io.netty.channel.unix
-
- DomainSocketReadMode() - Constructor for enum io.netty.channel.unix.DomainSocketReadMode
-
- domainToNameServerStreamMap - Variable in class io.netty.resolver.dns.UnixResolverDnsServerAddressStreamProvider
-
- doneAdding - Variable in class io.netty.util.concurrent.PromiseCombiner
-
- doneCount - Variable in class io.netty.util.concurrent.PromiseCombiner
-
- doNotDestroy - Variable in class io.netty.buffer.PoolSubpage
-
- doNotFree - Variable in class io.netty.buffer.UnpooledDirectByteBuf
-
- doNotFree - Variable in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
-
- 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.kqueue.AbstractKQueueChannel
-
Read bytes into the given
ByteBuf
and return the amount.
- 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.sctp.nio.NioSctpChannel
-
- doReadMessages(List<Object>) - Method in class io.netty.channel.sctp.nio.NioSctpServerChannel
-
- doReadMessages(List<Object>) - Method in class io.netty.channel.sctp.oio.OioSctpChannel
-
- doReadMessages(List<Object>) - Method in class io.netty.channel.sctp.oio.OioSctpServerChannel
-
- 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.kqueue.AbstractKQueueChannel
-
- 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
-
- doReleaseChannel(Channel, Promise<Void>) - Method in class io.netty.channel.pool.SimpleChannelPool
-
- doResolve(T, Promise<T>) - Method in class io.netty.resolver.AbstractAddressResolver
-
- 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
-
- doResolveAll(T, Promise<List<T>>) - Method in class io.netty.resolver.AbstractAddressResolver
-
- 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
-
- doResolveAllCached(String, DnsRecord[], Promise<List<InetAddress>>, DnsCache) - Method in class io.netty.resolver.dns.DnsNameResolver
-
- doResolveAllRec(String, Promise<List<T>>, int, Throwable) - Method in class io.netty.resolver.CompositeNameResolver
-
- doResolveAllUncached(String, DnsRecord[], Promise<List<InetAddress>>, DnsCache) - Method in class io.netty.resolver.dns.DnsNameResolver
-
- doResolveAndConnect(SocketAddress, SocketAddress) - Method in class io.netty.bootstrap.Bootstrap
-
- doResolveAndConnect0(Channel, SocketAddress, SocketAddress, ChannelPromise) - Method in class io.netty.bootstrap.Bootstrap
-
- doResolveCached(String, DnsRecord[], Promise<InetAddress>, DnsCache) - Method in class io.netty.resolver.dns.DnsNameResolver
-
- doResolveRec(String, Promise<T>, int, Throwable) - Method in class io.netty.resolver.CompositeNameResolver
-
- doResolveUncached(String, DnsRecord[], Promise<InetAddress>, DnsCache) - Method in class io.netty.resolver.dns.DnsNameResolver
-
- doSearchDomainQuery(int, FutureListener<T>) - Method in class io.netty.resolver.dns.DnsNameResolverContext
-
- doStartThread() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- DOT_CRLF - Static variable in class io.netty.handler.codec.smtp.SmtpRequestEncoder
-
- DOT_CRLF_BUFFER - Static variable in class io.netty.handler.codec.smtp.SmtpRequestEncoder
-
- dots - Variable in class io.netty.resolver.dns.DnsNameResolverContext.AuthoritativeNameServer
-
- DOUBLE_QUOTE - Static variable in class io.netty.util.internal.StringUtil
-
- doubleArrayAppend(StringBuilder, double[]) - Static method in class io.netty.util.internal.logging.MessageFormatter
-
- 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.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.sctp.oio.OioSctpChannel
-
- doWrite(ChannelOutboundBuffer) - Method in class io.netty.channel.sctp.oio.OioSctpServerChannel
-
- 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, int) - Method in class io.netty.channel.kqueue.AbstractKQueueChannel
-
- 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
-
- 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) - Method in class io.netty.channel.kqueue.KQueueDatagramChannel
-
- 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.sctp.nio.NioSctpChannel
-
- doWriteMessage(Object, ChannelOutboundBuffer) - Method in class io.netty.channel.sctp.nio.NioSctpServerChannel
-
- doWriteMessage(Object, ChannelOutboundBuffer) - Method in class io.netty.channel.socket.nio.NioDatagramChannel
-
- doWriteMessage(Object, ChannelOutboundBuffer) - Method in class io.netty.channel.socket.nio.NioServerSocketChannel
-
- doWriteMultiple(ChannelOutboundBuffer, int) - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel
-
- doWriteSingle(ChannelOutboundBuffer, int) - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel
-
- doWriteSingle(ChannelOutboundBuffer, int) - Method in class io.netty.channel.kqueue.KQueueDomainSocketChannel
-
- dropHandle(Recycler.DefaultHandle<?>) - Method in class io.netty.util.Recycler.Stack
-
- 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.
- dstAddr - Variable in class io.netty.handler.codec.socksx.v4.DefaultSocks4CommandRequest
-
- dstAddr() - Method in class io.netty.handler.codec.socksx.v4.DefaultSocks4CommandRequest
-
- dstAddr - Variable in class io.netty.handler.codec.socksx.v4.DefaultSocks4CommandResponse
-
- dstAddr() - Method in class io.netty.handler.codec.socksx.v4.DefaultSocks4CommandResponse
-
- dstAddr() - Method in interface io.netty.handler.codec.socksx.v4.Socks4CommandRequest
-
Returns the DSTIP
field of this request.
- dstAddr() - Method in interface io.netty.handler.codec.socksx.v4.Socks4CommandResponse
-
Returns the DSTIP
field of this response.
- dstAddr - Variable in class io.netty.handler.codec.socksx.v4.Socks4ServerDecoder
-
- dstAddr - Variable in class io.netty.handler.codec.socksx.v5.DefaultSocks5CommandRequest
-
- dstAddr() - Method in class io.netty.handler.codec.socksx.v5.DefaultSocks5CommandRequest
-
- dstAddr() - Method in interface io.netty.handler.codec.socksx.v5.Socks5CommandRequest
-
Returns the DST.ADDR
field of this request.
- dstAddrType - Variable in class io.netty.handler.codec.socksx.v5.DefaultSocks5CommandRequest
-
- dstAddrType() - Method in class io.netty.handler.codec.socksx.v5.DefaultSocks5CommandRequest
-
- dstAddrType() - Method in interface io.netty.handler.codec.socksx.v5.Socks5CommandRequest
-
Returns the type of the DST.ADDR
field of this request.
- dstPort - Variable in class io.netty.handler.codec.socksx.v4.DefaultSocks4CommandRequest
-
- dstPort() - Method in class io.netty.handler.codec.socksx.v4.DefaultSocks4CommandRequest
-
- dstPort - Variable in class io.netty.handler.codec.socksx.v4.DefaultSocks4CommandResponse
-
- dstPort() - Method in class io.netty.handler.codec.socksx.v4.DefaultSocks4CommandResponse
-
- dstPort() - Method in interface io.netty.handler.codec.socksx.v4.Socks4CommandRequest
-
Returns the DSTPORT
field of this request.
- dstPort() - Method in interface io.netty.handler.codec.socksx.v4.Socks4CommandResponse
-
Returns the DSTPORT
field of this response.
- dstPort - Variable in class io.netty.handler.codec.socksx.v4.Socks4ServerDecoder
-
- dstPort - Variable in class io.netty.handler.codec.socksx.v5.DefaultSocks5CommandRequest
-
- dstPort() - Method in class io.netty.handler.codec.socksx.v5.DefaultSocks5CommandRequest
-
- dstPort() - Method in interface io.netty.handler.codec.socksx.v5.Socks5CommandRequest
-
Returns the DST.PORT
field of this request.
- DUMMY - Static variable in class io.netty.util.Recycler.WeakOrderQueue
-
- 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.AbstractPooledDerivedByteBuf.PooledNonRetainedDuplicateByteBuf
-
- duplicate() - Method in class io.netty.buffer.AbstractPooledDerivedByteBuf.PooledNonRetainedSlicedByteBuf
-
- duplicate() - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- duplicate() - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- duplicate() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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
-
- duplicate() - Method in class io.netty.buffer.DefaultByteBufHolder
-
- duplicate() - Method in class io.netty.buffer.EmptyByteBuf
-
- duplicate() - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- duplicate() - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- duplicate() - Method in class io.netty.buffer.ReadOnlyByteBuf
-
Deprecated.
- duplicate() - Method in class io.netty.buffer.SimpleLeakAwareByteBuf
-
- duplicate() - Method in class io.netty.buffer.SimpleLeakAwareCompositeByteBuf
-
- duplicate() - Method in class io.netty.buffer.SwappedByteBuf
-
Deprecated.
- duplicate() - Method in class io.netty.buffer.UnreleasableByteBuf
-
- duplicate() - Method in class io.netty.buffer.WrappedByteBuf
-
- duplicate() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- duplicate() - Method in class io.netty.channel.sctp.SctpMessage
-
- 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.haproxy.HAProxyTLV
-
- 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.ReplayingDecoderByteBuf
-
- 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 interface io.netty.handler.ssl.PemEncoded
-
- duplicate() - Method in class io.netty.handler.ssl.PemPrivateKey
-
- duplicate() - Method in class io.netty.handler.ssl.PemValue
-
- duplicate() - Method in class io.netty.handler.ssl.PemX509Certificate
-
- duplicate() - Method in interface io.netty.resolver.dns.DnsServerAddressStream
-
Duplicate this object.
- duplicate() - Method in class io.netty.resolver.dns.SequentialDnsServerAddressStream
-
- duplicate() - Method in class io.netty.resolver.dns.ShuffledDnsServerAddressStream
-
- duplicate0() - Method in class io.netty.buffer.AbstractPooledDerivedByteBuf
-
- DuplicatedByteBuf - Class in io.netty.buffer
-
- DuplicatedByteBuf(ByteBuf) - Constructor for class io.netty.buffer.DuplicatedByteBuf
-
Deprecated.
- DuplicatedByteBuf(ByteBuf, int, int) - Constructor for class io.netty.buffer.DuplicatedByteBuf
-
Deprecated.
- 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
-
- elements - Variable in class io.netty.util.Recycler.Stack
-
- elements - Variable in class io.netty.util.Recycler.WeakOrderQueue.Link
-
- elementSize() - Method in class io.netty.buffer.PoolSubpage
-
- elementSize() - Method in interface io.netty.buffer.PoolSubpageMetric
-
Return the size (in bytes) of the elements that will be allocated.
- elemSize - Variable in class io.netty.buffer.PoolSubpage
-
- 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
-
- 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.
- EmbeddedChannel.DefaultUnsafe - Class in io.netty.channel.embedded
-
- EmbeddedChannel.EmbeddedChannelPipeline - Class in io.netty.channel.embedded
-
- EmbeddedChannel.State - Enum in io.netty.channel.embedded
-
- EmbeddedChannelId - Class in io.netty.channel.embedded
-
- EmbeddedChannelId() - Constructor for class io.netty.channel.embedded.EmbeddedChannelId
-
- EmbeddedChannelPipeline(EmbeddedChannel) - Constructor for class io.netty.channel.embedded.EmbeddedChannel.EmbeddedChannelPipeline
-
- EmbeddedEventLoop - Class in io.netty.channel.embedded
-
- EmbeddedEventLoop() - Constructor for class io.netty.channel.embedded.EmbeddedEventLoop
-
- EmbeddedSocketAddress - Class in io.netty.channel.embedded
-
- EmbeddedSocketAddress() - Constructor for class io.netty.channel.embedded.EmbeddedSocketAddress
-
- EMPTY - Static variable in class io.netty.buffer.FixedCompositeByteBuf
-
- EMPTY - Static variable in class io.netty.channel.group.VoidChannelGroupFuture
-
- EMPTY - Static variable in class io.netty.resolver.HostsFileEntries
-
Empty entries
- EMPTY_ADDITIONALS - Static variable in class io.netty.resolver.dns.DnsNameResolver
-
- EMPTY_ARRAY - Static variable in class io.netty.util.internal.DefaultPriorityQueue
-
- 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_BUFFER - Static variable in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- EMPTY_BYTE_BUFFER - Static variable in class io.netty.buffer.EmptyByteBuf
-
- EMPTY_BYTE_BUFFER_ADDRESS - Static variable in class io.netty.buffer.EmptyByteBuf
-
- 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_HANDLERS - Static variable in class io.netty.channel.embedded.EmbeddedChannel
-
- EMPTY_INSTANCE - Static variable in class io.netty.handler.codec.redis.ArrayRedisMessage
-
- EMPTY_INSTANCE - Static variable in class io.netty.handler.codec.redis.FullBulkStringRedisMessage
-
- EMPTY_INTS - Static variable in class io.netty.util.internal.EmptyArrays
-
- EMPTY_ITERATOR - Static variable in class io.netty.buffer.CompositeByteBuf
-
- 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_MAP - Static variable in class io.netty.util.collection.ByteCollections
-
- EMPTY_MAP - Static variable in class io.netty.util.collection.CharCollections
-
- EMPTY_MAP - Static variable in class io.netty.util.collection.IntCollections
-
- EMPTY_MAP - Static variable in class io.netty.util.collection.LongCollections
-
- EMPTY_MAP - Static variable in class io.netty.util.collection.ShortCollections
-
- EMPTY_METRICS - Static variable in class io.netty.buffer.PoolChunkList
-
- EMPTY_NIO_BUFFER - Static variable in class io.netty.buffer.CompositeByteBuf
-
- EMPTY_OBJECTS - Static variable in class io.netty.util.internal.EmptyArrays
-
- EMPTY_SELECTION - Static variable in class io.netty.handler.ssl.SniHandler
-
- 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
-
- emptyAdditionals(DnsRecord[]) - Static method in class io.netty.resolver.dns.DefaultDnsCache
-
- EmptyArrays - Class in io.netty.util.internal
-
- EmptyArrays() - Constructor for class io.netty.util.internal.EmptyArrays
-
- emptyBuf - Variable in class io.netty.buffer.AbstractByteBufAllocator
-
- 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
-
- EmptyByteBuf(ByteBufAllocator, ByteOrder) - 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
-
- EmptyMap() - Constructor for class io.netty.util.collection.ByteCollections.EmptyMap
-
- emptyMap() - Static method in class io.netty.util.collection.CharCollections
-
- EmptyMap() - Constructor for class io.netty.util.collection.CharCollections.EmptyMap
-
- emptyMap() - Static method in class io.netty.util.collection.IntCollections
-
- EmptyMap() - Constructor for class io.netty.util.collection.IntCollections.EmptyMap
-
- emptyMap() - Static method in class io.netty.util.collection.LongCollections
-
- EmptyMap() - Constructor for class io.netty.util.collection.LongCollections.EmptyMap
-
- emptyMap() - Static method in class io.netty.util.collection.ShortCollections
-
- EmptyMap() - Constructor for class io.netty.util.collection.ShortCollections.EmptyMap
-
- EmptyPriorityQueue<T> - Class in io.netty.util.internal
-
- EmptyPriorityQueue() - Constructor for class io.netty.util.internal.EmptyPriorityQueue
-
- enableAutoReadTask - Variable in class io.netty.bootstrap.ServerBootstrap.ServerBootstrapAcceptor
-
- enableOcsp - Variable in class io.netty.handler.ssl.SslContextBuilder
-
- enableOcsp(boolean) - Method in class io.netty.handler.ssl.SslContextBuilder
-
Enables OCSP stapling.
- encapsulatedTLVs() - Method in class io.netty.handler.codec.haproxy.HAProxySSLTLV
-
Returns an unmodifiable Set of encapsulated
HAProxyTLV
s.
- 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, I, ByteBuf) - Method in class io.netty.handler.codec.ByteToMessageCodec.Encoder
-
- encode(ChannelHandlerContext, ByteBuf, ByteBuf) - Method in class io.netty.handler.codec.compression.Bzip2Encoder
-
- encode(ByteBuf) - Method in class io.netty.handler.codec.compression.Bzip2HuffmanStageEncoder
-
Encodes and writes the block data.
- encode() - Method in class io.netty.handler.codec.compression.Bzip2MTFAndRLE2StageEncoder
-
Performs the Move To Front transform and Run Length Encoding[1] stages.
- 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, Object, List<Object>) - Method in class io.netty.handler.codec.memcache.binary.BinaryMemcacheClientCodec.Encoder
-
- encode(ChannelHandlerContext, I, ByteBuf) - Method in class io.netty.handler.codec.MessageToByteEncoder
-
- 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, ByteBuf, List<Object>) - Method in class io.netty.handler.codec.sctp.SctpOutboundByteStreamHandler
-
- 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(ByteBuf) - Method in class io.netty.handler.codec.smtp.SmtpCommand
-
- encode(ChannelHandlerContext, Object, List<Object>) - Method in class io.netty.handler.codec.smtp.SmtpRequestEncoder
-
- encode(ChannelHandlerContext, SocksMessage, ByteBuf) - Method in class io.netty.handler.codec.socks.SocksMessageEncoder
-
- encode(ChannelHandlerContext, Socks4CommandRequest, ByteBuf) - Method in class io.netty.handler.codec.socksx.v4.Socks4ClientEncoder
-
- encode(ChannelHandlerContext, Socks4CommandResponse, ByteBuf) - Method in class io.netty.handler.codec.socksx.v4.Socks4ServerEncoder
-
- encode(ChannelHandlerContext, Socks5Message, ByteBuf) - Method in class io.netty.handler.codec.socksx.v5.Socks5ClientEncoder
-
- encode(ChannelHandlerContext, Socks5Message, ByteBuf) - Method in class io.netty.handler.codec.socksx.v5.Socks5ServerEncoder
-
- 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
-
- encode3to4(ByteBuf, int, int, ByteBuf, int, byte[]) - Static method in class io.netty.handler.codec.base64.Base64
-
- encode3to4BigEndian(int, int, ByteBuf, int, byte[]) - Static method in class io.netty.handler.codec.base64.Base64
-
- encode3to4LittleEndian(int, int, ByteBuf, int, byte[]) - Static method in class io.netty.handler.codec.base64.Base64
-
- encodeAddress(Socks5AddressType, String, ByteBuf) - Method in interface io.netty.handler.codec.socksx.v5.Socks5AddressEncoder
-
Encodes a SOCKS5 address.
- encodeAndRetain(Object) - Static method in class io.netty.handler.codec.memcache.AbstractMemcacheObjectEncoder
-
Encode the content, depending on the object type.
- encodeAsByteBuf(ByteBuf) - Method in class io.netty.handler.codec.socks.SocksAuthRequest
-
- encodeAsByteBuf(ByteBuf) - Method in class io.netty.handler.codec.socks.SocksAuthResponse
-
- encodeAsByteBuf(ByteBuf) - Method in class io.netty.handler.codec.socks.SocksCmdRequest
-
- encodeAsByteBuf(ByteBuf) - Method in class io.netty.handler.codec.socks.SocksCmdResponse
-
- encodeAsByteBuf(ByteBuf) - Method in class io.netty.handler.codec.socks.SocksInitRequest
-
- encodeAsByteBuf(ByteBuf) - Method in class io.netty.handler.codec.socks.SocksInitResponse
-
- encodeAsByteBuf(ByteBuf) - Method in class io.netty.handler.codec.socks.SocksMessage
-
- encodeAsByteBuf(ByteBuf) - Method in class io.netty.handler.codec.socks.UnknownSocksRequest
-
- encodeAsByteBuf(ByteBuf) - Method in class io.netty.handler.codec.socks.UnknownSocksResponse
-
- encodeAuthMethodRequest(Socks5InitialRequest, ByteBuf) - Static method in class io.netty.handler.codec.socksx.v5.Socks5ClientEncoder
-
- encodeAuthMethodResponse(Socks5InitialResponse, ByteBuf) - Static method in class io.netty.handler.codec.socksx.v5.Socks5ServerEncoder
-
- encodeCommandRequest(Socks5CommandRequest, ByteBuf) - Method in class io.netty.handler.codec.socksx.v5.Socks5ClientEncoder
-
- encodeCommandResponse(Socks5CommandResponse, ByteBuf) - Method in class io.netty.handler.codec.socksx.v5.Socks5ServerEncoder
-
- encodeConnAckMessage(ByteBufAllocator, MqttConnAckMessage) - Static method in class io.netty.handler.codec.mqtt.MqttEncoder
-
- encodeConnectMessage(ByteBufAllocator, MqttConnectMessage) - Static method in class io.netty.handler.codec.mqtt.MqttEncoder
-
- encodeContent(StompContentSubframe, ChannelHandlerContext) - Static method in class io.netty.handler.codec.stomp.StompSubframeEncoder
-
- encodeCopy(ByteBuf, int, int) - Static method in class io.netty.handler.codec.compression.Snappy
-
Encodes a series of copies, each at most 64 bytes in length.
- encodeCopyWithOffset(ByteBuf, int, int) - Static method in class io.netty.handler.codec.compression.Snappy
-
- encodedBufferSize(int, boolean) - Static method in class io.netty.handler.codec.base64.Base64
-
- encodeExtras(ByteBuf, ByteBuf) - Static method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheEncoder
-
Encode the extras.
- encodeFrame(StompHeadersSubframe, ChannelHandlerContext) - Static method in class io.netty.handler.codec.stomp.StompSubframeEncoder
-
- encodeHeader(DnsQuery, ByteBuf) - Static method in class io.netty.handler.codec.dns.DatagramDnsQueryEncoder
-
Encodes the header that is always 12 bytes long.
- encodeHeader(DnsResponse, ByteBuf) - Static method in class io.netty.handler.codec.dns.DatagramDnsResponseEncoder
-
Encodes the header that is always 12 bytes long.
- 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
-
- encodeKey(ByteBuf, ByteBuf) - Static method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheEncoder
-
Encode the key.
- encodeLiteral(ByteBuf, ByteBuf, int) - Static method in class io.netty.handler.codec.compression.Snappy
-
Writes a literal to the supplied output buffer by directly copying from
the input buffer.
- encodeMessage(ChannelHandlerContext, M) - Method in class io.netty.handler.codec.memcache.AbstractMemcacheObjectEncoder
-
- encodeMessage(ChannelHandlerContext, M) - Method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheEncoder
-
- encodeMessageWithOnlySingleByteFixedHeader(ByteBufAllocator, MqttMessage) - Static method in class io.netty.handler.codec.mqtt.MqttEncoder
-
- encodeMessageWithOnlySingleByteFixedHeaderAndMessageId(ByteBufAllocator, MqttMessage) - Static method in class io.netty.handler.codec.mqtt.MqttEncoder
-
- encodeName(String, ByteBuf) - Method in class io.netty.handler.codec.dns.DefaultDnsRecordEncoder
-
- encodeOptEcsRecord(DnsOptEcsRecord, ByteBuf) - Method in class io.netty.handler.codec.dns.DefaultDnsRecordEncoder
-
- encodeOptPseudoRecord(DnsOptPseudoRecord, ByteBuf) - Method in class io.netty.handler.codec.dns.DefaultDnsRecordEncoder
-
- encodePasswordAuthRequest(Socks5PasswordAuthRequest, ByteBuf) - Static method in class io.netty.handler.codec.socksx.v5.Socks5ClientEncoder
-
- encodePasswordAuthResponse(Socks5PasswordAuthResponse, ByteBuf) - Static method in class io.netty.handler.codec.socksx.v5.Socks5ServerEncoder
-
- encodePtrRecord(DnsPtrRecord, ByteBuf) - Method in class io.netty.handler.codec.dns.DefaultDnsRecordEncoder
-
- encodePublishMessage(ByteBufAllocator, MqttPublishMessage) - Static method in class io.netty.handler.codec.mqtt.MqttEncoder
-
- encodeQuestion(DnsQuestion, ByteBuf) - Method in class io.netty.handler.codec.dns.DefaultDnsRecordEncoder
-
- encodeQuestion(DnsQuestion, ByteBuf) - Method in interface io.netty.handler.codec.dns.DnsRecordEncoder
-
- encodeQuestions(DnsQuery, ByteBuf) - Method in class io.netty.handler.codec.dns.DatagramDnsQueryEncoder
-
- encodeQuestions(DnsResponse, ByteBuf) - Method in class io.netty.handler.codec.dns.DatagramDnsResponseEncoder
-
- encoder - Variable in class io.netty.handler.codec.ByteToMessageCodec
-
- Encoder(boolean) - Constructor for class io.netty.handler.codec.ByteToMessageCodec.Encoder
-
- encoder - Variable in class io.netty.handler.codec.DatagramPacketEncoder
-
- Encoder() - Constructor for class io.netty.handler.codec.memcache.binary.BinaryMemcacheClientCodec.Encoder
-
- encoder - Variable in class io.netty.handler.codec.MessageToMessageCodec
-
- ENCODER - Static variable in class io.netty.resolver.dns.DnsNameResolver
-
- 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
.
- encodeRawRecord(DnsRawRecord, ByteBuf) - Method in class io.netty.handler.codec.dns.DefaultDnsRecordEncoder
-
- encodeRecord(DnsRecord, ByteBuf) - Method in class io.netty.handler.codec.dns.DefaultDnsRecordEncoder
-
- encodeRecord(DnsRecord, ByteBuf) - Method in interface io.netty.handler.codec.dns.DnsRecordEncoder
-
- encodeRecord0(DnsRecord, ByteBuf) - Method in class io.netty.handler.codec.dns.DefaultDnsRecordEncoder
-
- encodeRecords(DnsQuery, DnsSection, ByteBuf) - Method in class io.netty.handler.codec.dns.DatagramDnsQueryEncoder
-
- encodeRecords(DnsResponse, DnsSection, ByteBuf) - Method in class io.netty.handler.codec.dns.DatagramDnsResponseEncoder
-
- EncoderException - Exception in io.netty.handler.codec
-
- 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
.
- encodeString0(ByteBufAllocator, boolean, CharBuffer, Charset, int) - Static method in class io.netty.buffer.ByteBufUtil
-
- encodeStringUtf8(String) - Static method in class io.netty.handler.codec.mqtt.MqttEncoder
-
- encodeSubAckMessage(ByteBufAllocator, MqttSubAckMessage) - Static method in class io.netty.handler.codec.mqtt.MqttEncoder
-
- encodeSubscribeMessage(ByteBufAllocator, MqttSubscribeMessage) - Static method in class io.netty.handler.codec.mqtt.MqttEncoder
-
- encodeUnsubscribeMessage(ByteBufAllocator, MqttUnsubscribeMessage) - Static method in class io.netty.handler.codec.mqtt.MqttEncoder
-
- END_CERT - Static variable in class io.netty.handler.ssl.PemX509Certificate
-
- END_OF_STREAM_MAGIC_1 - Static variable in class io.netty.handler.codec.compression.Bzip2Constants
-
End of stream magic number.
- END_OF_STREAM_MAGIC_2 - Static variable in class io.netty.handler.codec.compression.Bzip2Constants
-
- END_PRIVATE_KEY - Static variable in class io.netty.handler.ssl.PemPrivateKey
-
- endIndex - Variable in class io.netty.buffer.ByteBufInputStream
-
- endOffset - Variable in class io.netty.buffer.CompositeByteBuf.Component
-
- endOffset - Variable in class io.netty.buffer.FixedCompositeByteBuf.Component
-
- endOffset - Variable in class io.netty.handler.stream.ChunkedFile
-
- endOffset() - Method in class io.netty.handler.stream.ChunkedFile
-
Returns the offset in the file where the transfer will end.
- endOffset - Variable in class io.netty.handler.stream.ChunkedNioFile
-
- 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 - Variable in class io.netty.handler.ssl.JdkSslEngine
-
- engine - Variable in class io.netty.handler.ssl.JdkSslSession
-
- engine - Variable in class io.netty.handler.ssl.SslHandler
-
- 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.
- engineGetTrustManagers() - Method in class io.netty.handler.ssl.util.SimpleTrustManagerFactory.SimpleTrustManagerFactorySpi
-
- 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.
- engineInit(KeyStore) - Method in class io.netty.handler.ssl.util.SimpleTrustManagerFactory.SimpleTrustManagerFactorySpi
-
- engineInit(ManagerFactoryParameters) - Method in class io.netty.handler.ssl.util.SimpleTrustManagerFactory.SimpleTrustManagerFactorySpi
-
- engineType - Variable in class io.netty.handler.ssl.SslHandler
-
- engineWrapper - Variable in class io.netty.handler.ssl.JdkBaseApplicationProtocolNegotiator.NoFailProtocolSelectionListener
-
- engineWrapper - Variable in class io.netty.handler.ssl.JdkBaseApplicationProtocolNegotiator.NoFailProtocolSelector
-
- ENOMEM - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseStatus
-
- ENSURE_OPEN_CLOSED_CHANNEL_EXCEPTION - Static variable in class io.netty.channel.AbstractChannel
-
- 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.kqueue.KQueue
-
- ensureBound() - Method in class io.netty.channel.socket.oio.OioDatagramChannel
-
- 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.AdvancedLeakAwareByteBuf
-
- ensureWritable(int, boolean) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- ensureWritable(int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- ensureWritable(int, boolean) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.
- ensureWritable(int) - Method in class io.netty.buffer.WrappedByteBuf
-
- ensureWritable(int, boolean) - Method in class io.netty.buffer.WrappedByteBuf
-
- ensureWritable(int, boolean) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- ensureWritable(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- ensureWritable(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- ensureWritable(int, boolean) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- ensureWritable0(int) - Method in class io.netty.buffer.AbstractByteBuf
-
- entries - Variable in class io.netty.handler.codec.DefaultHeaders
-
- entries - Variable in class io.netty.resolver.dns.DnsNameResolverContext.DnsCacheIterable
-
- entries() - Method in class io.netty.util.collection.ByteCollections.EmptyMap
-
- entries - Variable in class io.netty.util.collection.ByteCollections.UnmodifiableMap
-
- entries() - Method in class io.netty.util.collection.ByteCollections.UnmodifiableMap
-
- entries - Variable in class io.netty.util.collection.ByteObjectHashMap
-
- 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.CharCollections.EmptyMap
-
- entries - Variable in class io.netty.util.collection.CharCollections.UnmodifiableMap
-
- entries() - Method in class io.netty.util.collection.CharCollections.UnmodifiableMap
-
- entries - Variable in class io.netty.util.collection.CharObjectHashMap
-
- 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.IntCollections.EmptyMap
-
- entries - Variable in class io.netty.util.collection.IntCollections.UnmodifiableMap
-
- entries() - Method in class io.netty.util.collection.IntCollections.UnmodifiableMap
-
- entries - Variable in class io.netty.util.collection.IntObjectHashMap
-
- 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.LongCollections.EmptyMap
-
- entries - Variable in class io.netty.util.collection.LongCollections.UnmodifiableMap
-
- entries() - Method in class io.netty.util.collection.LongCollections.UnmodifiableMap
-
- entries - Variable in class io.netty.util.collection.LongObjectHashMap
-
- 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.ShortCollections.EmptyMap
-
- entries - Variable in class io.netty.util.collection.ShortCollections.UnmodifiableMap
-
- entries() - Method in class io.netty.util.collection.ShortCollections.UnmodifiableMap
-
- entries - Variable in class io.netty.util.collection.ShortObjectHashMap
-
- 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.
- Entry(Recycler.Handle<PoolThreadCache.MemoryRegionCache.Entry<?>>) - Constructor for class io.netty.buffer.PoolThreadCache.MemoryRegionCache.Entry
-
- Entry(Recycler.Handle<ChannelOutboundBuffer.Entry>) - Constructor for class io.netty.channel.ChannelOutboundBuffer.Entry
-
- entry - Variable in class io.netty.handler.codec.HeadersUtils.StringEntry
-
- entry - Variable in class io.netty.util.collection.ByteCollections.UnmodifiableMap.EntryImpl
-
- entry - Variable in class io.netty.util.collection.CharCollections.UnmodifiableMap.EntryImpl
-
- entry - Variable in class io.netty.util.collection.IntCollections.UnmodifiableMap.EntryImpl
-
- entry - Variable in class io.netty.util.collection.LongCollections.UnmodifiableMap.EntryImpl
-
- entry - Variable in class io.netty.util.collection.ShortCollections.UnmodifiableMap.EntryImpl
-
- Entry(Thread, Runnable, boolean) - Constructor for class io.netty.util.ThreadDeathWatcher.Entry
-
- EntryImpl(ByteObjectMap.PrimitiveEntry<V>) - Constructor for class io.netty.util.collection.ByteCollections.UnmodifiableMap.EntryImpl
-
- EntryImpl(CharObjectMap.PrimitiveEntry<V>) - Constructor for class io.netty.util.collection.CharCollections.UnmodifiableMap.EntryImpl
-
- EntryImpl(IntObjectMap.PrimitiveEntry<V>) - Constructor for class io.netty.util.collection.IntCollections.UnmodifiableMap.EntryImpl
-
- EntryImpl(LongObjectMap.PrimitiveEntry<V>) - Constructor for class io.netty.util.collection.LongCollections.UnmodifiableMap.EntryImpl
-
- EntryImpl(ShortObjectMap.PrimitiveEntry<V>) - Constructor for class io.netty.util.collection.ShortCollections.UnmodifiableMap.EntryImpl
-
- entryIndex - Variable in class io.netty.util.collection.ByteObjectHashMap.MapEntry
-
- entryIndex - Variable in class io.netty.util.collection.ByteObjectHashMap.PrimitiveIterator
-
- entryIndex - Variable in class io.netty.util.collection.CharObjectHashMap.MapEntry
-
- entryIndex - Variable in class io.netty.util.collection.CharObjectHashMap.PrimitiveIterator
-
- entryIndex - Variable in class io.netty.util.collection.IntObjectHashMap.MapEntry
-
- entryIndex - Variable in class io.netty.util.collection.IntObjectHashMap.PrimitiveIterator
-
- entryIndex - Variable in class io.netty.util.collection.LongObjectHashMap.MapEntry
-
- entryIndex - Variable in class io.netty.util.collection.LongObjectHashMap.PrimitiveIterator
-
- entryIndex - Variable in class io.netty.util.collection.ShortObjectHashMap.MapEntry
-
- entryIndex - Variable in class io.netty.util.collection.ShortObjectHashMap.PrimitiveIterator
-
- entrySet() - Method in class io.netty.handler.codec.serialization.ReferenceMap
-
- entrySet() - Method in class io.netty.util.collection.ByteCollections.EmptyMap
-
- entrySet - Variable in class io.netty.util.collection.ByteCollections.UnmodifiableMap
-
- entrySet() - Method in class io.netty.util.collection.ByteCollections.UnmodifiableMap
-
- entrySet - Variable in class io.netty.util.collection.ByteObjectHashMap
-
- entrySet() - Method in class io.netty.util.collection.ByteObjectHashMap
-
- EntrySet() - Constructor for class io.netty.util.collection.ByteObjectHashMap.EntrySet
-
- entrySet() - Method in class io.netty.util.collection.CharCollections.EmptyMap
-
- entrySet - Variable in class io.netty.util.collection.CharCollections.UnmodifiableMap
-
- entrySet() - Method in class io.netty.util.collection.CharCollections.UnmodifiableMap
-
- entrySet - Variable in class io.netty.util.collection.CharObjectHashMap
-
- entrySet() - Method in class io.netty.util.collection.CharObjectHashMap
-
- EntrySet() - Constructor for class io.netty.util.collection.CharObjectHashMap.EntrySet
-
- entrySet() - Method in class io.netty.util.collection.IntCollections.EmptyMap
-
- entrySet - Variable in class io.netty.util.collection.IntCollections.UnmodifiableMap
-
- entrySet() - Method in class io.netty.util.collection.IntCollections.UnmodifiableMap
-
- entrySet - Variable in class io.netty.util.collection.IntObjectHashMap
-
- entrySet() - Method in class io.netty.util.collection.IntObjectHashMap
-
- EntrySet() - Constructor for class io.netty.util.collection.IntObjectHashMap.EntrySet
-
- entrySet() - Method in class io.netty.util.collection.LongCollections.EmptyMap
-
- entrySet - Variable in class io.netty.util.collection.LongCollections.UnmodifiableMap
-
- entrySet() - Method in class io.netty.util.collection.LongCollections.UnmodifiableMap
-
- entrySet - Variable in class io.netty.util.collection.LongObjectHashMap
-
- entrySet() - Method in class io.netty.util.collection.LongObjectHashMap
-
- EntrySet() - Constructor for class io.netty.util.collection.LongObjectHashMap.EntrySet
-
- entrySet() - Method in class io.netty.util.collection.ShortCollections.EmptyMap
-
- entrySet - Variable in class io.netty.util.collection.ShortCollections.UnmodifiableMap
-
- entrySet() - Method in class io.netty.util.collection.ShortCollections.UnmodifiableMap
-
- entrySet - Variable in class io.netty.util.collection.ShortObjectHashMap
-
- entrySet() - Method in class io.netty.util.collection.ShortObjectHashMap
-
- EntrySet() - Constructor for class io.netty.util.collection.ShortObjectHashMap.EntrySet
-
- EOL_LENGTH - Static variable in class io.netty.handler.codec.redis.RedisConstants
-
- EOL_SHORT - Static variable in class io.netty.handler.codec.redis.RedisConstants
-
- 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.buffer.WrappedByteBuf
-
- equals(Object) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- 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.embedded.EmbeddedChannelId
-
- 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.sctp.SctpMessage
-
- 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
-
- equals(Object) - Method in class io.netty.handler.codec.EmptyHeaders
-
- equals(Object) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- 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.socksx.v4.Socks4CommandStatus
-
- equals(Object) - Method in class io.netty.handler.codec.socksx.v4.Socks4CommandType
-
- equals(Object) - Method in class io.netty.handler.codec.socksx.v5.Socks5AddressType
-
- equals(Object) - Method in class io.netty.handler.codec.socksx.v5.Socks5AuthMethod
-
- equals(Object) - Method in class io.netty.handler.codec.socksx.v5.Socks5CommandStatus
-
- equals(Object) - Method in class io.netty.handler.codec.socksx.v5.Socks5CommandType
-
- equals(Object) - Method in class io.netty.handler.codec.socksx.v5.Socks5PasswordAuthStatus
-
- 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(char, char) - Method in class io.netty.util.AsciiString.AsciiCaseInsensitiveCharEqualityComparator
-
- equals(char, char) - Method in interface io.netty.util.AsciiString.CharEqualityComparator
-
- equals(char, char) - Method in class io.netty.util.AsciiString.DefaultCharEqualityComparator
-
- equals(Object) - Method in class io.netty.util.AsciiString
-
- equals(char, char) - Method in class io.netty.util.AsciiString.GeneralCaseInsensitiveCharEqualityComparator
-
- 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(Object) - Method in class io.netty.util.concurrent.PromiseTask
-
- 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(byte[], int, byte[], int, int) - Static method in class io.netty.util.internal.PlatformDependent0
-
- equals(Object) - Method in class io.netty.util.ResourceLeakDetector.LeakEntry
-
- equals(Object) - Method in exception io.netty.util.ResourceLeakException
-
Deprecated.
- equals(Object) - Method in error io.netty.util.Signal
-
- equals(Object) - Method in class io.netty.util.ThreadDeathWatcher.Entry
-
- EQUALS_SIGN - Static variable in class io.netty.handler.codec.base64.Base64
-
The equals sign (=) as a byte.
- EQUALS_SIGN_ENC - Static variable in class io.netty.handler.codec.base64.Base64
-
- equalsConstantTime(int, int) - Static method in class io.netty.util.internal.ConstantTimeUtils
-
Compare two int
s without leaking timing information.
- equalsConstantTime(long, long) - Static method in class io.netty.util.internal.ConstantTimeUtils
-
Compare two longs
s 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.
- equalsConstantTime(byte[], int, byte[], int, int) - Static method in class io.netty.util.internal.PlatformDependent0
-
- equalsIgnoreCase(byte, byte) - Static method in class io.netty.util.AsciiString
-
- equalsIgnoreCase(char, char) - Static method in class io.netty.util.AsciiString
-
- equalsSafe(byte[], int, byte[], int, int) - Static method in class io.netty.util.internal.PlatformDependent
-
- 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
-
- errnoEAGAIN() - Static method in class io.netty.channel.unix.ErrorsStaticallyReferencedJniMethods
-
- errnoEBADF() - Static method in class io.netty.channel.unix.ErrorsStaticallyReferencedJniMethods
-
- errnoECONNRESET() - Static method in class io.netty.channel.unix.ErrorsStaticallyReferencedJniMethods
-
- errnoEINPROGRESS() - Static method in class io.netty.channel.unix.ErrorsStaticallyReferencedJniMethods
-
- errnoENOTCONN() - Static method in class io.netty.channel.unix.ErrorsStaticallyReferencedJniMethods
-
- errnoEPIPE() - Static method in class io.netty.channel.unix.ErrorsStaticallyReferencedJniMethods
-
- errnoEWOULDBLOCK() - Static method in class io.netty.channel.unix.ErrorsStaticallyReferencedJniMethods
-
- error(Throwable) - Method in class io.netty.util.internal.logging.AbstractInternalLogger
-
- error(String) - Method in class io.netty.util.internal.logging.CommonsLogger
-
Deprecated.
Delegates to the Log.error(Object)
method of the underlying
Log
instance.
- error(String, Object) - Method in class io.netty.util.internal.logging.CommonsLogger
-
Deprecated.
Delegates to the Log.error(Object)
method of the underlying
Log
instance.
- error(String, Object, Object) - Method in class io.netty.util.internal.logging.CommonsLogger
-
Deprecated.
Delegates to the Log.error(Object)
method of the underlying
Log
instance.
- error(String, Object...) - Method in class io.netty.util.internal.logging.CommonsLogger
-
Deprecated.
Delegates to the Log.error(Object)
method of the underlying
Log
instance.
- error(String, Throwable) - Method in class io.netty.util.internal.logging.CommonsLogger
-
Deprecated.
Delegates to the Log.error(Object, Throwable)
method of
the underlying Log
instance.
- 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(String) - Method in class io.netty.util.internal.logging.JdkLogger
-
Log a message object at the SEVERE level.
- error(String, Object) - Method in class io.netty.util.internal.logging.JdkLogger
-
Log a message at the SEVERE level according to the specified format and
argument.
- error(String, Object, Object) - Method in class io.netty.util.internal.logging.JdkLogger
-
Log a message at the SEVERE level according to the specified format and
arguments.
- error(String, Object...) - Method in class io.netty.util.internal.logging.JdkLogger
-
Log a message at level SEVERE according to the specified format and
arguments.
- error(String, Throwable) - Method in class io.netty.util.internal.logging.JdkLogger
-
Log an exception (throwable) at the SEVERE level with an accompanying
message.
- error(String) - Method in class io.netty.util.internal.logging.Log4JLogger
-
Log a message object at the ERROR level.
- error(String, Object) - Method in class io.netty.util.internal.logging.Log4JLogger
-
Log a message at the ERROR level according to the specified format and
argument.
- error(String, Object, Object) - Method in class io.netty.util.internal.logging.Log4JLogger
-
Log a message at the ERROR level according to the specified format and
arguments.
- error(String, Object...) - Method in class io.netty.util.internal.logging.Log4JLogger
-
Log a message at level ERROR according to the specified format and
arguments.
- error(String, Throwable) - Method in class io.netty.util.internal.logging.Log4JLogger
-
Log an exception (throwable) at the ERROR level with an accompanying
message.
- error(String) - Method in class io.netty.util.internal.logging.Slf4JLogger
-
- error(String, Object) - Method in class io.netty.util.internal.logging.Slf4JLogger
-
- error(String, Object, Object) - Method in class io.netty.util.internal.logging.Slf4JLogger
-
- error(String, Object...) - Method in class io.netty.util.internal.logging.Slf4JLogger
-
- error(String, Throwable) - Method in class io.netty.util.internal.logging.Slf4JLogger
-
- 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
-
- errorEALREADY() - Static method in class io.netty.channel.unix.ErrorsStaticallyReferencedJniMethods
-
- errorECONNREFUSED() - Static method in class io.netty.channel.unix.ErrorsStaticallyReferencedJniMethods
-
- errorEISCONN() - Static method in class io.netty.channel.unix.ErrorsStaticallyReferencedJniMethods
-
- errorENETUNREACH() - Static method in class io.netty.channel.unix.ErrorsStaticallyReferencedJniMethods
-
- ErrorRedisMessage - Class in io.netty.handler.codec.redis
-
- ErrorRedisMessage(String) - Constructor for class io.netty.handler.codec.redis.ErrorRedisMessage
-
- Errors - Class in io.netty.channel.unix
-
Internal usage only!
- Errors() - Constructor for class io.netty.channel.unix.Errors
-
- ERRORS - Static variable in class io.netty.channel.unix.Errors
-
Holds the mappings for errno codes to String messages.
- Errors.NativeConnectException - Exception in io.netty.channel.unix
-
- Errors.NativeIoException - Exception in io.netty.channel.unix
-
Internal usage only!
- ErrorsStaticallyReferencedJniMethods - Class in io.netty.channel.unix
-
This class is necessary to break the following cyclic dependency:
JNI_OnLoad
JNI Calls FindClass because RegisterNatives (used to register JNI methods) requires a class
FindClass loads the class, but static members variables of that class attempt to call a JNI method which has not
yet been registered.
java.lang.UnsatisfiedLinkError is thrown because native method has not yet been registered.
Static members which call JNI methods must not be declared in this class!
- ErrorsStaticallyReferencedJniMethods() - Constructor for class io.netty.channel.unix.ErrorsStaticallyReferencedJniMethods
-
- ESCAPE_CHAR - Static variable in class io.netty.util.internal.logging.MessageFormatter
-
- 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.
- ESTIMATE_TASK_SIZE_ON_SUBMIT - Static variable in class io.netty.channel.AbstractChannelHandlerContext.AbstractWriteTask
-
- estimateBufferSize(int, int, int) - Static method in class io.netty.util.DomainNameMappingBuilder.ImmutableDomainNameMapping
-
Estimates the length of string representation of the given instance:
est = lengthOfConstantComponents + defaultValueLength + (estimatedMappingLength * numOfMappings) * 1.10
- estimatedLength - Variable in class io.netty.handler.codec.serialization.ObjectEncoderOutputStream
-
- estimatorHandle - Variable in class io.netty.channel.DefaultChannelPipeline
-
- estimatorHandle() - Method in class io.netty.channel.DefaultChannelPipeline
-
- estimatorHandle - Variable in class io.netty.channel.PendingWriteQueue
-
- ETC_RESOLV_CONF_FILE - Static variable in class io.netty.resolver.dns.UnixResolverDnsServerAddressStreamProvider
-
- ETC_RESOLVER_DIR - Static variable in class io.netty.resolver.dns.UnixResolverDnsServerAddressStreamProvider
-
- EUI48_MAC_ADDRESS_LENGTH - Static variable in class io.netty.util.internal.MacAddressUtil
-
- EUI64_MAC_ADDRESS_LENGTH - Static variable in class io.netty.util.internal.MacAddressUtil
-
- EV_ADD - Static variable in class io.netty.channel.kqueue.Native
-
- EV_ADD_CLEAR_ENABLE - Static variable in class io.netty.channel.kqueue.Native
-
- EV_CLEAR - Static variable in class io.netty.channel.kqueue.Native
-
- EV_DELETE - Static variable in class io.netty.channel.kqueue.Native
-
- EV_DELETE_DISABLE - Static variable in class io.netty.channel.kqueue.Native
-
- EV_DISABLE - Static variable in class io.netty.channel.kqueue.Native
-
- EV_ENABLE - Static variable in class io.netty.channel.kqueue.Native
-
- EV_EOF - Static variable in class io.netty.channel.kqueue.Native
-
- EV_ERROR - Static variable in class io.netty.channel.kqueue.Native
-
- evAdd() - Static method in class io.netty.channel.kqueue.KQueueStaticallyReferencedJniMethods
-
- evClear() - Static method in class io.netty.channel.kqueue.KQueueStaticallyReferencedJniMethods
-
- evDelete() - Static method in class io.netty.channel.kqueue.KQueueStaticallyReferencedJniMethods
-
- evDisable() - Static method in class io.netty.channel.kqueue.KQueueStaticallyReferencedJniMethods
-
- evEnable() - Static method in class io.netty.channel.kqueue.KQueueStaticallyReferencedJniMethods
-
- EventExecutor - Interface in io.netty.util.concurrent
-
- EventExecutorChooserFactory - Interface in io.netty.util.concurrent
-
- EventExecutorChooserFactory.EventExecutorChooser - Interface in io.netty.util.concurrent
-
- EventExecutorGroup - Interface in io.netty.util.concurrent
-
- eventList - Variable in class io.netty.channel.kqueue.KQueueEventLoop
-
- eventLoop - Variable in class io.netty.channel.AbstractChannel
-
- eventLoop() - Method in class io.netty.channel.AbstractChannel
-
- eventLoop() - Method in interface io.netty.channel.Channel
-
- 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
-
- eventLoop - Variable in class io.netty.resolver.dns.DnsNameResolverBuilder
-
- EventLoopException - Exception in io.netty.channel
-
- 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
-
- evEOF() - Static method in class io.netty.channel.kqueue.KQueueStaticallyReferencedJniMethods
-
- evError() - Static method in class io.netty.channel.kqueue.KQueueStaticallyReferencedJniMethods
-
- EVFILT_READ - Static variable in class io.netty.channel.kqueue.Native
-
- EVFILT_USER - Static variable in class io.netty.channel.kqueue.Native
-
- EVFILT_WRITE - Static variable in class io.netty.channel.kqueue.Native
-
- evfiltRead() - Static method in class io.netty.channel.kqueue.KQueueStaticallyReferencedJniMethods
-
- evfiltUser() - Static method in class io.netty.channel.kqueue.KQueueStaticallyReferencedJniMethods
-
- evfiltWrite() - Static method in class io.netty.channel.kqueue.KQueueStaticallyReferencedJniMethods
-
- evSet(short, short) - Method in class io.netty.channel.kqueue.AbstractKQueueChannel
-
- evSet(AbstractKQueueChannel, short, short, int) - Method in class io.netty.channel.kqueue.KQueueEventArray
-
- evSet(long, AbstractKQueueChannel, int, short, short, int) - Static method in class io.netty.channel.kqueue.KQueueEventArray
-
- evSet(AbstractKQueueChannel, short, short, int) - Method in class io.netty.channel.kqueue.KQueueEventLoop
-
- evSet0(short, short) - Method in class io.netty.channel.kqueue.AbstractKQueueChannel
-
- EXCEPTION_MESSAGE - Static variable in class io.netty.util.internal.logging.AbstractInternalLogger
-
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class io.netty.bootstrap.ServerBootstrap.ServerBootstrapAcceptor
-
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in interface io.netty.channel.ChannelHandler
-
- 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.channel.DefaultChannelPipeline.HeadContext
-
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class io.netty.channel.DefaultChannelPipeline.TailContext
-
- 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
-
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class io.netty.resolver.dns.DnsNameResolver.DnsResponseHandler
-
- execute() - Method in class io.netty.channel.DefaultChannelPipeline.PendingHandlerAddedTask
-
- execute() - Method in class io.netty.channel.DefaultChannelPipeline.PendingHandlerCallback
-
- execute() - Method in class io.netty.channel.DefaultChannelPipeline.PendingHandlerRemovedTask
-
- execute(Runnable) - Method in class io.netty.channel.embedded.EmbeddedEventLoop
-
- 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.NonStickyEventExecutorGroup.NonStickyOrderedEventExecutor
-
- 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.
- executeReadReadyRunnable(ChannelConfig) - Method in class io.netty.channel.kqueue.AbstractKQueueChannel.AbstractKQueueUnsafe
-
- executor() - Method in class io.netty.bootstrap.AbstractBootstrap.PendingRegistrationPromise
-
- executor - Variable in class io.netty.channel.AbstractChannelHandlerContext
-
- executor() - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- 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.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- executor() - Method in class io.netty.channel.CompleteChannelFuture
-
- executor() - Method in class io.netty.channel.DefaultChannelProgressivePromise
-
- executor() - Method in class io.netty.channel.DefaultChannelPromise
-
- executor - Variable in class io.netty.channel.group.DefaultChannelGroup
-
- executor - Variable in class io.netty.channel.pool.FixedChannelPool
-
- executor - Variable in class io.netty.channel.ThreadPerChannelEventLoopGroup
-
- executor() - Method in class io.netty.handler.ssl.SslHandler.LazyChannelPromise
-
- executor - Variable in class io.netty.handler.traffic.TrafficCounter
-
Executor that will run the monitor
- executor - Variable in class io.netty.resolver.AbstractAddressResolver
-
- executor() - Method in class io.netty.resolver.AbstractAddressResolver
-
- executor() - Method in class io.netty.resolver.dns.DnsNameResolver
-
- executor - Variable in class io.netty.resolver.dns.InflightNameResolver
-
- executor - Variable in class io.netty.resolver.SimpleNameResolver
-
- executor() - Method in class io.netty.resolver.SimpleNameResolver
-
- executor - Variable in class io.netty.util.concurrent.CompleteFuture
-
- executor() - Method in class io.netty.util.concurrent.CompleteFuture
-
- executor - Variable in class io.netty.util.concurrent.DefaultPromise
-
- executor() - Method in class io.netty.util.concurrent.DefaultPromise
-
Get the executor used to notify listeners when this promise is complete.
- executor - Variable in class io.netty.util.concurrent.NonStickyEventExecutorGroup.NonStickyOrderedEventExecutor
-
- executor() - Method in class io.netty.util.concurrent.ScheduledFutureTask
-
- executor - Variable in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- executorCount() - Method in class io.netty.util.concurrent.MultithreadEventExecutorGroup
-
- executors - Variable in class io.netty.util.concurrent.DefaultEventExecutorChooserFactory.GenericEventExecutorChooser
-
- executors - Variable in class io.netty.util.concurrent.DefaultEventExecutorChooserFactory.PowerOfTwoEventExecutorChooser
-
- executorSet - Variable in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor
-
- exists(String) - Static method in class io.netty.channel.ChannelOption
-
- exists(String) - Static method in class io.netty.util.AttributeKey
-
- exists(String) - Method in class io.netty.util.ConstantPool
-
- expand(char[], int, int) - Static method in class io.netty.util.internal.AppendableCharSequence
-
- expandArray() - Method in class io.netty.handler.codec.CodecOutputList
-
- expandCumulation(ByteBufAllocator, ByteBuf, int) - Static method in class io.netty.handler.codec.ByteToMessageDecoder
-
- expandIndexedVariableTableAndSet(int, Object) - Method in class io.netty.util.internal.InternalThreadLocalMap
-
- expandNioBufferArray(ByteBuffer[], int, int) - Static method in class io.netty.channel.ChannelOutboundBuffer
-
- expect(Signal) - Method in error io.netty.util.Signal
-
Check if the given
Signal
is the same as this instance.
- EXPECTED - Static variable in class io.netty.handler.codec.dns.DnsRecordType
-
- EXPECTED_TYPE - Static variable in class io.netty.channel.sctp.oio.OioSctpChannel
-
- EXPECTED_TYPES - Static variable in class io.netty.channel.kqueue.AbstractKQueueStreamChannel
-
- EXPECTED_TYPES - Static variable in class io.netty.channel.kqueue.KQueueDatagramChannel
-
- EXPECTED_TYPES - Static variable in class io.netty.channel.nio.AbstractNioByteChannel
-
- EXPECTED_TYPES - Static variable in class io.netty.channel.oio.AbstractOioByteChannel
-
- EXPECTED_TYPES - Static variable in class io.netty.channel.socket.nio.NioDatagramChannel
-
- EXPECTED_TYPES - Static variable in class io.netty.channel.socket.oio.OioDatagramChannel
-
- expectedCount - Variable in class io.netty.util.concurrent.PromiseCombiner
-
- expectedErr - Variable in exception io.netty.channel.unix.Errors.NativeConnectException
-
- expectedErr() - Method in exception io.netty.channel.unix.Errors.NativeConnectException
-
- expectedErr - Variable in exception io.netty.channel.unix.Errors.NativeIoException
-
- expectedErr() - Method in exception io.netty.channel.unix.Errors.NativeIoException
-
- expectingMoreContent - Variable in class io.netty.handler.codec.memcache.AbstractMemcacheObjectEncoder
-
- expirationFuture - Variable in class io.netty.resolver.dns.DnsCacheEntry
-
- expire() - Method in class io.netty.util.HashedWheelTimer.HashedWheelTimeout
-
- expireNanoTime - Variable in class io.netty.channel.pool.FixedChannelPool.AcquireTask
-
- expireTimeouts(long) - Method in class io.netty.util.HashedWheelTimer.HashedWheelBucket
-
- explicitFlushAfterFlushes - Variable in class io.netty.handler.flush.FlushConsolidationHandler
-
- explicitNoUnsafe0() - Static method in class io.netty.util.internal.PlatformDependent0
-
- 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
-
- extractAuthoritativeNameServers(String, DnsResponse) - Static method in class io.netty.resolver.dns.DnsNameResolverContext
-
Returns the {@link AuthoritativeNameServerList} which were included in {@link DnsSection#AUTHORITY}
or {@code null} if non are found.
- extractFrame(ChannelHandlerContext, ByteBuf, int, int) - Method in class io.netty.handler.codec.LengthFieldBasedFrameDecoder
-
Extract the sub-region of the specified buffer.
- extractFrame(ByteBuf, int, int) - Static method in class io.netty.handler.codec.xml.XmlFrameDecoder
-
- 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 - Variable in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
-
Contains the optional extras.
- 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 - Variable in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
-
- 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 - Variable in class io.netty.channel.DefaultFileRegion
-
- factoryInstance - Static variable in class io.netty.util.ResourceLeakDetectorFactory
-
- fail() - Static method in class io.netty.channel.VoidChannelPromise
-
- fail(Inflater, String, int) - Static method in class io.netty.handler.codec.compression.ZlibUtil
-
- fail(Deflater, String, int) - Static method in class io.netty.handler.codec.compression.ZlibUtil
-
- fail(long) - Method in class io.netty.handler.codec.DelimiterBasedFrameDecoder
-
- fail(ChannelHandlerContext, String, Throwable) - Method in class io.netty.handler.codec.haproxy.HAProxyMessageDecoder
-
- fail(long) - Method in class io.netty.handler.codec.LengthFieldBasedFrameDecoder
-
- fail(ChannelHandlerContext, int) - Method in class io.netty.handler.codec.LineBasedFrameDecoder
-
- fail(ChannelHandlerContext, String) - Method in class io.netty.handler.codec.LineBasedFrameDecoder
-
- fail(List<Object>, Throwable) - Method in class io.netty.handler.codec.socksx.v4.Socks4ClientDecoder
-
- fail(List<Object>, Throwable) - Method in class io.netty.handler.codec.socksx.v4.Socks4ServerDecoder
-
- fail(List<Object>, Throwable) - Method in class io.netty.handler.codec.socksx.v5.Socks5CommandRequestDecoder
-
- fail(List<Object>, Throwable) - Method in class io.netty.handler.codec.socksx.v5.Socks5CommandResponseDecoder
-
- fail(List<Object>, Throwable) - Method in class io.netty.handler.codec.socksx.v5.Socks5InitialRequestDecoder
-
- fail(List<Object>, Throwable) - Method in class io.netty.handler.codec.socksx.v5.Socks5InitialResponseDecoder
-
- fail(List<Object>, Throwable) - Method in class io.netty.handler.codec.socksx.v5.Socks5PasswordAuthRequestDecoder
-
- fail(List<Object>, Throwable) - Method in class io.netty.handler.codec.socksx.v5.Socks5PasswordAuthResponseDecoder
-
- fail(long) - Method in class io.netty.handler.codec.xml.XmlFrameDecoder
-
- fail(ChannelHandlerContext) - Static method in class io.netty.handler.codec.xml.XmlFrameDecoder
-
- fail(Throwable) - Method in class io.netty.handler.stream.ChunkedWriteHandler.PendingWrite
-
- fail(Class<?>, String) - Static method in class io.netty.util.internal.TypeParameterMatcher
-
- FAIL_SELECTION_LISTENER_FACTORY - Static variable in class io.netty.handler.ssl.JdkBaseApplicationProtocolNegotiator
-
- FAIL_SELECTOR_FACTORY - Static variable in class io.netty.handler.ssl.JdkBaseApplicationProtocolNegotiator
-
- failAndRecycle(Throwable) - Method in class io.netty.util.internal.PendingWrite
-
Fails the underlying
Promise
with the given cause and recycle this instance.
- failed - Variable in exception io.netty.channel.group.ChannelGroupException
-
- FailedChannelFuture - Class in io.netty.channel
-
- FailedChannelFuture(Channel, EventExecutor, Throwable) - Constructor for class io.netty.channel.FailedChannelFuture
-
Creates a new instance.
- FailedFuture<V> - Class in io.netty.util.concurrent
-
- FailedFuture(EventExecutor, Throwable) - Constructor for class io.netty.util.concurrent.FailedFuture
-
Creates a new instance.
- failFast - Variable in class io.netty.handler.codec.DelimiterBasedFrameDecoder
-
- failFast - Variable in class io.netty.handler.codec.LengthFieldBasedFrameDecoder
-
- failFast - Variable in class io.netty.handler.codec.LineBasedFrameDecoder
-
Whether or not to throw an exception as soon as we exceed maxLength.
- failFlushed(Throwable, boolean) - Method in class io.netty.channel.ChannelOutboundBuffer
-
- failIfNecessary(boolean) - Method in class io.netty.handler.codec.LengthFieldBasedFrameDecoder
-
- failOnMissingResponse - Variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheClientCodec
-
- failOverLimit(ChannelHandlerContext, int) - Method in class io.netty.handler.codec.haproxy.HAProxyMessageDecoder
-
- failOverLimit(ChannelHandlerContext, String) - Method in class io.netty.handler.codec.haproxy.HAProxyMessageDecoder
-
- failPending - Variable in class io.netty.util.concurrent.PromiseAggregator
-
Deprecated.
- FailProtocolSelectionListener(JdkSslEngine, List<String>) - Constructor for class io.netty.handler.ssl.JdkBaseApplicationProtocolNegotiator.FailProtocolSelectionListener
-
- FailProtocolSelector(JdkSslEngine, Set<String>) - Constructor for class io.netty.handler.ssl.JdkBaseApplicationProtocolNegotiator.FailProtocolSelector
-
- failure(Throwable) - Static method in class io.netty.handler.codec.DecoderResult
-
- FAILURE - Static variable in class io.netty.handler.codec.socksx.v5.Socks5CommandStatus
-
- FAILURE - Static variable in class io.netty.handler.codec.socksx.v5.Socks5PasswordAuthStatus
-
- failureCount - Variable in class io.netty.channel.group.DefaultChannelGroupFuture
-
- FailureWrapper() - Constructor for class io.netty.handler.ssl.JdkAlpnApplicationProtocolNegotiator.FailureWrapper
-
- fallbackProtocol - Variable in class io.netty.handler.ssl.ApplicationProtocolNegotiationHandler
-
- 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.
- FAMILY_MASK - Static variable in enum io.netty.handler.codec.haproxy.HAProxyProxiedProtocol.AddressFamily
-
The highest 4 bits of the transport protocol and address family byte contain the address family
- fastGet(FastThreadLocalThread) - Static method in class io.netty.util.internal.InternalThreadLocalMap
-
- FastLz - Class in io.netty.handler.codec.compression
-
Core of FastLZ compression algorithm.
- FastLz() - Constructor for class io.netty.handler.codec.compression.FastLz
-
- FastLzFrameDecoder - Class in io.netty.handler.codec.compression
-
- 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.
- FastLzFrameDecoder.State - Enum in io.netty.handler.codec.compression
-
Current state of decompression.
- 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
-
- 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
-
- FCOMMENT - Static variable in class io.netty.handler.codec.compression.JdkZlibDecoder
-
- fd() - Method in class io.netty.channel.kqueue.AbstractKQueueChannel
-
- fd(int) - Method in class io.netty.channel.kqueue.KQueueEventArray
-
- fd - Variable in class io.netty.channel.unix.FileDescriptor
-
- fd - Variable in class io.netty.channel.unix.SocketWritableByteChannel
-
- fd() - Method in interface io.netty.channel.unix.UnixChannel
-
- fetchFromScheduledTaskQueue() - Method in class io.netty.util.concurrent.GlobalEventExecutor
-
- fetchFromScheduledTaskQueue() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- fetchWatchees() - Method in class io.netty.util.ThreadDeathWatcher.Watcher
-
- FEXTRA - Static variable in class io.netty.handler.codec.compression.JdkZlibDecoder
-
- fflags(int) - Method in class io.netty.channel.kqueue.KQueueEventArray
-
- FHCRC - Static variable in class io.netty.handler.codec.compression.JdkZlibDecoder
-
- file - Variable in class io.netty.channel.DefaultFileRegion
-
- file - Variable in class io.netty.handler.stream.ChunkedFile
-
- FileDescriptor - Class in io.netty.channel.unix
-
- FileDescriptor(int) - Constructor for class io.netty.channel.unix.FileDescriptor
-
- FileRegion - Interface in io.netty.channel
-
- fillArray(Object[]) - Method in class io.netty.handler.codec.HeadersUtils.DelegatingStringSet
-
- fillBufferArray(ByteBuffer[], ByteBuffer[], int) - Static method in class io.netty.channel.ChannelOutboundBuffer
-
- fillCallerData(String, LogRecord) - Static method in class io.netty.util.internal.logging.JdkLogger
-
Fill in caller data if possible.
- fillInStackTrace() - Method in exception io.netty.channel.AbstractChannel.AnnotatedConnectException
-
- fillInStackTrace() - Method in exception io.netty.channel.AbstractChannel.AnnotatedNoRouteToHostException
-
- fillInStackTrace() - Method in exception io.netty.channel.AbstractChannel.AnnotatedSocketException
-
- fillInStackTrace() - Method in exception io.netty.handler.timeout.TimeoutException
-
- fillInStackTrace() - Method in exception io.netty.resolver.dns.DnsNameResolverContext.SearchDomainUnknownHostException
-
- fillInStackTrace() - Method in exception io.netty.resolver.dns.DnsNameResolverException
-
- fillInStackTrace() - Method in error io.netty.util.Signal
-
- filter(int) - Method in class io.netty.channel.kqueue.KQueueEventArray
-
- filterArgs - Variable in class io.netty.channel.kqueue.AcceptFilter
-
- 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(String, ChannelHandler) - Method in class io.netty.channel.DefaultChannelPipeline
-
- filterName - Variable in class io.netty.channel.kqueue.AcceptFilter
-
- filterName() - Method in class io.netty.channel.kqueue.AcceptFilter
-
- filterOutboundMessage(Object) - Method in class io.netty.channel.AbstractChannel
-
- filterOutboundMessage(Object) - Method in class io.netty.channel.AbstractServerChannel
-
- 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.sctp.nio.NioSctpChannel
-
- filterOutboundMessage(Object) - Method in class io.netty.channel.sctp.nio.NioSctpServerChannel
-
- filterOutboundMessage(Object) - Method in class io.netty.channel.sctp.oio.OioSctpChannel
-
- filterOutboundMessage(Object) - Method in class io.netty.channel.sctp.oio.OioSctpServerChannel
-
- 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
-
- filterRule - Variable in class io.netty.handler.ipfilter.IpSubnetFilterRule
-
- finalize() - Method in class io.netty.buffer.PoolArena
-
- finalize() - Method in class io.netty.util.HashedWheelTimer
-
- finalize() - Method in class io.netty.util.Recycler.WeakOrderQueue
-
- find(ChannelId) - Method in interface io.netty.channel.group.ChannelGroup
-
- 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(Channel) - Method in class io.netty.channel.group.DefaultChannelGroupFuture
-
- find(Channel) - Method in class io.netty.channel.group.VoidChannelGroupFuture
-
- find(Object, Class<?>, String) - Static method in class io.netty.util.internal.TypeParameterMatcher
-
- find0(Object, Class<?>, String) - Static method in class io.netty.util.internal.TypeParameterMatcher
-
- FIND_CR - Static variable in interface io.netty.buffer.ByteBufProcessor
-
- 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
-
- 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
-
- 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_ASCII - Static variable in class io.netty.buffer.ByteBufUtil
-
Aborts on a byte which is not a valid ASCII character.
- FIND_NON_CR - Static variable in interface io.netty.buffer.ByteBufProcessor
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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 (';')
.
- findComponent(int) - Method in class io.netty.buffer.CompositeByteBuf
-
- findComponent(int) - Method in class io.netty.buffer.FixedCompositeByteBuf
-
- findContextInbound() - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- findContextOutbound() - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- findEndOfHeader(ByteBuf) - Static method in class io.netty.handler.codec.haproxy.HAProxyMessageDecoder
-
Returns the index in the buffer of the end of header if found.
- findEndOfLine(ByteBuf) - Static method in class io.netty.handler.codec.haproxy.HAProxyMessageDecoder
-
Returns the index in the buffer of the end of line found.
- findEndOfLine(ByteBuf) - Static method in class io.netty.handler.codec.LineBasedFrameDecoder
-
Returns the index in the buffer of the end of line found.
- findMatchingLength(ByteBuf, int, int, int) - Static method in class io.netty.handler.codec.compression.Snappy
-
Iterates over the supplied input buffer between the supplied minIndex and
maxIndex to find how long our matched copy overlaps with an already-written
literal value.
- findNextAvail() - Method in class io.netty.buffer.PoolSubpage
-
- findNextAvail0(int, long) - Method in class io.netty.buffer.PoolSubpage
-
- 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.
- findNodesToRelocate(int[], int) - Static method in class io.netty.handler.codec.compression.Bzip2HuffmanAllocator
-
Finds the number of nodes to relocate in order to achieve a given code length limit.
- findSubpagePoolHead(int) - Method in class io.netty.buffer.PoolArena
-
- findVersion(ByteBuf) - Static method in class io.netty.handler.codec.haproxy.HAProxyMessageDecoder
-
Returns the proxy protocol specification version in the buffer if the version is found.
- FINGERPRINT_PATTERN - Static variable in class io.netty.handler.ssl.util.FingerprintTrustManagerFactory
-
- FINGERPRINT_STRIP_PATTERN - Static variable in class io.netty.handler.ssl.util.FingerprintTrustManagerFactory
-
- fingerprints - Variable in class io.netty.handler.ssl.util.FingerprintTrustManagerFactory
-
- 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
-
- finish(boolean) - Method in class io.netty.channel.embedded.EmbeddedChannel
-
- finish(AddressedEnvelope<? extends DnsResponse, InetSocketAddress>) - Method in class io.netty.resolver.dns.DnsQueryContext
-
- finish(Promise<Void>) - Method in class io.netty.util.concurrent.PromiseCombiner
-
Sets the promise to be notified when all combined futures have finished.
- FINISH_CONNECT_REFUSED_EXCEPTION - Static variable in class io.netty.channel.unix.Socket
-
- FINISH_READ_FUTURE_UPDATER - Static variable in class io.netty.channel.local.LocalChannel
-
- 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 com.sun.nio.sctp.SctpChannel
-
- finishConnect() - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel.KQueueStreamUnsafe
-
- 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
-
- finishConnect(int) - Static method in class io.netty.channel.unix.Socket
-
- finished - Variable in class io.netty.handler.codec.compression.Bzip2Encoder
-
(@code true} if the compressed stream has been finished, otherwise false
.
- finished - Variable in class io.netty.handler.codec.compression.JdkZlibDecoder
-
- finished - Variable in class io.netty.handler.codec.compression.JdkZlibEncoder
-
- finished - Variable in class io.netty.handler.codec.compression.JZlibDecoder
-
- finished - Variable in class io.netty.handler.codec.compression.JZlibEncoder
-
- finished - Variable in class io.netty.handler.codec.haproxy.HAProxyMessageDecoder
-
true
if we're finished decoding the proxy protocol header
- finishEncode(ChannelHandlerContext, ChannelPromise) - Method in class io.netty.handler.codec.compression.Bzip2Encoder
-
- finishEncode(ChannelHandlerContext, ChannelPromise) - Method in class io.netty.handler.codec.compression.JdkZlibEncoder
-
- finishEncode(ChannelHandlerContext, ChannelPromise) - Method in class io.netty.handler.codec.compression.JZlibEncoder
-
- finishPeerRead(LocalChannel) - Method in class io.netty.channel.local.LocalChannel
-
- finishPeerRead0(LocalChannel) - Method in class io.netty.channel.local.LocalChannel
-
- finishPendingTasks(boolean) - Method in class io.netty.channel.embedded.EmbeddedChannel
-
- finishReadFuture - Variable in class io.netty.channel.local.LocalChannel
-
- finishResolve(Class<? extends InetAddress>, List<DnsCacheEntry>, Promise<List<InetAddress>>) - Method in class io.netty.resolver.dns.DnsNameResolver.ListResolverContext
-
- finishResolve(Class<? extends InetAddress>, List<DnsCacheEntry>, Promise<InetAddress>) - Method in class io.netty.resolver.dns.DnsNameResolver.SingleResolverContext
-
- finishResolve(Promise<T>) - Method in class io.netty.resolver.dns.DnsNameResolverContext
-
- finishResolve(Class<? extends InetAddress>, List<DnsCacheEntry>, Promise<T>) - Method in class io.netty.resolver.dns.DnsNameResolverContext
-
- finishWrap(ChannelHandlerContext, ByteBuf, ChannelPromise, boolean, boolean) - Method in class io.netty.handler.ssl.SslHandler
-
- FIRE_EXCEPTION_ON_FAILURE - Static variable in interface io.netty.channel.ChannelFutureListener
-
- fireChannelActive() - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- 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.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- fireChannelActive() - Method in class io.netty.channel.DefaultChannelPipeline
-
- fireChannelInactive() - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- 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.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- fireChannelInactive() - Method in class io.netty.channel.DefaultChannelPipeline
-
- fireChannelInactiveAndDeregister(boolean) - Method in class io.netty.channel.AbstractChannel.AbstractUnsafe
-
- fireChannelRead(Object) - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- fireChannelRead(Object) - Method in interface io.netty.channel.ChannelHandlerContext
-
- fireChannelRead(Object) - Method in interface io.netty.channel.ChannelInboundInvoker
-
- fireChannelRead(Object) - Method in interface io.netty.channel.ChannelPipeline
-
- fireChannelRead(Object) - Method in class io.netty.channel.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- fireChannelRead(Object) - Method in class io.netty.channel.DefaultChannelPipeline
-
- fireChannelRead(ChannelHandlerContext, List<Object>, int) - Static method in class io.netty.handler.codec.ByteToMessageDecoder
-
Get numElements
out of the List
and forward these through the pipeline.
- fireChannelRead(ChannelHandlerContext, CodecOutputList, int) - Static method in class io.netty.handler.codec.ByteToMessageDecoder
-
Get
numElements
out of the
CodecOutputList
and forward these through the pipeline.
- fireChannelReadComplete() - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- 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.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- fireChannelReadComplete() - Method in class io.netty.channel.DefaultChannelPipeline
-
- fireChannelRegistered() - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- fireChannelRegistered() - Method in interface io.netty.channel.ChannelHandlerContext
-
- fireChannelRegistered() - Method in interface io.netty.channel.ChannelInboundInvoker
-
- fireChannelRegistered() - Method in interface io.netty.channel.ChannelPipeline
-
- fireChannelRegistered() - Method in class io.netty.channel.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- fireChannelRegistered() - Method in class io.netty.channel.DefaultChannelPipeline
-
- fireChannelUnregistered() - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- fireChannelUnregistered() - Method in interface io.netty.channel.ChannelHandlerContext
-
- fireChannelUnregistered() - Method in interface io.netty.channel.ChannelInboundInvoker
-
- fireChannelUnregistered() - Method in interface io.netty.channel.ChannelPipeline
-
- fireChannelUnregistered() - Method in class io.netty.channel.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- fireChannelUnregistered() - Method in class io.netty.channel.DefaultChannelPipeline
-
- fireChannelWritabilityChanged() - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- fireChannelWritabilityChanged() - Method in interface io.netty.channel.ChannelHandlerContext
-
- fireChannelWritabilityChanged() - Method in interface io.netty.channel.ChannelInboundInvoker
-
- fireChannelWritabilityChanged(boolean) - Method in class io.netty.channel.ChannelOutboundBuffer
-
- fireChannelWritabilityChanged() - Method in interface io.netty.channel.ChannelPipeline
-
- fireChannelWritabilityChanged() - Method in class io.netty.channel.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- fireChannelWritabilityChanged() - Method in class io.netty.channel.DefaultChannelPipeline
-
- fireChannelWritabilityChangedTask - Variable in class io.netty.channel.ChannelOutboundBuffer
-
- firedChannelRead - Variable in class io.netty.handler.ssl.SslHandler
-
- fireEvent(Notification) - Method in class io.netty.channel.sctp.SctpNotificationHandler
-
- fireEventAndClose(Object) - Method in class io.netty.channel.kqueue.AbstractKQueueChannel.AbstractKQueueUnsafe
-
- fireException - Variable in class io.netty.channel.VoidChannelPromise
-
- fireException(Throwable) - Method in class io.netty.channel.VoidChannelPromise
-
- fireExceptionCaught(Throwable) - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- 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.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- fireExceptionCaught(Throwable) - Method in class io.netty.channel.DefaultChannelPipeline
-
- fireUserEventTriggered(Object) - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- 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.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- fireUserEventTriggered(Object) - Method in class io.netty.channel.DefaultChannelPipeline
-
- first() - Method in interface io.netty.channel.ChannelPipeline
-
- first() - Method in class io.netty.channel.DefaultChannelPipeline
-
- first - Variable in class io.netty.handler.codec.ByteToMessageDecoder
-
- first - Variable in class io.netty.handler.codec.compression.Bzip2DivSufSort.PartitionResult
-
- first(int[], int, int) - Static method in class io.netty.handler.codec.compression.Bzip2HuffmanAllocator
-
- first - Variable in class io.netty.handler.timeout.IdleStateEvent
-
- 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
-
- firstAllIdleEvent - Variable in class io.netty.handler.timeout.IdleStateHandler
-
- firstContext() - Method in interface io.netty.channel.ChannelPipeline
-
- firstContext() - Method in class io.netty.channel.DefaultChannelPipeline
-
- firstIndexOf(ByteBuf, int, int, byte) - Static method in class io.netty.buffer.ByteBufUtil
-
- firstReaderIdleEvent - Variable in class io.netty.handler.timeout.IdleStateHandler
-
- firstRegistration - Variable in class io.netty.channel.DefaultChannelPipeline
-
- firstWriterIdleEvent - Variable in class io.netty.handler.timeout.IdleStateHandler
-
- 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
-
- FixedChannelPool(Bootstrap, ChannelPoolHandler, int, int) - Constructor for class io.netty.channel.pool.FixedChannelPool
-
- 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.AcquireListener - Class in io.netty.channel.pool
-
- FixedChannelPool.AcquireTask - Class in io.netty.channel.pool
-
- FixedChannelPool.AcquireTimeoutAction - Enum in io.netty.channel.pool
-
- FixedChannelPool.TimeoutTask - Class in io.netty.channel.pool
-
- FixedCompositeByteBuf - Class in io.netty.buffer
-
ByteBuf
implementation which allows to wrap an array of
ByteBuf
in a read-only mode.
- FixedCompositeByteBuf(ByteBufAllocator, ByteBuf...) - Constructor for class io.netty.buffer.FixedCompositeByteBuf
-
- FixedCompositeByteBuf.Component - Class in io.netty.buffer
-
- fixedHeader() - Method in class io.netty.handler.codec.mqtt.MqttMessage
-
- FixedLengthFrameDecoder - Class in io.netty.handler.codec
-
A decoder that splits the received
ByteBuf
s 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
-
- FixedRecvByteBufAllocator(int) - Constructor for class io.netty.channel.FixedRecvByteBufAllocator
-
Creates a new predictor that always returns the same prediction of
the specified buffer size.
- FixedRecvByteBufAllocator.HandleImpl - Class in io.netty.channel
-
- FixedRedisMessagePool - Class in io.netty.handler.codec.redis
-
A default fixed redis message pool.
- FixedRedisMessagePool() - Constructor for class io.netty.handler.codec.redis.FixedRedisMessagePool
-
- flags(int) - Method in class io.netty.channel.kqueue.KQueueEventArray
-
- flags - Variable in class io.netty.handler.codec.compression.JdkZlibDecoder
-
- flags() - Method in class io.netty.handler.codec.dns.AbstractDnsOptPseudoRrRecord
-
- flags() - Method in interface io.netty.handler.codec.dns.DnsOptPseudoRecord
-
- floatArrayAppend(StringBuilder, float[]) - Static method in class io.netty.util.internal.logging.MessageFormatter
-
- FlowControlHandler - Class in io.netty.handler.flow
-
- FlowControlHandler() - Constructor for class io.netty.handler.flow.FlowControlHandler
-
- FlowControlHandler(boolean) - Constructor for class io.netty.handler.flow.FlowControlHandler
-
- FlowControlHandler.RecyclableArrayDeque - Class in io.netty.handler.flow
-
A recyclable ArrayDeque
.
- flush() - Method in class io.netty.channel.AbstractChannel.AbstractUnsafe
-
- flush() - Method in class io.netty.channel.AbstractChannel
-
- flush() - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- flush() - Method in interface io.netty.channel.Channel
-
- flush() - Method in interface io.netty.channel.Channel.Unsafe
-
- 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() - Method in class io.netty.channel.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- flush(ChannelHandlerContext) - Method in class io.netty.channel.CombinedChannelDuplexHandler
-
- flush() - Method in class io.netty.channel.DefaultChannelPipeline
-
- flush(ChannelHandlerContext) - Method in class io.netty.channel.DefaultChannelPipeline.HeadContext
-
- flush() - Method in interface io.netty.channel.group.ChannelGroup
-
- flush(ChannelMatcher) - Method in interface io.netty.channel.group.ChannelGroup
-
- flush() - Method in class io.netty.channel.group.DefaultChannelGroup
-
- flush(ChannelMatcher) - Method in class io.netty.channel.group.DefaultChannelGroup
-
- flush(ByteBuf) - Method in class io.netty.handler.codec.compression.Bzip2BitWriter
-
Writes any remaining bits to the output
ByteBuf
,
zero padding to a whole byte as required.
- 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, ChannelPromise) - 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
-
- FLUSH0_CLOSED_CHANNEL_EXCEPTION - Static variable in class io.netty.channel.AbstractChannel
-
- FLUSH0_NOT_YET_CONNECTED_EXCEPTION - Static variable in class io.netty.channel.AbstractChannel
-
- flushAndWrite(Object) - Method in interface io.netty.channel.group.ChannelGroup
-
- 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.ChannelFlushPromiseNotifier.DefaultFlushCheckpoint
-
- flushCheckpoint(long) - Method in class io.netty.channel.ChannelFlushPromiseNotifier.DefaultFlushCheckpoint
-
- flushCheckpoint() - Method in interface io.netty.channel.ChannelFlushPromiseNotifier.FlushCheckpoint
-
- flushCheckpoint(long) - Method in interface io.netty.channel.ChannelFlushPromiseNotifier.FlushCheckpoint
-
- 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
-
- flushCheckpoints - Variable in class io.netty.channel.ChannelFlushPromiseNotifier
-
- 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.
- flushed - Variable in class io.netty.channel.ChannelOutboundBuffer
-
- flushedBeforeHandshake - Variable in class io.netty.handler.ssl.SslHandler
-
- flushedEntry - Variable in class io.netty.channel.ChannelOutboundBuffer
-
- flushIfNeeded(ChannelHandlerContext) - Method in class io.netty.handler.flush.FlushConsolidationHandler
-
- flushIfNeeded(ChannelHandlerContext) - Method in class io.netty.handler.ssl.SslHandler
-
- flushInbound() - Method in class io.netty.channel.embedded.EmbeddedChannel
-
Flushes the inbound of this
Channel
.
- flushInbound(boolean, ChannelPromise) - Method in class io.netty.channel.embedded.EmbeddedChannel
-
- flushNow(ChannelHandlerContext) - Method in class io.netty.handler.flush.FlushConsolidationHandler
-
- flushOutbound() - Method in class io.netty.channel.embedded.EmbeddedChannel
-
Flushes the outbound of this
Channel
.
- flushOutbound0() - Method in class io.netty.channel.embedded.EmbeddedChannel
-
- flushPendingCount - Variable in class io.netty.handler.flush.FlushConsolidationHandler
-
- FLUSHQ - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
-
- flushTask - Variable in class io.netty.channel.nio.AbstractNioByteChannel
-
- flushTask - Variable in class io.netty.handler.flush.FlushConsolidationHandler
-
- FNAME - Static variable in class io.netty.handler.codec.compression.JdkZlibDecoder
-
- fold(V) - Method in class io.netty.handler.codec.serialization.ReferenceMap
-
- fold(V) - Method in class io.netty.handler.codec.serialization.SoftReferenceMap
-
- fold(V) - Method in class io.netty.handler.codec.serialization.WeakReferenceMap
-
- followCname(String, DnsQueryLifecycleObserver, Promise<T>) - Method in class io.netty.resolver.dns.DnsNameResolverContext
-
- FORBIDDEN - Static variable in class io.netty.handler.codec.socksx.v5.Socks5CommandStatus
-
- forceClose(Channel, Throwable) - Static method in class io.netty.bootstrap.ServerBootstrap.ServerBootstrapAcceptor
-
- forceFlush() - Method in class io.netty.channel.nio.AbstractNioChannel.AbstractNioUnsafe
-
- forceFlush() - Method in interface io.netty.channel.nio.AbstractNioChannel.NioUnsafe
-
- forceFlush(ChannelHandlerContext) - Method in class io.netty.handler.ssl.SslHandler
-
- forClient() - Static method in class io.netty.handler.ssl.SslContextBuilder
-
- forEachByte(ByteProcessor) - Method in class io.netty.buffer.AbstractByteBuf
-
- forEachByte(int, int, ByteProcessor) - Method in class io.netty.buffer.AbstractByteBuf
-
- forEachByte(int, int, ByteProcessor) - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- forEachByte(ByteProcessor) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- forEachByte(int, int, ByteProcessor) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- forEachByte(ByteProcessor) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- forEachByte(int, int, ByteProcessor) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.PooledDuplicatedByteBuf
-
- forEachByte(int, int, ByteProcessor) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- 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.buffer.WrappedByteBuf
-
- forEachByte(int, int, ByteProcessor) - Method in class io.netty.buffer.WrappedByteBuf
-
- forEachByte(ByteProcessor) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- forEachByte(int, int, ByteProcessor) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- forEachByte(ByteProcessor) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- forEachByte(int, int, ByteProcessor) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- 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.
- forEachByte0(int, int, ByteProcessor) - Method in class io.netty.util.AsciiString
-
- forEachByteAsc0(int, int, ByteProcessor) - Method in class io.netty.buffer.AbstractByteBuf
-
- forEachByteDesc(ByteProcessor) - Method in class io.netty.buffer.AbstractByteBuf
-
- forEachByteDesc(int, int, ByteProcessor) - Method in class io.netty.buffer.AbstractByteBuf
-
- forEachByteDesc(int, int, ByteProcessor) - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- forEachByteDesc(ByteProcessor) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- forEachByteDesc(int, int, ByteProcessor) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- forEachByteDesc(ByteProcessor) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- forEachByteDesc(int, int, ByteProcessor) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.PooledDuplicatedByteBuf
-
- forEachByteDesc(int, int, ByteProcessor) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- 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.buffer.WrappedByteBuf
-
- forEachByteDesc(int, int, ByteProcessor) - Method in class io.netty.buffer.WrappedByteBuf
-
- forEachByteDesc(ByteProcessor) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- forEachByteDesc(int, int, ByteProcessor) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- forEachByteDesc(ByteProcessor) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- forEachByteDesc(int, int, ByteProcessor) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- 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.
- forEachByteDesc0(int, int, ByteProcessor) - Method in class io.netty.buffer.AbstractByteBuf
-
- forEachByteDesc0(int, int, ByteProcessor) - Method in class io.netty.util.AsciiString
-
- forEachFlushedMessage(ChannelOutboundBuffer.MessageProcessor) - Method in class io.netty.channel.ChannelOutboundBuffer
-
- forEngine(SSLEngine) - Static method in enum io.netty.handler.ssl.SslHandler.SslEngineType
-
- 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.
- format(String, Object) - Static method in class io.netty.util.internal.logging.MessageFormatter
-
Performs single argument substitution for the 'messagePattern' passed as
parameter.
- format(String, Object, Object) - Static method in class io.netty.util.internal.logging.MessageFormatter
-
Performs a two argument substitution for the 'messagePattern' passed as
parameter.
- format0(Date) - Method in class io.netty.handler.codec.DateFormatter
-
- formatAddress(byte[]) - Static method in class io.netty.util.internal.MacAddressUtil
-
- formatByteBuf(ChannelHandlerContext, String, ByteBuf) - Static method in class io.netty.handler.logging.LoggingHandler
-
Generates the default log message of the specified event whose argument is a
ByteBuf
.
- formatByteBufHolder(ChannelHandlerContext, String, ByteBufHolder) - Static method in class io.netty.handler.logging.LoggingHandler
-
Generates the default log message of the specified event whose argument is a
ByteBufHolder
.
- formatSimple(ChannelHandlerContext, String, Object) - Static method in class io.netty.handler.logging.LoggingHandler
-
Generates the default log message of the specified event whose argument is an arbitrary object.
- formatter() - Static method in class io.netty.handler.codec.DateFormatter
-
- FormattingTuple - Class in io.netty.util.internal.logging
-
- FormattingTuple(String, Throwable) - Constructor for class io.netty.util.internal.logging.FormattingTuple
-
- FORMERR - Static variable in class io.netty.handler.codec.dns.DnsResponseCode
-
The 'FormErr' DNS RCODE (1), as defined in
RFC1035.
- forServer - Variable in class io.netty.handler.ssl.SslContextBuilder
-
- forServer(File, File) - Static method in class io.netty.handler.ssl.SslContextBuilder
-
- forServer(InputStream, InputStream) - Static method in class io.netty.handler.ssl.SslContextBuilder
-
- forServer(PrivateKey, X509Certificate...) - Static method in class io.netty.handler.ssl.SslContextBuilder
-
- forServer(File, File, String) - Static method in class io.netty.handler.ssl.SslContextBuilder
-
- forServer(InputStream, InputStream, String) - Static method in class io.netty.handler.ssl.SslContextBuilder
-
- forServer(PrivateKey, String, X509Certificate...) - Static method in class io.netty.handler.ssl.SslContextBuilder
-
- forServer(KeyManagerFactory) - Static method in class io.netty.handler.ssl.SslContextBuilder
-
- FQCN - Static variable in class io.netty.util.internal.logging.Log4JLogger
-
Following the pattern discussed in pages 162 through 168 of "The complete
log4j manual".
- fragments - Variable in class io.netty.handler.codec.sctp.SctpMessageCompletionHandler
-
- frameLength - Variable in class io.netty.handler.codec.FixedLengthFrameDecoder
-
- free(PoolChunk<T>, long, int, PoolThreadCache) - Method in class io.netty.buffer.PoolArena
-
- free(long) - Method in class io.netty.buffer.PoolChunk
-
Free a subpage or a run of pages
When a subpage is freed from PoolSubpage, it might be added back to subpage pool of the owning PoolArena
If the subpage pool in PoolArena has at least one other PoolSubpage of given elemSize, we can
completely free the owning Page so it is available for subsequent allocations
- free(PoolChunk<T>, long) - Method in class io.netty.buffer.PoolChunkList
-
- free(PoolSubpage<T>, int) - Method in class io.netty.buffer.PoolSubpage
-
- free() - Method in class io.netty.buffer.PoolThreadCache
-
Should be called if the Thread that uses this cache is about to exist to release resources out of the cache
- free(PoolThreadCache.MemoryRegionCache<?>[]) - Static method in class io.netty.buffer.PoolThreadCache
-
- free(PoolThreadCache.MemoryRegionCache<?>) - Static method in class io.netty.buffer.PoolThreadCache
-
- free() - Method in class io.netty.buffer.PoolThreadCache.MemoryRegionCache
-
Clear out this cache and free up all previous cached
PoolChunk
s and
handle
s.
- free(int) - Method in class io.netty.buffer.PoolThreadCache.MemoryRegionCache
-
- free() - Method in class io.netty.channel.kqueue.KQueueEventArray
-
- free() - Method in class io.netty.channel.kqueue.NativeLongArray
-
- free0() - Method in class io.netty.buffer.PoolThreadCache
-
- freeArray(byte[]) - Method in class io.netty.buffer.UnpooledByteBufAllocator.InstrumentedUnpooledHeapByteBuf
-
- freeArray(byte[]) - Method in class io.netty.buffer.UnpooledByteBufAllocator.InstrumentedUnpooledUnsafeHeapByteBuf
-
- freeArray(byte[]) - Method in class io.netty.buffer.UnpooledHeapByteBuf
-
- FREEBSD_SND_LOW_AT_MAX - Static variable in class io.netty.channel.kqueue.BsdSocket
-
- freeBytes - Variable in class io.netty.buffer.PoolChunk
-
- freeBytes() - Method in class io.netty.buffer.PoolChunk
-
- freeBytes() - Method in interface io.netty.buffer.PoolChunkMetric
-
Return the number of free bytes in the chunk.
- freeChunk(PoolChunk<T>, long, PoolArena.SizeClass) - Method in class io.netty.buffer.PoolArena
-
- freed - Variable in class io.netty.buffer.CompositeByteBuf
-
- freeDirect(ByteBuffer) - Method in class io.netty.buffer.UnpooledByteBufAllocator.InstrumentedUnpooledDirectByteBuf
-
- freeDirect(ByteBuffer) - Method in class io.netty.buffer.UnpooledByteBufAllocator.InstrumentedUnpooledUnsafeDirectByteBuf
-
- freeDirect(ByteBuffer) - Method in class io.netty.buffer.UnpooledByteBufAllocator.InstrumentedUnpooledUnsafeNoCleanerDirectByteBuf
-
- 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
- freeDirect(ByteBuffer) - Method in class io.netty.buffer.UnpooledUnsafeNoCleanerDirectByteBuf
-
- freeDirect(ByteBuffer) - Method in class io.netty.buffer.WrappedUnpooledUnsafeDirectByteBuf
-
- freeDirectBuffer(ByteBuffer) - Method in interface io.netty.util.internal.Cleaner
-
Free a direct ByteBuffer
if possible
- freeDirectBuffer(ByteBuffer) - Method in class io.netty.util.internal.CleanerJava6
-
- freeDirectBuffer(ByteBuffer) - Method in class io.netty.util.internal.CleanerJava9
-
- 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
-
- freeEntry(PoolThreadCache.MemoryRegionCache.Entry) - Method in class io.netty.buffer.PoolThreadCache.MemoryRegionCache
-
- freeIfNecessary() - Method in class io.netty.buffer.CompositeByteBuf.Component
-
- freeMemory(long) - Static method in class io.netty.util.internal.PlatformDependent
-
- freeMemory(long) - Static method in class io.netty.util.internal.PlatformDependent0
-
- freeSweepAllocationThreshold - Variable in class io.netty.buffer.PoolThreadCache
-
- freeTask - Variable in class io.netty.buffer.PoolThreadCache
-
- freeThreadLocalCache() - Method in class io.netty.buffer.PooledByteBufAllocator
-
Deprecated.
- FRESERVED - Static variable in class io.netty.handler.codec.compression.JdkZlibDecoder
-
- from(String) - Static method in class io.netty.channel.unix.FileDescriptor
-
- from(File) - Static method in class io.netty.channel.unix.FileDescriptor
-
- from(int) - Static method in class io.netty.handler.codec.mqtt.MqttMessageIdVariableHeader
-
- FROM_NULL_SENDER - Static variable in class io.netty.handler.codec.smtp.SmtpRequests
-
- fromByte(byte) - Static method in enum io.netty.handler.codec.socks.SocksAddressType
-
- fromByte(byte) - Static method in enum io.netty.handler.codec.socks.SocksAuthScheme
-
- fromByte(byte) - Static method in enum io.netty.handler.codec.socks.SocksAuthStatus
-
- fromByte(byte) - Static method in enum io.netty.handler.codec.socks.SocksCmdStatus
-
- fromByte(byte) - Static method in enum io.netty.handler.codec.socks.SocksCmdType
-
- fromByte(byte) - Static method in enum io.netty.handler.codec.socks.SocksProtocolVersion
-
- fromByte(byte) - Static method in enum io.netty.handler.codec.socks.SocksSubnegotiationVersion
-
- fromProtocolNameAndLevel(String, byte) - Static method in enum io.netty.handler.codec.mqtt.MqttVersion
-
- fulfillConnectPromise(ChannelPromise, boolean) - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel.KQueueStreamUnsafe
-
- fulfillConnectPromise(ChannelPromise, Throwable) - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel.KQueueStreamUnsafe
-
- fulfillConnectPromise(ChannelPromise, boolean) - Method in class io.netty.channel.nio.AbstractNioChannel.AbstractNioUnsafe
-
- fulfillConnectPromise(ChannelPromise, Throwable) - Method in class io.netty.channel.nio.AbstractNioChannel.AbstractNioUnsafe
-
- FULL_EXCEPTION - Static variable in class io.netty.channel.pool.FixedChannelPool
-
- FULL_EXCEPTION - Static variable in class io.netty.channel.pool.SimpleChannelPool
-
- FullBinaryMemcacheRequest - Interface in io.netty.handler.codec.memcache.binary
-
- FullBinaryMemcacheResponse - Interface in io.netty.handler.codec.memcache.binary
-
- FullBulkStringRedisMessage - Class in io.netty.handler.codec.redis
-
An aggregated bulk string of
RESP.
- FullBulkStringRedisMessage() - Constructor for class io.netty.handler.codec.redis.FullBulkStringRedisMessage
-
- FullBulkStringRedisMessage(ByteBuf) - Constructor for class io.netty.handler.codec.redis.FullBulkStringRedisMessage
-
- FullMemcacheMessage - Interface in io.netty.handler.codec.memcache
-
- future - Variable in class io.netty.channel.ChannelFlushPromiseNotifier.DefaultFlushCheckpoint
-
- Future<V> - Interface in io.netty.util.concurrent
-
The result of an asynchronous operation.
- future - Variable in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor.RunnableScheduledFutureTask
-
- FutureListener<V> - Interface in io.netty.util.concurrent
-
- futureListenerStackDepth() - Method in class io.netty.util.internal.InternalThreadLocalMap
-
- futureListenerStackDepth - Variable in class io.netty.util.internal.UnpaddedInternalThreadLocalMap
-
- futures - Variable in class io.netty.channel.group.DefaultChannelGroupFuture
-
- 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
-
- GeneralCaseInsensitiveCharEqualityComparator() - Constructor for class io.netty.util.AsciiString.GeneralCaseInsensitiveCharEqualityComparator
-
- generate(String, KeyPair, SecureRandom, Date, Date) - Static method in class io.netty.handler.ssl.util.OpenJdkSelfSignedCertGenerator
-
- generateHuffmanCodeLengths(int, int[], int[]) - Static method in class io.netty.handler.codec.compression.Bzip2HuffmanStageEncoder
-
Generate a Huffman code length table for a given list of symbol frequencies.
- generateHuffmanOptimisationSeeds() - Method in class io.netty.handler.codec.compression.Bzip2HuffmanStageEncoder
-
Generate initial Huffman code length tables, giving each table a different low cost section
of the alphabet that is roughly equal in overall cumulative frequency.
- generateKeySpec(char[], byte[]) - Static method in class io.netty.handler.ssl.SslContext
-
Generates a key specification for an (encrypted) private key.
- generateName(ChannelHandler) - Method in class io.netty.channel.DefaultChannelPipeline
-
- generateName0(Class<?>) - Static method in class io.netty.channel.DefaultChannelPipeline
-
- generateSeed(int) - Method in class io.netty.handler.ssl.util.ThreadLocalInsecureRandom
-
- GenericEventExecutorChooser(EventExecutor[]) - Constructor for class io.netty.util.concurrent.DefaultEventExecutorChooserFactory.GenericEventExecutorChooser
-
- 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
-
- get(Class<T>) - Method in interface io.netty.channel.ChannelPipeline
-
- get(String) - Method in class io.netty.channel.DefaultChannelPipeline
-
- get(Class<T>) - Method in class io.netty.channel.DefaultChannelPipeline
-
- get() - Method in class io.netty.channel.group.VoidChannelGroupFuture
-
- get(long, TimeUnit) - Method in class io.netty.channel.group.VoidChannelGroupFuture
-
- get(SocketAddress) - Static method in class io.netty.channel.local.LocalChannelRegistry
-
- get(K) - Method in class io.netty.channel.pool.AbstractChannelPoolMap
-
- get(K) - Method in interface io.netty.channel.pool.ChannelPoolMap
-
- get(int) - Method in class io.netty.handler.codec.CodecOutputList
-
- 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(Object) - Method in class io.netty.handler.codec.serialization.ReferenceMap
-
- 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(InetSocketAddress, int) - Method in class io.netty.resolver.dns.DnsQueryContextManager
-
- 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.ByteCollections.EmptyMap
-
- get(Object) - Method in class io.netty.util.collection.ByteCollections.EmptyMap
-
- get(byte) - Method in class io.netty.util.collection.ByteCollections.UnmodifiableMap
-
- get(Object) - Method in class io.netty.util.collection.ByteCollections.UnmodifiableMap
-
- 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.CharCollections.EmptyMap
-
- get(Object) - Method in class io.netty.util.collection.CharCollections.EmptyMap
-
- get(char) - Method in class io.netty.util.collection.CharCollections.UnmodifiableMap
-
- get(Object) - Method in class io.netty.util.collection.CharCollections.UnmodifiableMap
-
- 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.IntCollections.EmptyMap
-
- get(Object) - Method in class io.netty.util.collection.IntCollections.EmptyMap
-
- get(int) - Method in class io.netty.util.collection.IntCollections.UnmodifiableMap
-
- get(Object) - Method in class io.netty.util.collection.IntCollections.UnmodifiableMap
-
- 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.LongCollections.EmptyMap
-
- get(Object) - Method in class io.netty.util.collection.LongCollections.EmptyMap
-
- get(long) - Method in class io.netty.util.collection.LongCollections.UnmodifiableMap
-
- get(Object) - Method in class io.netty.util.collection.LongCollections.UnmodifiableMap
-
- 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.ShortCollections.EmptyMap
-
- get(Object) - Method in class io.netty.util.collection.ShortCollections.EmptyMap
-
- get(short) - Method in class io.netty.util.collection.ShortCollections.UnmodifiableMap
-
- get(Object) - Method in class io.netty.util.collection.ShortCollections.UnmodifiableMap
-
- 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.
- GET_OPTION - Static variable in class io.netty.channel.socket.nio.NioDatagramChannelConfig
-
- getAcceptedIssuers() - Method in class io.netty.handler.ssl.util.X509TrustManagerWrapper
-
- getAcceptFilter() - Method in class io.netty.channel.kqueue.BsdSocket
-
- getAcceptFilter(int) - Static method in class io.netty.channel.kqueue.BsdSocket
-
- getAcceptFilter() - Method in class io.netty.channel.kqueue.KQueueServerSocketChannelConfig
-
- getActiveOnOpen() - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
-
- getAlgorithm() - Method in class io.netty.handler.ssl.PemPrivateKey
-
- getAlgorithm() - Method in class io.netty.handler.ssl.util.ThreadLocalInsecureRandom
-
- 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
-
- getAllAsString(CharSequence) - Method in class io.netty.handler.codec.stomp.DefaultStompHeaders
-
- getAllAsString(CharSequence) - Method in interface io.netty.handler.codec.stomp.StompHeaders
-
- getAllIdleTimeInMillis() - Method in class io.netty.handler.timeout.IdleStateHandler
-
Return the allIdleTime that was given when instance this class in milliseconds.
- getAllLocalAddresses() - Method in class com.sun.nio.sctp.SctpChannel
-
- getAllLocalAddresses() - Method in class com.sun.nio.sctp.SctpServerChannel
-
- getAllocator() - Method in interface io.netty.channel.ChannelConfig
-
- 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
-
- getAndRemove() - Method in class io.netty.util.DefaultAttributeMap.DefaultAttribute
-
- 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.
- getApplicationBufferSize() - Method in class io.netty.handler.ssl.JdkSslSession
-
- getApplicationProtocol() - Method in interface io.netty.handler.ssl.ApplicationProtocolAccessor
-
Returns the name of the negotiated application-level protocol.
- getApplicationProtocol() - Method in class io.netty.handler.ssl.JdkSslSession
-
- getAsString(Headers<K, V, ?>, K) - Static method in class io.netty.handler.codec.HeadersUtils
-
- getAsString(CharSequence) - Method in class io.netty.handler.codec.stomp.DefaultStompHeaders
-
- getAsString(CharSequence) - Method in interface io.netty.handler.codec.stomp.StompHeaders
-
- getBacklog() - Method in class io.netty.channel.kqueue.KQueueServerChannelConfig
-
- getBacklog() - Method in class io.netty.channel.sctp.DefaultSctpServerChannelConfig
-
- getBacklog() - Method in interface io.netty.channel.sctp.SctpServerChannelConfig
-
Gets the backlog value to specify when the channel binds to a local address.
- 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.OpenSslX509Certificate
-
- 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.AdvancedLeakAwareByteBuf
-
- getBoolean(int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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(int) - Method in class io.netty.buffer.WrappedByteBuf
-
- getBoolean(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- 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(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- 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.AbstractUnpooledSlicedByteBuf
-
- getByte(int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- getByte(int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.FixedCompositeByteBuf
-
- getByte(byte[], int) - Static method in class io.netty.buffer.HeapByteBufUtil
-
- getByte(int) - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- getByte(int) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- getByte(int) - Method in class io.netty.buffer.ReadOnlyByteBuf
-
Deprecated.
- getByte(int) - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- 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(int) - Method in class io.netty.buffer.UnpooledUnsafeHeapByteBuf
-
- getByte(long) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- getByte(byte[], int) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- getByte(int) - Method in class io.netty.buffer.WrappedByteBuf
-
- getByte(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- 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(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- getByte(long) - Static method in class io.netty.util.internal.PlatformDependent
-
- getByte(byte[], int) - Static method in class io.netty.util.internal.PlatformDependent
-
- getByte(long) - Static method in class io.netty.util.internal.PlatformDependent0
-
- getByte(byte[], int) - Static method in class io.netty.util.internal.PlatformDependent0
-
- 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, int, int) - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- getBytes(int, byte[], int, int) - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- getBytes(int, ByteBuffer) - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- getBytes(int, OutputStream, int) - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- getBytes(int, GatheringByteChannel, int) - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- getBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- getBytes(int, ByteBuf) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- getBytes(int, ByteBuf, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- getBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- getBytes(int, byte[]) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- getBytes(int, byte[], int, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- getBytes(int, ByteBuffer) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- getBytes(int, OutputStream, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- getBytes(int, GatheringByteChannel, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- getBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- getBytes(int, ByteBuf) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- getBytes(int, ByteBuf, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- getBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- getBytes(int, byte[]) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- getBytes(int, byte[], int, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- getBytes(int, ByteBuffer) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- getBytes(int, OutputStream, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- getBytes(int, GatheringByteChannel, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- getBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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, byte[], int, int) - Method in class io.netty.buffer.FixedCompositeByteBuf
-
- getBytes(int, ByteBuffer) - Method in class io.netty.buffer.FixedCompositeByteBuf
-
- getBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.FixedCompositeByteBuf
-
- getBytes(int, GatheringByteChannel, int) - Method in class io.netty.buffer.FixedCompositeByteBuf
-
- getBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.FixedCompositeByteBuf
-
- getBytes(int, OutputStream, int) - Method in class io.netty.buffer.FixedCompositeByteBuf
-
- getBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.PooledDirectByteBuf
-
- getBytes(int, byte[], int, int) - Method in class io.netty.buffer.PooledDirectByteBuf
-
- getBytes(int, byte[], int, int, boolean) - Method in class io.netty.buffer.PooledDirectByteBuf
-
- getBytes(int, ByteBuffer) - Method in class io.netty.buffer.PooledDirectByteBuf
-
- getBytes(int, ByteBuffer, boolean) - Method in class io.netty.buffer.PooledDirectByteBuf
-
- getBytes(int, OutputStream, int) - Method in class io.netty.buffer.PooledDirectByteBuf
-
- getBytes(int, OutputStream, int, boolean) - Method in class io.netty.buffer.PooledDirectByteBuf
-
- getBytes(int, GatheringByteChannel, int) - Method in class io.netty.buffer.PooledDirectByteBuf
-
- getBytes(int, GatheringByteChannel, int, boolean) - Method in class io.netty.buffer.PooledDirectByteBuf
-
- getBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.PooledDirectByteBuf
-
- getBytes(int, FileChannel, long, int, boolean) - Method in class io.netty.buffer.PooledDirectByteBuf
-
- getBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- getBytes(int, byte[], int, int) - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- getBytes(int, ByteBuffer) - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- getBytes(int, OutputStream, int) - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- getBytes(int, GatheringByteChannel, int) - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- getBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- getBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.PooledHeapByteBuf
-
- getBytes(int, byte[], int, int) - Method in class io.netty.buffer.PooledHeapByteBuf
-
- getBytes(int, ByteBuffer) - Method in class io.netty.buffer.PooledHeapByteBuf
-
- getBytes(int, OutputStream, int) - Method in class io.netty.buffer.PooledHeapByteBuf
-
- getBytes(int, GatheringByteChannel, int) - Method in class io.netty.buffer.PooledHeapByteBuf
-
- getBytes(int, GatheringByteChannel, int, boolean) - Method in class io.netty.buffer.PooledHeapByteBuf
-
- getBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.PooledHeapByteBuf
-
- getBytes(int, FileChannel, long, int, boolean) - Method in class io.netty.buffer.PooledHeapByteBuf
-
- getBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- getBytes(int, byte[], int, int) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- getBytes(int, ByteBuffer) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- getBytes(int, OutputStream, int) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- getBytes(int, GatheringByteChannel, int) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- getBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- getBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- getBytes(int, byte[], int, int) - Method in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- getBytes(int, ByteBuffer) - Method in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- getBytes(int, OutputStream, int) - Method in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- getBytes(int, GatheringByteChannel, int) - Method in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- getBytes(int, GatheringByteChannel, int, boolean) - Method in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- getBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- getBytes(int, FileChannel, long, int, boolean) - Method in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- 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, int, int) - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- getBytes(int, byte[], int, int) - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- getBytes(int, ByteBuffer) - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- getBytes(int, OutputStream, int) - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- getBytes(int, GatheringByteChannel, int) - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- getBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- getBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.ReadOnlyUnsafeDirectByteBuf
-
- getBytes(int, byte[], int, int) - Method in class io.netty.buffer.ReadOnlyUnsafeDirectByteBuf
-
- getBytes(int, ByteBuffer) - Method in class io.netty.buffer.ReadOnlyUnsafeDirectByteBuf
-
- 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, byte[], int, int, boolean) - Method in class io.netty.buffer.UnpooledDirectByteBuf
-
- getBytes(int, ByteBuffer) - Method in class io.netty.buffer.UnpooledDirectByteBuf
-
- getBytes(int, ByteBuffer, boolean) - Method in class io.netty.buffer.UnpooledDirectByteBuf
-
- getBytes(int, OutputStream, int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
-
- getBytes(int, OutputStream, int, boolean) - Method in class io.netty.buffer.UnpooledDirectByteBuf
-
- getBytes(int, GatheringByteChannel, int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
-
- getBytes(int, GatheringByteChannel, int, boolean) - Method in class io.netty.buffer.UnpooledDirectByteBuf
-
- getBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
-
- getBytes(int, FileChannel, long, int, boolean) - 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, GatheringByteChannel, int, boolean) - Method in class io.netty.buffer.UnpooledHeapByteBuf
-
- getBytes(int, FileChannel, long, int, boolean) - 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, GatheringByteChannel, int, boolean) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
-
- getBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
-
- getBytes(int, FileChannel, long, int, boolean) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
-
- getBytes(AbstractByteBuf, long, int, ByteBuf, int, int) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- getBytes(AbstractByteBuf, long, int, byte[], int, int) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- getBytes(AbstractByteBuf, long, int, ByteBuffer) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- getBytes(AbstractByteBuf, long, int, OutputStream, int) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- getBytes(int, ByteBuf) - Method in class io.netty.buffer.WrappedByteBuf
-
- getBytes(int, ByteBuf, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- getBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- getBytes(int, byte[]) - Method in class io.netty.buffer.WrappedByteBuf
-
- getBytes(int, byte[], int, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- getBytes(int, ByteBuffer) - Method in class io.netty.buffer.WrappedByteBuf
-
- getBytes(int, OutputStream, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- getBytes(int, GatheringByteChannel, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- getBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- getBytes(int, byte[], int, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- getBytes(int, ByteBuffer) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- getBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- getBytes(int, GatheringByteChannel, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- getBytes(int, OutputStream, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- getBytes(int, ByteBuf) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- getBytes(int, ByteBuf, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- getBytes(int, byte[]) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- getBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- getBytes(int, byte[], int, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- getBytes(int, byte[]) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- getBytes(int, ByteBuffer) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- getBytes(int, ByteBuf, int, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- getBytes(int, ByteBuf, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- getBytes(int, ByteBuf) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- getBytes(int, GatheringByteChannel, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- getBytes(int, FileChannel, long, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- getBytes(int, OutputStream, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- getCertificatesFromBuffers(ByteBuf[]) - Static method in class io.netty.handler.ssl.SslContext
-
- getChannel(long) - Static method in class io.netty.channel.kqueue.KQueueEventArray
-
- getChar(int) - Method in class io.netty.buffer.AbstractByteBuf
-
- getChar(int) - Method in class io.netty.buffer.AbstractUnsafeSwappedByteBuf
-
- getChar(int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- getChar(int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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(int) - Method in class io.netty.buffer.WrappedByteBuf
-
- getChar(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- 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.
- getChar(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- 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.AbstractUnpooledSlicedByteBuf
-
- getCharSequence(int, int, Charset) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- getCharSequence(int, int, Charset) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.
- getCharSequence(int, int, Charset) - Method in class io.netty.buffer.WrappedByteBuf
-
- getCharSequence(int, int, Charset) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- getCharSequence(int, int, Charset) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- getCheckInterval() - Method in class io.netty.handler.traffic.AbstractTrafficShapingHandler
-
- getCipherSuite() - Method in class io.netty.handler.ssl.JdkSslSession
-
- getClassLoader(Class<?>) - Static method in class io.netty.util.internal.PlatformDependent
-
Return the ClassLoader
for the given Class
.
- getClassLoader(Class<?>) - Static method in class io.netty.util.internal.PlatformDependent0
-
- 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
-
- getConnVariableHeaderFlag(MqttConnectVariableHeader) - Static method in class io.netty.handler.codec.mqtt.MqttEncoder
-
- getContentLength(StompHeaders, long) - Static method in class io.netty.handler.codec.stomp.StompSubframeDecoder
-
- getContextClassLoader() - Static method in class io.netty.util.internal.PlatformDependent
-
Return the context ClassLoader
for the current Thread
.
- getContextClassLoader() - Static method in class io.netty.util.internal.PlatformDependent0
-
- getContextMap(InetSocketAddress) - Method in class io.netty.resolver.dns.DnsQueryContextManager
-
- getContextOrDie(String) - Method in class io.netty.channel.DefaultChannelPipeline
-
- getContextOrDie(ChannelHandler) - Method in class io.netty.channel.DefaultChannelPipeline
-
- getContextOrDie(Class<? extends ChannelHandler>) - Method in class io.netty.channel.DefaultChannelPipeline
-
- getCRC() - Method in class io.netty.handler.codec.compression.Crc32
-
- getCreationTime() - Method in class io.netty.handler.ssl.JdkSslSession
-
- getCriticalExtensionOIDs() - Method in class io.netty.handler.ssl.OpenSslX509Certificate
-
- 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.
- getDelay(TimeUnit) - Method in class io.netty.util.concurrent.ScheduledFutureTask
-
- getDelay(TimeUnit) - Method in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor.RunnableScheduledFutureTask
-
- getDelegatedTask() - Method in class io.netty.handler.ssl.JdkSslEngine
-
- getDouble(int) - Method in class io.netty.buffer.AbstractByteBuf
-
- getDouble(int) - Method in class io.netty.buffer.AbstractUnsafeSwappedByteBuf
-
- getDouble(int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- getDouble(int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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(int) - Method in class io.netty.buffer.WrappedByteBuf
-
- getDouble(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- 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.
- getDouble(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- 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.
- getEnabledCipherSuites() - Method in class io.netty.handler.ssl.JdkSslEngine
-
- getEnabledProtocols() - Method in class io.netty.handler.ssl.JdkSslEngine
-
- getEnableSessionCreation() - Method in class io.netty.handler.ssl.JdkSslEngine
-
- getEncoded() - Method in class io.netty.handler.ssl.OpenSslJavaxX509Certificate
-
- getEncoded() - Method in class io.netty.handler.ssl.OpenSslX509Certificate
-
- 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
-
- getEncryptedPacketLength(ByteBuf, int) - Static method in class io.netty.handler.ssl.SslUtils
-
Return how much bytes can be read out of the encrypted data.
- getEncryptedPacketLength(ByteBuffer[], int) - Static method in class io.netty.handler.ssl.SslUtils
-
- getEncryptedPacketLength(ByteBuffer) - Static method in class io.netty.handler.ssl.SslUtils
-
- 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
-
- getError(ByteBuf) - Method in interface io.netty.handler.codec.redis.RedisMessagePool
-
- getExtensionValue(String) - Method in class io.netty.handler.ssl.OpenSslX509Certificate
-
- getExtensionValue(String) - Method in class io.netty.handler.ssl.PemX509Certificate
-
- getFixedHeaderByte1(MqttFixedHeader) - Static method in class io.netty.handler.codec.mqtt.MqttEncoder
-
- getFloat(int) - Method in class io.netty.buffer.AbstractByteBuf
-
- getFloat(int) - Method in class io.netty.buffer.AbstractUnsafeSwappedByteBuf
-
- getFloat(int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- getFloat(int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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(int) - Method in class io.netty.buffer.WrappedByteBuf
-
- getFloat(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- 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.
- getFloat(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- 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
-
- getHandshakeSession() - Method in class io.netty.handler.ssl.JdkSslEngine
-
- getHandshakeStatus() - Method in class io.netty.handler.ssl.JdkSslEngine
-
- getHandshakeTimeoutMillis() - Method in class io.netty.handler.ssl.SslHandler
-
- getHashTable(int) - Static method in class io.netty.handler.codec.compression.Snappy
-
Creates an appropriately sized hashtable for the given input size
- getId() - Method in class io.netty.handler.ssl.JdkSslSession
-
- getIDX(int) - Static method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- getIfSet() - Static method in class io.netty.util.internal.InternalThreadLocalMap
-
- getInitialSeedUniquifier() - Static method in class io.netty.util.internal.ThreadLocalRandom
-
- getInitMaxStreams() - Method in class io.netty.channel.sctp.DefaultSctpChannelConfig
-
- getInitMaxStreams() - Method in class io.netty.channel.sctp.DefaultSctpServerChannelConfig
-
- getInitMaxStreams() - Method in interface io.netty.channel.sctp.SctpChannelConfig
-
- getInitMaxStreams() - Method in interface io.netty.channel.sctp.SctpServerChannelConfig
-
- 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.AbstractUnpooledSlicedByteBuf
-
- getInt(int) - Method in class io.netty.buffer.AbstractUnsafeSwappedByteBuf
-
- getInt(int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- getInt(int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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(byte[], int) - Static method in class io.netty.buffer.HeapByteBufUtil
-
- getInt(int) - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- getInt(int) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- getInt(int) - Method in class io.netty.buffer.ReadOnlyByteBuf
-
Deprecated.
- getInt(int) - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- 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(int) - Method in class io.netty.buffer.UnpooledUnsafeHeapByteBuf
-
- getInt(long) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- getInt(byte[], int) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- getInt(int) - Method in class io.netty.buffer.WrappedByteBuf
-
- getInt(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- 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(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- 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(Object, long) - Static method in class io.netty.util.internal.PlatformDependent0
-
- getInt(long) - Static method in class io.netty.util.internal.PlatformDependent0
-
- getInt(byte[], int) - Static method in class io.netty.util.internal.PlatformDependent0
-
- 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
-
- getInteger(ByteBuf) - Method in interface io.netty.handler.codec.redis.RedisMessagePool
-
- 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
-
- getInterface() - Method in class io.netty.channel.socket.nio.NioDatagramChannelConfig
-
- getIntLE(int) - Method in class io.netty.buffer.AbstractByteBuf
-
- getIntLE(int) - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- getIntLE(int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- getIntLE(int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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(byte[], int) - Static method in class io.netty.buffer.HeapByteBufUtil
-
- getIntLE(int) - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- getIntLE(int) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- getIntLE(int) - Method in class io.netty.buffer.ReadOnlyByteBuf
-
Deprecated.
- getIntLE(int) - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- getIntLE(int) - Method in class io.netty.buffer.SwappedByteBuf
-
Deprecated.
- getIntLE(int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
-
- getIntLE(int) - Method in class io.netty.buffer.UnpooledUnsafeHeapByteBuf
-
- getIntLE(long) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- getIntLE(byte[], int) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- getIntLE(int) - Method in class io.netty.buffer.WrappedByteBuf
-
- getIntLE(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- getIntLE(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- getIntSafe(byte[], int) - Static method in class io.netty.util.internal.PlatformDependent
-
- getIoRatio() - Method in class io.netty.channel.kqueue.KQueueEventLoop
-
Returns the percentage of the desired amount of time spent for I/O in the event loop.
- 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.
- getIPv6ByName(CharSequence, boolean) - Static method in class io.netty.util.NetUtil
-
Returns the byte array representation of a CharSequence
IP address.
- getIssuerDN() - Method in class io.netty.handler.ssl.OpenSslJavaxX509Certificate
-
- getIssuerDN() - Method in class io.netty.handler.ssl.OpenSslX509Certificate
-
- getIssuerDN() - Method in class io.netty.handler.ssl.PemX509Certificate
-
- getIssuerUniqueID() - Method in class io.netty.handler.ssl.OpenSslX509Certificate
-
- getIssuerUniqueID() - Method in class io.netty.handler.ssl.PemX509Certificate
-
- GETK - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
-
- getKEventOffset(int) - Method in class io.netty.channel.kqueue.KQueueEventArray
-
- getKey() - Method in class io.netty.channel.group.DefaultChannelGroupFuture.DefaultEntry
-
- getKey() - Method in class io.netty.handler.codec.DefaultHeaders.HeaderEntry
-
- getKey() - Method in class io.netty.handler.codec.HeadersUtils.StringEntry
-
- getKey() - Method in class io.netty.util.collection.ByteObjectHashMap.MapEntry
-
- getKey() - Method in class io.netty.util.collection.CharObjectHashMap.MapEntry
-
- getKey() - Method in class io.netty.util.collection.IntObjectHashMap.MapEntry
-
- getKey() - Method in class io.netty.util.collection.LongObjectHashMap.MapEntry
-
- getKey() - Method in class io.netty.util.collection.ShortObjectHashMap.MapEntry
-
- getKeyUsage() - Method in class io.netty.handler.ssl.OpenSslX509Certificate
-
- getKeyUsage() - Method in class io.netty.handler.ssl.PemX509Certificate
-
- GETKQ - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
-
- getLastAccessedTime() - Method in class io.netty.handler.ssl.JdkSslSession
-
- getLevel() - Static method in class io.netty.util.ResourceLeakDetector
-
Returns the current resource leak detection level.
- getLocalCertificates() - Method in class io.netty.handler.ssl.JdkSslSession
-
- getLocalPrincipal() - Method in class io.netty.handler.ssl.JdkSslSession
-
- getLong(int) - Method in class io.netty.buffer.AbstractByteBuf
-
- getLong(int) - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- getLong(int) - Method in class io.netty.buffer.AbstractUnsafeSwappedByteBuf
-
- getLong(int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- getLong(int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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(byte[], int) - Static method in class io.netty.buffer.HeapByteBufUtil
-
- getLong(int) - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- getLong(int) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- getLong(int) - Method in class io.netty.buffer.ReadOnlyByteBuf
-
Deprecated.
- getLong(int) - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- 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(int) - Method in class io.netty.buffer.UnpooledUnsafeHeapByteBuf
-
- getLong(long) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- getLong(byte[], int) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- getLong(int) - Method in class io.netty.buffer.WrappedByteBuf
-
- getLong(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- 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(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- getLong(long) - Static method in class io.netty.util.internal.PlatformDependent
-
- getLong(byte[], int) - Static method in class io.netty.util.internal.PlatformDependent
-
- getLong(Object, long) - Static method in class io.netty.util.internal.PlatformDependent0
-
- getLong(long) - Static method in class io.netty.util.internal.PlatformDependent0
-
- getLong(byte[], int) - Static method in class io.netty.util.internal.PlatformDependent0
-
- 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.AbstractUnpooledSlicedByteBuf
-
- getLongLE(int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- getLongLE(int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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(byte[], int) - Static method in class io.netty.buffer.HeapByteBufUtil
-
- getLongLE(int) - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- getLongLE(int) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- getLongLE(int) - Method in class io.netty.buffer.ReadOnlyByteBuf
-
Deprecated.
- getLongLE(int) - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- getLongLE(int) - Method in class io.netty.buffer.SwappedByteBuf
-
Deprecated.
- getLongLE(int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
-
- getLongLE(int) - Method in class io.netty.buffer.UnpooledUnsafeHeapByteBuf
-
- getLongLE(long) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- getLongLE(byte[], int) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- getLongLE(int) - Method in class io.netty.buffer.WrappedByteBuf
-
- getLongLE(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- getLongLE(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- getLongSafe(byte[], int) - Static method in class io.netty.util.internal.PlatformDependent
-
- 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
-
- 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.AdvancedLeakAwareByteBuf
-
- getMedium(int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.
- getMedium(int) - Method in class io.netty.buffer.WrappedByteBuf
-
- getMedium(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- getMedium(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- getMediumLE(int) - Method in class io.netty.buffer.AbstractByteBuf
-
- getMediumLE(int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- getMediumLE(int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.
- getMediumLE(int) - Method in class io.netty.buffer.WrappedByteBuf
-
- getMediumLE(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- getMediumLE(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- getMessage() - Method in class io.netty.util.internal.logging.FormattingTuple
-
- getMessageSizeEstimator() - Method in interface io.netty.channel.ChannelConfig
-
- getMessageSizeEstimator() - Method in class io.netty.channel.DefaultChannelConfig
-
- getNameServers(String) - Method in class io.netty.resolver.dns.DnsNameResolverContext
-
- getNameServersFromCache(String) - Method in class io.netty.resolver.dns.DnsNameResolverContext
-
- getNeedClientAuth() - Method in class io.netty.handler.ssl.JdkSslEngine
-
- getNetworkInterface() - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
-
- getNetworkInterface() - Method in interface io.netty.channel.socket.DatagramChannelConfig
-
Gets the StandardSocketOptions.IP_MULTICAST_IF
option.
- getNetworkInterface() - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
-
- getNetworkInterface() - Method in class io.netty.channel.socket.nio.NioDatagramChannelConfig
-
- getNextAvail() - Method in class io.netty.buffer.PoolSubpage
-
- getNonCriticalExtensionOIDs() - Method in class io.netty.handler.ssl.OpenSslX509Certificate
-
- getNonCriticalExtensionOIDs() - Method in class io.netty.handler.ssl.PemX509Certificate
-
- getNotAfter() - Method in class io.netty.handler.ssl.OpenSslJavaxX509Certificate
-
- getNotAfter() - Method in class io.netty.handler.ssl.OpenSslX509Certificate
-
- getNotAfter() - Method in class io.netty.handler.ssl.PemX509Certificate
-
- getNotBefore() - Method in class io.netty.handler.ssl.OpenSslJavaxX509Certificate
-
- getNotBefore() - Method in class io.netty.handler.ssl.OpenSslX509Certificate
-
- getNotBefore() - Method in class io.netty.handler.ssl.PemX509Certificate
-
- getNow() - Method in class io.netty.channel.CompleteChannelFuture
-
- getNow() - Method in class io.netty.channel.group.VoidChannelGroupFuture
-
- getNow() - Method in class io.netty.channel.VoidChannelPromise
-
- 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
-
- getNumericalValue(char) - Static method in class io.netty.handler.codec.DateFormatter
-
- getObject(Object, long) - Static method in class io.netty.util.internal.PlatformDependent0
-
- getOption(SctpSocketOption<T>) - Method in class com.sun.nio.sctp.SctpChannel
-
- getOption(SctpSocketOption<T>) - Method in class com.sun.nio.sctp.SctpServerChannel
-
- getOption(ChannelOption<T>) - Method in interface io.netty.channel.ChannelConfig
-
- getOption(ChannelOption<T>) - Method in class io.netty.channel.DefaultChannelConfig
-
- 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.sctp.DefaultSctpChannelConfig
-
- getOption(ChannelOption<T>) - Method in class io.netty.channel.sctp.DefaultSctpServerChannelConfig
-
- 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
-
- getOption0(Object) - Method in class io.netty.channel.socket.nio.NioDatagramChannelConfig
-
- getOptions() - Method in interface io.netty.channel.ChannelConfig
-
- 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.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.sctp.DefaultSctpChannelConfig
-
- getOptions() - Method in class io.netty.channel.sctp.DefaultSctpServerChannelConfig
-
- 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
-
- getOrCreate(String) - Method in class io.netty.util.ConstantPool
-
Get existing constant by name or creates new one if not exists.
- getOrCreateContextMap(InetSocketAddress) - Method in class io.netty.resolver.dns.DnsQueryContextManager
-
- getOrSetPerChannel(ChannelHandlerContext) - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
-
- getOrSetPerChannel(ChannelHandlerContext) - Method in class io.netty.handler.traffic.GlobalTrafficShapingHandler
-
- getPacketBufferSize() - Method in class io.netty.handler.ssl.JdkSslSession
-
- getPeerCertificateChain() - Method in class io.netty.handler.ssl.JdkSslSession
-
- getPeerCertificates() - Method in class io.netty.handler.ssl.JdkSslSession
-
- getPeerCredentials() - Method in class io.netty.channel.kqueue.BsdSocket
-
- getPeerCredentials(int) - Static method in class io.netty.channel.kqueue.BsdSocket
-
- getPeerHost() - Method in class io.netty.handler.ssl.JdkSslEngine
-
- getPeerHost() - Method in class io.netty.handler.ssl.JdkSslSession
-
- getPeerPort() - Method in class io.netty.handler.ssl.JdkSslEngine
-
- getPeerPort() - Method in class io.netty.handler.ssl.JdkSslSession
-
- getPeerPrincipal() - Method in class io.netty.handler.ssl.JdkSslSession
-
- getPinEventExecutorPerGroup() - Method in class io.netty.channel.DefaultChannelConfig
-
- getPrivateKeyFromByteBuffer(ByteBuf, String) - Static method in class io.netty.handler.ssl.SslContext
-
- getProtocol() - Method in class io.netty.handler.ssl.JdkSslSession
-
- getPublicKey() - Method in class io.netty.handler.ssl.OpenSslJavaxX509Certificate
-
- getPublicKey() - Method in class io.netty.handler.ssl.OpenSslX509Certificate
-
- 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.kqueue.KQueueDomainSocketChannelConfig
-
- getReadMode() - Method in interface io.netty.channel.unix.DomainSocketChannelConfig
-
- 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.kqueue.KQueueDatagramChannelConfig
-
- getReceiveBufferSize() - Method in class io.netty.channel.kqueue.KQueueServerChannelConfig
-
- getReceiveBufferSize() - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
-
- getReceiveBufferSize() - Method in class io.netty.channel.sctp.DefaultSctpChannelConfig
-
- getReceiveBufferSize() - Method in class io.netty.channel.sctp.DefaultSctpServerChannelConfig
-
- getReceiveBufferSize() - Method in interface io.netty.channel.sctp.SctpChannelConfig
-
- getReceiveBufferSize() - Method in interface io.netty.channel.sctp.SctpServerChannelConfig
-
- getReceiveBufferSize() - Method in interface io.netty.channel.socket.DatagramChannelConfig
-
Gets the StandardSocketOptions.SO_RCVBUF
option.
- 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
-
Gets the StandardSocketOptions.SO_RCVBUF
option.
- getReceiveBufferSize() - Method in interface io.netty.channel.socket.SocketChannelConfig
-
Gets the StandardSocketOptions.SO_RCVBUF
option.
- getReceiveBufferSize() - Method in class io.netty.channel.unix.Socket
-
- getReceiveBufferSize(int) - Static method in class io.netty.channel.unix.Socket
-
- getRecvByteBufAllocator() - Method in interface io.netty.channel.ChannelConfig
-
- getRecvByteBufAllocator() - Method in class io.netty.channel.DefaultChannelConfig
-
- getRemoteAddresses() - Method in class com.sun.nio.sctp.SctpChannel
-
- getResolver(EventExecutor) - Method in class io.netty.resolver.AddressResolverGroup
-
- getSendBufferSize() - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
-
- getSendBufferSize() - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
-
- getSendBufferSize() - Method in class io.netty.channel.sctp.DefaultSctpChannelConfig
-
- getSendBufferSize() - Method in class io.netty.channel.sctp.DefaultSctpServerChannelConfig
-
- getSendBufferSize() - Method in interface io.netty.channel.sctp.SctpChannelConfig
-
- getSendBufferSize() - Method in interface io.netty.channel.sctp.SctpServerChannelConfig
-
- getSendBufferSize() - Method in interface io.netty.channel.socket.DatagramChannelConfig
-
Gets the StandardSocketOptions.SO_SNDBUF
option.
- 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
-
Gets the StandardSocketOptions.SO_SNDBUF
option.
- getSendBufferSize() - Method in class io.netty.channel.unix.Socket
-
- getSendBufferSize(int) - Static method in class io.netty.channel.unix.Socket
-
- getSerialNumber() - Method in class io.netty.handler.ssl.OpenSslJavaxX509Certificate
-
- getSerialNumber() - Method in class io.netty.handler.ssl.OpenSslX509Certificate
-
- getSerialNumber() - Method in class io.netty.handler.ssl.PemX509Certificate
-
- getSession() - Method in class io.netty.handler.ssl.JdkSslEngine
-
- getSessionContext() - Method in class io.netty.handler.ssl.JdkSslSession
-
- getShort(int) - Method in class io.netty.buffer.AbstractByteBuf
-
- getShort(int) - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- getShort(int) - Method in class io.netty.buffer.AbstractUnsafeSwappedByteBuf
-
- getShort(int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- getShort(int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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(byte[], int) - Static method in class io.netty.buffer.HeapByteBufUtil
-
- getShort(int) - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- getShort(int) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- getShort(int) - Method in class io.netty.buffer.ReadOnlyByteBuf
-
Deprecated.
- getShort(int) - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- 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(int) - Method in class io.netty.buffer.UnpooledUnsafeHeapByteBuf
-
- getShort(long) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- getShort(byte[], int) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- getShort(int) - Method in class io.netty.buffer.WrappedByteBuf
-
- getShort(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- 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(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- getShort(long) - Static method in class io.netty.util.internal.PlatformDependent
-
- getShort(byte[], int) - Static method in class io.netty.util.internal.PlatformDependent
-
- getShort(long) - Static method in class io.netty.util.internal.PlatformDependent0
-
- getShort(byte[], int) - Static method in class io.netty.util.internal.PlatformDependent0
-
- 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.AbstractUnpooledSlicedByteBuf
-
- getShortLE(int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- getShortLE(int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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(byte[], int) - Static method in class io.netty.buffer.HeapByteBufUtil
-
- getShortLE(int) - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- getShortLE(int) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- getShortLE(int) - Method in class io.netty.buffer.ReadOnlyByteBuf
-
Deprecated.
- getShortLE(int) - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- getShortLE(int) - Method in class io.netty.buffer.SwappedByteBuf
-
Deprecated.
- getShortLE(int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
-
- getShortLE(int) - Method in class io.netty.buffer.UnpooledUnsafeHeapByteBuf
-
- getShortLE(long) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- getShortLE(byte[], int) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- getShortLE(int) - Method in class io.netty.buffer.WrappedByteBuf
-
- getShortLE(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- getShortLE(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- getShortSafe(byte[], int) - Static method in class io.netty.util.internal.PlatformDependent
-
- getSigAlgName() - Method in class io.netty.handler.ssl.OpenSslJavaxX509Certificate
-
- getSigAlgName() - Method in class io.netty.handler.ssl.OpenSslX509Certificate
-
- getSigAlgName() - Method in class io.netty.handler.ssl.PemX509Certificate
-
- getSigAlgOID() - Method in class io.netty.handler.ssl.OpenSslJavaxX509Certificate
-
- getSigAlgOID() - Method in class io.netty.handler.ssl.OpenSslX509Certificate
-
- getSigAlgOID() - Method in class io.netty.handler.ssl.PemX509Certificate
-
- getSigAlgParams() - Method in class io.netty.handler.ssl.OpenSslJavaxX509Certificate
-
- getSigAlgParams() - Method in class io.netty.handler.ssl.OpenSslX509Certificate
-
- getSigAlgParams() - Method in class io.netty.handler.ssl.PemX509Certificate
-
- getSignature() - Method in class io.netty.handler.ssl.OpenSslX509Certificate
-
- 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
-
- getSimpleString(ByteBuf) - Method in interface io.netty.handler.codec.redis.RedisMessagePool
-
- getSizeTableIndex(int) - Static method in class io.netty.channel.AdaptiveRecvByteBufAllocator
-
- getSndLowAt() - Method in class io.netty.channel.kqueue.BsdSocket
-
- getSndLowAt(int) - Static method in class io.netty.channel.kqueue.BsdSocket
-
- getSndLowAt() - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
-
- getSniHostNames(SSLParameters) - Static method in class io.netty.handler.ssl.Java8SslUtils
-
- getSoError() - Method in class io.netty.channel.unix.Socket
-
- getSoError(int) - Static method in class io.netty.channel.unix.Socket
-
- 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
-
Gets the StandardSocketOptions.SO_LINGER
option.
- getSoLinger() - Method in class io.netty.channel.unix.Socket
-
- getSoLinger(int) - Static 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.
- getSSLParameters() - Method in class io.netty.handler.ssl.JdkSslEngine
-
- getSubjectDN() - Method in class io.netty.handler.ssl.OpenSslJavaxX509Certificate
-
- getSubjectDN() - Method in class io.netty.handler.ssl.OpenSslX509Certificate
-
- getSubjectDN() - Method in class io.netty.handler.ssl.PemX509Certificate
-
- getSubjectUniqueID() - Method in class io.netty.handler.ssl.OpenSslX509Certificate
-
- getSubjectUniqueID() - Method in class io.netty.handler.ssl.PemX509Certificate
-
- getSupportedCipherSuites() - Method in class io.netty.handler.ssl.JdkSslEngine
-
- getSupportedProtocols() - Method in class io.netty.handler.ssl.JdkSslEngine
-
- getSystemClassLoader() - Static method in class io.netty.util.internal.PlatformDependent
-
Return the system ClassLoader
.
- getSystemClassLoader() - Static method in class io.netty.util.internal.PlatformDependent0
-
- getTBSCertificate() - Method in class io.netty.handler.ssl.OpenSslX509Certificate
-
- getTBSCertificate() - Method in class io.netty.handler.ssl.PemX509Certificate
-
- getTcpNoPush(int) - Static method in class io.netty.channel.kqueue.BsdSocket
-
- getThrowable() - Method in class io.netty.util.internal.logging.FormattingTuple
-
- 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.kqueue.KQueueDatagramChannelConfig
-
- getTimeToLive() - Method in interface io.netty.channel.socket.DatagramChannelConfig
-
Gets the StandardSocketOptions.IP_MULTICAST_TTL
option.
- getTimeToLive() - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
-
- getTimeToLive() - Method in class io.netty.channel.socket.nio.NioDatagramChannelConfig
-
- 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
-
Gets the StandardSocketOptions.IP_TOS
option.
- 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
-
Gets the StandardSocketOptions.IP_TOS
option.
- getTrafficClass() - Method in class io.netty.channel.unix.Socket
-
- getTrafficClass(int) - Static 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.
- getUnsafe(int) - Method in class io.netty.handler.codec.CodecOutputList
-
Returns the element on the given index.
- getUnsignedByte(int) - Method in class io.netty.buffer.AbstractByteBuf
-
- getUnsignedByte(int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- getUnsignedByte(int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.
- getUnsignedByte(int) - Method in class io.netty.buffer.WrappedByteBuf
-
- getUnsignedByte(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- getUnsignedByte(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- getUnsignedInt(int) - Method in class io.netty.buffer.AbstractByteBuf
-
- getUnsignedInt(int) - Method in class io.netty.buffer.AbstractUnsafeSwappedByteBuf
-
- getUnsignedInt(int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- getUnsignedInt(int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.
- getUnsignedInt(int) - Method in class io.netty.buffer.WrappedByteBuf
-
- getUnsignedInt(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- getUnsignedInt(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- getUnsignedIntLE(int) - Method in class io.netty.buffer.AbstractByteBuf
-
- getUnsignedIntLE(int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- getUnsignedIntLE(int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.
- getUnsignedIntLE(int) - Method in class io.netty.buffer.WrappedByteBuf
-
- getUnsignedIntLE(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- getUnsignedIntLE(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- getUnsignedMedium(int) - Method in class io.netty.buffer.AbstractByteBuf
-
- getUnsignedMedium(int) - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- getUnsignedMedium(int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- getUnsignedMedium(int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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(byte[], int) - Static method in class io.netty.buffer.HeapByteBufUtil
-
- getUnsignedMedium(int) - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- getUnsignedMedium(int) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- getUnsignedMedium(int) - Method in class io.netty.buffer.ReadOnlyByteBuf
-
Deprecated.
- getUnsignedMedium(int) - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- 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
-
- getUnsignedMedium(int) - Method in class io.netty.buffer.UnpooledUnsafeHeapByteBuf
-
- getUnsignedMedium(long) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- getUnsignedMedium(byte[], int) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- getUnsignedMedium(int) - Method in class io.netty.buffer.WrappedByteBuf
-
- getUnsignedMedium(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- getUnsignedMedium(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- getUnsignedMediumLE(int) - Method in class io.netty.buffer.AbstractByteBuf
-
- getUnsignedMediumLE(int) - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- getUnsignedMediumLE(int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- getUnsignedMediumLE(int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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(byte[], int) - Static method in class io.netty.buffer.HeapByteBufUtil
-
- getUnsignedMediumLE(int) - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- getUnsignedMediumLE(int) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- getUnsignedMediumLE(int) - Method in class io.netty.buffer.ReadOnlyByteBuf
-
Deprecated.
- getUnsignedMediumLE(int) - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- getUnsignedMediumLE(int) - Method in class io.netty.buffer.SwappedByteBuf
-
Deprecated.
- getUnsignedMediumLE(int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
-
- getUnsignedMediumLE(int) - Method in class io.netty.buffer.UnpooledUnsafeHeapByteBuf
-
- getUnsignedMediumLE(long) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- getUnsignedMediumLE(byte[], int) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- getUnsignedMediumLE(int) - Method in class io.netty.buffer.WrappedByteBuf
-
- getUnsignedMediumLE(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- getUnsignedMediumLE(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- getUnsignedShort(int) - Method in class io.netty.buffer.AbstractByteBuf
-
- getUnsignedShort(int) - Method in class io.netty.buffer.AbstractUnsafeSwappedByteBuf
-
- getUnsignedShort(int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- getUnsignedShort(int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.
- getUnsignedShort(int) - Method in class io.netty.buffer.WrappedByteBuf
-
- getUnsignedShort(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- getUnsignedShort(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- getUnsignedShortLE(int) - Method in class io.netty.buffer.AbstractByteBuf
-
- getUnsignedShortLE(int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- getUnsignedShortLE(int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.
- getUnsignedShortLE(int) - Method in class io.netty.buffer.WrappedByteBuf
-
- getUnsignedShortLE(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- getUnsignedShortLE(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- getUseCipherSuitesOrder(SSLParameters) - Static method in class io.netty.handler.ssl.Java8SslUtils
-
- getUseClientMode() - Method in class io.netty.handler.ssl.JdkSslEngine
-
- 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.channel.group.DefaultChannelGroupFuture.DefaultEntry
-
- getValue() - Method in class io.netty.handler.codec.compression.ByteBufChecksum.SlowByteBufChecksum
-
- getValue() - Method in class io.netty.handler.codec.compression.Crc32c
-
- getValue() - Method in class io.netty.handler.codec.DefaultHeaders.HeaderEntry
-
- getValue() - Method in class io.netty.handler.codec.HeadersUtils.StringEntry
-
- getValue(String) - Method in class io.netty.handler.ssl.JdkSslSession
-
- getValue() - Method in class io.netty.util.collection.ByteObjectHashMap.MapEntry
-
- getValue() - Method in class io.netty.util.collection.CharObjectHashMap.MapEntry
-
- getValue() - Method in class io.netty.util.collection.IntObjectHashMap.MapEntry
-
- getValue() - Method in class io.netty.util.collection.LongObjectHashMap.MapEntry
-
- getValue() - Method in class io.netty.util.collection.ShortObjectHashMap.MapEntry
-
- getValueNames() - Method in class io.netty.handler.ssl.JdkSslSession
-
- getVariableLengthInt(int) - Static method in class io.netty.handler.codec.mqtt.MqttEncoder
-
- getVersion() - Method in class io.netty.handler.ssl.OpenSslJavaxX509Certificate
-
- getVersion() - Method in class io.netty.handler.ssl.OpenSslX509Certificate
-
- getVersion() - Method in class io.netty.handler.ssl.PemX509Certificate
-
- getWantClientAuth() - Method in class io.netty.handler.ssl.JdkSslEngine
-
- getWrappedEngine() - Method in class io.netty.handler.ssl.JdkSslEngine
-
- 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 - Variable in class io.netty.channel.unix.PeerCredentials
-
- gids() - Method in class io.netty.channel.unix.PeerCredentials
-
- GLOBAL_DEFAULT_USER_DEFINED_WRITABILITY_INDEX - Static variable in class io.netty.handler.traffic.AbstractTrafficShapingHandler
-
Default value for Global UserDefinedWritability index
- GLOBALCHANNEL_DEFAULT_USER_DEFINED_WRITABILITY_INDEX - Static variable in class io.netty.handler.traffic.AbstractTrafficShapingHandler
-
Default value for GlobalChannel UserDefinedWritability index
- GlobalChannelTrafficCounter - Class in io.netty.handler.traffic
-
- GlobalChannelTrafficCounter(GlobalChannelTrafficShapingHandler, ScheduledExecutorService, String, long) - Constructor for class io.netty.handler.traffic.GlobalChannelTrafficCounter
-
- GlobalChannelTrafficCounter.MixedTrafficMonitoringTask - Class in io.netty.handler.traffic
-
Class to implement monitoring at fix delay.
- 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.
- GlobalChannelTrafficShapingHandler.PerChannel - Class in io.netty.handler.traffic
-
- GlobalChannelTrafficShapingHandler.ToSend - Class in io.netty.handler.traffic
-
- GlobalEventExecutor - Class in io.netty.util.concurrent
-
- GlobalEventExecutor() - Constructor for class io.netty.util.concurrent.GlobalEventExecutor
-
- GlobalEventExecutor.TaskRunner - Class in io.netty.util.concurrent
-
- 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.
- GlobalTrafficShapingHandler.PerChannel - Class in io.netty.handler.traffic
-
- GlobalTrafficShapingHandler.ToSend - Class in io.netty.handler.traffic
-
- gotPreferredAddress() - Method in class io.netty.resolver.dns.DnsNameResolverContext
-
- gracefulShutdownQuietPeriod - Variable in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- gracefulShutdownStartTime - Variable in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- gracefulShutdownTimeout - Variable in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- grantedQoSLevels - Variable in class io.netty.handler.codec.mqtt.MqttSubAckPayload
-
- grantedQoSLevels() - Method in class io.netty.handler.codec.mqtt.MqttSubAckPayload
-
- group - Variable in class io.netty.bootstrap.AbstractBootstrap
-
- group(EventLoopGroup) - Method in class io.netty.bootstrap.AbstractBootstrap
-
- group() - Method in class io.netty.bootstrap.AbstractBootstrap
-
- 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.
- group - Variable in class io.netty.channel.group.DefaultChannelGroupFuture
-
- group() - Method in class io.netty.channel.group.DefaultChannelGroupFuture
-
- group - Variable in class io.netty.channel.group.VoidChannelGroupFuture
-
- group() - Method in class io.netty.channel.group.VoidChannelGroupFuture
-
- group - Variable in class io.netty.util.concurrent.NonStickyEventExecutorGroup
-
- groupIndex - Variable in class io.netty.handler.codec.compression.Bzip2HuffmanStageDecoder
-
The index of the current group within the selectors array.
- groupPosition - Variable in class io.netty.handler.codec.compression.Bzip2HuffmanStageDecoder
-
The byte position within the current group.
- growSize() - Method in class io.netty.util.collection.ByteObjectHashMap
-
Grows the map size after an insertion.
- growSize() - Method in class io.netty.util.collection.CharObjectHashMap
-
Grows the map size after an insertion.
- growSize() - Method in class io.netty.util.collection.IntObjectHashMap
-
Grows the map size after an insertion.
- growSize() - Method in class io.netty.util.collection.LongObjectHashMap
-
Grows the map size after an insertion.
- growSize() - Method in class io.netty.util.collection.ShortObjectHashMap
-
Grows the map size after an insertion.
- GSSAPI - Static variable in class io.netty.handler.codec.socksx.v5.Socks5AuthMethod
-
- guess() - Method in class io.netty.channel.AdaptiveRecvByteBufAllocator.HandleImpl
-
- guess() - Method in class io.netty.channel.DefaultMaxBytesRecvByteBufAllocator.HandleImpl
-
- guess() - Method in class io.netty.channel.FixedRecvByteBufAllocator.HandleImpl
-
- guess() - Method in class io.netty.channel.kqueue.KQueueRecvByteAllocatorHandle
-
- guess() - Method in class io.netty.channel.RecvByteBufAllocator.DelegatingHandle
-
- guess() - Method in interface io.netty.channel.RecvByteBufAllocator.Handle
-
Deprecated.
- guess0() - Method in class io.netty.channel.kqueue.KQueueRecvByteAllocatorHandle
-
- gzipHeader - Static variable in class io.netty.handler.codec.compression.JdkZlibEncoder
-
- gzipState - Variable in class io.netty.handler.codec.compression.JdkZlibDecoder
-
- GzipState() - Constructor for enum io.netty.handler.codec.compression.JdkZlibDecoder.GzipState
-
- handle - Variable in class io.netty.buffer.ByteBufUtil.ThreadLocalDirectByteBuf
-
- handle - Variable in class io.netty.buffer.ByteBufUtil.ThreadLocalUnsafeDirectByteBuf
-
- handle - Variable in class io.netty.buffer.PooledByteBuf
-
- handle - Variable in class io.netty.buffer.PoolThreadCache.MemoryRegionCache.Entry
-
- handle - Variable in class io.netty.channel.AbstractChannelHandlerContext.AbstractWriteTask
-
- handle - Variable in class io.netty.channel.ChannelOutboundBuffer.Entry
-
- handle - Variable in class io.netty.channel.DefaultMessageSizeEstimator
-
- handle - Variable in class io.netty.channel.PendingWriteQueue.PendingWrite
-
- handle - Variable in class io.netty.handler.codec.CodecOutputList
-
- handle - Variable in class io.netty.handler.flow.FlowControlHandler.RecyclableArrayDeque
-
- handle - Variable in class io.netty.util.internal.PendingWrite
-
- handle - Variable in class io.netty.util.internal.RecyclableArrayList
-
- HandleImpl(int, int, int) - Constructor for class io.netty.channel.AdaptiveRecvByteBufAllocator.HandleImpl
-
- HandleImpl() - Constructor for class io.netty.channel.DefaultMaxBytesRecvByteBufAllocator.HandleImpl
-
- HandleImpl(int) - Constructor for class io.netty.channel.DefaultMessageSizeEstimator.HandleImpl
-
- HandleImpl(int) - Constructor for class io.netty.channel.FixedRecvByteBufAllocator.HandleImpl
-
- handleInaccessibleObjectException(RuntimeException) - Static method in class io.netty.util.internal.ReflectionUtil
-
- handleInboundMessage(Object) - Method in class io.netty.channel.embedded.EmbeddedChannel
-
Called for each inbound message.
- handleLoopException(Throwable) - Static method in class io.netty.channel.kqueue.KQueueEventLoop
-
- handleLoopException(Throwable) - Static method in class io.netty.channel.nio.NioEventLoop
-
- handleNewChannel(ChannelHandlerContext) - Method in class io.netty.handler.ipfilter.AbstractRemoteAddressFilter
-
- handleNonSsl(ChannelHandlerContext) - Method in class io.netty.handler.ssl.OptionalSslHandler
-
- handleNotification(AssociationChangeNotification, Object) - Method in class com.sun.nio.sctp.AbstractNotificationHandler
-
- handleNotification(Notification, Object) - Method in class com.sun.nio.sctp.AbstractNotificationHandler
-
- handleNotification(PeerAddressChangeNotification, Object) - Method in class com.sun.nio.sctp.AbstractNotificationHandler
-
- handleNotification(SendFailedNotification, Object) - Method in class com.sun.nio.sctp.AbstractNotificationHandler
-
- handleNotification(ShutdownNotification, Object) - Method in class com.sun.nio.sctp.AbstractNotificationHandler
-
- handleNotification(AssociationChangeNotification, Object) - Method in class io.netty.channel.sctp.SctpNotificationHandler
-
- handleNotification(PeerAddressChangeNotification, Object) - Method in class io.netty.channel.sctp.SctpNotificationHandler
-
- handleNotification(SendFailedNotification, Object) - Method in class io.netty.channel.sctp.SctpNotificationHandler
-
- handleNotification(ShutdownNotification, Object) - Method in class io.netty.channel.sctp.SctpNotificationHandler
-
- 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 - Variable in class io.netty.bootstrap.AbstractBootstrap
-
- handler(ChannelHandler) - Method in class io.netty.bootstrap.AbstractBootstrap
-
- handler() - Method in class io.netty.bootstrap.AbstractBootstrap
-
- 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
-
- handler - Variable in class io.netty.channel.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- handler() - Method in class io.netty.channel.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- handler - Variable in class io.netty.channel.DefaultChannelHandlerContext
-
- handler() - Method in class io.netty.channel.DefaultChannelHandlerContext
-
- handler() - Method in class io.netty.channel.DefaultChannelPipeline.HeadContext
-
- handler() - Method in class io.netty.channel.DefaultChannelPipeline.TailContext
-
- handler - Variable in class io.netty.channel.pool.SimpleChannelPool
-
- handler() - Method in class io.netty.channel.pool.SimpleChannelPool
-
- HANDLER_STATE_UPDATER - Static variable in class io.netty.channel.AbstractChannelHandlerContext
-
- 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 - Variable in class io.netty.channel.CombinedChannelDuplexHandler
-
- handlerAdded(ChannelHandlerContext) - Method in class io.netty.channel.CombinedChannelDuplexHandler
-
- handlerAdded(ChannelHandlerContext) - Method in class io.netty.channel.DefaultChannelPipeline.HeadContext
-
- handlerAdded(ChannelHandlerContext) - Method in class io.netty.channel.DefaultChannelPipeline.TailContext
-
- 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
-
- handleReadException(ChannelPipeline, ByteBuf, Throwable, boolean, KQueueRecvByteAllocatorHandle) - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel.KQueueStreamUnsafe
-
- handleReadException(ChannelPipeline, ByteBuf, Throwable, boolean, RecvByteBufAllocator.Handle) - Method in class io.netty.channel.nio.AbstractNioByteChannel.NioByteUnsafe
-
- handleReadException(ChannelPipeline, ByteBuf, Throwable, boolean, RecvByteBufAllocator.Handle) - Method in class io.netty.channel.oio.AbstractOioByteChannel
-
- handleRecycleCount - Variable in class io.netty.util.Recycler.Stack
-
- handleRedirect(DnsQuestion, AddressedEnvelope<DnsResponse, InetSocketAddress>, DnsQueryLifecycleObserver, Promise<T>) - Method in class io.netty.resolver.dns.DnsNameResolverContext
-
Handles a redirect answer if needed and returns true
if a redirect query has been made.
- 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.channel.DefaultChannelPipeline.HeadContext
-
- handlerRemoved(ChannelHandlerContext) - Method in class io.netty.channel.DefaultChannelPipeline.TailContext
-
- 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
-
- HandlerResult - Enum in com.sun.nio.sctp
-
- HandlerResult() - Constructor for enum com.sun.nio.sctp.HandlerResult
-
- handlerSharableCache() - Method in class io.netty.util.internal.InternalThreadLocalMap
-
- handlerSharableCache - Variable in class io.netty.util.internal.UnpaddedInternalThreadLocalMap
-
- handlerState - Variable in class io.netty.channel.AbstractChannelHandlerContext
-
- handleSsl(ChannelHandlerContext) - Method in class io.netty.handler.ssl.OptionalSslHandler
-
- handlingOversizedMessage - Variable in class io.netty.handler.codec.MessageAggregator
-
- handshake(Promise<Channel>) - Method in class io.netty.handler.ssl.SslHandler
-
Performs TLS (re)negotiation.
- HANDSHAKE_TIMED_OUT - Static variable in class io.netty.handler.ssl.SslHandler
-
- handshakeFailed - Variable in class io.netty.handler.ssl.AbstractSniHandler
-
- 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.
- handshakePromise - Variable in class io.netty.handler.ssl.SslHandler
-
- handshakeTimeoutMillis - Variable in class io.netty.handler.ssl.SslHandler
-
- HAProxyCommand - Enum in io.netty.handler.codec.haproxy
-
The command of an HAProxy proxy protocol header
- HAProxyCommand(byte) - Constructor for enum io.netty.handler.codec.haproxy.HAProxyCommand
-
Creates a new instance
- HAProxyConstants - Class in io.netty.handler.codec.haproxy
-
- HAProxyConstants() - Constructor for class io.netty.handler.codec.haproxy.HAProxyConstants
-
- HAProxyMessage - Class in io.netty.handler.codec.haproxy
-
Message container for decoded HAProxy proxy protocol parameters
- HAProxyMessage(HAProxyProtocolVersion, HAProxyCommand, HAProxyProxiedProtocol, String, String, String, String) - Constructor for class io.netty.handler.codec.haproxy.HAProxyMessage
-
Creates a new instance
- HAProxyMessage(HAProxyProtocolVersion, HAProxyCommand, HAProxyProxiedProtocol, String, String, int, int) - Constructor for class io.netty.handler.codec.haproxy.HAProxyMessage
-
Creates a new instance
- HAProxyMessage(HAProxyProtocolVersion, HAProxyCommand, HAProxyProxiedProtocol, String, String, int, int, List<HAProxyTLV>) - Constructor for class io.netty.handler.codec.haproxy.HAProxyMessage
-
Creates a new instance
- HAProxyMessageDecoder - Class in io.netty.handler.codec.haproxy
-
Decodes an HAProxy proxy protocol header
- HAProxyMessageDecoder() - Constructor for class io.netty.handler.codec.haproxy.HAProxyMessageDecoder
-
Creates a new decoder with no additional data (TLV) restrictions
- HAProxyMessageDecoder(int) - Constructor for class io.netty.handler.codec.haproxy.HAProxyMessageDecoder
-
Creates a new decoder with restricted additional data (TLV) size
- HAProxyProtocolException - Exception in io.netty.handler.codec.haproxy
-
A
DecoderException
which is thrown when an invalid HAProxy proxy protocol header is encountered
- HAProxyProtocolException() - Constructor for exception io.netty.handler.codec.haproxy.HAProxyProtocolException
-
Creates a new instance
- HAProxyProtocolException(String, Throwable) - Constructor for exception io.netty.handler.codec.haproxy.HAProxyProtocolException
-
Creates a new instance
- HAProxyProtocolException(String) - Constructor for exception io.netty.handler.codec.haproxy.HAProxyProtocolException
-
Creates a new instance
- HAProxyProtocolException(Throwable) - Constructor for exception io.netty.handler.codec.haproxy.HAProxyProtocolException
-
Creates a new instance
- HAProxyProtocolVersion - Enum in io.netty.handler.codec.haproxy
-
The HAProxy proxy protocol specification version.
- HAProxyProtocolVersion(byte) - Constructor for enum io.netty.handler.codec.haproxy.HAProxyProtocolVersion
-
Creates a new instance
- HAProxyProxiedProtocol - Enum in io.netty.handler.codec.haproxy
-
A protocol proxied by HAProxy which is represented by its transport protocol and address family.
- HAProxyProxiedProtocol(byte, HAProxyProxiedProtocol.AddressFamily, HAProxyProxiedProtocol.TransportProtocol) - Constructor for enum io.netty.handler.codec.haproxy.HAProxyProxiedProtocol
-
Creates a new instance.
- HAProxyProxiedProtocol.AddressFamily - Enum in io.netty.handler.codec.haproxy
-
The address family of an HAProxy proxy protocol header.
- HAProxyProxiedProtocol.TransportProtocol - Enum in io.netty.handler.codec.haproxy
-
The transport protocol of an HAProxy proxy protocol header
- HAProxySSLTLV - Class in io.netty.handler.codec.haproxy
-
- HAProxySSLTLV(int, byte, List<HAProxyTLV>, ByteBuf) - Constructor for class io.netty.handler.codec.haproxy.HAProxySSLTLV
-
Creates a new HAProxySSLTLV
- HAProxyTLV - Class in io.netty.handler.codec.haproxy
-
A Type-Length Value (TLV vector) that can be added to the PROXY protocol
to include additional information like SSL information.
- HAProxyTLV(HAProxyTLV.Type, byte, ByteBuf) - Constructor for class io.netty.handler.codec.haproxy.HAProxyTLV
-
Creates a new HAProxyTLV
- HAProxyTLV.Type - Enum in io.netty.handler.codec.haproxy
-
The registered types a TLV can have regarding the PROXY protocol 1.5 spec
- hardwareAddressFromNetworkInterface(NetworkInterface) - Static method in class io.netty.util.internal.SocketUtils
-
- HAS_UNSAFE - Static variable in class io.netty.buffer.PoolArena
-
- HAS_UNSAFE - Static variable in class io.netty.util.internal.PlatformDependent
-
- hasAllocateArrayMethod() - Static method in class io.netty.util.internal.PlatformDependent0
-
- hasArray() - Method in class io.netty.buffer.AbstractPooledDerivedByteBuf
-
- hasArray() - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- 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.FixedCompositeByteBuf
-
- hasArray() - Method in class io.netty.buffer.PooledDirectByteBuf
-
- hasArray() - Method in class io.netty.buffer.PooledHeapByteBuf
-
- hasArray() - Method in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- hasArray() - Method in class io.netty.buffer.ReadOnlyByteBuf
-
Deprecated.
- hasArray() - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- 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
-
- hasArray() - Method in class io.netty.buffer.WrappedByteBuf
-
- hasArray() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- hasArray() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- hasAttr(AttributeKey<T>) - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- hasAttr(AttributeKey<T>) - Method in interface io.netty.channel.ChannelHandlerContext
-
- hasAttr(AttributeKey<T>) - Method in class io.netty.channel.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- hasAttr(AttributeKey<T>) - Method in interface io.netty.util.AttributeMap
-
- hasAttr(AttributeKey<T>) - Method in class io.netty.util.DefaultAttributeMap
-
- hasBeenRecycled - Variable in class io.netty.util.Recycler.DefaultHandle
-
- hasChecksum - Variable in class io.netty.handler.codec.compression.FastLzFrameDecoder
-
Indicates is this chunk has checksum or not.
- hasDirectBufferNoCleanerConstructor() - Static method in class io.netty.util.internal.PlatformDependent0
-
- hasDisconnect - Variable in class io.netty.channel.ChannelMetadata
-
- hasDisconnect() - Method in class io.netty.channel.ChannelMetadata
-
- hasFinalData() - Method in class io.netty.util.Recycler.WeakOrderQueue
-
- hash(ByteBuf, int, int) - Static method in class io.netty.handler.codec.compression.Snappy
-
Hashes the 4 bytes located at index, shifting the resulting hash into
the appropriate range for our hash table.
- hash - Variable in class io.netty.handler.codec.DefaultHeaders.HeaderEntry
-
- hash - Variable in class io.netty.util.AsciiString
-
The hash code is cached after it is first computed.
- HASH - Static variable in class io.netty.util.ResourceLeakDetector.LeakEntry
-
- HASH_CODE_ASCII_SEED - Static variable in class io.netty.util.internal.PlatformDependent0
-
- HASH_CODE_C1 - Static variable in class io.netty.util.internal.PlatformDependent0
-
- HASH_CODE_C2 - Static variable in class io.netty.util.internal.PlatformDependent0
-
- HASH_CODE_SEED - Static variable in class io.netty.handler.codec.DefaultHeaders
-
Constant used to seed the hash code generation.
- HASH_LOG - Static variable in class io.netty.handler.codec.compression.FastLz
-
- HASH_MASK - Static variable in class io.netty.handler.codec.compression.FastLz
-
- HASH_SIZE - Static variable in class io.netty.handler.codec.compression.FastLz
-
- 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.buffer.WrappedByteBuf
-
- hashCode() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- hashCode() - Method in class io.netty.channel.AbstractChannel
-
Returns the ID of this channel.
- hashCode - Variable in class io.netty.channel.DefaultChannelId
-
- hashCode() - Method in class io.netty.channel.DefaultChannelId
-
- hashCode() - Method in class io.netty.channel.embedded.EmbeddedChannelId
-
- 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.sctp.SctpMessage
-
- 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 - Variable in class io.netty.handler.codec.dns.AbstractDnsRecord
-
- 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.ReplayingDecoderByteBuf
-
- hashCode() - Method in class io.netty.handler.codec.smtp.DefaultSmtpRequest
-
- hashCode() - Method in class io.netty.handler.codec.smtp.DefaultSmtpResponse
-
- hashCode - Variable in class io.netty.handler.codec.smtp.SmtpCommand
-
- hashCode() - Method in class io.netty.handler.codec.smtp.SmtpCommand
-
- hashCode() - Method in class io.netty.handler.codec.socksx.v4.Socks4CommandStatus
-
- hashCode() - Method in class io.netty.handler.codec.socksx.v4.Socks4CommandType
-
- hashCode() - Method in class io.netty.handler.codec.socksx.v5.Socks5AddressType
-
- hashCode() - Method in class io.netty.handler.codec.socksx.v5.Socks5AuthMethod
-
- hashCode() - Method in class io.netty.handler.codec.socksx.v5.Socks5CommandStatus
-
- hashCode() - Method in class io.netty.handler.codec.socksx.v5.Socks5CommandType
-
- hashCode() - Method in class io.netty.handler.codec.socksx.v5.Socks5PasswordAuthStatus
-
- 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(byte) - Static method in class io.netty.util.collection.ByteObjectHashMap
-
Returns the hash code for the key.
- hashCode() - Method in class io.netty.util.collection.CharObjectHashMap
-
- hashCode(char) - Static method in class io.netty.util.collection.CharObjectHashMap
-
Returns the hash code for the key.
- hashCode() - Method in class io.netty.util.collection.IntObjectHashMap
-
- hashCode(int) - Static method in class io.netty.util.collection.IntObjectHashMap
-
Returns the hash code for the key.
- hashCode() - Method in class io.netty.util.collection.LongObjectHashMap
-
- hashCode(long) - Static method in class io.netty.util.collection.LongObjectHashMap
-
Returns the hash code for the key.
- hashCode() - Method in class io.netty.util.collection.ShortObjectHashMap
-
- hashCode(short) - Static method in class io.netty.util.collection.ShortObjectHashMap
-
Returns the hash code for the key.
- hashCode() - Method in class io.netty.util.concurrent.PromiseTask
-
- 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 class io.netty.util.ResourceLeakDetector.LeakEntry
-
- hashCode() - Method in exception io.netty.util.ResourceLeakException
-
Deprecated.
- hashCode() - Method in error io.netty.util.Signal
-
- hashCode() - Method in class io.netty.util.ThreadDeathWatcher.Entry
-
- 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.
- hashCodeAscii(byte[], int, int) - Static method in class io.netty.util.internal.PlatformDependent0
-
- hashCodeAsciiCompute(CharSequence, int, int) - Static method in class io.netty.util.internal.PlatformDependent
-
- hashCodeAsciiCompute(long, int) - Static method in class io.netty.util.internal.PlatformDependent0
-
- hashCodeAsciiSafe(byte[], int, int) - Static method in class io.netty.util.internal.PlatformDependent
-
Package private for testing purposes only!
- hashCodeAsciiSanitize(int) - Static method in class io.netty.util.internal.PlatformDependent0
-
- hashCodeAsciiSanitize(short) - Static method in class io.netty.util.internal.PlatformDependent0
-
- hashCodeAsciiSanitize(byte) - Static method in class io.netty.util.internal.PlatformDependent0
-
- hashCodeAsciiSanitizeByte(char) - Static method in class io.netty.util.internal.PlatformDependent
-
- hashCodeAsciiSanitizeInt(CharSequence, int) - Static method in class io.netty.util.internal.PlatformDependent
-
- hashCodeAsciiSanitizeShort(CharSequence, int) - Static method in class io.netty.util.internal.PlatformDependent
-
- HashedWheelBucket() - Constructor for class io.netty.util.HashedWheelTimer.HashedWheelBucket
-
- HashedWheelTimeout(HashedWheelTimer, TimerTask, long) - Constructor for class io.netty.util.HashedWheelTimer.HashedWheelTimeout
-
- 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.
- HashedWheelTimer.HashedWheelBucket - Class in io.netty.util
-
Bucket that stores HashedWheelTimeouts.
- HashedWheelTimer.HashedWheelTimeout - Class in io.netty.util
-
- HashedWheelTimer.Worker - Class in io.netty.util
-
- hashFunction(byte[], int) - Static method in class io.netty.handler.codec.compression.FastLz
-
- hashIndex(byte) - Method in class io.netty.util.collection.ByteObjectHashMap
-
Returns the hashed index for the given key.
- hashIndex(char) - Method in class io.netty.util.collection.CharObjectHashMap
-
Returns the hashed index for the given key.
- hashIndex(int) - Method in class io.netty.util.collection.IntObjectHashMap
-
Returns the hashed index for the given key.
- hashIndex(long) - Method in class io.netty.util.collection.LongObjectHashMap
-
Returns the hashed index for the given key.
- hashIndex(short) - Method in class io.netty.util.collection.ShortObjectHashMap
-
Returns the hashed index for the given key.
- hashingStrategy - Variable in class io.netty.handler.codec.DefaultHeaders
-
- HashingStrategy<T> - Interface in io.netty.util
-
Abstraction for hash code generation and equality comparison.
- hashMask - Variable in class io.netty.handler.codec.DefaultHeaders
-
- hasMemoryAddress() - Method in class io.netty.buffer.AbstractPooledDerivedByteBuf
-
- hasMemoryAddress() - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- 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.FixedCompositeByteBuf
-
- hasMemoryAddress() - Method in class io.netty.buffer.PooledDirectByteBuf
-
- hasMemoryAddress() - Method in class io.netty.buffer.PooledHeapByteBuf
-
- hasMemoryAddress() - Method in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- hasMemoryAddress() - Method in class io.netty.buffer.ReadOnlyByteBuf
-
Deprecated.
- hasMemoryAddress() - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- 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
-
- hasMemoryAddress() - Method in class io.netty.buffer.WrappedByteBuf
-
- hasMemoryAddress() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- hasMemoryAddress() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- hasNext() - Method in class io.netty.buffer.CompositeByteBuf.CompositeByteBufIterator
-
- hasNext() - Method in class io.netty.channel.group.CombinedIterator
-
- hasNext() - Method in class io.netty.handler.codec.DefaultHeaders.HeaderIterator
-
- hasNext() - Method in class io.netty.handler.codec.HeadersUtils.StringEntryIterator
-
- hasNext() - Method in class io.netty.handler.codec.HeadersUtils.StringIterator
-
- hasNext() - Method in class io.netty.util.collection.ByteCollections.UnmodifiableMap.IteratorImpl
-
- hasNext() - Method in class io.netty.util.collection.ByteObjectHashMap.MapIterator
-
- hasNext() - Method in class io.netty.util.collection.ByteObjectHashMap.PrimitiveIterator
-
- hasNext() - Method in class io.netty.util.collection.CharCollections.UnmodifiableMap.IteratorImpl
-
- hasNext() - Method in class io.netty.util.collection.CharObjectHashMap.MapIterator
-
- hasNext() - Method in class io.netty.util.collection.CharObjectHashMap.PrimitiveIterator
-
- hasNext() - Method in class io.netty.util.collection.IntCollections.UnmodifiableMap.IteratorImpl
-
- hasNext() - Method in class io.netty.util.collection.IntObjectHashMap.MapIterator
-
- hasNext() - Method in class io.netty.util.collection.IntObjectHashMap.PrimitiveIterator
-
- hasNext() - Method in class io.netty.util.collection.LongCollections.UnmodifiableMap.IteratorImpl
-
- hasNext() - Method in class io.netty.util.collection.LongObjectHashMap.MapIterator
-
- hasNext() - Method in class io.netty.util.collection.LongObjectHashMap.PrimitiveIterator
-
- hasNext() - Method in class io.netty.util.collection.ShortCollections.UnmodifiableMap.IteratorImpl
-
- hasNext() - Method in class io.netty.util.collection.ShortObjectHashMap.MapIterator
-
- hasNext() - Method in class io.netty.util.collection.ShortObjectHashMap.PrimitiveIterator
-
- hasNext() - Method in class io.netty.util.internal.DefaultPriorityQueue.PriorityQueueIterator
-
- hasNext() - Method in class io.netty.util.internal.ReadOnlyIterator
-
- hasOutputChanged(ChannelHandlerContext, boolean) - Method in class io.netty.handler.timeout.IdleStateHandler
-
- hasPassword - Variable in class io.netty.handler.codec.mqtt.MqttConnectVariableHeader
-
- hasPassword() - Method in class io.netty.handler.codec.mqtt.MqttConnectVariableHeader
-
- hasPassword - Variable in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
-
- hasPassword(boolean) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
-
- hasReadableBits(int) - Method in class io.netty.handler.codec.compression.Bzip2BitReader
-
Checks that the specified number of bits available for reading.
- hasReadableBytes(int) - Method in class io.netty.handler.codec.compression.Bzip2BitReader
-
Checks that the specified number of bytes available for reading.
- 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.
- hasUnsafe() - Static method in class io.netty.util.internal.PlatformDependent0
-
- hasUnsafe0() - Static method in class io.netty.util.internal.PlatformDependent
-
- hasUnsupportedCriticalExtension() - Method in class io.netty.handler.ssl.OpenSslX509Certificate
-
- hasUnsupportedCriticalExtension() - Method in class io.netty.handler.ssl.PemX509Certificate
-
- hasUser - Variable in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
-
- hasUser(boolean) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
-
- hasUserName - Variable in class io.netty.handler.codec.mqtt.MqttConnectVariableHeader
-
- hasUserName() - Method in class io.netty.handler.codec.mqtt.MqttConnectVariableHeader
-
- head - Variable in class io.netty.buffer.PoolChunkList
-
- head - Variable in class io.netty.channel.DefaultChannelPipeline
-
- head - Variable in class io.netty.channel.PendingWriteQueue
-
- head - Variable in class io.netty.handler.codec.DefaultHeaders
-
- head - Variable in class io.netty.resolver.dns.DnsNameResolverContext.AuthoritativeNameServerList
-
- head - Variable in class io.netty.util.DefaultAttributeMap.DefaultAttribute
-
- head - Variable in class io.netty.util.HashedWheelTimer.HashedWheelBucket
-
- head - Variable in class io.netty.util.Recycler.Stack
-
- head - Variable in class io.netty.util.Recycler.WeakOrderQueue
-
- HEAD_NAME - Static variable in class io.netty.channel.DefaultChannelPipeline
-
- HeadContext(DefaultChannelPipeline) - Constructor for class io.netty.channel.DefaultChannelPipeline.HeadContext
-
- HeaderEntry(int, K) - Constructor for class io.netty.handler.codec.DefaultHeaders.HeaderEntry
-
- HeaderEntry(int, K, V, DefaultHeaders.HeaderEntry<K, V>, DefaultHeaders.HeaderEntry<K, V>) - Constructor for class io.netty.handler.codec.DefaultHeaders.HeaderEntry
-
- HeaderEntry() - Constructor for class io.netty.handler.codec.DefaultHeaders.HeaderEntry
-
- HeaderIterator() - Constructor for class io.netty.handler.codec.DefaultHeaders.HeaderIterator
-
- 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
.
- HeadersUtils() - Constructor for class io.netty.handler.codec.HeadersUtils
-
- HeadersUtils.CharSequenceDelegatingStringSet - Class in io.netty.handler.codec
-
- HeadersUtils.DelegatingStringSet<T> - Class in io.netty.handler.codec
-
- HeadersUtils.StringEntry - Class in io.netty.handler.codec
-
- HeadersUtils.StringEntryIterator - Class in io.netty.handler.codec
-
- HeadersUtils.StringIterator<T> - Class in io.netty.handler.codec
-
- healthCheck - Variable in class io.netty.channel.pool.SimpleChannelPool
-
- healthChecker() - Method in class io.netty.channel.pool.SimpleChannelPool
-
- HeapArena(PooledByteBufAllocator, int, int, int, int, int) - Constructor for class io.netty.buffer.PoolArena.HeapArena
-
- heapArena - Variable in class io.netty.buffer.PoolThreadCache
-
- heapArenaMetrics - Variable in class io.netty.buffer.PooledByteBufAllocator
-
- heapArenas - Variable in class io.netty.buffer.PooledByteBufAllocator
-
- heapArenas() - Method in class io.netty.buffer.PooledByteBufAllocator
-
- heapArenas() - Method in class io.netty.buffer.PooledByteBufAllocatorMetric
-
- 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
-
- 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.
- heapBuffer() - Method in class io.netty.channel.local.PreferHeapByteBufAllocator
-
- heapBuffer(int) - Method in class io.netty.channel.local.PreferHeapByteBufAllocator
-
- heapBuffer(int, int) - Method in class io.netty.channel.local.PreferHeapByteBufAllocator
-
- HeapByteBufUtil - Class in io.netty.buffer
-
Utility class for heap buffers.
- HeapByteBufUtil() - Constructor for class io.netty.buffer.HeapByteBufUtil
-
- heapCounter - Variable in class io.netty.buffer.UnpooledByteBufAllocator.UnpooledByteBufAllocatorMetric
-
- 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.
- HELP_NO_ARG - Static variable in class io.netty.handler.codec.smtp.SmtpRequests
-
- 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.
- hexDump(ByteBuf, int, int) - Static method in class io.netty.buffer.ByteBufUtil.HexUtil
-
- hexDump(byte[], int, int) - Static method in class io.netty.buffer.ByteBufUtil.HexUtil
-
- HEXDUMP_ROWPREFIXES - Static variable in class io.netty.buffer.ByteBufUtil.HexUtil
-
- HEXDUMP_TABLE - Static variable in class io.netty.buffer.ByteBufUtil.HexUtil
-
- HEXPADDING - Static variable in class io.netty.buffer.ByteBufUtil.HexUtil
-
- HexUtil() - Constructor for class io.netty.buffer.ByteBufUtil.HexUtil
-
- high - Variable in class io.netty.channel.WriteBufferWaterMark
-
- 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.
- holder - Static variable in class io.netty.util.NettyRuntime
-
- host - Variable in class io.netty.handler.codec.socks.SocksCmdRequest
-
- host() - Method in class io.netty.handler.codec.socks.SocksCmdRequest
-
- host - Variable in class io.netty.handler.codec.socks.SocksCmdResponse
-
- host() - Method in class io.netty.handler.codec.socks.SocksCmdResponse
-
- HOST - Static variable in interface io.netty.handler.codec.stomp.StompHeaders
-
- HOST_UNREACHABLE - Static variable in class io.netty.handler.codec.socksx.v5.Socks5CommandStatus
-
- hostname - Variable in class io.netty.handler.codec.dns.DefaultDnsPtrRecord
-
- 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 - Variable in class io.netty.handler.ssl.SniHandler.Selection
-
- hostname - Variable in class io.netty.resolver.dns.DnsCacheEntry
-
- hostname() - Method in class io.netty.resolver.dns.DnsCacheEntry
-
- hostname(String) - Static method in class io.netty.resolver.dns.DnsNameResolver
-
- hostname - Variable in class io.netty.resolver.dns.DnsNameResolverContext
-
- 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 - Variable in class io.netty.resolver.dns.DnsNameResolver
-
- 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 - Variable in class io.netty.resolver.dns.DnsNameResolverBuilder
-
- 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.
- HostsFileParser() - Constructor for class io.netty.resolver.HostsFileParser
-
Can't be instantiated.
- hours - Variable in class io.netty.handler.codec.DateFormatter
-
- 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
- HUFFMAN_DECODE_MAX_CODE_LENGTH - Static variable in class io.netty.handler.codec.compression.Bzip2Constants
-
The longest Huffman code length accepted by the decoder.
- HUFFMAN_ENCODE_MAX_CODE_LENGTH - Static variable in class io.netty.handler.codec.compression.Bzip2Constants
-
The longest Huffman code length created by the encoder.
- HUFFMAN_GROUP_RUN_LENGTH - Static variable in class io.netty.handler.codec.compression.Bzip2Constants
-
Number of symbols decoded after which a new Huffman table is selected.
- HUFFMAN_HIGH_SYMBOL_COST - Static variable in class io.netty.handler.codec.compression.Bzip2HuffmanStageEncoder
-
Used in initial Huffman table generation.
- HUFFMAN_MAX_ALPHABET_SIZE - Static variable in class io.netty.handler.codec.compression.Bzip2Constants
-
Maximum possible Huffman alphabet size.
- HUFFMAN_MAXIMUM_TABLES - Static variable in class io.netty.handler.codec.compression.Bzip2Constants
-
Maximum number of alternative Huffman tables.
- HUFFMAN_MINIMUM_TABLES - Static variable in class io.netty.handler.codec.compression.Bzip2Constants
-
Minimum number of alternative Huffman tables.
- HUFFMAN_SELECTOR_LIST_MAX_LENGTH - Static variable in class io.netty.handler.codec.compression.Bzip2Constants
-
Maximum length of zero-terminated bit runs of MTF'ed Huffman table.
- HUFFMAN_SYMBOL_RANGE_SIZE - Static variable in class io.netty.handler.codec.compression.Bzip2Constants
-
Huffman symbols range size for Huffman used map.
- HUFFMAN_SYMBOL_RUNA - Static variable in class io.netty.handler.codec.compression.Bzip2Constants
-
Huffman symbols used for run-length encoding.
- HUFFMAN_SYMBOL_RUNB - Static variable in class io.netty.handler.codec.compression.Bzip2Constants
-
- huffmanCodeLengths - Variable in class io.netty.handler.codec.compression.Bzip2HuffmanStageEncoder
-
The Canonical Huffman code lengths for each table.
- huffmanEndOfBlockSymbol - Variable in class io.netty.handler.codec.compression.Bzip2BlockDecompressor
-
The end-of-block Huffman symbol.
- huffmanInUse16 - Variable in class io.netty.handler.codec.compression.Bzip2BlockDecompressor
-
Bitmap, of ranges of 16 bytes, present/not present.
- huffmanMergedCodeSymbols - Variable in class io.netty.handler.codec.compression.Bzip2HuffmanStageEncoder
-
Merged code symbols for each table.
- huffmanStageDecoder - Variable in class io.netty.handler.codec.compression.Bzip2Decoder
-
Bzip2 Huffman coding stage.
- huffmanSymbolMap - Variable in class io.netty.handler.codec.compression.Bzip2BlockDecompressor
-
A map from Huffman symbol index to output character.
- i - Variable in class io.netty.resolver.dns.SequentialDnsServerAddressStream
-
- i - Variable in class io.netty.resolver.dns.ShuffledDnsServerAddressStream
-
- i1 - Variable in class io.netty.channel.group.CombinedIterator
-
- i2 - Variable in class io.netty.channel.group.CombinedIterator
-
- id - Variable in class io.netty.channel.AbstractChannel
-
- 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 - Variable in class io.netty.channel.local.LocalAddress
-
- id() - Method in class io.netty.channel.local.LocalAddress
-
Returns the ID of this address.
- id - Variable in class io.netty.handler.codec.dns.AbstractDnsMessage
-
- 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 - Variable in class io.netty.resolver.dns.DnsQueryContext
-
- id - Variable in class io.netty.util.AbstractConstant
-
- id() - Method in class io.netty.util.AbstractConstant
-
- id - Variable in class io.netty.util.concurrent.ScheduledFutureTask
-
- id() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor.DefaultThreadProperties
-
- 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 - Variable in class io.netty.util.Recycler.WeakOrderQueue
-
- id() - Method in error io.netty.util.Signal
-
- ID_GENERATOR - Static variable in class io.netty.util.Recycler
-
- IDENTD_AUTH_FAILURE - Static variable in class io.netty.handler.codec.socksx.v4.Socks4CommandStatus
-
- IDENTD_UNREACHABLE - Static variable in class io.netty.handler.codec.socksx.v4.Socks4CommandStatus
-
- 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.
- IdentityCipherSuiteFilter() - Constructor for class io.netty.handler.ssl.IdentityCipherSuiteFilter
-
- idleChildren - Variable in class io.netty.channel.ThreadPerChannelEventLoopGroup
-
- IdleState - Enum in io.netty.handler.timeout
-
An
Enum
that represents the idle state of a
Channel
.
- IdleState() - Constructor for enum io.netty.handler.timeout.IdleState
-
- IdleStateEvent - Class in io.netty.handler.timeout
-
- IdleStateEvent(IdleState, boolean) - Constructor for class io.netty.handler.timeout.IdleStateEvent
-
Constructor for sub-classes.
- IdleStateHandler - Class in io.netty.handler.timeout
-
- IdleStateHandler(int, int, int) - Constructor for class io.netty.handler.timeout.IdleStateHandler
-
- 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
-
- IdleStateHandler.AbstractIdleTask - Class in io.netty.handler.timeout
-
- IdleStateHandler.AllIdleTimeoutTask - Class in io.netty.handler.timeout
-
- IdleStateHandler.ReaderIdleTimeoutTask - Class in io.netty.handler.timeout
-
- IdleStateHandler.WriterIdleTimeoutTask - Class in io.netty.handler.timeout
-
- idx(int) - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
Returns the index with the needed adjustment.
- idx(int) - Method in class io.netty.buffer.PooledByteBuf
-
- idx(int) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- idx(ByteBuf, int) - Static method in class io.netty.buffer.UnsafeHeapSwappedByteBuf
-
- idx - Variable in class io.netty.handler.codec.json.JsonObjectDecoder
-
- idx - Variable in class io.netty.util.concurrent.DefaultEventExecutorChooserFactory.GenericEventExecutorChooser
-
- idx - Variable in class io.netty.util.concurrent.DefaultEventExecutorChooserFactory.PowerOfTwoEventExecutorChooser
-
- IGNORABLE_CLASS_IN_STACK - Static variable in class io.netty.handler.ssl.SslHandler
-
- IGNORABLE_ERROR_MESSAGE - Static variable in class io.netty.handler.ssl.SslHandler
-
- 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
-
- ignoreException(Throwable) - Method in class io.netty.handler.ssl.SslHandler
-
Checks if the given Throwable
can be ignore and just "swallowed"
When an ssl connection is closed a close_notify message is sent.
- 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.
- ImmediateEventExecutor() - Constructor for class io.netty.util.concurrent.ImmediateEventExecutor
-
- ImmediateEventExecutor.ImmediateProgressivePromise<V> - Class in io.netty.util.concurrent
-
- ImmediateEventExecutor.ImmediatePromise<V> - Class in io.netty.util.concurrent
-
- ImmediateExecutor - Class in io.netty.util.concurrent
-
Executor
which execute tasks in the callers thread.
- ImmediateExecutor() - Constructor for class io.netty.util.concurrent.ImmediateExecutor
-
- ImmediateProgressivePromise(EventExecutor) - Constructor for class io.netty.util.concurrent.ImmediateEventExecutor.ImmediateProgressivePromise
-
- ImmediatePromise(EventExecutor) - Constructor for class io.netty.util.concurrent.ImmediateEventExecutor.ImmediatePromise
-
- ImmutableDomainNameMapping(V, Map<String, V>) - Constructor for class io.netty.util.DomainNameMappingBuilder.ImmutableDomainNameMapping
-
- in - Variable in class io.netty.handler.codec.compression.Bzip2BitReader
-
The
ByteBuf
from which to read data.
- in - Variable in class io.netty.handler.codec.serialization.ObjectDecoderInputStream
-
- in - Variable in class io.netty.handler.stream.ChunkedNioFile
-
- in - Variable in class io.netty.handler.stream.ChunkedNioStream
-
- in - Variable in class io.netty.handler.stream.ChunkedStream
-
- INADDRSZ4 - Static variable in class io.netty.resolver.dns.DnsNameResolverContext
-
- INADDRSZ6 - Static variable in class io.netty.resolver.dns.DnsNameResolverContext
-
- inbound - Variable in class io.netty.channel.AbstractChannelHandlerContext
-
- inboundBuffer - Variable in class io.netty.channel.local.LocalChannel
-
- inboundBuffer - Variable in class io.netty.channel.local.LocalServerChannel
-
- inboundCtx - Variable in class io.netty.channel.CombinedChannelDuplexHandler
-
- inboundHandler - Variable in class io.netty.channel.CombinedChannelDuplexHandler
-
- inboundHandler() - Method in class io.netty.channel.CombinedChannelDuplexHandler
-
- inboundMessages - Variable in class io.netty.channel.embedded.EmbeddedChannel
-
- inboundMessages() - Method in class io.netty.channel.embedded.EmbeddedChannel
-
Returns the
Queue
which holds all the
Object
s that were received by this
Channel
.
- inboundMsgMatcher - Variable in class io.netty.handler.codec.MessageToMessageCodec
-
- incMessagesRead(int) - Method in class io.netty.channel.DefaultMaxBytesRecvByteBufAllocator.HandleImpl
-
- incMessagesRead(int) - Method in class io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator.MaxMessageHandle
-
- incMessagesRead(int) - Method in class io.netty.channel.kqueue.KQueueRecvByteAllocatorHandle
-
- 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
-
- increaseCapacity() - Method in class io.netty.channel.nio.SelectedSelectionKeySet
-
- increaseCapacity(int) - Method in class io.netty.util.Recycler.Stack
-
- 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
-
- increment() - Method in class io.netty.util.internal.PlatformDependent.AtomicLongCounter
-
- incrementDirect(int) - Method in class io.netty.buffer.UnpooledByteBufAllocator
-
- incrementHeap(int) - Method in class io.netty.buffer.UnpooledByteBufAllocator
-
- incrementMemoryCounter(int) - Static method in class io.netty.util.internal.PlatformDependent
-
- incrementPendingOutboundBytes(long) - Method in class io.netty.channel.ChannelOutboundBuffer
-
Increment the pending bytes which will be written at some point.
- incrementPendingOutboundBytes(long, boolean) - Method in class io.netty.channel.ChannelOutboundBuffer
-
- INCREMENTQ - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
-
- incTinySmallAllocation(boolean) - Method in class io.netty.buffer.PoolArena
-
- incWaiters() - Method in class io.netty.util.concurrent.DefaultPromise
-
- index - Variable in class io.netty.buffer.CompositeByteBuf.CompositeByteBufIterator
-
- index - Variable in class io.netty.buffer.FixedCompositeByteBuf.Component
-
- index - Variable in class io.netty.channel.AdaptiveRecvByteBufAllocator.HandleImpl
-
- index(int) - Method in class io.netty.handler.codec.DefaultHeaders
-
- index - Variable in class io.netty.util.concurrent.FastThreadLocal
-
- index(AttributeKey<?>) - Static method in class io.netty.util.DefaultAttributeMap
-
- index - Variable in class io.netty.util.internal.DefaultPriorityQueue.PriorityQueueIterator
-
- INDEX_DECREMENT - Static variable in class io.netty.channel.AdaptiveRecvByteBufAllocator
-
- INDEX_INCREMENT - Static variable in class io.netty.channel.AdaptiveRecvByteBufAllocator
-
- INDEX_NOT_FOUND - Static variable in class io.netty.util.AsciiString
-
- INDEX_NOT_IN_QUEUE - Static variable in interface io.netty.util.internal.PriorityQueueNode
-
- indexedVariable(int) - Method in class io.netty.util.internal.InternalThreadLocalMap
-
- indexedVariables - Variable in class io.netty.util.internal.UnpaddedInternalThreadLocalMap
-
- 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.AdvancedLeakAwareByteBuf
-
- indexOf(int, int, byte) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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
-
- indexOf(int, int, byte) - Method in class io.netty.buffer.EmptyByteBuf
-
- indexOf(int, int, byte) - Method in class io.netty.buffer.SwappedByteBuf
-
Deprecated.
- indexOf(int, int, byte) - Method in class io.netty.buffer.WrappedByteBuf
-
- indexOf(int, int, byte) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- indexOf(ByteBuf, ByteBuf) - Static method in class io.netty.handler.codec.DelimiterBasedFrameDecoder
-
Returns the number of bytes between the readerIndex of the haystack and
the first needle found in the haystack.
- indexOf(int, int, byte) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- 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.
- indexOf(byte) - Method in class io.netty.util.collection.ByteObjectHashMap
-
Locates the index for the given key.
- indexOf(char) - Method in class io.netty.util.collection.CharObjectHashMap
-
Locates the index for the given key.
- indexOf(int) - Method in class io.netty.util.collection.IntObjectHashMap
-
Locates the index for the given key.
- indexOf(long) - Method in class io.netty.util.collection.LongObjectHashMap
-
Locates the index for the given key.
- indexOf(short) - Method in class io.netty.util.collection.ShortObjectHashMap
-
Locates the index for the given key.
- indexOfFirstNonOwsChar(CharSequence, int) - Static method in class io.netty.util.internal.StringUtil
-
- 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.
- indexOfLastNonOwsChar(CharSequence, int, int) - Static method in class io.netty.util.internal.StringUtil
-
- 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
-
- indexToFront(int) - Method in class io.netty.handler.codec.compression.Bzip2MoveToFrontTable
-
Gets the value from a given index and moves it to the front of the MTF list (inverse Move To Front transform).
- individualReadMax - Variable in class io.netty.channel.DefaultMaxBytesRecvByteBufAllocator.HandleImpl
-
- inet4Entries - Variable in class io.netty.resolver.DefaultHostsFileEntriesResolver
-
- inet4Entries - Variable in class io.netty.resolver.HostsFileEntries
-
- inet4Entries() - Method in class io.netty.resolver.HostsFileEntries
-
The IPv4 entries
- inet6Entries - Variable in class io.netty.resolver.DefaultHostsFileEntriesResolver
-
- inet6Entries - Variable in class io.netty.resolver.HostsFileEntries
-
- 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.channel.embedded.EmbeddedEventLoop
-
- inEventLoop(Thread) - Method in class io.netty.channel.embedded.EmbeddedEventLoop
-
- 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.NonStickyEventExecutorGroup.NonStickyOrderedEventExecutor
-
- inEventLoop() - Method in class io.netty.util.concurrent.NonStickyEventExecutorGroup.NonStickyOrderedEventExecutor
-
- 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
-
- inExceptionCaught(Throwable) - Static method in class io.netty.channel.AbstractChannelHandlerContext
-
- inFail - Variable in class io.netty.channel.ChannelOutboundBuffer
-
- inflater - Variable in class io.netty.handler.codec.compression.JdkZlibDecoder
-
- inflaterException(Inflater, String, int) - Static method in class io.netty.handler.codec.compression.ZlibUtil
-
- InflightNameResolver<T> - Class in io.netty.resolver.dns
-
- InflightNameResolver(EventExecutor, NameResolver<T>, ConcurrentMap<String, Promise<T>>, ConcurrentMap<String, Promise<List<T>>>) - Constructor for class io.netty.resolver.dns.InflightNameResolver
-
- inFlush0 - Variable in class io.netty.channel.AbstractChannel.AbstractUnsafe
-
- info(Throwable) - Method in class io.netty.util.internal.logging.AbstractInternalLogger
-
- info(String) - Method in class io.netty.util.internal.logging.CommonsLogger
-
Deprecated.
Delegates to the Log.debug(Object)
method of the underlying
Log
instance.
- info(String, Object) - Method in class io.netty.util.internal.logging.CommonsLogger
-
Deprecated.
Delegates to the Log.info(Object)
method of the underlying
Log
instance.
- info(String, Object, Object) - Method in class io.netty.util.internal.logging.CommonsLogger
-
Deprecated.
Delegates to the Log.info(Object)
method of the underlying
Log
instance.
- info(String, Object...) - Method in class io.netty.util.internal.logging.CommonsLogger
-
Deprecated.
Delegates to the Log.info(Object)
method of the underlying
Log
instance.
- info(String, Throwable) - Method in class io.netty.util.internal.logging.CommonsLogger
-
Deprecated.
Delegates to the Log.info(Object, Throwable)
method of
the underlying Log
instance.
- 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.
- info(String) - Method in class io.netty.util.internal.logging.JdkLogger
-
Log a message object at the INFO level.
- info(String, Object) - Method in class io.netty.util.internal.logging.JdkLogger
-
Log a message at level INFO according to the specified format and argument.
- info(String, Object, Object) - Method in class io.netty.util.internal.logging.JdkLogger
-
Log a message at the INFO level according to the specified format and
arguments.
- info(String, Object...) - Method in class io.netty.util.internal.logging.JdkLogger
-
Log a message at level INFO according to the specified format and
arguments.
- info(String, Throwable) - Method in class io.netty.util.internal.logging.JdkLogger
-
Log an exception (throwable) at the INFO level with an accompanying
message.
- info(String) - Method in class io.netty.util.internal.logging.Log4JLogger
-
Log a message object at the INFO level.
- info(String, Object) - Method in class io.netty.util.internal.logging.Log4JLogger
-
Log a message at level INFO according to the specified format and argument.
- info(String, Object, Object) - Method in class io.netty.util.internal.logging.Log4JLogger
-
Log a message at the INFO level according to the specified format and
arguments.
- info(String, Object...) - Method in class io.netty.util.internal.logging.Log4JLogger
-
Log a message at level INFO according to the specified format and
arguments.
- info(String, Throwable) - Method in class io.netty.util.internal.logging.Log4JLogger
-
Log an exception (throwable) at the INFO level with an accompanying
message.
- info(String) - Method in class io.netty.util.internal.logging.Slf4JLogger
-
- info(String, Object) - Method in class io.netty.util.internal.logging.Slf4JLogger
-
- info(String, Object, Object) - Method in class io.netty.util.internal.logging.Slf4JLogger
-
- info(String, Object...) - Method in class io.netty.util.internal.logging.Slf4JLogger
-
- info(String, Throwable) - Method in class io.netty.util.internal.logging.Slf4JLogger
-
- informReadOperation(ChannelHandlerContext, long) - Method in class io.netty.handler.traffic.AbstractTrafficShapingHandler
-
Method overridden in GTSH to take into account specific timer for the channel.
- informReadOperation(ChannelHandlerContext, long) - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
-
- informReadOperation(ChannelHandlerContext, long) - Method in class io.netty.handler.traffic.GlobalTrafficShapingHandler
-
- init(Channel) - Method in class io.netty.bootstrap.AbstractBootstrap
-
- init(Channel) - Method in class io.netty.bootstrap.Bootstrap
-
- init(Channel) - Method in class io.netty.bootstrap.ServerBootstrap
-
- init(AbstractByteBuf, ByteBuf, int, int, int) - Method in class io.netty.buffer.AbstractPooledDerivedByteBuf
-
- init(PoolChunk<T>, long, int, int, int, PoolThreadCache) - Method in class io.netty.buffer.PooledByteBuf
-
- init(PoolChunk<ByteBuffer>, long, int, int, int, PoolThreadCache) - Method in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- init(PoolSubpage<T>, int) - Method in class io.netty.buffer.PoolSubpage
-
- init(AbstractChannelHandlerContext.AbstractWriteTask, AbstractChannelHandlerContext, Object, ChannelPromise) - Static method in class io.netty.channel.AbstractChannelHandlerContext.AbstractWriteTask
-
- INIT - Static variable in class io.netty.channel.AbstractChannelHandlerContext
-
- init(I, O) - Method in class io.netty.channel.CombinedChannelDuplexHandler
-
Initialized this handler with the specified handlers.
- init(SimpleTrustManagerFactory) - Method in class io.netty.handler.ssl.util.SimpleTrustManagerFactory.SimpleTrustManagerFactorySpi
-
- init(long) - Method in class io.netty.handler.traffic.TrafficCounter
-
- init0(PoolChunk<T>, long, int, int, int, PoolThreadCache) - Method in class io.netty.buffer.PooledByteBuf
-
- initAndRegister() - Method in class io.netty.bootstrap.AbstractBootstrap
-
- initBuf(PooledByteBuf<T>, long, int) - Method in class io.netty.buffer.PoolChunk
-
- initBuf(PoolChunk<T>, long, PooledByteBuf<T>, int) - Method in class io.netty.buffer.PoolThreadCache.MemoryRegionCache
-
Init the
PooledByteBuf
using the provided chunk and handle with the capacity restrictions.
- initBuf(PoolChunk<T>, long, PooledByteBuf<T>, int) - Method in class io.netty.buffer.PoolThreadCache.NormalMemoryRegionCache
-
- initBuf(PoolChunk<T>, long, PooledByteBuf<T>, int) - Method in class io.netty.buffer.PoolThreadCache.SubPageMemoryRegionCache
-
- initBufWithSubpage(PooledByteBuf<T>, long, int) - Method in class io.netty.buffer.PoolChunk
-
- initBufWithSubpage(PooledByteBuf<T>, long, int, int) - Method in class io.netty.buffer.PoolChunk
-
- 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.
- initChannel(ChannelHandlerContext) - Method in class io.netty.channel.ChannelInitializer
-
- initDecoding(byte) - Method in class io.netty.handler.codec.json.JsonObjectDecoder
-
- initEngine(SSLEngine) - Method in class io.netty.handler.ssl.DelegatingSslContext
-
Init the SSLEngine
.
- initial - Variable in class io.netty.channel.AdaptiveRecvByteBufAllocator
-
- INITIAL_CAPACITY - Static variable in class io.netty.util.Recycler
-
- initialBytesToStrip - Variable in class io.netty.handler.codec.LengthFieldBasedFrameDecoder
-
- initialiseInverseBWT() - Method in class io.netty.handler.codec.compression.Bzip2BlockDecompressor
-
Set up the Inverse Burrows-Wheeler Transform merged pointer array.
- initialize(ChannelHandlerContext) - Method in class io.netty.handler.timeout.IdleStateHandler
-
- initialize(InternalThreadLocalMap) - Method in class io.netty.util.concurrent.FastThreadLocal
-
- initialized - Variable in class io.netty.util.internal.ThreadLocalRandom
-
Initialization flag to permit calls to setSeed to succeed only
while executing the Random constructor.
- initialSeedUniquifier - Static variable in class io.netty.util.internal.ThreadLocalRandom
-
- initialValue() - Method in class io.netty.buffer.PooledByteBufAllocator.PoolThreadLocalCache
-
- initialValue() - Method in class io.netty.util.concurrent.FastThreadLocal
-
Returns the initial value for this thread-local variable.
- initLength(int) - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- initLength(int) - Method in class io.netty.buffer.SlicedByteBuf
-
Deprecated.
- initMap - Variable in class io.netty.channel.ChannelInitializer
-
- InitMaxStreams() - Constructor for class com.sun.nio.sctp.SctpStandardSocketOptions.InitMaxStreams
-
- initMemoryAddress() - Method in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- initOutputChanged(ChannelHandlerContext) - Method in class io.netty.handler.timeout.IdleStateHandler
-
- initUnpooled(PoolChunk<T>, int) - Method in class io.netty.buffer.PooledByteBuf
-
- initUnpooled(PoolChunk<ByteBuffer>, int) - Method in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- inline - Variable in enum io.netty.handler.codec.redis.RedisMessageType
-
- inputClosedSeenErrorOnRead - Variable in class io.netty.channel.kqueue.AbstractKQueueChannel
-
- inputShutdown - Variable in class io.netty.channel.nio.AbstractNioMessageChannel
-
- inputShutdown(int) - Static method in class io.netty.channel.unix.FileDescriptor
-
- inRangeEndExclusive(int, int, int) - Static method in class io.netty.util.NetUtil
-
Does a range check on value
if is within start
(inclusive) and end
(exclusive).
- InsecureTrustManagerFactory - Class in io.netty.handler.ssl.util
-
An insecure TrustManagerFactory
that trusts all X.509 certificates without any verification.
- InsecureTrustManagerFactory() - Constructor for class io.netty.handler.ssl.util.InsecureTrustManagerFactory
-
- insert(int, Object) - Method in class io.netty.handler.codec.CodecOutputList
-
- INSERTIONSORT_THRESHOLD - Static variable in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- insertSinceRecycled - Variable in class io.netty.handler.codec.CodecOutputList
-
- insertSinceRecycled() - Method in class io.netty.handler.codec.CodecOutputList
-
Returns true
if any elements where added or set.
- insertSinceRecycled - Variable in class io.netty.util.internal.RecyclableArrayList
-
- insertSinceRecycled() - Method in class io.netty.util.internal.RecyclableArrayList
-
Returns true
if any elements where added or set.
- insideString - Variable in class io.netty.handler.codec.json.JsonObjectDecoder
-
- INSTANCE - Static variable in class io.netty.channel.DefaultSelectStrategy
-
- INSTANCE - Static variable in class io.netty.channel.DefaultSelectStrategyFactory
-
- INSTANCE - Static variable in class io.netty.channel.embedded.EmbeddedChannelId
-
- 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
-
- INSTANCE - Static variable in class io.netty.handler.codec.socksx.v4.Socks4ClientEncoder
-
- INSTANCE - Static variable in class io.netty.handler.codec.socksx.v4.Socks4ServerEncoder
-
- INSTANCE - Static variable in class io.netty.handler.codec.UnsupportedValueConverter
-
- 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.JdkDefaultApplicationProtocolNegotiator
-
- 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 class io.netty.handler.ssl.util.ThreadLocalInsecureRandom
-
- 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.NoopDnsQueryLifecycleObserver
-
- 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.AsciiString.AsciiCaseInsensitiveCharEqualityComparator
-
- INSTANCE - Static variable in class io.netty.util.AsciiString.DefaultCharEqualityComparator
-
- INSTANCE - Static variable in class io.netty.util.AsciiString.GeneralCaseInsensitiveCharEqualityComparator
-
- 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 variable in class io.netty.util.internal.EmptyPriorityQueue
-
- instance() - Static method in class io.netty.util.internal.EmptyPriorityQueue
-
- 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.Log4JLoggerFactory
-
- INSTANCE - Static variable in class io.netty.util.internal.logging.Slf4JLoggerFactory
-
- INSTANCE - Static variable in class io.netty.util.ResourceLeakDetector.LeakEntry
-
- instance() - Static method in class io.netty.util.ResourceLeakDetectorFactory
-
Get the singleton instance of this factory class.
- INSTANCE_COUNT_LIMIT - Static variable in class io.netty.util.HashedWheelTimer
-
- INSTANCE_COUNTER - Static variable in class io.netty.util.HashedWheelTimer
-
- InstanceMatcher(Channel) - Constructor for class io.netty.channel.group.ChannelMatchers.InstanceMatcher
-
- INSTANCES - Static variable in class io.netty.handler.codec.DateFormatter
-
- InstrumentedUnpooledDirectByteBuf(UnpooledByteBufAllocator, int, int) - Constructor for class io.netty.buffer.UnpooledByteBufAllocator.InstrumentedUnpooledDirectByteBuf
-
- InstrumentedUnpooledHeapByteBuf(UnpooledByteBufAllocator, int, int) - Constructor for class io.netty.buffer.UnpooledByteBufAllocator.InstrumentedUnpooledHeapByteBuf
-
- InstrumentedUnpooledUnsafeDirectByteBuf(UnpooledByteBufAllocator, int, int) - Constructor for class io.netty.buffer.UnpooledByteBufAllocator.InstrumentedUnpooledUnsafeDirectByteBuf
-
- InstrumentedUnpooledUnsafeHeapByteBuf(UnpooledByteBufAllocator, int, int) - Constructor for class io.netty.buffer.UnpooledByteBufAllocator.InstrumentedUnpooledUnsafeHeapByteBuf
-
- InstrumentedUnpooledUnsafeNoCleanerDirectByteBuf(UnpooledByteBufAllocator, int, int) - Constructor for class io.netty.buffer.UnpooledByteBufAllocator.InstrumentedUnpooledUnsafeNoCleanerDirectByteBuf
-
- intArrayAppend(StringBuilder, int[]) - Static method in class io.netty.util.internal.logging.MessageFormatter
-
- IntCollections - Class in io.netty.util.collection
-
Utilities for int-based primitive collections.
- IntCollections() - Constructor for class io.netty.util.collection.IntCollections
-
- IntCollections.EmptyMap - Class in io.netty.util.collection
-
An empty map.
- IntCollections.UnmodifiableMap<V> - Class in io.netty.util.collection
-
- IntCollections.UnmodifiableMap.EntryImpl - Class in io.netty.util.collection
-
Unmodifiable wrapper for an entry.
- IntCollections.UnmodifiableMap.IteratorImpl - Class in io.netty.util.collection
-
Unmodifiable wrapper for an iterator.
- INTEGER_SIZE_MINUS_ONE - Static variable in class io.netty.buffer.PoolChunk
-
- IntegerHolder - Class in io.netty.util.internal
-
- IntegerHolder() - Constructor for class io.netty.util.internal.IntegerHolder
-
- IntegerRedisMessage - Class in io.netty.handler.codec.redis
-
- IntegerRedisMessage(long) - Constructor for class io.netty.handler.codec.redis.IntegerRedisMessage
-
- INTERNAL_UNSAFE - Static variable in class io.netty.util.internal.PlatformDependent0
-
- 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.
- internalComponent(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- internalComponentAtOffset(int) - Method in class io.netty.buffer.CompositeByteBuf
-
Return the internal
ByteBuf
on the specified offset.
- internalComponentAtOffset(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- internalLevel - Variable in class io.netty.handler.logging.LoggingHandler
-
- internalLevel - Variable in enum io.netty.handler.logging.LogLevel
-
- 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
-
- InternalLogLevel() - Constructor for enum io.netty.util.internal.logging.InternalLogLevel
-
- internalNioBuffer(int, int) - Method in class io.netty.buffer.AbstractDerivedByteBuf
-
Deprecated.
- internalNioBuffer(int, int) - Method in class io.netty.buffer.AbstractPooledDerivedByteBuf
-
- internalNioBuffer(int, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- internalNioBuffer(int, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.FixedCompositeByteBuf
-
- internalNioBuffer() - Method in class io.netty.buffer.PooledByteBuf
-
- internalNioBuffer(int, int) - Method in class io.netty.buffer.PooledDirectByteBuf
-
- internalNioBuffer(int, int) - Method in class io.netty.buffer.PooledHeapByteBuf
-
- internalNioBuffer(int, int) - Method in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- internalNioBuffer() - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- internalNioBuffer(int, int) - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- internalNioBuffer(int, int) - Method in class io.netty.buffer.SwappedByteBuf
-
Deprecated.
- internalNioBuffer(int, int) - Method in class io.netty.buffer.UnpooledDirectByteBuf
-
- internalNioBuffer() - Method in class io.netty.buffer.UnpooledDirectByteBuf
-
- internalNioBuffer(int, int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
-
- internalNioBuffer() - Method in class io.netty.buffer.UnpooledHeapByteBuf
-
- internalNioBuffer(int, int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
-
- internalNioBuffer() - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
-
- internalNioBuffer(int, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- internalNioBuffer(int, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- internalNioBuffer(int, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- internalResolve(Promise<T>) - Method in class io.netty.resolver.dns.DnsNameResolverContext
-
- InternalThreadLocalMap - Class in io.netty.util.internal
-
The internal data structure that stores the thread-local variables for Netty and all
FastThreadLocal
s.
- InternalThreadLocalMap() - Constructor for class io.netty.util.internal.InternalThreadLocalMap
-
- InternetProtocolFamily - Enum in io.netty.channel.socket
-
- InternetProtocolFamily(Class<? extends InetAddress>, int, InetAddress) - Constructor for enum io.netty.channel.socket.InternetProtocolFamily
-
- interrupted - Variable in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- 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
-
- IntObjectHashMap.EntrySet - Class in io.netty.util.collection
-
Set implementation for iterating over the entries of the map.
- IntObjectHashMap.KeySet - Class in io.netty.util.collection
-
Set implementation for iterating over the keys.
- IntObjectHashMap.MapEntry - Class in io.netty.util.collection
-
A single entry in the map.
- IntObjectHashMap.MapIterator - Class in io.netty.util.collection
-
Iterator used by the Map
interface.
- IntObjectHashMap.PrimitiveIterator - Class in io.netty.util.collection
-
Iterator over primitive entries.
- IntObjectMap<V> - Interface in io.netty.util.collection
-
Interface for a primitive map that uses int
s as keys.
- IntObjectMap.PrimitiveEntry<V> - Interface in io.netty.util.collection
-
- 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 - Variable in class io.netty.handler.codec.dns.DnsRecordType
-
- 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
-
- 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 variable in class io.netty.handler.codec.ProtocolDetectionResult
-
- invalid() - Static method in class io.netty.handler.codec.ProtocolDetectionResult
-
- invalidate() - Method in class io.netty.handler.ssl.JdkSslSession
-
- invalidateLocalAddress() - Method in class io.netty.channel.AbstractChannel
-
- invalidateRemoteAddress() - Method in class io.netty.channel.AbstractChannel
-
- invalidChunk(Exception) - Method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheDecoder
-
Helper method to create a content chunk indicating a invalid decoding result.
- invalidMessage(Exception) - Method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheDecoder
-
Helper method to create a message indicating a invalid decoding result.
- invalidMessage(Throwable) - Method in class io.netty.handler.codec.mqtt.MqttDecoder
-
- invert(ChannelMatcher) - Static method in class io.netty.channel.group.ChannelMatchers
-
- InvertMatcher(ChannelMatcher) - Constructor for class io.netty.channel.group.ChannelMatchers.InvertMatcher
-
- INVOKE_CLEANER - Static variable in class io.netty.util.internal.CleanerJava9
-
- 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
-
- invokeBind(SocketAddress, ChannelPromise) - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- invokeChannelActive(AbstractChannelHandlerContext) - Static method in class io.netty.channel.AbstractChannelHandlerContext
-
- invokeChannelActive() - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- invokeChannelInactive(AbstractChannelHandlerContext) - Static method in class io.netty.channel.AbstractChannelHandlerContext
-
- invokeChannelInactive() - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- invokeChannelRead(AbstractChannelHandlerContext, Object) - Static method in class io.netty.channel.AbstractChannelHandlerContext
-
- invokeChannelRead(Object) - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- invokeChannelReadComplete(AbstractChannelHandlerContext) - Static method in class io.netty.channel.AbstractChannelHandlerContext
-
- invokeChannelReadComplete() - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- invokeChannelReadCompleteTask - Variable in class io.netty.channel.AbstractChannelHandlerContext
-
- invokeChannelRegistered(AbstractChannelHandlerContext) - Static method in class io.netty.channel.AbstractChannelHandlerContext
-
- invokeChannelRegistered() - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- invokeChannelUnregistered(AbstractChannelHandlerContext) - Static method in class io.netty.channel.AbstractChannelHandlerContext
-
- invokeChannelUnregistered() - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- invokeChannelUnregistered(NioTask<SelectableChannel>, SelectionKey, Throwable) - Static method in class io.netty.channel.nio.NioEventLoop
-
- invokeChannelWritabilityChanged(AbstractChannelHandlerContext) - Static method in class io.netty.channel.AbstractChannelHandlerContext
-
- invokeChannelWritabilityChanged() - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- invokeChannelWritableStateChangedTask - Variable in class io.netty.channel.AbstractChannelHandlerContext
-
- invokeClose(ChannelPromise) - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- invokeConnect(SocketAddress, SocketAddress, ChannelPromise) - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- invokeDeregister(ChannelPromise) - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- invokeDisconnect(ChannelPromise) - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- invokeExceptionCaught(AbstractChannelHandlerContext, Throwable) - Static method in class io.netty.channel.AbstractChannelHandlerContext
-
- invokeExceptionCaught(Throwable) - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- invokeFlush() - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- invokeFlush0() - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- invokeFlushTask - Variable in class io.netty.channel.AbstractChannelHandlerContext
-
- invokeHandleOversizedMessage(ChannelHandlerContext, S) - Method in class io.netty.handler.codec.MessageAggregator
-
- invokeHandler() - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- invokeHandlerAddedIfNeeded() - Method in class io.netty.channel.DefaultChannelPipeline
-
- invokeLater(Runnable) - Method in class io.netty.channel.AbstractChannel.AbstractUnsafe
-
- invokeRead() - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- invokeReadTask - Variable in class io.netty.channel.AbstractChannelHandlerContext
-
- invokeUserEventTriggered(AbstractChannelHandlerContext, Object) - Static method in class io.netty.channel.AbstractChannelHandlerContext
-
- invokeUserEventTriggered(Object) - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- invokeWrite(Object, ChannelPromise) - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- invokeWrite0(Object, ChannelPromise) - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- invokeWriteAndFlush(Object, ChannelPromise) - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- 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.group - package io.netty.channel.group
-
A channel registry which helps a user maintain the list of open
Channel
s 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.sctp - package io.netty.channel.sctp
-
Abstract SCTP socket interfaces which extend the core channel API.
- io.netty.channel.sctp.nio - package io.netty.channel.sctp.nio
-
NIO-based SCTP Channel
API implementation - recommended for a large number of connections (>= 1000).
- io.netty.channel.sctp.oio - package io.netty.channel.sctp.oio
-
Old blocking I/O based SCTP channel API implementation - recommended for
a small number of connections (< 1000).
- 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
ByteBuf
s
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.haproxy - package io.netty.handler.codec.haproxy
-
Decodes an HAProxy proxy protocol header
- io.netty.handler.codec.json - package io.netty.handler.codec.json
-
- 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.sctp - package io.netty.handler.codec.sctp
-
Decoder and encoders to manage message completion and multi-streaming codec in SCTP/IP.
- 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
-
- io.netty.handler.codec.socks - package io.netty.handler.codec.socks
-
Encoder, decoder and their related message types for Socks.
- io.netty.handler.codec.socksx - package io.netty.handler.codec.socksx
-
Encoder, decoder and their related message types for SOCKS protocol.
- io.netty.handler.codec.socksx.v4 - package io.netty.handler.codec.socksx.v4
-
Encoder, decoder and their related message types for SOCKSv4 protocol.
- io.netty.handler.codec.socksx.v5 - package io.netty.handler.codec.socksx.v5
-
Encoder, decoder and their related message types for SOCKSv5 protocol.
- io.netty.handler.codec.stomp - package io.netty.handler.codec.stomp
-
- 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
-
- 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.collection - package io.netty.util.collection
-
- 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.
- ioBuffer() - Method in class io.netty.channel.local.PreferHeapByteBufAllocator
-
- ioBuffer(int) - Method in class io.netty.channel.local.PreferHeapByteBufAllocator
-
- ioBuffer(int, int) - Method in class io.netty.channel.local.PreferHeapByteBufAllocator
-
- ioRatio - Variable in class io.netty.channel.kqueue.KQueueEventLoop
-
- ioRatio - Variable in class io.netty.channel.nio.NioEventLoop
-
- 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
-
- IOV_SIZE - Static variable in class io.netty.channel.unix.IovArray
-
The size of an iovec
struct in bytes.
- iovArray - Variable in class io.netty.channel.kqueue.KQueueEventLoop
-
- 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
-
- iovMax() - Static method in class io.netty.channel.unix.LimitsStaticallyReferencedJniMethods
-
- Ip4SubnetFilterRule(Inet4Address, int, IpFilterRuleType) - Constructor for class io.netty.handler.ipfilter.IpSubnetFilterRule.Ip4SubnetFilterRule
-
- Ip6SubnetFilterRule(Inet6Address, int, IpFilterRuleType) - Constructor for class io.netty.handler.ipfilter.IpSubnetFilterRule.Ip6SubnetFilterRule
-
- IP_MULTICAST_ADDR - Static variable in class io.netty.channel.ChannelOption
-
- IP_MULTICAST_IF - Static variable in class io.netty.channel.ChannelOption
-
- IP_MULTICAST_IF - Static variable in class io.netty.channel.socket.nio.NioDatagramChannelConfig
-
- IP_MULTICAST_LOOP - Static variable in class io.netty.channel.socket.nio.NioDatagramChannelConfig
-
- IP_MULTICAST_LOOP_DISABLED - Static variable in class io.netty.channel.ChannelOption
-
- IP_MULTICAST_TTL - Static variable in class io.netty.channel.ChannelOption
-
- IP_MULTICAST_TTL - Static variable in class io.netty.channel.socket.nio.NioDatagramChannelConfig
-
- IP_TOS - Static variable in class io.netty.channel.ChannelOption
-
- ipBytesToString(ByteBuf, int) - Static method in class io.netty.handler.codec.haproxy.HAProxyMessage
-
Convert ip address bytes to string representation
- 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.
- IpFilterRuleType() - Constructor for enum io.netty.handler.ipfilter.IpFilterRuleType
-
- 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
-
- IpSubnetFilterRule.Ip4SubnetFilterRule - Class in io.netty.handler.ipfilter
-
- IpSubnetFilterRule.Ip6SubnetFilterRule - Class in io.netty.handler.ipfilter
-
- ipToInt(Inet4Address) - Static method in class io.netty.handler.ipfilter.IpSubnetFilterRule.Ip4SubnetFilterRule
-
- ipToInt(Inet6Address) - Static method in class io.netty.handler.ipfilter.IpSubnetFilterRule.Ip6SubnetFilterRule
-
- IPv4 - Static variable in class io.netty.handler.codec.socksx.v5.Socks5AddressType
-
- IPv4_DOMAIN_MARKER - Static variable in class io.netty.handler.codec.socksx.v4.Socks4ClientEncoder
-
- IPv4_HOSTNAME_ZEROED - Static variable in class io.netty.handler.codec.socks.SocksCmdResponse
-
- IPv4_HOSTNAME_ZEROED - Static variable in class io.netty.handler.codec.socksx.v4.Socks4ServerEncoder
-
- IPV4_MAPPED_IPV6_PREFIX - Static variable in class io.netty.channel.unix.NativeInetAddress
-
- IPV4_MAX_CHAR_BETWEEN_SEPARATOR - Static variable in class io.netty.util.NetUtil
-
Maximum amount of value adding characters in between IPV4 separators
- IPV4_ONLY_RESOLVED_PROTOCOL_FAMILIES - Static variable in class io.netty.resolver.dns.DnsNameResolver
-
- IPV4_ONLY_RESOLVED_RECORD_TYPES - Static variable in class io.netty.resolver.dns.DnsNameResolver
-
- IPV4_PREFERRED - Static variable in class io.netty.util.NetUtil
-
true
if IPv4 should be used even if the system supports both IPv4 and IPv6.
- IPV4_PREFERRED_RESOLVED_PROTOCOL_FAMILIES - Static variable in class io.netty.resolver.dns.DnsNameResolver
-
- IPV4_PREFERRED_RESOLVED_RECORD_TYPES - Static variable in class io.netty.resolver.dns.DnsNameResolver
-
- IPV4_SEPARATORS - Static variable in class io.netty.util.NetUtil
-
Number of separators that must be present in an IPv4 string
- ipv4MappedIpv6Address(byte[]) - Static method in class io.netty.channel.unix.NativeInetAddress
-
- ipv4WordToByte(String, int, int) - Static method in class io.netty.util.NetUtil
-
- IPv6 - Static variable in class io.netty.handler.codec.socksx.v5.Socks5AddressType
-
- IPV6_ADDRESSES_PREFERRED - Static variable in class io.netty.util.NetUtil
-
true
if an IPv6 address should be preferred when a host has both an IPv4 address and an IPv6 address.
- IPV6_BYTE_COUNT - Static variable in class io.netty.util.NetUtil
-
Number of bytes needed to represent and IPV6 value
- IPv6_HOSTNAME_ZEROED - Static variable in class io.netty.handler.codec.socks.SocksCmdResponse
-
- IPV6_MAX_CHAR_BETWEEN_SEPARATOR - Static variable in class io.netty.util.NetUtil
-
Maximum amount of value adding characters in between IPV6 separators
- IPV6_MAX_CHAR_COUNT - Static variable in class io.netty.util.NetUtil
-
The maximum number of characters for an IPV6 string with no scope
- IPV6_MAX_SEPARATORS - Static variable in class io.netty.util.NetUtil
-
Maximum number of separators that must be present in an IPv6 string
- IPV6_MIN_SEPARATORS - Static variable in class io.netty.util.NetUtil
-
Minimum number of separators that must be present in an IPv6 string
- IPV6_ONLY_RESOLVED_PROTOCOL_FAMILIES - Static variable in class io.netty.resolver.dns.DnsNameResolver
-
- IPV6_ONLY_RESOLVED_RECORD_TYPES - Static variable in class io.netty.resolver.dns.DnsNameResolver
-
- IPV6_PREFERRED_RESOLVED_PROTOCOL_FAMILIES - Static variable in class io.netty.resolver.dns.DnsNameResolver
-
- IPV6_PREFERRED_RESOLVED_RECORD_TYPES - Static variable in class io.netty.resolver.dns.DnsNameResolver
-
- IPV6_WORD_COUNT - Static variable in class io.netty.util.NetUtil
-
This defines how many words (represented as ints) are needed to represent an IPv6 address
- ipv6hextetSeparator - Static variable in class io.netty.handler.codec.socks.SocksCommonUtils
-
- ipv6toStr(byte[]) - Static method in class io.netty.handler.codec.socks.SocksCommonUtils
-
Converts numeric IPv6 to standard (non-compressed) format.
- ipv6toStr(StringBuilder, byte[], int, int) - Static method in class io.netty.handler.codec.socks.SocksCommonUtils
-
- 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
-
- is - Variable in class io.netty.channel.oio.OioByteStreamChannel
-
- IS_ANDROID - Static variable in class io.netty.util.internal.PlatformDependent0
-
- IS_EXPLICIT_NO_UNSAFE - Static variable in class io.netty.util.internal.PlatformDependent0
-
- IS_WINDOWS - Static variable in class io.netty.util.internal.PlatformDependent
-
- 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.kqueue.AbstractKQueueChannel
-
- 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.sctp.nio.NioSctpChannel
-
- isActive() - Method in class io.netty.channel.sctp.nio.NioSctpServerChannel
-
- isActive() - Method in class io.netty.channel.sctp.oio.OioSctpChannel
-
- isActive() - Method in class io.netty.channel.sctp.oio.OioSctpServerChannel
-
- 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 class io.netty.util.concurrent.SingleThreadEventExecutor.DefaultThreadProperties
-
- isAlive() - Method in interface io.netty.util.concurrent.ThreadProperties
-
- isAllowHalfClosure(ChannelConfig) - Method in class io.netty.channel.kqueue.AbstractKQueueChannel
-
- 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
- isAndroid() - Static method in class io.netty.util.internal.PlatformDependent0
-
- isAndroid0() - Static method in class io.netty.util.internal.PlatformDependent0
-
- isAscii(ByteBuf, int, int) - Static method in class io.netty.buffer.ByteBufUtil
-
Returns
true
if the specified
ByteBuf
starting at
index
with
length
is valid
ASCII text, otherwise return
false
.
- 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
-
- 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.kqueue.KQueue
-
- isBroadcast() - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
-
- isBroadcast() - Method in interface io.netty.channel.socket.DatagramChannelConfig
-
Gets the StandardSocketOptions.SO_BROADCAST
option.
- isBroadcast() - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
-
- isBroadcast() - Method in class io.netty.channel.unix.Socket
-
- isBroadcast(int) - Static 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.
- isBufferCopyNeededForWrite(ByteBuf, int) - Static method in class io.netty.channel.unix.UnixChannelUtil
-
- isCancellable() - Method in class io.netty.channel.group.VoidChannelGroupFuture
-
- isCancellable() - Method in class io.netty.channel.VoidChannelPromise
-
- 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
-
- isCancelled() - Method in class io.netty.channel.group.VoidChannelGroupFuture
-
- isCancelled() - Method in class io.netty.channel.VoidChannelPromise
-
- isCancelled() - Method in class io.netty.util.concurrent.CompleteFuture
-
- isCancelled() - Method in class io.netty.util.concurrent.DefaultPromise
-
- isCancelled() - Method in class io.netty.util.HashedWheelTimer.HashedWheelTimeout
-
- isCancelled() - Method in interface io.netty.util.Timeout
-
Returns
true
if and only if the
TimerTask
associated
with this handle has been cancelled.
- isCancelled0(Object) - Static method in class io.netty.util.concurrent.DefaultPromise
-
- isCDATABlockStart(ByteBuf, int) - Static method in class io.netty.handler.codec.xml.XmlFrameDecoder
-
- isCleanSession - Variable in class io.netty.handler.codec.mqtt.MqttConnectVariableHeader
-
- isCleanSession() - Method in class io.netty.handler.codec.mqtt.MqttConnectVariableHeader
-
- isClient() - Method in class io.netty.handler.ssl.DelegatingSslContext
-
- isClient - Variable in class io.netty.handler.ssl.JdkSslContext
-
- 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(int) - Static method in class io.netty.channel.unix.FileDescriptor
-
- 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.
- isCommentBlockStart(ByteBuf, int) - Static method in class io.netty.handler.codec.xml.XmlFrameDecoder
-
- 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.kqueue.AbstractKQueueChannel
-
- 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
-
- isComplete() - Method in class com.sun.nio.sctp.MessageInfo
-
- isComplete() - Method in class io.netty.channel.sctp.SctpMessage
-
Return true
if this message is complete.
- isCompressed - Variable in class io.netty.handler.codec.compression.FastLzFrameDecoder
-
Indicates is this chunk compressed or not.
- isConnected() - Method in class io.netty.channel.kqueue.KQueueDatagramChannel
-
- isConnected() - Method in interface io.netty.channel.socket.DatagramChannel
-
- isConnected() - Method in class io.netty.channel.socket.nio.NioDatagramChannel
-
- isConnected() - Method in class io.netty.channel.socket.oio.OioDatagramChannel
-
- isContentExpected() - Method in class io.netty.handler.codec.smtp.SmtpCommand
-
- 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 class io.netty.util.concurrent.SingleThreadEventExecutor.DefaultThreadProperties
-
- isDaemon() - Method in interface io.netty.util.concurrent.ThreadProperties
-
- isDebugEnabled() - Method in class io.netty.util.internal.logging.CommonsLogger
-
Deprecated.
Delegates to the Log.isDebugEnabled()
method of the underlying
Log
instance.
- isDebugEnabled() - Method in interface io.netty.util.internal.logging.InternalLogger
-
Is the logger instance enabled for the DEBUG level?
- isDebugEnabled() - Method in class io.netty.util.internal.logging.JdkLogger
-
Is this logger instance enabled for the FINE level?
- isDebugEnabled() - Method in class io.netty.util.internal.logging.Log4JLogger
-
Is this logger instance enabled for the DEBUG level?
- isDebugEnabled() - Method in class io.netty.util.internal.logging.Slf4JLogger
-
- isDecodeIdn() - Method in class io.netty.resolver.dns.DnsNameResolver
-
- isDelim(char) - Static method in class io.netty.handler.codec.DateFormatter
-
- isDestroyed() - Method in class io.netty.handler.ssl.PemPrivateKey
-
NOTE: This is a JDK8 interface/method.
- isDigit(char) - Static method in class io.netty.handler.codec.DateFormatter
-
- isDirect() - Method in class io.netty.buffer.AbstractPooledDerivedByteBuf
-
- isDirect() - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- 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.FixedCompositeByteBuf
-
- isDirect() - Method in class io.netty.buffer.PoolArena.DirectArena
-
- isDirect() - Method in class io.netty.buffer.PoolArena.HeapArena
-
- isDirect() - Method in class io.netty.buffer.PoolArena
-
- isDirect() - Method in class io.netty.buffer.PooledDirectByteBuf
-
- isDirect() - Method in class io.netty.buffer.PooledHeapByteBuf
-
- isDirect() - Method in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- isDirect() - Method in class io.netty.buffer.ReadOnlyByteBuf
-
Deprecated.
- isDirect() - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- 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
-
- isDirect() - Method in class io.netty.buffer.WrappedByteBuf
-
- isDirect() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- isDirect() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- 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
-
- isDirectBufferPooled() - Method in class io.netty.channel.local.PreferHeapByteBufAllocator
-
- 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.channel.group.VoidChannelGroupFuture
-
- isDone() - Method in class io.netty.channel.VoidChannelPromise
-
- isDone() - Method in class io.netty.util.concurrent.CompleteFuture
-
- isDone() - Method in class io.netty.util.concurrent.DefaultPromise
-
- isDone0(Object) - Static method in class io.netty.util.concurrent.DefaultPromise
-
- isDoubleQuote(char) - Static method in class io.netty.util.internal.StringUtil
-
- isDup - Variable in class io.netty.handler.codec.mqtt.MqttFixedHeader
-
- isDup() - Method in class io.netty.handler.codec.mqtt.MqttFixedHeader
-
- isEmpty() - Method in class io.netty.channel.ChannelOutboundBuffer
-
- 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.kqueue.NativeLongArray
-
- 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
-
- isEmpty() - Method in class io.netty.handler.codec.compression.Bzip2BlockCompressor
-
Determines if any bytes have been written to the block.
- 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
-
- isEmpty() - Method in class io.netty.handler.codec.HeadersUtils.DelegatingStringSet
-
- isEmpty() - Method in class io.netty.handler.codec.serialization.ReferenceMap
-
- isEmpty() - Method in class io.netty.util.AsciiString
-
Determine if this instance has 0 length.
- isEmpty() - Method in class io.netty.util.collection.ByteCollections.EmptyMap
-
- isEmpty() - Method in class io.netty.util.collection.ByteCollections.UnmodifiableMap
-
- isEmpty() - Method in class io.netty.util.collection.ByteObjectHashMap
-
- isEmpty() - Method in class io.netty.util.collection.CharCollections.EmptyMap
-
- isEmpty() - Method in class io.netty.util.collection.CharCollections.UnmodifiableMap
-
- isEmpty() - Method in class io.netty.util.collection.CharObjectHashMap
-
- isEmpty() - Method in class io.netty.util.collection.IntCollections.EmptyMap
-
- isEmpty() - Method in class io.netty.util.collection.IntCollections.UnmodifiableMap
-
- isEmpty() - Method in class io.netty.util.collection.IntObjectHashMap
-
- isEmpty() - Method in class io.netty.util.collection.LongCollections.EmptyMap
-
- isEmpty() - Method in class io.netty.util.collection.LongCollections.UnmodifiableMap
-
- isEmpty() - Method in class io.netty.util.collection.LongObjectHashMap
-
- isEmpty() - Method in class io.netty.util.collection.ShortCollections.EmptyMap
-
- isEmpty() - Method in class io.netty.util.collection.ShortCollections.UnmodifiableMap
-
- 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
-
- isErrorEnabled() - Method in class io.netty.util.internal.logging.CommonsLogger
-
Deprecated.
Delegates to the Log.isErrorEnabled()
method of the underlying
Log
instance.
- isErrorEnabled() - Method in interface io.netty.util.internal.logging.InternalLogger
-
Is the logger instance enabled for the ERROR level?
- isErrorEnabled() - Method in class io.netty.util.internal.logging.JdkLogger
-
Is this logger instance enabled for level SEVERE?
- isErrorEnabled() - Method in class io.netty.util.internal.logging.Log4JLogger
-
Is this logger instance enabled for level ERROR?
- isErrorEnabled() - Method in class io.netty.util.internal.logging.Slf4JLogger
-
- isExpired() - Method in class io.netty.util.HashedWheelTimer.HashedWheelTimeout
-
- isExpired() - Method in interface io.netty.util.Timeout
-
Returns
true
if and only if the
TimerTask
associated
with this handle has been expired.
- isExplicitNoUnsafe() - Static method in class io.netty.util.internal.PlatformDependent0
-
- 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
- isFlushedEntry(ChannelOutboundBuffer.Entry) - Method in class io.netty.channel.ChannelOutboundBuffer
-
- isFlushPending() - Method in class io.netty.channel.nio.AbstractNioChannel.AbstractNioUnsafe
-
- isFull() - Method in class io.netty.handler.codec.compression.Bzip2BlockCompressor
-
Determines if the block is full and ready for compression.
- isHandlerActive(ChannelHandlerContext) - Static method in class io.netty.handler.traffic.AbstractTrafficShapingHandler
-
- isHandlingOversizedMessage() - Method in class io.netty.handler.codec.MessageAggregator
-
- isHealthy(Channel) - Method in interface io.netty.channel.pool.ChannelHealthChecker
-
Check if the given channel is healthy which means it can be used.
- isInbound(ChannelHandler) - Static method in class io.netty.channel.DefaultChannelHandlerContext
-
- isInboundDone() - Method in class io.netty.handler.ssl.JdkSslEngine
-
- isIndexedVariableSet(int) - Method in class io.netty.util.internal.InternalThreadLocalMap
-
- isInfoEnabled() - Method in class io.netty.util.internal.logging.CommonsLogger
-
Deprecated.
Delegates to the Log.isInfoEnabled()
method of the underlying
Log
instance.
- isInfoEnabled() - Method in interface io.netty.util.internal.logging.InternalLogger
-
Is the logger instance enabled for the INFO level?
- isInfoEnabled() - Method in class io.netty.util.internal.logging.JdkLogger
-
Is this logger instance enabled for the INFO level?
- isInfoEnabled() - Method in class io.netty.util.internal.logging.Log4JLogger
-
Is this logger instance enabled for the INFO level?
- isInfoEnabled() - Method in class io.netty.util.internal.logging.Slf4JLogger
-
- 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.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(int) - Static method in class io.netty.channel.unix.FileDescriptor
-
- 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
-
- isInterrupted() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor.DefaultThreadProperties
-
- isInterrupted() - Method in interface io.netty.util.concurrent.ThreadProperties
-
- 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.
- isJ2OCached(String, String) - Static method in class io.netty.handler.ssl.CipherSuiteConverter
-
Tests if the specified key-value pair has been cached in Java-to-OpenSSL cache.
- 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
-
Gets the StandardSocketOptions.SO_KEEPALIVE
option.
- isKeepAlive() - Method in class io.netty.channel.unix.Socket
-
- isKeepAlive(int) - Static 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
-
- isLineBased(ByteBuf[]) - Static method in class io.netty.handler.codec.DelimiterBasedFrameDecoder
-
Returns true if the delimiters are "\n" and "\r\n".
- isLoopbackModeDisabled() - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
-
- isLoopbackModeDisabled() - Method in interface io.netty.channel.socket.DatagramChannelConfig
-
Gets the StandardSocketOptions.IP_MULTICAST_LOOP
option.
- isLoopbackModeDisabled() - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
-
- isLoopbackModeDisabled() - Method in class io.netty.channel.socket.nio.NioDatagramChannelConfig
-
- isLowerCase(byte) - Static method in class io.netty.util.AsciiString
-
- isNonServerChannel() - Static method in class io.netty.channel.group.ChannelMatchers
-
- isNot(Channel) - Static method in class io.netty.channel.group.ChannelMatchers
-
- isNotEmpty(Queue<Object>) - Static method in class io.netty.channel.embedded.EmbeddedChannel
-
- isNotInstanceOf(Class<? extends Channel>) - Static method in class io.netty.channel.group.ChannelMatchers
-
Returns a
ChannelMatcher
that matches all
Channel
s that are
not an
instance of sub-type of the given class.
- isNotValidPromise(ChannelPromise, boolean) - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- 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(Queue<ScheduledFutureTask<?>>) - Static method in class io.netty.util.concurrent.AbstractScheduledEventExecutor
-
- isNullOrEmpty(String) - Static method in class io.netty.util.internal.StringUtil
-
Determine if a string is null
or String.isEmpty()
returns true
.
- isO2JCached(String, String, String) - Static method in class io.netty.handler.ssl.CipherSuiteConverter
-
Tests if the specified key-value pair has been cached in OpenSSL-to-Java cache.
- 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.kqueue.AbstractKQueueChannel
-
- 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.nio.SelectedSelectionKeySetSelector
-
- isOpen() - Method in class io.netty.channel.sctp.oio.OioSctpChannel
-
- isOpen() - Method in class io.netty.channel.sctp.oio.OioSctpServerChannel
-
- 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.
- isOSX() - Static method in class io.netty.util.internal.NativeLibraryLoader
-
- isOutbound(ChannelHandler) - Static method in class io.netty.channel.DefaultChannelHandlerContext
-
- isOutboundDone() - Method in class io.netty.handler.ssl.JdkSslEngine
-
- 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.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(int) - Static method in class io.netty.channel.unix.FileDescriptor
-
- isOutputShutdown() - Method in class io.netty.channel.unix.Socket
-
- isOws(char) - Static method in class io.netty.util.internal.StringUtil
-
- 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.
- isPartialFailure() - Method in class io.netty.channel.group.DefaultChannelGroupFuture
-
- isPartialFailure() - Method in class io.netty.channel.group.VoidChannelGroupFuture
-
- 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.
- isPartialSuccess() - Method in class io.netty.channel.group.DefaultChannelGroupFuture
-
- isPartialSuccess() - Method in class io.netty.channel.group.VoidChannelGroupFuture
-
- isPeriodic() - Method in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor.RunnableScheduledFutureTask
-
- isPowerOfTwo(int) - Static method in class io.netty.util.concurrent.DefaultEventExecutorChooserFactory
-
- isPP2ClientCertConn() - Method in class io.netty.handler.codec.haproxy.HAProxySSLTLV
-
Returns true
if the bit field for PP2_CLIENT_CERT_CONN was set
- isPP2ClientCertSess() - Method in class io.netty.handler.codec.haproxy.HAProxySSLTLV
-
Returns true
if the bit field for PP2_CLIENT_CERT_SESS was set
- isPP2ClientSSL() - Method in class io.netty.handler.codec.haproxy.HAProxySSLTLV
-
Returns true
if the bit field for PP2_CLIENT_SSL was set
- isPreferDirect() - Method in class io.netty.handler.codec.MessageToByteEncoder
-
- isQueueEmpty() - Method in class io.netty.handler.flow.FlowControlHandler
-
Determine if the underlying Queue
is empty.
- 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.
- isReadable() - Method in class io.netty.buffer.WrappedByteBuf
-
- isReadable(int) - Method in class io.netty.buffer.WrappedByteBuf
-
- isReadable() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- isReadable(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- isReadable() - Method in class io.netty.handler.codec.compression.Bzip2BitReader
-
Checks that at least one bit is available for reading.
- isReadable() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- isReadable(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- isReadOnly() - Method in class io.netty.buffer.AbstractByteBuf
-
- isReadOnly() - Method in class io.netty.buffer.AbstractDerivedByteBuf
-
Deprecated.
- isReadOnly() - Method in class io.netty.buffer.AbstractPooledDerivedByteBuf
-
- isReadOnly() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.ReadOnlyByteBufferBuf
-
- isReadOnly() - Method in class io.netty.buffer.SwappedByteBuf
-
Deprecated.
- isReadOnly() - Method in class io.netty.buffer.WrappedByteBuf
-
- isReadOnly() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- isReadOnly() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- isReadPending() - Method in class io.netty.channel.nio.AbstractNioChannel
-
- isReadPending() - Method in class io.netty.channel.oio.AbstractOioChannel
-
- 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
-
- isRemoved() - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- isRemoved() - Method in interface io.netty.channel.ChannelHandlerContext
-
- isRemoved() - Method in class io.netty.channel.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- 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 - Variable in class io.netty.handler.codec.mqtt.MqttFixedHeader
-
- isRetain() - Method in class io.netty.handler.codec.mqtt.MqttFixedHeader
-
- 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
-
Gets the StandardSocketOptions.SO_REUSEADDR
option.
- 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
-
Gets the StandardSocketOptions.SO_REUSEADDR
option.
- isReuseAddress() - Method in interface io.netty.channel.socket.SocketChannelConfig
-
Gets the StandardSocketOptions.SO_REUSEADDR
option.
- isReuseAddress() - Method in class io.netty.channel.unix.Socket
-
- isReuseAddress(int) - Static method in class io.netty.channel.unix.Socket
-
- 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
-
- isReusePort(int) - Static method in class io.netty.channel.unix.Socket
-
- isRootServer() - Method in class io.netty.resolver.dns.DnsNameResolverContext.AuthoritativeNameServer
-
Returns true
if its a root server.
- isSctpNoDelay() - Method in class io.netty.channel.sctp.DefaultSctpChannelConfig
-
- isSctpNoDelay() - Method in interface io.netty.channel.sctp.SctpChannelConfig
-
- isSensitive() - Method in interface io.netty.handler.ssl.PemEncoded
-
Returns true
if the PEM encoded value is considered
sensitive information such as a private key.
- isSensitive() - Method in class io.netty.handler.ssl.PemPrivateKey
-
- isSensitive() - Method in class io.netty.handler.ssl.PemValue
-
- 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
-
- 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
ChannelPipeline
s.
- 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.embedded.EmbeddedEventLoop
-
- 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.NonStickyEventExecutorGroup.NonStickyOrderedEventExecutor
-
- isShutdown() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- isShuttingDown() - Method in class io.netty.channel.embedded.EmbeddedEventLoop
-
- isShuttingDown() - Method in class io.netty.channel.ThreadPerChannelEventLoopGroup
-
- isShuttingDown() - Method in interface io.netty.util.concurrent.EventExecutorGroup
-
- 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.NonStickyEventExecutorGroup.NonStickyOrderedEventExecutor
-
- 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
-
- isSingleDecode() - Method in class io.netty.handler.codec.haproxy.HAProxyMessageDecoder
-
- isSingleDirectBuffer(ByteBuf) - Static method in class io.netty.channel.socket.nio.NioDatagramChannel
-
Checks if the specified buffer is a direct buffer and is composed of a single NIO buffer.
- isSoErrorZero(BsdSocket) - Static method in class io.netty.channel.kqueue.AbstractKQueueChannel
-
- 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
-
- isSubclass() - Method in class io.netty.handler.codec.DelimiterBasedFrameDecoder
-
Return true
if the current instance is a subclass of DelimiterBasedFrameDecoder
- isSuccess() - Method in class io.netty.channel.FailedChannelFuture
-
- 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.channel.group.VoidChannelGroupFuture
-
- isSuccess() - Method in class io.netty.channel.SucceededChannelFuture
-
- isSuccess() - Method in class io.netty.channel.VoidChannelPromise
-
- isSuccess() - Method in class io.netty.handler.codec.DecoderResult
-
- isSuccess() - Method in class io.netty.handler.codec.socksx.v4.Socks4CommandStatus
-
- isSuccess() - Method in class io.netty.handler.codec.socksx.v5.Socks5CommandStatus
-
- isSuccess() - Method in class io.netty.handler.codec.socksx.v5.Socks5PasswordAuthStatus
-
- 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.
- isSupported() - Static method in class io.netty.util.internal.CleanerJava6
-
- isSupported() - Static method in class io.netty.util.internal.CleanerJava9
-
- 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
-
- 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
-
Gets the StandardSocketOptions.TCP_NODELAY
option.
- isTcpNoDelay() - Method in class io.netty.channel.unix.Socket
-
- isTcpNoDelay(int) - Static method in class io.netty.channel.unix.Socket
-
- isTcpNoPush() - Method in class io.netty.channel.kqueue.BsdSocket
-
- isTcpNoPush() - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
-
- isTerminated() - Method in class io.netty.channel.embedded.EmbeddedEventLoop
-
- 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.NonStickyEventExecutorGroup.NonStickyOrderedEventExecutor
-
- 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
.
- isTiny(int) - Static method in class io.netty.buffer.PoolArena
-
- isTinyOrSmall(int) - Method in class io.netty.buffer.PoolArena
-
- isTraceCapable() - Method in class io.netty.util.internal.logging.Log4JLogger
-
- isTraceEnabled() - Method in class io.netty.util.internal.logging.CommonsLogger
-
Deprecated.
Delegates to the Log.isTraceEnabled()
method of the underlying
Log
instance.
- isTraceEnabled() - Method in interface io.netty.util.internal.logging.InternalLogger
-
Is the logger instance enabled for the TRACE level?
- isTraceEnabled() - Method in class io.netty.util.internal.logging.JdkLogger
-
Is this logger instance enabled for the FINEST level?
- isTraceEnabled() - Method in class io.netty.util.internal.logging.Log4JLogger
-
Is this logger instance enabled for the TRACE level?
- isTraceEnabled() - Method in class io.netty.util.internal.logging.Slf4JLogger
-
- 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.
- isUnaligned() - Static method in class io.netty.util.internal.PlatformDependent0
-
- isUnordered() - Method in class com.sun.nio.sctp.MessageInfo
-
- isUnordered() - Method in class io.netty.channel.sctp.SctpMessage
-
return the unordered flag
- isUpperCase(byte) - Static method in class io.netty.util.AsciiString
-
- isUpperCase(char) - Static method in class io.netty.util.AsciiString
-
- isUtf8(ByteBuf, int, int) - Static method in class io.netty.buffer.ByteBufUtil
-
Returns
true
if the specified
ByteBuf
starting at
index
with
length
is valid
UTF8 text, otherwise return
false
.
- isValid() - Method in class io.netty.handler.ssl.JdkSslSession
-
- isValidClientId(MqttVersion, String) - Static method in class io.netty.handler.codec.mqtt.MqttCodecUtil
-
- isValidHexChar(char) - Static method in class io.netty.util.NetUtil
-
- 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.
- isValidIpV4Address(String, int, int) - Static method in class io.netty.util.NetUtil
-
- isValidIPv4Mapped(byte[], int, int, int) - Static method in class io.netty.util.NetUtil
-
- isValidIPv4MappedChar(char) - Static method in class io.netty.util.NetUtil
-
- isValidIPv4MappedSeparators(byte, byte, boolean) - Static method in class io.netty.util.NetUtil
-
- isValidIpV4Word(CharSequence, int, int) - Static method in class io.netty.util.NetUtil
-
- isValidIpV6Address(String) - Static method in class io.netty.util.NetUtil
-
- isValidMessageId(int) - Static method in class io.netty.handler.codec.mqtt.MqttCodecUtil
-
- isValidNumericChar(char) - Static method in class io.netty.util.NetUtil
-
- isValidPublishTopicName(String) - Static method in class io.netty.handler.codec.mqtt.MqttCodecUtil
-
- isValidStartCharForXmlElement(byte) - Static method in class io.netty.handler.codec.xml.XmlFrameDecoder
-
Asks whether the given byte is a valid
start char for an xml element name.
- isVoid() - Method in interface io.netty.channel.ChannelFuture
-
- isVoid() - Method in class io.netty.channel.CompleteChannelFuture
-
- isVoid() - Method in class io.netty.channel.DefaultChannelProgressivePromise
-
- isVoid() - Method in class io.netty.channel.DefaultChannelPromise
-
- isVoid() - Method in class io.netty.channel.VoidChannelPromise
-
- isWarnEnabled() - Method in class io.netty.util.internal.logging.CommonsLogger
-
Deprecated.
Delegates to the Log.isWarnEnabled()
method of the underlying
Log
instance.
- isWarnEnabled() - Method in interface io.netty.util.internal.logging.InternalLogger
-
Is the logger instance enabled for the WARN level?
- isWarnEnabled() - Method in class io.netty.util.internal.logging.JdkLogger
-
Is this logger instance enabled for the WARNING level?
- isWarnEnabled() - Method in class io.netty.util.internal.logging.Log4JLogger
-
Is this logger instance enabled for the WARN level?
- isWarnEnabled() - Method in class io.netty.util.internal.logging.Slf4JLogger
-
- isWatch - Variable in class io.netty.util.ThreadDeathWatcher.Entry
-
- isWillFlag - Variable in class io.netty.handler.codec.mqtt.MqttConnectVariableHeader
-
- isWillFlag() - Method in class io.netty.handler.codec.mqtt.MqttConnectVariableHeader
-
- isWillRetain - Variable 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.NativeLibraryLoader
-
- isWindows() - Static method in class io.netty.util.internal.PlatformDependent
-
Return true
if the JVM is running on Windows
- isWindows0() - Static method in class io.netty.util.internal.PlatformDependent
-
- 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.FixedCompositeByteBuf
-
- isWritable(int) - Method in class io.netty.buffer.FixedCompositeByteBuf
-
- 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.buffer.WrappedByteBuf
-
- isWritable(int) - Method in class io.netty.buffer.WrappedByteBuf
-
- isWritable() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- isWritable(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- 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
-
- isWritable() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- isWritable(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- isZero(byte[], int, int) - Static method in class io.netty.util.internal.PlatformDependent
-
Determine if a subsection of an array is zero.
- isZero(byte[], int, int) - Static method in class io.netty.util.internal.PlatformDependent0
-
- isZeroSafe(byte[], int, int) - Static method in class io.netty.util.internal.PlatformDependent
-
- iter - Variable in class io.netty.handler.codec.HeadersUtils.StringEntryIterator
-
- iter - Variable in class io.netty.handler.codec.HeadersUtils.StringIterator
-
- iter - Variable in class io.netty.util.collection.ByteCollections.UnmodifiableMap.IteratorImpl
-
- iter - Variable in class io.netty.util.collection.ByteObjectHashMap.MapIterator
-
- iter - Variable in class io.netty.util.collection.CharCollections.UnmodifiableMap.IteratorImpl
-
- iter - Variable in class io.netty.util.collection.CharObjectHashMap.MapIterator
-
- iter - Variable in class io.netty.util.collection.IntCollections.UnmodifiableMap.IteratorImpl
-
- iter - Variable in class io.netty.util.collection.IntObjectHashMap.MapIterator
-
- iter - Variable in class io.netty.util.collection.LongCollections.UnmodifiableMap.IteratorImpl
-
- iter - Variable in class io.netty.util.collection.LongObjectHashMap.MapIterator
-
- iter - Variable in class io.netty.util.collection.ShortCollections.UnmodifiableMap.IteratorImpl
-
- iter - Variable in class io.netty.util.collection.ShortObjectHashMap.MapIterator
-
- iterator() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- iterator() - Method in class io.netty.buffer.CompositeByteBuf
-
- iterator() - Method in class io.netty.buffer.PoolChunkList
-
- iterator() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- 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
ChannelFuture
s
which are associated with this future.
- iterator() - Method in class io.netty.channel.group.DefaultChannelGroup
-
- iterator() - Method in class io.netty.channel.group.DefaultChannelGroupFuture
-
- iterator() - Method in class io.netty.channel.group.VoidChannelGroupFuture
-
- iterator() - Method in class io.netty.channel.nio.SelectedSelectionKeySet
-
- 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.handler.codec.HeadersUtils.DelegatingStringSet
-
- iterator() - Method in class io.netty.resolver.dns.DnsNameResolverContext.DnsCacheIterable
-
- iterator() - Method in class io.netty.util.collection.ByteObjectHashMap.EntrySet
-
- iterator() - Method in class io.netty.util.collection.ByteObjectHashMap.KeySet
-
- iterator() - Method in class io.netty.util.collection.CharObjectHashMap.EntrySet
-
- iterator() - Method in class io.netty.util.collection.CharObjectHashMap.KeySet
-
- iterator() - Method in class io.netty.util.collection.IntObjectHashMap.EntrySet
-
- iterator() - Method in class io.netty.util.collection.IntObjectHashMap.KeySet
-
- iterator() - Method in class io.netty.util.collection.LongObjectHashMap.EntrySet
-
- iterator() - Method in class io.netty.util.collection.LongObjectHashMap.KeySet
-
- iterator() - Method in class io.netty.util.collection.ShortObjectHashMap.EntrySet
-
- iterator() - Method in class io.netty.util.collection.ShortObjectHashMap.KeySet
-
- 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
-
- iterator - Variable in class io.netty.util.internal.ReadOnlyIterator
-
- iteratorAsString(Iterable<Map.Entry<CharSequence, CharSequence>>) - Static method in class io.netty.handler.codec.HeadersUtils
-
- iteratorAsString() - Method in class io.netty.handler.codec.stomp.DefaultStompHeaders
-
- iteratorAsString() - Method in interface io.netty.handler.codec.stomp.StompHeaders
-
- IteratorImpl(Iterator<ByteObjectMap.PrimitiveEntry<V>>) - Constructor for class io.netty.util.collection.ByteCollections.UnmodifiableMap.IteratorImpl
-
- IteratorImpl(Iterator<CharObjectMap.PrimitiveEntry<V>>) - Constructor for class io.netty.util.collection.CharCollections.UnmodifiableMap.IteratorImpl
-
- IteratorImpl(Iterator<IntObjectMap.PrimitiveEntry<V>>) - Constructor for class io.netty.util.collection.IntCollections.UnmodifiableMap.IteratorImpl
-
- IteratorImpl(Iterator<LongObjectMap.PrimitiveEntry<V>>) - Constructor for class io.netty.util.collection.LongCollections.UnmodifiableMap.IteratorImpl
-
- IteratorImpl(Iterator<ShortObjectMap.PrimitiveEntry<V>>) - Constructor for class io.netty.util.collection.ShortCollections.UnmodifiableMap.IteratorImpl
-
- 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.
- last() - Method in interface io.netty.channel.ChannelPipeline
-
- last() - Method in class io.netty.channel.DefaultChannelPipeline
-
- last - Variable in class io.netty.handler.codec.compression.Bzip2DivSufSort.PartitionResult
-
- LastBulkStringRedisContent - Interface in io.netty.handler.codec.redis
-
A last chunk of Bulk Strings.
- lastBytesRead - Variable in class io.netty.channel.DefaultMaxBytesRecvByteBufAllocator.HandleImpl
-
- lastBytesRead(int) - Method in class io.netty.channel.DefaultMaxBytesRecvByteBufAllocator.HandleImpl
-
- lastBytesRead() - Method in class io.netty.channel.DefaultMaxBytesRecvByteBufAllocator.HandleImpl
-
- lastBytesRead - Variable in class io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator.MaxMessageHandle
-
- 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.kqueue.KQueueRecvByteAllocatorHandle
-
- lastBytesRead() - Method in class io.netty.channel.kqueue.KQueueRecvByteAllocatorHandle
-
- 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.
- lastChangeCheckTimeStamp - Variable in class io.netty.handler.timeout.IdleStateHandler
-
- lastContent - Variable in class io.netty.handler.codec.stomp.StompSubframeDecoder
-
- lastContext() - Method in interface io.netty.channel.ChannelPipeline
-
- lastContext() - Method in class io.netty.channel.DefaultChannelPipeline
-
- lastCumulativeTime - Variable in class io.netty.handler.traffic.TrafficCounter
-
Last Time where cumulative bytes where reset to zero: this time is a real EPOC time (informative only)
- lastCumulativeTime() - Method in class io.netty.handler.traffic.TrafficCounter
-
- lastException - Variable in class io.netty.channel.embedded.EmbeddedChannel
-
- lastExecutionTime - Variable in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- lastInboundBuffer() - Method in class io.netty.channel.embedded.EmbeddedChannel
-
- lastIndexOf(ByteBuf, int, int, byte) - Static method in class io.netty.buffer.ByteBufUtil
-
- 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
-
- lastMessageHashCode - Variable in class io.netty.handler.timeout.IdleStateHandler
-
- lastOutboundBuffer() - Method in class io.netty.channel.embedded.EmbeddedChannel
-
- lastPendingWriteBytes - Variable in class io.netty.handler.timeout.IdleStateHandler
-
- lastReadBytes - Variable in class io.netty.handler.traffic.TrafficCounter
-
Last read bytes number during last check interval
- lastReadBytes() - Method in class io.netty.handler.traffic.TrafficCounter
-
- lastReaderIndex - Variable in class io.netty.handler.codec.json.JsonObjectDecoder
-
- lastReadingTime - Variable in class io.netty.handler.traffic.TrafficCounter
-
Last reading time during last check interval
- lastReadThroughput - Variable in class io.netty.handler.traffic.TrafficCounter
-
Last reading bandwidth
- lastReadThroughput() - Method in class io.netty.handler.traffic.TrafficCounter
-
- lastReadTime - Variable in class io.netty.handler.timeout.IdleStateHandler
-
- lastReadTimestamp - Variable in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler.PerChannel
-
- lastReadTimestamp - Variable in class io.netty.handler.traffic.GlobalTrafficShapingHandler.PerChannel
-
- lastRecords - Variable in class io.netty.util.ResourceLeakDetector.DefaultResourceLeak
-
- lastRecycledId - Variable in class io.netty.util.Recycler.DefaultHandle
-
- LastSmtpContent - Interface in io.netty.handler.codec.smtp
-
The last part of a sequence of
SmtpContent
s that are sent after a
DATA
request.
- LastStompContentSubframe - Interface in io.netty.handler.codec.stomp
-
- lastTask - Variable in class io.netty.handler.timeout.WriteTimeoutHandler
-
A doubly-linked list to track all WriteTimeoutTasks
- lastTime - Variable in class io.netty.handler.traffic.TrafficCounter
-
Last Time Check taken
- lastTime() - Method in class io.netty.handler.traffic.TrafficCounter
-
- lastVariableIndex() - Static method in class io.netty.util.internal.InternalThreadLocalMap
-
- lastWriteThroughput - Variable in class io.netty.handler.traffic.TrafficCounter
-
Last writing bandwidth
- lastWriteThroughput() - Method in class io.netty.handler.traffic.TrafficCounter
-
- lastWriteTime - Variable in class io.netty.handler.timeout.IdleStateHandler
-
- lastWriteTimestamp - Variable in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler.PerChannel
-
- lastWriteTimestamp - Variable in class io.netty.handler.traffic.GlobalTrafficShapingHandler.PerChannel
-
- lastWritingTime - Variable in class io.netty.handler.traffic.TrafficCounter
-
Last future writing time during last check interval
- lastWrittenBytes - Variable in class io.netty.handler.traffic.TrafficCounter
-
Last written bytes number during last check interval
- lastWrittenBytes() - Method in class io.netty.handler.traffic.TrafficCounter
-
- LazyChannelPromise() - Constructor for class io.netty.handler.ssl.SslHandler.LazyChannelPromise
-
- leak - Variable in class io.netty.buffer.SimpleLeakAwareByteBuf
-
- leak - Variable in class io.netty.buffer.SimpleLeakAwareCompositeByteBuf
-
- leak - Variable in class io.netty.handler.codec.dns.AbstractDnsMessage
-
- leak - Variable in class io.netty.util.HashedWheelTimer
-
- leakDetector - Static variable in class io.netty.buffer.AbstractByteBuf
-
- leakDetector - Static variable in class io.netty.handler.codec.dns.AbstractDnsMessage
-
- leakDetector - Static variable in class io.netty.util.HashedWheelTimer
-
- LeakEntry() - Constructor for class io.netty.util.ResourceLeakDetector.LeakEntry
-
- leastUsedArena(PoolArena<T>[]) - Method in class io.netty.buffer.PooledByteBufAllocator.PoolThreadLocalCache
-
- 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.buffer.AbstractUnpooledSlicedByteBuf
-
- length - Variable in class io.netty.buffer.CompositeByteBuf.Component
-
- length - Variable in class io.netty.buffer.PooledByteBuf
-
- length - Variable in class io.netty.buffer.SlicedByteBuf
-
Deprecated.
- length() - Method in class io.netty.buffer.SlicedByteBuf
-
Deprecated.
- length - Variable in class io.netty.handler.codec.redis.ArrayHeaderRedisMessage
-
- length() - Method in class io.netty.handler.codec.redis.ArrayHeaderRedisMessage
-
Get length of this array object.
- length - Variable in class io.netty.handler.codec.redis.RedisArrayAggregator.AggregateState
-
- 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 - Variable in class io.netty.util.AsciiString
-
- 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.
- LENGTH_PLACEHOLDER - Static variable in class io.netty.handler.codec.serialization.ObjectEncoder
-
- lengthAdjustment - Variable in class io.netty.handler.codec.LengthFieldBasedFrameDecoder
-
- lengthAdjustment - Variable in class io.netty.handler.codec.LengthFieldPrepender
-
- LengthFieldBasedFrameDecoder - Class in io.netty.handler.codec
-
A decoder that splits the received
ByteBuf
s 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.
- lengthFieldEndOffset - Variable in class io.netty.handler.codec.LengthFieldBasedFrameDecoder
-
- lengthFieldLength - Variable in class io.netty.handler.codec.LengthFieldBasedFrameDecoder
-
- lengthFieldLength - Variable in class io.netty.handler.codec.LengthFieldPrepender
-
- lengthFieldOffset - Variable in class io.netty.handler.codec.LengthFieldBasedFrameDecoder
-
- 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.
- lengthIncludesLengthFieldLength - Variable in class io.netty.handler.codec.LengthFieldPrepender
-
- level - Variable in class io.netty.handler.codec.compression.FastLzFrameEncoder
-
Compression level.
- level - Variable in enum io.netty.handler.codec.mqtt.MqttVersion
-
- level - Variable in class io.netty.handler.logging.LoggingHandler
-
- level() - Method in class io.netty.handler.logging.LoggingHandler
-
Returns the
LogLevel
that this handler uses to log
- level - Variable in class io.netty.resolver.dns.TraceDnsQueryLifecycleObserver
-
- level - Variable in class io.netty.resolver.dns.TraceDnsQueryLifeCycleObserverFactory
-
- level - Static variable in class io.netty.util.ResourceLeakDetector
-
- Level() - Constructor for enum io.netty.util.ResourceLeakDetector.Level
-
- LEVEL_1 - Static variable in class io.netty.handler.codec.compression.FastLz
-
Level 1 is the fastest compression and generally useful for short data.
- LEVEL_2 - Static variable in class io.netty.handler.codec.compression.FastLz
-
Level 2 is slightly slower but it gives better compression ratio.
- LEVEL_AUTO - Static variable in class io.netty.handler.codec.compression.FastLz
-
- LF - Static variable in class io.netty.handler.codec.stomp.StompConstants
-
- Limits - Class in io.netty.channel.unix
-
- Limits() - Constructor for class io.netty.channel.unix.Limits
-
- LimitsStaticallyReferencedJniMethods - Class in io.netty.channel.unix
-
This class is necessary to break the following cyclic dependency:
JNI_OnLoad
JNI Calls FindClass because RegisterNatives (used to register JNI methods) requires a class
FindClass loads the class, but static members variables of that class attempt to call a JNI method which has not
yet been registered.
java.lang.UnsatisfiedLinkError is thrown because native method has not yet been registered.
Static members which call JNI methods must not be declared in this class!
- LimitsStaticallyReferencedJniMethods() - Constructor for class io.netty.channel.unix.LimitsStaticallyReferencedJniMethods
-
- LINE_FEED - Static variable in class io.netty.util.internal.StringUtil
-
- lineBasedDecoder - Variable in class io.netty.handler.codec.DelimiterBasedFrameDecoder
-
Set only when decoding with "\n" and "\r\n" as the delimiter.
- LineBasedFrameDecoder - Class in io.netty.handler.codec
-
A decoder that splits the received
ByteBuf
s 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.
- lineBuf - Variable in class io.netty.buffer.ByteBufInputStream
-
- 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 - Variable in class io.netty.handler.codec.string.LineEncoder
-
- 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
-
- Link() - Constructor for class io.netty.util.Recycler.WeakOrderQueue.Link
-
- LINK_CAPACITY - Static variable in class io.netty.util.Recycler
-
- listen(int) - Method in class io.netty.channel.unix.Socket
-
- listen(int, int) - Static method in class io.netty.channel.unix.Socket
-
- listener - Variable in class io.netty.util.concurrent.PromiseCombiner
-
- listenerFactory - Variable in class io.netty.handler.ssl.JdkBaseApplicationProtocolNegotiator
-
- listeners - Variable in class io.netty.util.concurrent.DefaultFutureListeners
-
- listeners() - Method in class io.netty.util.concurrent.DefaultFutureListeners
-
- listeners - Variable in class io.netty.util.concurrent.DefaultPromise
-
One or more listeners.
- ListResolverContext(DnsNameResolver, String, DnsRecord[], DnsCache, DnsServerAddressStream) - Constructor for class io.netty.resolver.dns.DnsNameResolver.ListResolverContext
-
- LITERAL - Static variable in class io.netty.handler.codec.compression.Snappy
-
- 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
- loadFactor - Variable in class io.netty.util.collection.ByteObjectHashMap
-
The load factor for the map.
- loadFactor - Variable in class io.netty.util.collection.CharObjectHashMap
-
The load factor for the map.
- loadFactor - Variable in class io.netty.util.collection.IntObjectHashMap
-
The load factor for the map.
- loadFactor - Variable in class io.netty.util.collection.LongObjectHashMap
-
The load factor for the map.
- loadFactor - Variable in class io.netty.util.collection.ShortObjectHashMap
-
The load factor for the map.
- loadFirstAvailable(ClassLoader, String...) - Static method in class io.netty.util.internal.NativeLibraryLoader
-
Loads the first available library in the collection with the specified
ClassLoader
.
- loadLibrary(ClassLoader, String, boolean) - Static method in class io.netty.util.internal.NativeLibraryLoader
-
Loading the native library into the specified ClassLoader
.
- loadLibrary(String, boolean) - Static method in class io.netty.util.internal.NativeLibraryUtil
-
Delegate the calling to System.load(String)
or System.loadLibrary(String)
.
- loadLibraryByHelper(Class<?>, String, boolean) - Static method in class io.netty.util.internal.NativeLibraryLoader
-
- loadNativeLibrary() - Static method in class io.netty.channel.kqueue.Native
-
- LOC - Static variable in class io.netty.handler.codec.dns.DnsRecordType
-
Location record RFC 1876 Specifies a geographical location associated
with a domain name.
- local - Variable in class io.netty.channel.kqueue.KQueueDatagramChannel
-
- local - Variable in class io.netty.channel.kqueue.KQueueDomainSocketChannel
-
- local - Variable in class io.netty.channel.kqueue.KQueueServerDomainSocketChannel
-
- local - Variable in class io.netty.channel.kqueue.KQueueServerSocketChannel
-
- local - Variable in class io.netty.channel.kqueue.KQueueSocketChannel
-
- LOCAL_ADDRESS - Static variable in class io.netty.channel.embedded.EmbeddedChannel
-
- localAddress - Variable in class io.netty.bootstrap.AbstractBootstrap
-
- 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.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 - Variable in class io.netty.channel.AbstractChannel
-
- 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.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(Channel) - Constructor for class io.netty.channel.local.LocalAddress
-
Creates a new ephemeral port based on the ID of the specified channel.
- LocalAddress(String) - Constructor for class io.netty.channel.local.LocalAddress
-
Creates a new instance with the specified ID.
- localAddress - Variable in class io.netty.channel.local.LocalChannel
-
- localAddress() - Method in class io.netty.channel.local.LocalChannel
-
- localAddress - Variable in class io.netty.channel.local.LocalServerChannel
-
- localAddress() - Method in class io.netty.channel.local.LocalServerChannel
-
- localAddress() - Method in class io.netty.channel.sctp.nio.NioSctpChannel
-
- localAddress() - Method in class io.netty.channel.sctp.nio.NioSctpServerChannel
-
- localAddress() - Method in class io.netty.channel.sctp.oio.OioSctpChannel
-
- localAddress() - Method in class io.netty.channel.sctp.oio.OioSctpServerChannel
-
- localAddress() - Method in interface io.netty.channel.sctp.SctpChannel
-
Return the (primary) local address of the SCTP channel.
- localAddress() - Method in interface io.netty.channel.sctp.SctpServerChannel
-
Return the (primary) local address of the SCTP server channel.
- 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
-
- localAddress(int) - Static 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.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.sctp.nio.NioSctpChannel
-
- localAddress0() - Method in class io.netty.channel.sctp.nio.NioSctpServerChannel
-
- localAddress0() - Method in class io.netty.channel.sctp.oio.OioSctpChannel
-
- localAddress0() - Method in class io.netty.channel.sctp.oio.OioSctpServerChannel
-
- 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
-
- LocalChannel() - Constructor for class io.netty.channel.local.LocalChannel
-
- LocalChannel(LocalServerChannel, LocalChannel) - Constructor for class io.netty.channel.local.LocalChannel
-
- LocalChannel.LocalUnsafe - Class in io.netty.channel.local
-
- LocalChannel.State - Enum in io.netty.channel.local
-
- localChannelReaderStackDepth() - Method in class io.netty.util.internal.InternalThreadLocalMap
-
- localChannelReaderStackDepth - Variable in class io.netty.util.internal.UnpaddedInternalThreadLocalMap
-
- LocalChannelRegistry - Class in io.netty.channel.local
-
- LocalChannelRegistry() - Constructor for class io.netty.channel.local.LocalChannelRegistry
-
- LocalEventLoopGroup - Class in io.netty.channel.local
-
- 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 - Variable in enum io.netty.channel.socket.InternetProtocolFamily
-
- 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.resolver.dns.DnsNameResolver
-
- 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'
- LOCALHOST_ADDRESS - Static variable in class io.netty.resolver.dns.DnsNameResolver
-
- 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
-
- LocalUnsafe() - Constructor for class io.netty.channel.local.LocalChannel.LocalUnsafe
-
- locateHostsFile() - Static method in class io.netty.resolver.HostsFileParser
-
- 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
.
- log(String, Level, String, Throwable) - Method in class io.netty.util.internal.logging.JdkLogger
-
Log the message at the specified level with the specified throwable if any.
- log2(int) - Static method in class io.netty.buffer.PoolChunk
-
- log2(int) - Static method in class io.netty.buffer.PoolThreadCache
-
- log2ChunkSize - Variable in class io.netty.buffer.PoolChunk
-
- Log4JLogger - Class in io.netty.util.internal.logging
-
- Log4JLogger(Logger) - Constructor for class io.netty.util.internal.logging.Log4JLogger
-
- Log4JLoggerFactory - Class in io.netty.util.internal.logging
-
- Log4JLoggerFactory() - Constructor for class io.netty.util.internal.logging.Log4JLoggerFactory
-
- LOG_2_TABLE - Static variable in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- logger - Static variable in class io.netty.bootstrap.Bootstrap
-
- logger - Static variable in class io.netty.bootstrap.ServerBootstrap
-
- logger - Static variable in class io.netty.buffer.AbstractByteBuf
-
- logger - Static variable in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- logger - Static variable in class io.netty.buffer.ByteBufUtil
-
- logger - Static variable in class io.netty.buffer.PooledByteBufAllocator
-
- logger - Static variable in class io.netty.buffer.PoolThreadCache
-
- logger - Static variable in class io.netty.channel.AbstractChannel
-
- logger - Static variable in class io.netty.channel.AbstractChannelHandlerContext
-
- logger - Static variable in class io.netty.channel.ChannelInitializer
-
- logger - Static variable in class io.netty.channel.ChannelOutboundBuffer
-
- logger - Static variable in class io.netty.channel.CombinedChannelDuplexHandler
-
- logger - Static variable in class io.netty.channel.DefaultChannelId
-
- logger - Static variable in class io.netty.channel.DefaultChannelPipeline
-
- logger - Static variable in class io.netty.channel.DefaultFileRegion
-
- logger - Static variable in class io.netty.channel.embedded.EmbeddedChannel
-
- logger - Static variable in class io.netty.channel.kqueue.KQueueEventLoop
-
- logger - Static variable in class io.netty.channel.kqueue.KQueueServerDomainSocketChannel
-
- logger - Static variable in class io.netty.channel.local.LocalChannel
-
- logger - Static variable in class io.netty.channel.MultithreadEventLoopGroup
-
- logger - Static variable in class io.netty.channel.nio.AbstractNioChannel
-
- logger - Static variable in class io.netty.channel.nio.NioEventLoop
-
- logger - Static variable in class io.netty.channel.PendingWriteQueue
-
- logger - Static variable in class io.netty.channel.sctp.nio.NioSctpChannel
-
- logger - Static variable in class io.netty.channel.sctp.oio.OioSctpChannel
-
- logger - Static variable in class io.netty.channel.sctp.oio.OioSctpServerChannel
-
- logger - Static variable in class io.netty.channel.socket.DefaultDatagramChannelConfig
-
- logger - Static variable in class io.netty.channel.socket.nio.NioServerSocketChannel
-
- logger - Static variable in class io.netty.channel.socket.nio.NioSocketChannel
-
- logger - Static variable in class io.netty.channel.socket.oio.OioDatagramChannel
-
- logger - Static variable in class io.netty.channel.socket.oio.OioServerSocketChannel
-
- logger - Static variable in class io.netty.channel.socket.oio.OioSocketChannel
-
- logger - Static variable in class io.netty.handler.codec.compression.ZlibCodecFactory
-
- logger - Static variable in class io.netty.handler.codec.socksx.SocksPortUnificationServerHandler
-
- logger - Static variable in class io.netty.handler.flow.FlowControlHandler
-
- logger - Variable in class io.netty.handler.logging.LoggingHandler
-
- logger - Static variable in class io.netty.handler.ssl.AbstractSniHandler
-
- logger - Static variable in class io.netty.handler.ssl.ApplicationProtocolNegotiationHandler
-
- logger - Static variable in class io.netty.handler.ssl.CipherSuiteConverter
-
- logger - Static variable in class io.netty.handler.ssl.JdkSslContext
-
- logger - Static variable in class io.netty.handler.ssl.PemReader
-
- logger - Static variable in class io.netty.handler.ssl.SslHandler
-
- logger - Static variable in class io.netty.handler.ssl.util.InsecureTrustManagerFactory
-
- logger - Static variable in class io.netty.handler.ssl.util.SelfSignedCertificate
-
- logger - Static variable in class io.netty.handler.stream.ChunkedWriteHandler
-
- logger - Static variable in class io.netty.handler.traffic.AbstractTrafficShapingHandler
-
- logger - Static variable in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
-
- logger - Static variable in class io.netty.handler.traffic.TrafficCounter
-
- logger - Static variable in class io.netty.resolver.AddressResolverGroup
-
- logger - Static variable in class io.netty.resolver.dns.DefaultDnsServerAddressStreamProvider
-
- logger - Static variable in class io.netty.resolver.dns.DnsNameResolver
-
- logger - Static variable in class io.netty.resolver.dns.DnsQueryContext
-
- logger - Variable in class io.netty.resolver.dns.TraceDnsQueryLifecycleObserver
-
- logger - Variable in class io.netty.resolver.dns.TraceDnsQueryLifeCycleObserverFactory
-
- logger - Static variable in class io.netty.resolver.dns.UnixResolverDnsServerAddressStreamProvider
-
- logger - Static variable in class io.netty.resolver.HostsFileParser
-
- logger - Static variable in class io.netty.util.concurrent.AbstractEventExecutor
-
- logger - Static variable in class io.netty.util.concurrent.DefaultPromise
-
- logger - Static variable in class io.netty.util.concurrent.GlobalEventExecutor
-
- logger - Static variable in class io.netty.util.concurrent.ImmediateEventExecutor
-
- logger - Static variable in class io.netty.util.concurrent.PromiseNotifier
-
- logger - Static variable in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- logger - Static variable in class io.netty.util.concurrent.UnaryPromiseNotifier
-
- logger - Static variable in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor
-
- logger - Static variable in class io.netty.util.HashedWheelTimer
-
- logger - Static variable in class io.netty.util.internal.CleanerJava6
-
- logger - Static variable in class io.netty.util.internal.CleanerJava9
-
- logger - Variable in class io.netty.util.internal.logging.CommonsLogger
-
Deprecated.
- logger - Variable in class io.netty.util.internal.logging.JdkLogger
-
- logger - Variable in class io.netty.util.internal.logging.Log4JLogger
-
- logger - Variable in class io.netty.util.internal.logging.Slf4JLogger
-
- logger - Static variable in class io.netty.util.internal.MacAddressUtil
-
- logger - Static variable in class io.netty.util.internal.NativeLibraryLoader
-
- logger - Static variable in class io.netty.util.internal.PlatformDependent
-
- logger - Static variable in class io.netty.util.internal.PlatformDependent0
-
- logger - Static variable in class io.netty.util.internal.SystemPropertyUtil
-
- logger - Static variable in class io.netty.util.internal.ThreadLocalRandom
-
- logger - Static variable in class io.netty.util.NetUtil
-
The logger being used by this class
- logger - Static variable in class io.netty.util.Recycler
-
- logger - Static variable in class io.netty.util.ReferenceCountUtil
-
- logger - Static variable in class io.netty.util.ResourceLeakDetector
-
- logger - Static variable in class io.netty.util.ResourceLeakDetectorFactory
-
- logger - Static variable in class io.netty.util.ThreadDeathWatcher
-
- LoggingHandler - Class in io.netty.handler.logging
-
- 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
-
- logKnownVersion(ChannelHandlerContext, SocksVersion) - Static method in class io.netty.handler.codec.socksx.SocksPortUnificationServerHandler
-
- LogLevel - Enum in io.netty.handler.logging
-
- LogLevel(InternalLogLevel) - Constructor for enum io.netty.handler.logging.LogLevel
-
- logNotifyFailure - Variable in class io.netty.util.concurrent.PromiseNotifier
-
- logUnknownVersion(ChannelHandlerContext, byte) - Static method in class io.netty.handler.codec.socksx.SocksPortUnificationServerHandler
-
- LONG_MASK - Static variable in class io.netty.handler.codec.compression.Crc32c
-
- LONG_MAX_LENGTH - Static variable in class io.netty.handler.codec.redis.RedisConstants
-
- LongAdderCounter - Class in io.netty.util.internal
-
- LongAdderCounter() - Constructor for class io.netty.util.internal.LongAdderCounter
-
- longArrayAppend(StringBuilder, long[]) - Static method in class io.netty.util.internal.logging.MessageFormatter
-
- LongCollections - Class in io.netty.util.collection
-
Utilities for long-based primitive collections.
- LongCollections() - Constructor for class io.netty.util.collection.LongCollections
-
- LongCollections.EmptyMap - Class in io.netty.util.collection
-
An empty map.
- LongCollections.UnmodifiableMap<V> - Class in io.netty.util.collection
-
- LongCollections.UnmodifiableMap.EntryImpl - Class in io.netty.util.collection
-
Unmodifiable wrapper for an entry.
- LongCollections.UnmodifiableMap.IteratorImpl - Class in io.netty.util.collection
-
Unmodifiable wrapper for an iterator.
- longCommitHash - Variable in class io.netty.util.Version
-
- 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
-
- LongObjectHashMap.EntrySet - Class in io.netty.util.collection
-
Set implementation for iterating over the entries of the map.
- LongObjectHashMap.KeySet - Class in io.netty.util.collection
-
Set implementation for iterating over the keys.
- LongObjectHashMap.MapEntry - Class in io.netty.util.collection
-
A single entry in the map.
- LongObjectHashMap.MapIterator - Class in io.netty.util.collection
-
Iterator used by the Map
interface.
- LongObjectHashMap.PrimitiveIterator - Class in io.netty.util.collection
-
Iterator over primitive entries.
- LongObjectMap<V> - Interface in io.netty.util.collection
-
Interface for a primitive map that uses long
s as keys.
- LongObjectMap.PrimitiveEntry<V> - Interface in io.netty.util.collection
-
- longToAsciiBytes(long) - Static method in class io.netty.handler.codec.redis.RedisCodecUtil
-
- longToByteBufs - Variable in class io.netty.handler.codec.redis.FixedRedisMessagePool
-
- longToIntegers - Variable in class io.netty.handler.codec.redis.FixedRedisMessagePool
-
- longValue - Variable in class io.netty.channel.DefaultChannelId
-
- 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.
- looksLikeZlib(short) - Static method in class io.netty.handler.codec.compression.JdkZlibDecoder
-
- lookup(ChannelHandlerContext, String) - Method in class io.netty.handler.ssl.AbstractSniHandler
-
- lookup(ChannelHandlerContext, String) - Method in class io.netty.handler.ssl.SniHandler
-
- loop - Variable in class io.netty.channel.embedded.EmbeddedChannel
-
- LOOPBACK_IF - Static variable in class io.netty.util.NetUtil
-
The loopback NetworkInterface
of the current machine
- loopbackAddress() - Method in class io.netty.resolver.dns.DnsNameResolver
-
- loopbackAddress() - Static method in class io.netty.util.internal.SocketUtils
-
- low - Variable in class io.netty.channel.WriteBufferWaterMark
-
- low() - Method in class io.netty.channel.WriteBufferWaterMark
-
Returns the low water mark for the write buffer.
- lsIntroSort(int, int, int, int, int) - Method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- lsSort(int, int, int) - Method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- lsUpdateGroup(int, int, int) - Method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- MacAddressUtil - Class in io.netty.util.internal
-
- MacAddressUtil() - Constructor for class io.netty.util.internal.MacAddressUtil
-
- MACHINE_ID - Static variable in class io.netty.channel.DefaultChannelId
-
- magic - Variable in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
-
- 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.
- MAGIC_NUMBER - Static variable in class io.netty.handler.codec.compression.Bzip2Constants
-
Magic number of Bzip2 stream.
- MAGIC_NUMBER - Static variable in class io.netty.handler.codec.compression.FastLz
-
- 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
.
- majorVersion(String) - Static method in class io.netty.util.internal.PlatformDependent0
-
- majorVersionFromJavaSpecificationVersion() - Static method in class io.netty.util.internal.PlatformDependent0
-
- makeShort(char, char) - Static method in class io.netty.handler.codec.redis.RedisCodecUtil
-
Returns a short
value using endian order.
- map - Variable in class io.netty.channel.pool.AbstractChannelPoolMap
-
- map(String, Promise<SslContext>) - Method in class io.netty.handler.ssl.SniHandler.AsyncMappingAdapter
-
- map - Variable in class io.netty.resolver.dns.DnsQueryContextManager
-
A map whose key is the DNS server address and value is the map of the DNS query ID and its corresponding
DnsQueryContext
.
- map(IN, Promise<OUT>) - Method in interface io.netty.util.AsyncMapping
-
Returns the
Future
that will provide the result of the mapping.
- map - Variable in class io.netty.util.collection.ByteCollections.UnmodifiableMap
-
- map - Variable in class io.netty.util.collection.CharCollections.UnmodifiableMap
-
- map - Variable in class io.netty.util.collection.IntCollections.UnmodifiableMap
-
- map - Variable in class io.netty.util.collection.LongCollections.UnmodifiableMap
-
- map - Variable in class io.netty.util.collection.ShortCollections.UnmodifiableMap
-
- map - Variable in class io.netty.util.DomainNameMapping
-
- map(String) - Method in class io.netty.util.DomainNameMapping
-
- map - Variable in class io.netty.util.DomainNameMappingBuilder.ImmutableDomainNameMapping
-
- map(String) - Method in class io.netty.util.DomainNameMappingBuilder.ImmutableDomainNameMapping
-
- map - Variable in class io.netty.util.DomainNameMappingBuilder
-
- map - Variable in class io.netty.util.internal.ConcurrentSet
-
- map(IN) - Method in interface io.netty.util.Mapping
-
Returns mapped value of the specified input.
- mapChunkType(byte) - Static method in class io.netty.handler.codec.compression.SnappyFrameDecoder
-
Decodes the chunk type from the type tag byte.
- MapEntry(int) - Constructor for class io.netty.util.collection.ByteObjectHashMap.MapEntry
-
- MapEntry(int) - Constructor for class io.netty.util.collection.CharObjectHashMap.MapEntry
-
- MapEntry(int) - Constructor for class io.netty.util.collection.IntObjectHashMap.MapEntry
-
- MapEntry(int) - Constructor for class io.netty.util.collection.LongObjectHashMap.MapEntry
-
- MapEntry(int) - Constructor for class io.netty.util.collection.ShortObjectHashMap.MapEntry
-
- MapIterator() - Constructor for class io.netty.util.collection.ByteObjectHashMap.MapIterator
-
- MapIterator() - Constructor for class io.netty.util.collection.CharObjectHashMap.MapIterator
-
- MapIterator() - Constructor for class io.netty.util.collection.IntObjectHashMap.MapIterator
-
- MapIterator() - Constructor for class io.netty.util.collection.LongObjectHashMap.MapIterator
-
- MapIterator() - Constructor for class io.netty.util.collection.ShortObjectHashMap.MapIterator
-
- mapping - Variable in class io.netty.handler.ssl.SniHandler.AsyncMappingAdapter
-
- 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
-
- markedReaderIndex - Variable in class io.netty.buffer.AbstractByteBuf
-
- markedWriterIndex - Variable in class io.netty.buffer.AbstractByteBuf
-
- 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.
- markReaderIndex() - Method in class io.netty.buffer.WrappedByteBuf
-
- markReaderIndex() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- markReaderIndex() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- 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.
- markWriterIndex() - Method in class io.netty.buffer.WrappedByteBuf
-
- markWriterIndex() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- markWriterIndex() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- mask - Variable in class io.netty.util.collection.ByteObjectHashMap
-
- mask - Variable in class io.netty.util.collection.CharObjectHashMap
-
- mask - Variable in class io.netty.util.collection.IntObjectHashMap
-
- mask - Variable in class io.netty.util.collection.LongObjectHashMap
-
- mask - Variable in class io.netty.util.collection.ShortObjectHashMap
-
- MASK - Static variable in class io.netty.util.DefaultAttributeMap
-
- mask - Variable in class io.netty.util.HashedWheelTimer
-
- mask - Static variable in class io.netty.util.internal.ThreadLocalRandom
-
- maskChecksum(int) - Static method in class io.netty.handler.codec.compression.Snappy
-
From the spec:
"Checksums are not stored directly, but masked, as checksumming data and
then its own checksum can be problematic.
- match(byte[], ByteBuf, int) - Static method in class io.netty.handler.codec.haproxy.HAProxyMessageDecoder
-
- match(Object) - Method in class io.netty.util.internal.NoOpTypeParameterMatcher
-
- match(Object) - Method in class io.netty.util.internal.TypeParameterMatcher
-
- match(Object) - Method in class io.netty.util.internal.TypeParameterMatcher.ReflectiveMatcher
-
- matcher - Variable in class io.netty.channel.group.ChannelMatchers.InvertMatcher
-
- matcher - Variable in class io.netty.channel.SimpleChannelInboundHandler
-
- matcher - Variable in class io.netty.handler.codec.MessageToByteEncoder
-
- matcher - Variable in class io.netty.handler.codec.MessageToMessageDecoder
-
- matcher - Variable in class io.netty.handler.codec.MessageToMessageEncoder
-
- matcher - Variable in class io.netty.resolver.AbstractAddressResolver
-
- matchers - Variable in class io.netty.channel.group.ChannelMatchers.CompositeMatcher
-
- matches(Channel) - Method in interface io.netty.channel.group.ChannelMatcher
-
Returns
true
if the operation should be also executed on the given
Channel
.
- matches(Channel) - Method in class io.netty.channel.group.ChannelMatchers.ClassMatcher
-
- matches(Channel) - Method in class io.netty.channel.group.ChannelMatchers.CompositeMatcher
-
- matches(Channel) - Method in class io.netty.channel.group.ChannelMatchers.InstanceMatcher
-
- matches(Channel) - Method in class io.netty.channel.group.ChannelMatchers.InvertMatcher
-
- matches(InetSocketAddress) - Method in interface io.netty.handler.ipfilter.IpFilterRule
-
- matches(InetSocketAddress) - Method in class io.netty.handler.ipfilter.IpSubnetFilterRule.Ip4SubnetFilterRule
-
- matches(InetSocketAddress) - Method in class io.netty.handler.ipfilter.IpSubnetFilterRule.Ip6SubnetFilterRule
-
- 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.
- matches(String, String) - Static method in class io.netty.util.DomainNameMapping
-
- matchMonth(String, CharSequence, int) - Static method in class io.netty.handler.codec.DateFormatter
-
- MathUtil - Class in io.netty.util.internal
-
Math utility methods.
- MathUtil() - Constructor for class io.netty.util.internal.MathUtil
-
- MAX_ALLOWED_MPSC_CAPACITY - Static variable in class io.netty.util.internal.PlatformDependent
-
- MAX_BLOCK_SIZE - Static variable in class io.netty.handler.codec.compression.Bzip2Constants
-
- MAX_BYTES_PER_CHAR_UTF8 - Static variable in class io.netty.buffer.ByteBufUtil
-
- MAX_CACHED_INTEGER_NUMBER - Static variable in class io.netty.handler.codec.redis.FixedRedisMessagePool
-
- MAX_CHAR_BUFFER_SIZE - Static variable in class io.netty.buffer.ByteBufUtil
-
- MAX_CHAR_VALUE - Static variable in class io.netty.util.AsciiString
-
- MAX_CHUNK_LENGTH - Static variable in class io.netty.handler.codec.compression.FastLz
-
- MAX_CHUNK_SIZE - Static variable in class io.netty.buffer.PooledByteBufAllocator
-
- MAX_CIPHERTEXT_LENGTH - Static variable in class io.netty.handler.ssl.SslHandler
-
- MAX_CLIENT_ID_LENGTH - Static variable in class io.netty.handler.codec.mqtt.MqttCodecUtil
-
- MAX_COMPRESSED_LENGTH - Static variable in class io.netty.handler.ssl.SslHandler
-
- MAX_COPY - Static variable in class io.netty.handler.codec.compression.FastLz
-
- MAX_COUNT_OF_READABLE_BYTES - Static variable in class io.netty.handler.codec.compression.Bzip2BitReader
-
Maximum count of possible readable bytes to check.
- MAX_DELAYED_QUEUES_PER_THREAD - Static variable in class io.netty.util.Recycler
-
- MAX_DEVIATION - Static variable in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
-
- MAX_DIRECT_MEMORY - Static variable in class io.netty.util.internal.PlatformDependent
-
- MAX_DIRECT_MEMORY_SIZE_ARG_PATTERN - Static variable in class io.netty.util.internal.PlatformDependent
-
- MAX_DISTANCE - Static variable in class io.netty.handler.codec.compression.FastLz
-
- MAX_ENCRYPTED_PACKET_LENGTH - Static variable in class io.netty.handler.ssl.SslHandler
-
- MAX_ENCRYPTION_OVERHEAD_LENGTH - Static variable in class io.netty.handler.ssl.SslHandler
-
- MAX_FARDISTANCE - Static variable in class io.netty.handler.codec.compression.FastLz
-
- MAX_FIELD_LENGTH - Static variable in class io.netty.handler.codec.socksx.v4.Socks4ServerDecoder
-
- MAX_HT_SIZE - Static variable in class io.netty.handler.codec.compression.Snappy
-
- MAX_LEN - Static variable in class io.netty.handler.codec.compression.FastLz
-
- MAX_LINE_LENGTH - Static variable in class io.netty.handler.codec.base64.Base64
-
Maximum line length (76) of Base64 output.
- MAX_LISTENER_STACK_DEPTH - Static variable in class io.netty.util.concurrent.DefaultPromise
-
- MAX_MESSAGES_PER_READ - Static variable in class io.netty.channel.ChannelOption
-
- MAX_PLAINTEXT_LENGTH - Static variable in class io.netty.handler.ssl.SslHandler
-
- MAX_READER_STACK_DEPTH - Static variable in class io.netty.channel.local.LocalChannel
-
- MAX_RECORDS - Static variable in class io.netty.util.ResourceLeakDetector
-
- MAX_SELECTORS - Static variable in class io.netty.handler.codec.compression.Bzip2Constants
-
Maximum possible number of Huffman table selectors.
- MAX_SHARED_CAPACITY_FACTOR - Static variable in class io.netty.util.Recycler
-
- MAX_SSL_RECORDS - Static variable in class io.netty.handler.ssl.AbstractSniHandler
-
- MAX_UNCOMPRESSED_DATA_SIZE - Static variable in class io.netty.handler.codec.compression.SnappyFrameDecoder
-
- maxAllowedQueries - Variable in class io.netty.resolver.dns.DnsNameResolverContext
-
- maxBytesInMessage - Variable in class io.netty.handler.codec.mqtt.MqttDecoder
-
- maxBytesPerIndividualRead - Variable in class io.netty.channel.DefaultMaxBytesRecvByteBufAllocator
-
- 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 - Variable in class io.netty.channel.DefaultMaxBytesRecvByteBufAllocator
-
- 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 - Variable in class io.netty.buffer.AbstractByteBuf
-
- 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.FixedCompositeByteBuf
-
- maxCapacity - Variable in class io.netty.buffer.PoolChunkList
-
- maxCapacity() - Method in class io.netty.buffer.SwappedByteBuf
-
Deprecated.
- maxCapacity() - Method in class io.netty.buffer.WrappedByteBuf
-
- maxCapacity() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- maxCapacity() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- maxCapacity - Variable in class io.netty.util.Recycler.Stack
-
- maxCapacityPerThread - Variable in class io.netty.util.Recycler
-
- maxChannels - Variable in class io.netty.channel.ThreadPerChannelEventLoopGroup
-
- maxChunkSize - Variable in class io.netty.handler.codec.stomp.StompSubframeDecoder
-
- maxConnections - Variable in class io.netty.channel.pool.FixedChannelPool
-
- maxContentLength - Variable in class io.netty.handler.codec.MessageAggregator
-
- maxContentLength() - Method in class io.netty.handler.codec.MessageAggregator
-
Returns the maximum allowed length of the aggregated message in bytes.
- maxCumulationBufferComponents - Variable in class io.netty.handler.codec.MessageAggregator
-
- maxCumulationBufferComponents() - Method in class io.netty.handler.codec.MessageAggregator
-
Returns the maximum number of components in the cumulation buffer.
- maxDelayedQueues - Variable in class io.netty.util.Recycler.Stack
-
- maxDelayedQueuesPerThread - Variable in class io.netty.util.Recycler
-
- maxDeviation - Variable in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
-
- 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.
- maxDirectMemory0() - Static method in class io.netty.util.internal.PlatformDependent
-
- maxFrameLength - Variable in class io.netty.handler.codec.DelimiterBasedFrameDecoder
-
- maxFrameLength - Variable in class io.netty.handler.codec.LengthFieldBasedFrameDecoder
-
- maxFrameLength - Variable in class io.netty.handler.codec.xml.XmlFrameDecoder
-
- maxGlobalWriteSize - Variable in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
-
Max size in the list before proposing to stop writing new objects from next handlers
for all channel (global)
- maxGlobalWriteSize - Variable in class io.netty.handler.traffic.GlobalTrafficShapingHandler
-
Max size in the list before proposing to stop writing new objects from next handlers
for all channel (global)
- maximumCumulativeReadBytes() - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
-
- maximumCumulativeWrittenBytes() - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
-
- maxIndex - Variable in class io.netty.channel.AdaptiveRecvByteBufAllocator.HandleImpl
-
- maxIndex - Variable in class io.netty.channel.AdaptiveRecvByteBufAllocator
-
- maxInlineMessageLength - Variable in class io.netty.handler.codec.redis.RedisDecoder
-
- maxInStreams() - Method in class com.sun.nio.sctp.SctpStandardSocketOptions.InitMaxStreams
-
- maxLength - Variable in class io.netty.buffer.PooledByteBuf
-
- maxLength - Variable in class io.netty.handler.codec.LineBasedFrameDecoder
-
Maximum length of a frame we're willing to decode.
- maxLineLength - Variable in class io.netty.handler.codec.stomp.StompSubframeDecoder
-
- MaxMessageHandle() - Constructor for class io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator.MaxMessageHandle
-
- maxMessagePerRead - Variable in class io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator.MaxMessageHandle
-
- maxMessagesPerRead - Variable in class io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator
-
- 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 - Variable in class io.netty.buffer.CompositeByteBuf
-
- maxNumComponents() - Method in class io.netty.buffer.CompositeByteBuf
-
Return the max number of
ByteBuf
's that are composed in this instance
- maxNumComponents() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- maxNumElements() - Method in class io.netty.buffer.PoolSubpage
-
- maxNumElements() - Method in interface io.netty.buffer.PoolSubpageMetric
-
Return the number of maximal elements that can be allocated out of the sub-page.
- maxNumElems - Variable in class io.netty.buffer.PoolSubpage
-
- maxObjectLength - Variable in class io.netty.handler.codec.json.JsonObjectDecoder
-
- maxObjectSize - Variable in class io.netty.handler.codec.serialization.ObjectDecoderInputStream
-
- maxOrder - Variable in class io.netty.buffer.PoolArena
-
- maxOrder - Variable in class io.netty.buffer.PoolChunk
-
- maxOutStreams() - Method in class com.sun.nio.sctp.SctpStandardSocketOptions.InitMaxStreams
-
- maxPacketBufferSize - Variable in class io.netty.handler.ssl.SslHandler
-
- maxPayloadSize - Variable in class io.netty.resolver.dns.DnsNameResolver
-
- maxPayloadSize() - Method in class io.netty.resolver.dns.DnsNameResolver
-
Returns the capacity of the datagram packet buffer (in bytes).
- maxPayloadSize - Variable in class io.netty.resolver.dns.DnsNameResolverBuilder
-
- maxPayloadSize(int) - Method in class io.netty.resolver.dns.DnsNameResolverBuilder
-
Sets the capacity of the datagram packet buffer (in bytes).
- maxPendingAcquires - Variable in class io.netty.channel.pool.FixedChannelPool
-
- maxPendingTasks - Variable in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- maxPendingTimeouts - Variable in class io.netty.util.HashedWheelTimer
-
- maxQueriesPerResolve - Variable in class io.netty.resolver.dns.DnsNameResolver
-
- 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 - Variable in class io.netty.resolver.dns.DnsNameResolverBuilder
-
- 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.
- maxSharedCapacityFactor - Variable in class io.netty.util.Recycler
-
- maxSize - Variable in class io.netty.util.collection.ByteObjectHashMap
-
The maximum number of elements allowed without allocating more space.
- maxSize - Variable in class io.netty.util.collection.CharObjectHashMap
-
The maximum number of elements allowed without allocating more space.
- maxSize - Variable in class io.netty.util.collection.IntObjectHashMap
-
The maximum number of elements allowed without allocating more space.
- maxSize - Variable in class io.netty.util.collection.LongObjectHashMap
-
The maximum number of elements allowed without allocating more space.
- maxSize - Variable in class io.netty.util.collection.ShortObjectHashMap
-
The maximum number of elements allowed without allocating more space.
- maxSubpageAllocs - Variable in class io.netty.buffer.PoolChunk
-
- maxTaskExecutePerRun - Variable in class io.netty.util.concurrent.NonStickyEventExecutorGroup
-
- maxTaskExecutePerRun - Variable in class io.netty.util.concurrent.NonStickyEventExecutorGroup.NonStickyOrderedEventExecutor
-
- maxTime - Variable in class io.netty.handler.traffic.AbstractTrafficShapingHandler
-
Max delay in wait
- maxTtl - Variable in class io.netty.resolver.dns.DefaultDnsCache
-
- maxTtl() - Method in class io.netty.resolver.dns.DefaultDnsCache
-
Returns the maximum TTL of the cached DNS resource records (in seconds).
- maxTtl - Variable in class io.netty.resolver.dns.DnsNameResolverBuilder
-
- maxUsage - Variable in class io.netty.buffer.PoolChunkList
-
- maxUsage() - Method in class io.netty.buffer.PoolChunkList
-
- 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.
- maxWritableBytes() - Method in class io.netty.buffer.WrappedByteBuf
-
- maxWritableBytes() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- maxWritableBytes() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- maxWriteDelay - Variable in class io.netty.handler.traffic.AbstractTrafficShapingHandler
-
Max time to delay before proposing to stop writing new objects from next handlers
- maxWriteSize - Variable in class io.netty.handler.traffic.AbstractTrafficShapingHandler
-
Max size in the list before proposing to stop writing new objects from next handlers
- MAYBE_SUPER_USER - Static variable in class io.netty.util.internal.PlatformDependent
-
- maybeMoreDataToRead - Variable in class io.netty.channel.kqueue.AbstractKQueueChannel.AbstractKQueueUnsafe
-
- maybeMoreDataToRead() - Method in class io.netty.channel.kqueue.KQueueRecvByteAllocatorHandle
-
- maybeSuperUser() - Static method in class io.netty.util.internal.PlatformDependent
-
Return true
if the current user may be a super-user.
- maybeSuperUser0() - Static method in class io.netty.util.internal.PlatformDependent
-
- mayOverrideNameServers() - Method in class io.netty.resolver.dns.UnixResolverDnsServerAddressStreamProvider
-
- memberships - Variable in class io.netty.channel.socket.nio.NioDatagramChannel
-
- 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
-
- memory - Variable in class io.netty.buffer.PoolChunk
-
- memory - Variable in class io.netty.buffer.PooledByteBuf
-
- memoryAddress() - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- 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.FixedCompositeByteBuf
-
- memoryAddress() - Method in class io.netty.buffer.PooledDirectByteBuf
-
- memoryAddress() - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- memoryAddress() - Method in class io.netty.buffer.PooledHeapByteBuf
-
- memoryAddress() - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- memoryAddress - Variable in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- memoryAddress() - Method in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- memoryAddress() - Method in class io.netty.buffer.ReadOnlyByteBuf
-
Deprecated.
- memoryAddress() - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- memoryAddress - Variable in class io.netty.buffer.ReadOnlyUnsafeDirectByteBuf
-
- 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 - Variable in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
-
- memoryAddress() - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
-
- memoryAddress() - Method in class io.netty.buffer.WrappedByteBuf
-
- memoryAddress() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- memoryAddress - Variable in class io.netty.channel.kqueue.KQueueEventArray
-
- memoryAddress() - Method in class io.netty.channel.kqueue.KQueueEventArray
-
- memoryAddress - Variable in class io.netty.channel.kqueue.NativeLongArray
-
- memoryAddress() - Method in class io.netty.channel.kqueue.NativeLongArray
-
- memoryAddress - Variable in class io.netty.channel.unix.IovArray
-
- memoryAddress(int) - Method in class io.netty.channel.unix.IovArray
-
Returns the memoryAddress
for the given offset
.
- memoryAddress() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- memoryAddressEnd() - Method in class io.netty.channel.kqueue.NativeLongArray
-
- memoryCopy(ByteBuffer, int, ByteBuffer, int, int) - Method in class io.netty.buffer.PoolArena.DirectArena
-
- memoryCopy(byte[], int, byte[], int, int) - Method in class io.netty.buffer.PoolArena.HeapArena
-
- memoryCopy(T, int, T, int, int) - Method in class io.netty.buffer.PoolArena
-
- memoryMap - Variable in class io.netty.buffer.PoolChunk
-
- memoryMapIdx(long) - Static method in class io.netty.buffer.PoolChunk
-
- memoryMapIdx - Variable in class io.netty.buffer.PoolSubpage
-
- memoryOffset(int) - Method in class io.netty.channel.kqueue.NativeLongArray
-
- MemoryRegionCache(int, PoolArena.SizeClass) - Constructor for class io.netty.buffer.PoolThreadCache.MemoryRegionCache
-
- MERGE_CUMULATOR - Static variable in class io.netty.handler.codec.ByteToMessageDecoder
-
Cumulate
ByteBuf
s by merge them into one
ByteBuf
's, using memory copies.
- message - Variable in class io.netty.channel.DefaultAddressedEnvelope
-
- MESSAGE - Static variable in interface io.netty.handler.codec.stomp.StompHeaders
-
- message(String, Class<?>...) - Static method in exception io.netty.handler.codec.UnsupportedMessageTypeException
-
- message - Variable in class io.netty.util.internal.logging.FormattingTuple
-
- 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
-
- MessageFormatter - Class in io.netty.util.internal.logging
-
Formats messages according to very simple substitution rules.
- MessageFormatter() - Constructor for class io.netty.util.internal.logging.MessageFormatter
-
- messageId - Variable in class io.netty.handler.codec.mqtt.MqttMessageBuilders.PublishBuilder
-
- messageId(int) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.PublishBuilder
-
- messageId - Variable in class io.netty.handler.codec.mqtt.MqttMessageBuilders.SubscribeBuilder
-
- messageId(int) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.SubscribeBuilder
-
- messageId - Variable in class io.netty.handler.codec.mqtt.MqttMessageBuilders.UnsubscribeBuilder
-
- messageId(int) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.UnsubscribeBuilder
-
- messageId - Variable in class io.netty.handler.codec.mqtt.MqttMessageIdVariableHeader
-
- messageId() - Method in class io.netty.handler.codec.mqtt.MqttMessageIdVariableHeader
-
- messageId() - Method in class io.netty.handler.codec.mqtt.MqttPublishVariableHeader
-
- MessageInfo - Class in com.sun.nio.sctp
-
- MessageInfo() - Constructor for class com.sun.nio.sctp.MessageInfo
-
- messageInfo() - Method in class io.netty.channel.sctp.SctpMessage
-
Return the
MessageInfo
for inbound messages or
null
for
outbound messages.
- messagePool - Variable in class io.netty.handler.codec.redis.RedisDecoder
-
- messagePool - Variable in class io.netty.handler.codec.redis.RedisEncoder
-
- MessageSizeEstimator - Interface in io.netty.channel
-
Responsible to estimate size of a message.
- MessageSizeEstimator.Handle - Interface in io.netty.channel
-
- messagesQueue - Variable in class io.netty.handler.traffic.ChannelTrafficShapingHandler
-
- messagesQueue - Variable in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler.PerChannel
-
- messagesQueue - Variable in class io.netty.handler.traffic.GlobalTrafficShapingHandler.PerChannel
-
- MessageToByteEncoder<I> - Class in io.netty.handler.codec
-
- MessageToByteEncoder() - Constructor for class io.netty.handler.codec.MessageToByteEncoder
-
- 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
-
- 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 - Variable in class io.netty.handler.codec.mqtt.MqttFixedHeader
-
- messageType() - Method in class io.netty.handler.codec.mqtt.MqttFixedHeader
-
- METADATA - Static variable in class io.netty.channel.AbstractServerChannel
-
- metadata() - Method in class io.netty.channel.AbstractServerChannel
-
- metadata() - Method in interface io.netty.channel.Channel
-
- metadata - Variable in class io.netty.channel.embedded.EmbeddedChannel
-
- metadata(boolean) - Static method in class io.netty.channel.embedded.EmbeddedChannel
-
- metadata() - Method in class io.netty.channel.embedded.EmbeddedChannel
-
- METADATA - Static variable in class io.netty.channel.kqueue.AbstractKQueueChannel
-
- metadata() - Method in class io.netty.channel.kqueue.AbstractKQueueChannel
-
- METADATA - Static variable in class io.netty.channel.kqueue.AbstractKQueueServerChannel
-
- metadata() - Method in class io.netty.channel.kqueue.AbstractKQueueServerChannel
-
- METADATA - Static variable in class io.netty.channel.kqueue.AbstractKQueueStreamChannel
-
- metadata() - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel
-
- METADATA - Static variable in class io.netty.channel.kqueue.KQueueDatagramChannel
-
- metadata() - Method in class io.netty.channel.kqueue.KQueueDatagramChannel
-
- METADATA - Static variable in class io.netty.channel.local.LocalChannel
-
- metadata() - Method in class io.netty.channel.local.LocalChannel
-
- METADATA - Static variable in class io.netty.channel.nio.AbstractNioByteChannel
-
- metadata() - Method in class io.netty.channel.nio.AbstractNioByteChannel
-
- METADATA - Static variable in class io.netty.channel.oio.AbstractOioByteChannel
-
- metadata() - Method in class io.netty.channel.oio.AbstractOioByteChannel
-
- METADATA - Static variable in class io.netty.channel.sctp.nio.NioSctpChannel
-
- metadata() - Method in class io.netty.channel.sctp.nio.NioSctpChannel
-
- METADATA - Static variable in class io.netty.channel.sctp.nio.NioSctpServerChannel
-
- metadata() - Method in class io.netty.channel.sctp.nio.NioSctpServerChannel
-
- METADATA - Static variable in class io.netty.channel.sctp.oio.OioSctpChannel
-
- metadata() - Method in class io.netty.channel.sctp.oio.OioSctpChannel
-
- METADATA - Static variable in class io.netty.channel.sctp.oio.OioSctpServerChannel
-
- metadata() - Method in class io.netty.channel.sctp.oio.OioSctpServerChannel
-
- METADATA - Static variable in class io.netty.channel.socket.nio.NioDatagramChannel
-
- metadata() - Method in class io.netty.channel.socket.nio.NioDatagramChannel
-
- METADATA - Static variable in class io.netty.channel.socket.nio.NioServerSocketChannel
-
- metadata() - Method in class io.netty.channel.socket.nio.NioServerSocketChannel
-
- METADATA - Static variable in class io.netty.channel.socket.oio.OioDatagramChannel
-
- metadata() - Method in class io.netty.channel.socket.oio.OioDatagramChannel
-
- METADATA - Static variable in class io.netty.channel.socket.oio.OioServerSocketChannel
-
- metadata() - Method in class io.netty.channel.socket.oio.OioServerSocketChannel
-
- METADATA_DISCONNECT - Static variable in class io.netty.channel.embedded.EmbeddedChannel
-
- METADATA_NO_DISCONNECT - Static variable in class io.netty.channel.embedded.EmbeddedChannel
-
- method - Variable in class io.netty.handler.codec.compression.ByteBufChecksum.ReflectiveByteBufChecksum
-
- metric() - Method in interface io.netty.buffer.ByteBufAllocatorMetricProvider
-
- metric - Variable in class io.netty.buffer.PooledByteBufAllocator
-
- metric() - Method in class io.netty.buffer.PooledByteBufAllocator
-
- metric - Variable in class io.netty.buffer.UnpooledByteBufAllocator
-
- metric() - Method in class io.netty.buffer.UnpooledByteBufAllocator
-
- milliSecondFromNano() - Static method in class io.netty.handler.traffic.TrafficCounter
-
- MIN_BLOCK_SIZE - Static variable in class io.netty.handler.codec.compression.Bzip2Constants
-
Minimum and maximum size of one block.
- MIN_CACHED_INTEGER_NUMBER - Static variable in class io.netty.handler.codec.redis.FixedRedisMessagePool
-
- MIN_CLIENT_ID_LENGTH - Static variable in class io.netty.handler.codec.mqtt.MqttCodecUtil
-
- MIN_COMPRESSIBLE_BYTES - Static variable in class io.netty.handler.codec.compression.Snappy
-
- MIN_COMPRESSIBLE_LENGTH - Static variable in class io.netty.handler.codec.compression.SnappyFrameEncoder
-
The minimum amount that we'll consider actually attempting to compress.
- MIN_LENGTH_TO_COMPRESSION - Static variable in class io.netty.handler.codec.compression.FastLz
-
- MIN_MAX_MPSC_CAPACITY - Static variable in class io.netty.util.internal.PlatformDependent
-
- MIN_PAGE_SIZE - Static variable in class io.netty.buffer.PooledByteBufAllocator
-
- MIN_PREMATURE_SELECTOR_RETURNS - Static variable in class io.netty.channel.nio.NioEventLoop
-
- MIN_RECOMENDED_LENGTH_FOR_LEVEL_2 - Static variable in class io.netty.handler.codec.compression.FastLz
-
- MIN_TIMEOUT_NANOS - Static variable in class io.netty.handler.timeout.IdleStateHandler
-
- MIN_TIMEOUT_NANOS - Static variable in class io.netty.handler.timeout.WriteTimeoutHandler
-
- MINIMAL_WAIT - Static variable in class io.netty.handler.traffic.AbstractTrafficShapingHandler
-
Default minimal time to wait
- MINIMUM_HEADER_SIZE - Static variable in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheEncoder
-
Every binary memcache message has at least a 24 bytes header.
- minimumLengths - Variable in class io.netty.handler.codec.compression.Bzip2HuffmanStageDecoder
-
The minimum code length for each Huffman table.
- minIndex - Variable in class io.netty.channel.AdaptiveRecvByteBufAllocator.HandleImpl
-
- minIndex - Variable in class io.netty.channel.AdaptiveRecvByteBufAllocator
-
- minTtl - Variable in class io.netty.resolver.dns.DefaultDnsCache
-
- minTtl() - Method in class io.netty.resolver.dns.DefaultDnsCache
-
Returns the minimum TTL of the cached DNS resource records (in seconds).
- minTtl - Variable in class io.netty.resolver.dns.DnsNameResolverBuilder
-
- MINUS_ONE - Static variable in class io.netty.handler.ipfilter.IpSubnetFilterRule.Ip6SubnetFilterRule
-
- minUsage - Variable in class io.netty.buffer.PoolChunkList
-
- minUsage() - Method in class io.netty.buffer.PoolChunkList
-
- 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.
- minUsage0(int) - Static method in class io.netty.buffer.PoolChunkList
-
- minutes - Variable in class io.netty.handler.codec.DateFormatter
-
- mix64(long) - Static method in class io.netty.util.internal.ThreadLocalRandom
-
- MixedTrafficMonitoringTask(GlobalChannelTrafficShapingHandler, TrafficCounter) - Constructor for class io.netty.handler.traffic.GlobalChannelTrafficCounter.MixedTrafficMonitoringTask
-
- mode - Variable in class io.netty.channel.kqueue.KQueueDomainSocketChannelConfig
-
- modifyLength - Variable in class io.netty.handler.codec.compression.Bzip2HuffmanStageDecoder
-
- monitor - Variable in class io.netty.handler.traffic.TrafficCounter
-
Monitor created once in start()
- monitorActive - Variable in class io.netty.handler.traffic.TrafficCounter
-
Is Monitor active
- month - Variable in class io.netty.handler.codec.DateFormatter
-
- monthFound - Variable in class io.netty.handler.codec.DateFormatter
-
- move(PoolChunk<T>) - Method in class io.netty.buffer.PoolChunkList
-
- move0(PoolChunk<T>) - Method in class io.netty.buffer.PoolChunkList
-
- Mpsc() - Constructor for class io.netty.util.internal.PlatformDependent.Mpsc
-
- MPSC_CHUNK_SIZE - Static variable in class io.netty.util.internal.PlatformDependent
-
- MqttCodecUtil - Class in io.netty.handler.codec.mqtt
-
- MqttCodecUtil() - Constructor for class io.netty.handler.codec.mqtt.MqttCodecUtil
-
- 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
-
- 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
-
- MqttConnectReturnCode(byte) - Constructor for enum io.netty.handler.codec.mqtt.MqttConnectReturnCode
-
- MqttConnectVariableHeader - Class in io.netty.handler.codec.mqtt
-
- 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
-
- MqttDecoder() - Constructor for class io.netty.handler.codec.mqtt.MqttDecoder
-
- MqttDecoder(int) - Constructor for class io.netty.handler.codec.mqtt.MqttDecoder
-
- MqttDecoder.DecoderState - Enum in io.netty.handler.codec.mqtt
-
States of the decoder.
- MqttDecoder.Result<T> - Class in io.netty.handler.codec.mqtt
-
- MqttEncoder - Class in io.netty.handler.codec.mqtt
-
Encodes Mqtt messages into bytes following the protocol specification v3.1
as described here
MQTTV3.1
- MqttEncoder() - Constructor for class io.netty.handler.codec.mqtt.MqttEncoder
-
- mqttFixedHeader - Variable in class io.netty.handler.codec.mqtt.MqttDecoder
-
- MqttFixedHeader - Class in io.netty.handler.codec.mqtt
-
- MqttFixedHeader(MqttMessageType, boolean, MqttQoS, boolean, int) - Constructor for class io.netty.handler.codec.mqtt.MqttFixedHeader
-
- mqttFixedHeader - Variable in class io.netty.handler.codec.mqtt.MqttMessage
-
- MqttIdentifierRejectedException - Exception in io.netty.handler.codec.mqtt
-
- 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() - Constructor for class io.netty.handler.codec.mqtt.MqttMessageBuilders
-
- 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.
- MqttMessageFactory() - Constructor for class io.netty.handler.codec.mqtt.MqttMessageFactory
-
- MqttMessageIdVariableHeader - Class in io.netty.handler.codec.mqtt
-
- MqttMessageIdVariableHeader(int) - Constructor for class io.netty.handler.codec.mqtt.MqttMessageIdVariableHeader
-
- MqttMessageType - Enum in io.netty.handler.codec.mqtt
-
MQTT Message Types.
- MqttMessageType(int) - Constructor for enum io.netty.handler.codec.mqtt.MqttMessageType
-
- 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
-
- MqttPublishVariableHeader(String, int) - Constructor for class io.netty.handler.codec.mqtt.MqttPublishVariableHeader
-
- MqttQoS - Enum in io.netty.handler.codec.mqtt
-
- MqttQoS(int) - Constructor for enum io.netty.handler.codec.mqtt.MqttQoS
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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.
- MqttVersion(String, byte) - Constructor for enum io.netty.handler.codec.mqtt.MqttVersion
-
- msg - Variable in class io.netty.channel.AbstractChannelHandlerContext.AbstractWriteTask
-
- msg - Variable in class io.netty.channel.ChannelOutboundBuffer.Entry
-
- msg - Variable in class io.netty.channel.PendingWriteQueue.PendingWrite
-
- msg - Variable in class io.netty.handler.stream.ChunkedWriteHandler.PendingWrite
-
- msg - Variable in class io.netty.util.internal.PendingWrite
-
- msg() - Method in class io.netty.util.internal.PendingWrite
-
- msgInfo - Variable in class io.netty.channel.sctp.SctpMessage
-
- msgSizeEstimator - Variable in class io.netty.channel.DefaultChannelConfig
-
- mtf - Variable in class io.netty.handler.codec.compression.Bzip2MoveToFrontTable
-
The Move To Front list.
- mtfAlphabetSize - Variable in class io.netty.handler.codec.compression.Bzip2HuffmanStageEncoder
-
- mtfAlphabetSize() - Method in class io.netty.handler.codec.compression.Bzip2MTFAndRLE2StageEncoder
-
- mtfBlock - Variable in class io.netty.handler.codec.compression.Bzip2HuffmanStageEncoder
-
The output of the Move To Front Transform and Run Length Encoding[2] stages.
- mtfBlock - Variable in class io.netty.handler.codec.compression.Bzip2MTFAndRLE2StageEncoder
-
The output of the Move To Front Transform and Run-Length Encoding[2] stages.
- mtfBlock() - Method in class io.netty.handler.codec.compression.Bzip2MTFAndRLE2StageEncoder
-
- mtfLength - Variable in class io.netty.handler.codec.compression.Bzip2HuffmanStageEncoder
-
- mtfLength - Variable in class io.netty.handler.codec.compression.Bzip2MTFAndRLE2StageEncoder
-
- mtfLength() - Method in class io.netty.handler.codec.compression.Bzip2MTFAndRLE2StageEncoder
-
- mtfSymbolFrequencies - Variable in class io.netty.handler.codec.compression.Bzip2HuffmanStageEncoder
-
- mtfSymbolFrequencies - Variable in class io.netty.handler.codec.compression.Bzip2MTFAndRLE2StageEncoder
-
- mtfSymbolFrequencies() - Method in class io.netty.handler.codec.compression.Bzip2MTFAndRLE2StageEncoder
-
- mtfValue - Variable in class io.netty.handler.codec.compression.Bzip2BlockDecompressor
-
- MultiDnsServerAddressStreamProvider - Class in io.netty.resolver.dns
-
- 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.
- multiplier - Static variable in class io.netty.util.internal.ThreadLocalRandom
-
- 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 - Variable in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- name() - Method in interface com.sun.nio.sctp.SctpSocketOption
-
- name - Variable in class io.netty.channel.AbstractChannelHandlerContext
-
- name() - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- name() - Method in interface io.netty.channel.ChannelHandlerContext
-
- name() - Method in class io.netty.channel.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- name() - Method in interface io.netty.channel.group.ChannelGroup
-
Returns the name of this group.
- name - Variable in class io.netty.channel.group.DefaultChannelGroup
-
- name() - Method in class io.netty.channel.group.DefaultChannelGroup
-
- name - Variable in class io.netty.handler.codec.dns.AbstractDnsRecord
-
- name() - Method in class io.netty.handler.codec.dns.AbstractDnsRecord
-
- name - Variable in class io.netty.handler.codec.dns.DnsOpCode
-
- name() - Method in interface io.netty.handler.codec.dns.DnsRecord
-
Returns the name of this resource record.
- name - Variable in class io.netty.handler.codec.dns.DnsRecordType
-
- name() - Method in class io.netty.handler.codec.dns.DnsRecordType
-
Returns the name of this type, as seen in bind config files
- name - Variable in class io.netty.handler.codec.dns.DnsResponseCode
-
- name - Variable in class io.netty.handler.codec.HeadersUtils.StringEntry
-
- name - Variable in class io.netty.handler.codec.mqtt.MqttConnectVariableHeader
-
- name() - Method in class io.netty.handler.codec.mqtt.MqttConnectVariableHeader
-
- name - Variable in enum io.netty.handler.codec.mqtt.MqttVersion
-
- name - Variable in class io.netty.handler.codec.smtp.SmtpCommand
-
- name() - Method in class io.netty.handler.codec.smtp.SmtpCommand
-
Return the command name.
- name - Variable in class io.netty.handler.codec.socksx.v4.Socks4CommandStatus
-
- name - Variable in class io.netty.handler.codec.socksx.v4.Socks4CommandType
-
- name - Variable in class io.netty.handler.codec.socksx.v5.Socks5AddressType
-
- name - Variable in class io.netty.handler.codec.socksx.v5.Socks5AuthMethod
-
- name - Variable in class io.netty.handler.codec.socksx.v5.Socks5CommandStatus
-
- name - Variable in class io.netty.handler.codec.socksx.v5.Socks5CommandType
-
- name - Variable in class io.netty.handler.codec.socksx.v5.Socks5PasswordAuthStatus
-
- name - Variable in class io.netty.handler.traffic.TrafficCounter
-
Name of this Monitor
- name() - Method in class io.netty.handler.traffic.TrafficCounter
-
- name - Variable in class io.netty.util.AbstractConstant
-
- name() - Method in class io.netty.util.AbstractConstant
-
- name() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor.DefaultThreadProperties
-
- name() - Method in interface io.netty.util.concurrent.ThreadProperties
-
- name() - Method in interface io.netty.util.Constant
-
- name - Variable in class io.netty.util.internal.logging.AbstractInternalLogger
-
- name() - Method in class io.netty.util.internal.logging.AbstractInternalLogger
-
- name() - Method in interface io.netty.util.internal.logging.InternalLogger
-
- name() - Method in error io.netty.util.Signal
-
- NAME_SERVERS_EXHAUSTED_EXCEPTION - Static variable in class io.netty.resolver.dns.DnsNameResolverContext
-
- nameCaches - Static variable in class io.netty.channel.DefaultChannelPipeline
-
- nameResolver - Variable in class io.netty.resolver.InetSocketAddressResolver
-
- NameResolver<T> - Interface in io.netty.resolver
-
Resolves an arbitrary string that represents the name of an endpoint into an address.
- nameResolver - Variable in class io.netty.resolver.RoundRobinInetAddressResolver
-
- 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
-
- NAMESERVER_ROW_LABEL - Static variable in class io.netty.resolver.dns.UnixResolverDnsServerAddressStreamProvider
-
- nameServerAddr - Variable in class io.netty.resolver.dns.DnsQueryContext
-
- nameServerAddr() - Method in class io.netty.resolver.dns.DnsQueryContext
-
- 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.UniSequentialDnsServerAddressStreamProvider
-
- nameServerAddressStream(String) - Method in class io.netty.resolver.dns.UnixResolverDnsServerAddressStreamProvider
-
- nameServerAddrs - Variable in class io.netty.resolver.dns.DnsNameResolverContext
-
- nameServerAddrStream - Variable in class io.netty.resolver.dns.DnsNameResolver
-
- nameServerProvider - Variable in class io.netty.resolver.dns.DnsAddressResolverGroup
-
- nameServerProvider(DnsServerAddressStreamProvider) - Method in class io.netty.resolver.dns.DnsNameResolverBuilder
-
- nameValidator - Variable in class io.netty.handler.codec.DefaultHeaders
-
- nanoTime() - Static method in class io.netty.util.concurrent.AbstractScheduledEventExecutor
-
- nanoTime() - Static method in class io.netty.util.concurrent.ScheduledFutureTask
-
- 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.kqueue
-
Navite helper methods
- Native() - Constructor for class io.netty.channel.kqueue.Native
-
- NATIVE_RESOURCE_HOME - Static variable in class io.netty.util.internal.NativeLibraryLoader
-
- nativeByteOrder - Variable in class io.netty.buffer.AbstractUnsafeSwappedByteBuf
-
- NativeConnectException(String, int) - Constructor for exception io.netty.channel.unix.Errors.NativeConnectException
-
- 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.
- NativeLibraryLoader() - Constructor for class io.netty.util.internal.NativeLibraryLoader
-
- NativeLibraryLoader.NoexecVolumeDetector - Class in io.netty.util.internal
-
- NativeLibraryUtil - Class in io.netty.util.internal
-
A Utility to Call the System.load(String)
or System.loadLibrary(String)
.
- NativeLibraryUtil() - Constructor for class io.netty.util.internal.NativeLibraryUtil
-
- NativeLongArray - Class in io.netty.channel.kqueue
-
- NativeLongArray(int) - Constructor for class io.netty.channel.kqueue.NativeLongArray
-
- ndots - Variable in class io.netty.resolver.dns.DnsNameResolver
-
- ndots() - Method in class io.netty.resolver.dns.DnsNameResolver
-
- ndots - Variable in class io.netty.resolver.dns.DnsNameResolverBuilder
-
- 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.
- NDOTS_LABEL - Static variable in class io.netty.resolver.dns.UnixResolverDnsServerAddressStreamProvider
-
- NEEDS_MORE_DATE - Static variable in class io.netty.handler.codec.ProtocolDetectionResult
-
- needsFlush - Variable in class io.netty.handler.ssl.SslHandler
-
Set by wrap*() methods when something is produced.
- needsMoreData() - Static method in class io.netty.handler.codec.ProtocolDetectionResult
-
- needsNormalization(String) - Static method in class io.netty.util.DomainNameMapping
-
- needsToSelectAgain - Variable in class io.netty.channel.nio.NioEventLoop
-
- negativeTtl - Variable in class io.netty.resolver.dns.DefaultDnsCache
-
- negativeTtl() - Method in class io.netty.resolver.dns.DefaultDnsCache
-
Returns the TTL of the cache for the failed DNS queries (in seconds).
- negativeTtl - Variable in class io.netty.resolver.dns.DnsNameResolverBuilder
-
- 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
.
- NettyRuntime() - Constructor for class io.netty.util.NettyRuntime
-
No public constructor to prevent instances from being created.
- NettyRuntime.AvailableProcessorsHolder - Class in io.netty.util
-
Holder class for available processors to enable testing.
- NetUtil - Class in io.netty.util
-
A class that holds a number of network-related constants.
- NetUtil() - Constructor for class io.netty.util.NetUtil
-
A constructor to stop this class being constructed.
- NETWORK_UNREACHABLE - Static variable in class io.netty.handler.codec.socksx.v5.Socks5CommandStatus
-
- networkAddress - Variable in class io.netty.handler.ipfilter.IpSubnetFilterRule.Ip4SubnetFilterRule
-
- networkAddress - Variable in class io.netty.handler.ipfilter.IpSubnetFilterRule.Ip6SubnetFilterRule
-
- neverRegistered - Variable in class io.netty.channel.AbstractChannel.AbstractUnsafe
-
true if the channel has never been registered, false otherwise
- NEW_LINE - Static variable in class io.netty.handler.codec.base64.Base64
-
The new line character (\n) as a byte.
- newAddressResolver(EventLoop, NameResolver<InetAddress>) - Method in class io.netty.resolver.dns.DnsAddressResolverGroup
-
- newAddressResolver(EventLoop, NameResolver<InetAddress>) - Method in class io.netty.resolver.dns.RoundRobinDnsAddressResolverGroup
-
- newArenaArray(int) - Static method in class io.netty.buffer.PooledByteBufAllocator
-
- newAttrArray(int) - Static method in class io.netty.bootstrap.ServerBootstrap
-
- newBuffer(ByteBufAllocator, boolean, int) - Static method in class io.netty.handler.ssl.PemX509Certificate
-
- newByteArray(int) - Static method in class io.netty.buffer.PoolArena.HeapArena
-
- newByteBuf(int) - Method in class io.netty.buffer.PoolArena.DirectArena
-
- newByteBuf(int) - Method in class io.netty.buffer.PoolArena.HeapArena
-
- newByteBuf(int) - Method in class io.netty.buffer.PoolArena
-
- newCache() - Method in class io.netty.resolver.dns.DnsNameResolverBuilder
-
- 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
-
- 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.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
-
- newChild(Executor, Object...) - Method in class io.netty.util.concurrent.DefaultEventExecutorGroup
-
- newChild(Executor, Object...) - Method in class io.netty.util.concurrent.MultithreadEventExecutorGroup
-
- newChildChannel(int, byte[], int, int) - Method in class io.netty.channel.kqueue.AbstractKQueueServerChannel
-
- 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
-
- newChunk(int, int, int, int) - Method in class io.netty.buffer.PoolArena.DirectArena
-
- newChunk(int, int, int, int) - Method in class io.netty.buffer.PoolArena.HeapArena
-
- newChunk(int, int, int, int) - Method in class io.netty.buffer.PoolArena
-
- newClientContext() - Static method in class io.netty.handler.ssl.SslContext
-
- newClientContext(File) - Static method in class io.netty.handler.ssl.SslContext
-
- newClientContext(TrustManagerFactory) - Static method in class io.netty.handler.ssl.SslContext
-
- newClientContext(File, TrustManagerFactory) - Static method in class io.netty.handler.ssl.SslContext
-
- newClientContext(File, TrustManagerFactory, Iterable<String>, Iterable<String>, long, long) - Static method in class io.netty.handler.ssl.SslContext
-
- newClientContext(File, TrustManagerFactory, Iterable<String>, CipherSuiteFilter, ApplicationProtocolConfig, long, long) - Static method in class io.netty.handler.ssl.SslContext
-
- newClientContext(SslProvider) - Static method in class io.netty.handler.ssl.SslContext
-
- newClientContext(SslProvider, File) - Static method in class io.netty.handler.ssl.SslContext
-
- newClientContext(SslProvider, TrustManagerFactory) - Static method in class io.netty.handler.ssl.SslContext
-
- newClientContext(SslProvider, File, TrustManagerFactory) - Static method in class io.netty.handler.ssl.SslContext
-
- newClientContext(SslProvider, File, TrustManagerFactory, Iterable<String>, Iterable<String>, long, long) - Static method in class io.netty.handler.ssl.SslContext
-
- newClientContext(SslProvider, File, TrustManagerFactory, Iterable<String>, CipherSuiteFilter, ApplicationProtocolConfig, long, long) - Static method in class io.netty.handler.ssl.SslContext
-
- newClientContext(SslProvider, File, TrustManagerFactory, File, File, String, KeyManagerFactory, Iterable<String>, CipherSuiteFilter, ApplicationProtocolConfig, long, long) - Static method in class io.netty.handler.ssl.SslContext
-
- newClientContextInternal(SslProvider, Provider, X509Certificate[], TrustManagerFactory, X509Certificate[], PrivateKey, String, KeyManagerFactory, Iterable<String>, CipherSuiteFilter, ApplicationProtocolConfig, String[], long, long, boolean) - Static method in class io.netty.handler.ssl.SslContext
-
- newCloseFuture() - Method in interface io.netty.channel.group.ChannelGroup
-
- newCloseFuture(ChannelMatcher) - Method in interface io.netty.channel.group.ChannelGroup
-
- 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
-
- newContext(EventExecutorGroup, String, ChannelHandler) - Method in class io.netty.channel.DefaultChannelPipeline
-
- 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
-
- newDecoderException(ByteBuf, int, int) - Static method in class io.netty.handler.codec.smtp.SmtpResponseDecoder
-
- newDefaultFactory(String) - Static method in class io.netty.util.internal.logging.InternalLoggerFactory
-
- 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.kqueue.AbstractKQueueChannel
-
Returns an off-heap copy of the specified
ByteBuf
, and releases the original one.
- newDirectBuffer(Object, ByteBuf) - Method in class io.netty.channel.kqueue.AbstractKQueueChannel
-
Returns an off-heap copy of the specified
ByteBuf
, and releases the specified holder.
- 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.
- newDirectBuffer(long, int) - Static method in class io.netty.util.internal.PlatformDependent0
-
- newDirectBuffer0(Object, ByteBuf, ByteBufAllocator, int) - Static method in class io.netty.channel.kqueue.AbstractKQueueChannel
-
- newDnsQueryLifecycleObserver(DnsQuestion) - Method in class io.netty.resolver.dns.BiDnsQueryLifecycleObserverFactory
-
- newDnsQueryLifecycleObserver(DnsQuestion) - Method in interface io.netty.resolver.dns.DnsQueryLifecycleObserverFactory
-
- newDnsQueryLifecycleObserver(DnsQuestion) - Method in class io.netty.resolver.dns.NoopDnsQueryLifecycleObserverFactory
-
- newDnsQueryLifecycleObserver(DnsQuestion) - Method in class io.netty.resolver.dns.TraceDnsQueryLifeCycleObserverFactory
-
- 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.
- newEntry(PoolChunk<?>, long) - Static method in class io.netty.buffer.PoolThreadCache.MemoryRegionCache
-
- newExecutor(EventExecutor) - Method in class io.netty.util.concurrent.NonStickyEventExecutorGroup
-
- newFailedFuture(Throwable) - Method in class io.netty.channel.AbstractChannel
-
- newFailedFuture(Throwable) - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- newFailedFuture(Throwable) - Method in interface io.netty.channel.ChannelOutboundInvoker
-
- newFailedFuture(Throwable) - Method in class io.netty.channel.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- 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.
- newHandle() - Method in class io.netty.util.Recycler.Stack
-
- newHandler(ByteBufAllocator) - Method in class io.netty.handler.ssl.SslContext
-
- 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
-
- newIdleStateEvent(IdleState, boolean) - Method in class io.netty.handler.timeout.IdleStateHandler
-
- newIndexedVariableTable() - Static method in class io.netty.util.internal.InternalThreadLocalMap
-
- newInlineRedisMessage(RedisMessageType, ByteBuf) - Method in class io.netty.handler.codec.redis.RedisDecoder
-
- newInstance() - Static method in class io.netty.buffer.ByteBufUtil.ThreadLocalDirectByteBuf
-
- newInstance() - Static method in class io.netty.buffer.ByteBufUtil.ThreadLocalUnsafeDirectByteBuf
-
- newInstance(int) - Static method in class io.netty.buffer.PooledDirectByteBuf
-
- newInstance(AbstractByteBuf, ByteBuf, int, int) - Static method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- newInstance(int) - Static method in class io.netty.buffer.PooledHeapByteBuf
-
- newInstance(AbstractByteBuf, ByteBuf, int, int) - Static method in class io.netty.buffer.PooledSlicedByteBuf
-
- newInstance(int) - Static method in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- newInstance(AbstractChannelHandlerContext, Object, ChannelPromise) - Static method in class io.netty.channel.AbstractChannelHandlerContext.WriteAndFlushTask
-
- newInstance(AbstractChannelHandlerContext, Object, ChannelPromise) - Static method in class io.netty.channel.AbstractChannelHandlerContext.WriteTask
-
- 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(Object, int, long, ChannelPromise) - Static method in class io.netty.channel.ChannelOutboundBuffer.Entry
-
- newInstance() - Static method in class io.netty.channel.DefaultChannelId
-
- newInstance(Object, int, ChannelPromise) - Static method in class io.netty.channel.PendingWriteQueue.PendingWrite
-
- newInstance(InetAddress) - Static method in class io.netty.channel.unix.NativeInetAddress
-
- newInstance() - Static method in class io.netty.handler.codec.CodecOutputList
-
- newInstance() - Static method in class io.netty.handler.flow.FlowControlHandler.RecyclableArrayDeque
-
- 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.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
-
- newInstance() - Static method in class io.netty.util.internal.RecyclableArrayList
-
- newInstance(int) - Static method in class io.netty.util.internal.RecyclableArrayList
-
- newInstance0(AbstractByteBuf, ByteBuf, int, int) - Static method in class io.netty.buffer.PooledSlicedByteBuf
-
- newInternalNioBuffer(T) - Method in class io.netty.buffer.PooledByteBuf
-
- newInternalNioBuffer(ByteBuffer) - Method in class io.netty.buffer.PooledDirectByteBuf
-
- newInternalNioBuffer(byte[]) - Method in class io.netty.buffer.PooledHeapByteBuf
-
- newInternalNioBuffer(ByteBuffer) - Method in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- newInvalidEscapedCsvFieldException(CharSequence, int) - Static method in class io.netty.util.internal.StringUtil
-
- newInvalidMessage(Throwable) - Static method in class io.netty.handler.codec.mqtt.MqttMessageFactory
-
- newIOException(String, int) - Static method in class io.netty.channel.unix.Errors
-
- newKQueue() - Static method in class io.netty.channel.kqueue.Native
-
- newLeakAwareByteBuf(ByteBuf, ByteBuf, ResourceLeakTracker<ByteBuf>) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- newLeakAwareByteBuf(ByteBuf, ByteBuf, ResourceLeakTracker<ByteBuf>) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- newLeakAwareByteBuf(ByteBuf, ResourceLeakTracker<ByteBuf>) - Method in class io.netty.buffer.SimpleLeakAwareByteBuf
-
- newLeakAwareByteBuf(ByteBuf, ByteBuf, ResourceLeakTracker<ByteBuf>) - Method in class io.netty.buffer.SimpleLeakAwareByteBuf
-
- newLeakAwareByteBuf(ByteBuf) - Method in class io.netty.buffer.SimpleLeakAwareCompositeByteBuf
-
- newLeakAwareByteBuf(ByteBuf, ByteBuf, ResourceLeakTracker<ByteBuf>) - Method in class io.netty.buffer.SimpleLeakAwareCompositeByteBuf
-
- NEWLINE - Static variable in class io.netty.util.internal.StringUtil
-
- newlineType - Variable in class io.netty.handler.codec.AsciiHeadersEncoder
-
- NewlineType() - Constructor for enum io.netty.handler.codec.AsciiHeadersEncoder.NewlineType
-
- newList(int) - Static method in class io.netty.buffer.CompositeByteBuf
-
- newListener(SSLEngine, List<String>) - Method in interface io.netty.handler.ssl.JdkApplicationProtocolNegotiator.ProtocolSelectionListenerFactory
-
- newLocalChannel(LocalChannel) - Method in class io.netty.channel.local.LocalServerChannel
-
- newLongCounter() - Static method in class io.netty.util.internal.PlatformDependent
-
Creates a new fastest
LongCounter
implementation for the current platform.
- newLongValue() - Method in class io.netty.channel.DefaultChannelId
-
- newMessage(MqttFixedHeader, Object, Object) - Static method in class io.netty.handler.codec.mqtt.MqttMessageFactory
-
- newMpscQueue(int) - Static method in class io.netty.util.internal.PlatformDependent.Mpsc
-
- 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
-
- 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
.
- newOptionArray(int) - Static method in class io.netty.bootstrap.ServerBootstrap
-
- newPipe() - Static method in class io.netty.channel.unix.FileDescriptor
-
- 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 class io.netty.channel.AbstractChannelHandlerContext
-
- newProgressivePromise() - Method in interface io.netty.channel.ChannelOutboundInvoker
-
- newProgressivePromise() - Method in class io.netty.channel.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- 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
-
- 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 class io.netty.channel.AbstractChannelHandlerContext
-
- newPromise() - Method in interface io.netty.channel.ChannelOutboundInvoker
-
- newPromise() - Method in class io.netty.channel.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- 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
-
- newPromise() - Method in class io.netty.util.concurrent.ImmediateEventExecutor
-
- newPromise() - Method in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor
-
- newQuery(DatagramPacket, ByteBuf) - Static method in class io.netty.handler.codec.dns.DatagramDnsQueryDecoder
-
- newQuestion(String, DnsRecordType) - Method in class io.netty.resolver.dns.DnsNameResolverContext
-
- newQueue(Recycler.Stack<?>, Thread) - Static method in class io.netty.util.Recycler.WeakOrderQueue
-
- newRecord(Object, int) - Static method in class io.netty.util.ResourceLeakDetector
-
- newRecordList() - Static method in class io.netty.handler.codec.dns.AbstractDnsMessage
-
- 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
-
- newResolverContext(DnsNameResolver, String, DnsRecord[], DnsCache, DnsServerAddressStream) - Method in class io.netty.resolver.dns.DnsNameResolver.ListResolverContext
-
- newResolverContext(DnsNameResolver, String, DnsRecord[], DnsCache, DnsServerAddressStream) - Method in class io.netty.resolver.dns.DnsNameResolver.SingleResolverContext
-
- newResolverContext(DnsNameResolver, String, DnsRecord[], DnsCache, DnsServerAddressStream) - Method in class io.netty.resolver.dns.DnsNameResolverContext
-
- newResourceLeakDetector(Class<T>, int, long) - Method in class io.netty.util.ResourceLeakDetectorFactory.DefaultResourceLeakDetectorFactory
-
- newResourceLeakDetector(Class<T>, int) - Method in class io.netty.util.ResourceLeakDetectorFactory.DefaultResourceLeakDetectorFactory
-
- newResourceLeakDetector(Class<T>) - Method in class io.netty.util.ResourceLeakDetectorFactory
-
- newResourceLeakDetector(Class<T>, int, long) - Method in class io.netty.util.ResourceLeakDetectorFactory
-
- newResourceLeakDetector(Class<T>, int) - Method in class io.netty.util.ResourceLeakDetectorFactory
-
- newResponse(DatagramPacket, ByteBuf) - Static method in class io.netty.handler.codec.dns.DatagramDnsResponseDecoder
-
- newSctpChannel() - Static method in class io.netty.channel.sctp.nio.NioSctpChannel
-
- newSeed() - Static method in class io.netty.util.internal.ThreadLocalRandom
-
- 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
-
- newSelfSignedCertificate(String, PrivateKey, X509Certificate) - Static method in class io.netty.handler.ssl.util.SelfSignedCertificate
-
- newServerContext(File, File) - Static method in class io.netty.handler.ssl.SslContext
-
- newServerContext(File, File, String) - Static method in class io.netty.handler.ssl.SslContext
-
- newServerContext(File, File, String, Iterable<String>, Iterable<String>, long, long) - Static method in class io.netty.handler.ssl.SslContext
-
- newServerContext(File, File, String, Iterable<String>, CipherSuiteFilter, ApplicationProtocolConfig, long, long) - Static method in class io.netty.handler.ssl.SslContext
-
- newServerContext(SslProvider, File, File) - Static method in class io.netty.handler.ssl.SslContext
-
- newServerContext(SslProvider, File, File, String) - Static method in class io.netty.handler.ssl.SslContext
-
- newServerContext(SslProvider, File, File, String, Iterable<String>, Iterable<String>, long, long) - Static method in class io.netty.handler.ssl.SslContext
-
- newServerContext(SslProvider, File, File, String, TrustManagerFactory, Iterable<String>, Iterable<String>, long, long) - Static method in class io.netty.handler.ssl.SslContext
-
- newServerContext(SslProvider, File, File, String, Iterable<String>, CipherSuiteFilter, ApplicationProtocolConfig, long, long) - Static method in class io.netty.handler.ssl.SslContext
-
- newServerContext(SslProvider, File, TrustManagerFactory, File, File, String, KeyManagerFactory, Iterable<String>, CipherSuiteFilter, ApplicationProtocolConfig, long, long) - Static method in class io.netty.handler.ssl.SslContext
-
- newServerContextInternal(SslProvider, Provider, X509Certificate[], TrustManagerFactory, X509Certificate[], PrivateKey, String, KeyManagerFactory, Iterable<String>, CipherSuiteFilter, ApplicationProtocolConfig, long, long, ClientAuth, String[], boolean, boolean) - Static method in class io.netty.handler.ssl.SslContext
-
- newServerSocket() - Static method in class io.netty.channel.sctp.oio.OioSctpServerChannel
-
- newServerSocket() - Static method in class io.netty.channel.socket.oio.OioServerSocketChannel
-
- newSharedLeakAwareByteBuf(ByteBuf) - Method in class io.netty.buffer.SimpleLeakAwareByteBuf
-
- newSocket() - Static method in class io.netty.channel.sctp.nio.NioSctpServerChannel
-
- newSocket(SelectorProvider) - Static method in class io.netty.channel.socket.nio.NioDatagramChannel
-
- newSocket(SelectorProvider, InternetProtocolFamily) - Static method in class io.netty.channel.socket.nio.NioDatagramChannel
-
- newSocket(SelectorProvider) - Static method in class io.netty.channel.socket.nio.NioServerSocketChannel
-
- newSocket(SelectorProvider) - Static method in class io.netty.channel.socket.nio.NioSocketChannel
-
- newSocket() - Static method in class io.netty.channel.socket.oio.OioDatagramChannel
-
- newSocket() - Method in class io.netty.channel.unix.tests.SocketTest
-
- newSocketAddress() - Static method in class io.netty.channel.unix.tests.UnixTestUtils
-
- newSocketAddressStringBuilder(String, String, boolean) - Static method in class io.netty.util.NetUtil
-
- newSocketDgram() - Static method in class io.netty.channel.kqueue.BsdSocket
-
- newSocketDgram() - Static method in class io.netty.channel.unix.Socket
-
- newSocketDgram0() - Static method in class io.netty.channel.unix.Socket
-
- newSocketDgramFd() - Static method in class io.netty.channel.unix.Socket
-
- newSocketDomain() - Static method in class io.netty.channel.kqueue.BsdSocket
-
- newSocketDomain() - Static method in class io.netty.channel.unix.Socket
-
- newSocketDomain0() - Static method in class io.netty.channel.unix.Socket
-
- newSocketDomainFd() - Static method in class io.netty.channel.unix.Socket
-
- newSocketStream() - Static method in class io.netty.channel.kqueue.BsdSocket
-
- newSocketStream() - Static method in class io.netty.channel.unix.Socket
-
- newSocketStream0() - Static method in class io.netty.channel.unix.Socket
-
- newSocketStreamFd() - 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!).
- newSSLContext(Provider, X509Certificate[], TrustManagerFactory, X509Certificate[], PrivateKey, String, KeyManagerFactory, long, long) - Static method in class io.netty.handler.ssl.JdkSslClientContext
-
Deprecated.
- newSSLContext(Provider, X509Certificate[], TrustManagerFactory, X509Certificate[], PrivateKey, String, KeyManagerFactory, long, long) - Static method in class io.netty.handler.ssl.JdkSslServerContext
-
Deprecated.
- 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
.
- newSubpageArray(int) - Method in class io.netty.buffer.PoolChunk
-
- newSubpagePoolArray(int) - Method in class io.netty.buffer.PoolArena
-
- newSubpagePoolHead(int) - Method in class io.netty.buffer.PoolArena
-
- newSucceededFuture() - Method in class io.netty.channel.AbstractChannel
-
- newSucceededFuture() - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- newSucceededFuture() - Method in interface io.netty.channel.ChannelOutboundInvoker
-
- newSucceededFuture() - Method in class io.netty.channel.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- 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
-
- newSwappedByteBuf() - Method in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- newSwappedByteBuf() - Method in class io.netty.buffer.PooledUnsafeHeapByteBuf
-
Deprecated.
- newSwappedByteBuf() - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
-
- newSwappedByteBuf() - Method in class io.netty.buffer.UnpooledUnsafeHeapByteBuf
-
Deprecated.
- newSwappedByteBuf() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- 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.kqueue.KQueueEventLoop
-
- newTaskQueue(int) - Method in class io.netty.channel.nio.NioEventLoop
-
- newTaskQueue() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- 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.
- newUnpooledChunk(int) - Method in class io.netty.buffer.PoolArena.DirectArena
-
- newUnpooledChunk(int) - Method in class io.netty.buffer.PoolArena.HeapArena
-
- newUnpooledChunk(int) - Method in class io.netty.buffer.PoolArena
-
- newUnsafe() - Method in class io.netty.channel.AbstractChannel
-
- newUnsafe() - Method in class io.netty.channel.AbstractServerChannel
-
- newUnsafe() - Method in class io.netty.channel.embedded.EmbeddedChannel
-
- newUnsafe() - Method in class io.netty.channel.kqueue.AbstractKQueueChannel
-
- 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
-
- newUnsafeDirectByteBuf(ByteBufAllocator, int, int) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- newUnsafeInstance(int) - Static method in class io.netty.buffer.PooledUnsafeHeapByteBuf
-
- 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.buffer.CompositeByteBuf.CompositeByteBufIterator
-
- next - Variable in class io.netty.buffer.PoolChunk
-
- next - Variable in class io.netty.buffer.PoolSubpage
-
- next - Variable in class io.netty.channel.AbstractChannelHandlerContext
-
- next() - Method in class io.netty.channel.AbstractEventLoop
-
- next() - Method in class io.netty.channel.AbstractEventLoopGroup
-
- next - Variable in class io.netty.channel.ChannelOutboundBuffer.Entry
-
- next - Variable in class io.netty.channel.DefaultChannelPipeline.PendingHandlerCallback
-
- next() - Method in class io.netty.channel.embedded.EmbeddedEventLoop
-
- next() - Method in interface io.netty.channel.EventLoopGroup
-
- next() - Method in class io.netty.channel.group.CombinedIterator
-
- next() - Method in class io.netty.channel.MultithreadEventLoopGroup
-
- next - Variable in class io.netty.channel.PendingWriteQueue.PendingWrite
-
- 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 class io.netty.handler.codec.DefaultHeaders.HeaderIterator
-
- next() - Method in class io.netty.handler.codec.HeadersUtils.StringEntryIterator
-
- next() - Method in class io.netty.handler.codec.HeadersUtils.StringIterator
-
- next - Variable in class io.netty.handler.timeout.WriteTimeoutHandler.WriteTimeoutTask
-
- next - Variable in class io.netty.resolver.dns.DnsNameResolverContext.AuthoritativeNameServer
-
- next() - Method in interface io.netty.resolver.dns.DnsServerAddressStream
-
Retrieves the next DNS server address from the stream.
- next() - Method in class io.netty.resolver.dns.SequentialDnsServerAddressStream
-
- next() - Method in class io.netty.resolver.dns.ShuffledDnsServerAddressStream
-
- next() - Method in class io.netty.util.collection.ByteCollections.UnmodifiableMap.IteratorImpl
-
- next() - Method in class io.netty.util.collection.ByteObjectHashMap.MapIterator
-
- next() - Method in class io.netty.util.collection.ByteObjectHashMap.PrimitiveIterator
-
- next() - Method in class io.netty.util.collection.CharCollections.UnmodifiableMap.IteratorImpl
-
- next() - Method in class io.netty.util.collection.CharObjectHashMap.MapIterator
-
- next() - Method in class io.netty.util.collection.CharObjectHashMap.PrimitiveIterator
-
- next() - Method in class io.netty.util.collection.IntCollections.UnmodifiableMap.IteratorImpl
-
- next() - Method in class io.netty.util.collection.IntObjectHashMap.MapIterator
-
- next() - Method in class io.netty.util.collection.IntObjectHashMap.PrimitiveIterator
-
- next() - Method in class io.netty.util.collection.LongCollections.UnmodifiableMap.IteratorImpl
-
- next() - Method in class io.netty.util.collection.LongObjectHashMap.MapIterator
-
- next() - Method in class io.netty.util.collection.LongObjectHashMap.PrimitiveIterator
-
- next() - Method in class io.netty.util.collection.ShortCollections.UnmodifiableMap.IteratorImpl
-
- next() - Method in class io.netty.util.collection.ShortObjectHashMap.MapIterator
-
- next() - Method in class io.netty.util.collection.ShortObjectHashMap.PrimitiveIterator
-
- next() - Method in class io.netty.util.concurrent.AbstractEventExecutor
-
- next() - Method in class io.netty.util.concurrent.DefaultEventExecutorChooserFactory.GenericEventExecutorChooser
-
- next() - Method in class io.netty.util.concurrent.DefaultEventExecutorChooserFactory.PowerOfTwoEventExecutorChooser
-
- next() - Method in interface io.netty.util.concurrent.EventExecutor
-
Returns a reference to itself.
- next() - Method in interface io.netty.util.concurrent.EventExecutorChooserFactory.EventExecutorChooser
-
- next() - Method in interface io.netty.util.concurrent.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 - Variable in class io.netty.util.DefaultAttributeMap.DefaultAttribute
-
- next - Variable in class io.netty.util.HashedWheelTimer.HashedWheelTimeout
-
- next() - Method in class io.netty.util.internal.DefaultPriorityQueue.PriorityQueueIterator
-
- next() - Method in class io.netty.util.internal.ReadOnlyIterator
-
- next(int) - Method in class io.netty.util.internal.ThreadLocalRandom
-
- next - Variable in class io.netty.util.Recycler.WeakOrderQueue.Link
-
- next - Variable in class io.netty.util.Recycler.WeakOrderQueue
-
- nextAvail - Variable in class io.netty.buffer.PoolSubpage
-
- nextBoolean() - Method in class io.netty.handler.ssl.util.ThreadLocalInsecureRandom
-
- nextBytes(byte[]) - Method in class io.netty.handler.ssl.util.ThreadLocalInsecureRandom
-
- nextChild() - Method in class io.netty.channel.ThreadPerChannelEventLoopGroup
-
- nextDouble() - Method in class io.netty.handler.ssl.util.ThreadLocalInsecureRandom
-
- 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).
- nextFloat() - Method in class io.netty.handler.ssl.util.ThreadLocalInsecureRandom
-
- nextGaussian() - Method in class io.netty.handler.ssl.util.ThreadLocalInsecureRandom
-
- nextId - Static variable in class io.netty.channel.group.DefaultChannelGroup
-
- nextId - Variable in class io.netty.util.concurrent.DefaultThreadFactory
-
- nextId - Variable in class io.netty.util.ConstantPool
-
- nextId() - Method in class io.netty.util.ConstantPool
-
Deprecated.
- nextIndex - Variable in class io.netty.util.collection.ByteObjectHashMap.PrimitiveIterator
-
- nextIndex - Variable in class io.netty.util.collection.CharObjectHashMap.PrimitiveIterator
-
- nextIndex - Variable in class io.netty.util.collection.IntObjectHashMap.PrimitiveIterator
-
- nextIndex - Variable in class io.netty.util.collection.LongObjectHashMap.PrimitiveIterator
-
- nextIndex - Variable in class io.netty.util.collection.ShortObjectHashMap.PrimitiveIterator
-
- nextIndex - Static variable in class io.netty.util.internal.UnpaddedInternalThreadLocalMap
-
- nextInt() - Method in class io.netty.handler.ssl.util.ThreadLocalInsecureRandom
-
- nextInt(int) - Method in class io.netty.handler.ssl.util.ThreadLocalInsecureRandom
-
- 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).
- nextList - Variable in class io.netty.buffer.PoolChunkList
-
- nextLong() - Method in class io.netty.handler.ssl.util.ThreadLocalInsecureRandom
-
- 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).
- nextNameServerAddress() - Method in class io.netty.resolver.dns.DnsNameResolver
-
- nextProtocols() - Method in class io.netty.handler.ssl.SslContext
-
- nextReceiveBufferSize - Variable in class io.netty.channel.AdaptiveRecvByteBufAllocator.HandleImpl
-
- nextScheduledFlush - Variable in class io.netty.handler.flush.FlushConsolidationHandler
-
- nextScheduledTask() - Method in class io.netty.channel.embedded.EmbeddedEventLoop
-
- 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.
- nextSequence - Static variable in class io.netty.channel.DefaultChannelId
-
- nextSymbol() - Method in class io.netty.handler.codec.compression.Bzip2HuffmanStageDecoder
-
Decodes and returns the next symbol.
- nextTaskId - Static variable in class io.netty.util.concurrent.ScheduledFutureTask
-
- nextVariableIndex() - Static method in class io.netty.util.internal.InternalThreadLocalMap
-
- NIO_BUFFERS - Static variable in class io.netty.channel.ChannelOutboundBuffer
-
- nioBuffer() - Method in class io.netty.buffer.AbstractByteBuf
-
- nioBuffer(int, int) - Method in class io.netty.buffer.AbstractDerivedByteBuf
-
Deprecated.
- nioBuffer(int, int) - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- nioBuffer() - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- nioBuffer(int, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- nioBuffer() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- nioBuffer(int, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.FixedCompositeByteBuf
-
- nioBuffer(int, int) - Method in class io.netty.buffer.PooledDirectByteBuf
-
- nioBuffer(int, int) - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- nioBuffer(int, int) - Method in class io.netty.buffer.PooledHeapByteBuf
-
- nioBuffer(int, int) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- nioBuffer(int, int) - Method in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- nioBuffer(int, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
-
Deprecated.
- nioBuffer(int, int) - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- 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
-
- nioBuffer() - Method in class io.netty.buffer.WrappedByteBuf
-
- nioBuffer(int, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- nioBuffer() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- nioBuffer(int, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- nioBuffer() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- nioBuffer(int, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- nioBufferCount() - Method in class io.netty.buffer.AbstractPooledDerivedByteBuf
-
- nioBufferCount() - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- nioBufferCount() - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- nioBufferCount() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- nioBufferCount() - Method in class io.netty.buffer.ByteBuf
-
Returns the maximum number of NIO ByteBuffer
s 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 - Variable in class io.netty.buffer.FixedCompositeByteBuf
-
- nioBufferCount() - Method in class io.netty.buffer.FixedCompositeByteBuf
-
- nioBufferCount() - Method in class io.netty.buffer.PooledDirectByteBuf
-
- nioBufferCount() - Method in class io.netty.buffer.PooledHeapByteBuf
-
- nioBufferCount() - Method in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- nioBufferCount() - Method in class io.netty.buffer.ReadOnlyByteBuf
-
Deprecated.
- nioBufferCount() - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- 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.buffer.WrappedByteBuf
-
- nioBufferCount() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- nioBufferCount - Variable in class io.netty.channel.ChannelOutboundBuffer
-
- nioBufferCount() - Method in class io.netty.channel.ChannelOutboundBuffer
-
- nioBufferCount() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- nioBuffers() - Method in class io.netty.buffer.AbstractByteBuf
-
- nioBuffers(int, int) - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- nioBuffers() - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- nioBuffers(int, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- nioBuffers() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- nioBuffers(int, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.FixedCompositeByteBuf
-
- nioBuffers(int, int) - Method in class io.netty.buffer.PooledDirectByteBuf
-
- nioBuffers(int, int) - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- nioBuffers(int, int) - Method in class io.netty.buffer.PooledHeapByteBuf
-
- nioBuffers(int, int) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- nioBuffers(int, int) - Method in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- nioBuffers(int, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
-
Deprecated.
- nioBuffers(int, int) - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- 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.buffer.WrappedByteBuf
-
- nioBuffers(int, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- nioBuffers(int, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- nioBuffers() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- 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.
- nioBuffers() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- nioBuffers(int, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- nioBufferSize - Variable in class io.netty.channel.ChannelOutboundBuffer
-
- nioBufferSize() - Method in class io.netty.channel.ChannelOutboundBuffer
-
- NioByteUnsafe() - Constructor for class io.netty.channel.nio.AbstractNioByteChannel.NioByteUnsafe
-
- NioDatagramChannel - Class in io.netty.channel.socket.nio
-
- NioDatagramChannel() - Constructor for class io.netty.channel.socket.nio.NioDatagramChannel
-
- 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
-
- NioDatagramChannel(SelectorProvider, InternetProtocolFamily) - Constructor for class io.netty.channel.socket.nio.NioDatagramChannel
-
- NioDatagramChannel(DatagramChannel) - Constructor for class io.netty.channel.socket.nio.NioDatagramChannel
-
Create a new instance from the given DatagramChannel
.
- NioDatagramChannelConfig - Class in io.netty.channel.socket.nio
-
- NioDatagramChannelConfig(NioDatagramChannel, DatagramChannel) - Constructor for class io.netty.channel.socket.nio.NioDatagramChannelConfig
-
- NioEventLoop - Class in io.netty.channel.nio
-
- NioEventLoop(NioEventLoopGroup, Executor, SelectorProvider, SelectStrategy, RejectedExecutionHandler) - Constructor for class io.netty.channel.nio.NioEventLoop
-
- NioEventLoop.SelectorTuple - Class in io.netty.channel.nio
-
- NioEventLoopGroup - Class in io.netty.channel.nio
-
- 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
-
- NioMessageUnsafe() - Constructor for class io.netty.channel.nio.AbstractNioMessageChannel.NioMessageUnsafe
-
- NioSctpChannel - Class in io.netty.channel.sctp.nio
-
- NioSctpChannel() - Constructor for class io.netty.channel.sctp.nio.NioSctpChannel
-
Create a new instance
- NioSctpChannel(SctpChannel) - Constructor for class io.netty.channel.sctp.nio.NioSctpChannel
-
- NioSctpChannel(Channel, SctpChannel) - Constructor for class io.netty.channel.sctp.nio.NioSctpChannel
-
Create a new instance
- NioSctpChannel.NioSctpChannelConfig - Class in io.netty.channel.sctp.nio
-
- NioSctpChannelConfig(NioSctpChannel, SctpChannel) - Constructor for class io.netty.channel.sctp.nio.NioSctpChannel.NioSctpChannelConfig
-
- NioSctpServerChannel - Class in io.netty.channel.sctp.nio
-
- NioSctpServerChannel() - Constructor for class io.netty.channel.sctp.nio.NioSctpServerChannel
-
Create a new instance
- NioSctpServerChannel.NioSctpServerChannelConfig - Class in io.netty.channel.sctp.nio
-
- NioSctpServerChannelConfig(NioSctpServerChannel, SctpServerChannel) - Constructor for class io.netty.channel.sctp.nio.NioSctpServerChannel.NioSctpServerChannelConfig
-
- 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
.
- NioServerSocketChannel.NioServerSocketChannelConfig - Class in io.netty.channel.socket.nio
-
- NioServerSocketChannelConfig(NioServerSocketChannel, ServerSocket) - Constructor for class io.netty.channel.socket.nio.NioServerSocketChannel.NioServerSocketChannelConfig
-
- NioSocketChannel - Class in io.netty.channel.socket.nio
-
- 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
- NioSocketChannel.NioSocketChannelConfig - Class in io.netty.channel.socket.nio
-
- NioSocketChannel.NioSocketChannelUnsafe - Class in io.netty.channel.socket.nio
-
- NioSocketChannelConfig(NioSocketChannel, Socket) - Constructor for class io.netty.channel.socket.nio.NioSocketChannel.NioSocketChannelConfig
-
- NioSocketChannelUnsafe() - Constructor for class io.netty.channel.socket.nio.NioSocketChannel.NioSocketChannelUnsafe
-
- NioTask<C extends java.nio.channels.SelectableChannel> - Interface in io.netty.channel.nio
-
An arbitrary task that can be executed by
NioEventLoop
when a
SelectableChannel
becomes ready.
- NO_AUTH - Static variable in class io.netty.handler.codec.socksx.v5.Socks5AuthMethod
-
- NO_FAIL_SELECTION_LISTENER_FACTORY - Static variable in class io.netty.handler.ssl.JdkBaseApplicationProtocolNegotiator
-
- NO_FAIL_SELECTOR_FACTORY - Static variable in class io.netty.handler.ssl.JdkBaseApplicationProtocolNegotiator
-
- NO_MATCHING_RECORD_QUERY_FAILED_EXCEPTION - Static variable in class io.netty.resolver.dns.DnsNameResolverContext
-
- NOERROR - Static variable in class io.netty.handler.codec.dns.DnsResponseCode
-
The 'NoError' DNS RCODE (0), as defined in
RFC1035.
- NoexecVolumeDetector() - Constructor for class io.netty.util.internal.NativeLibraryLoader.NoexecVolumeDetector
-
- NoFailProtocolSelectionListener(JdkSslEngine, List<String>) - Constructor for class io.netty.handler.ssl.JdkBaseApplicationProtocolNegotiator.NoFailProtocolSelectionListener
-
- NoFailProtocolSelector(JdkSslEngine, Set<String>) - Constructor for class io.netty.handler.ssl.JdkBaseApplicationProtocolNegotiator.NoFailProtocolSelector
-
- noJdkZlibDecoder - Static variable in class io.netty.handler.codec.compression.ZlibCodecFactory
-
- noJdkZlibEncoder - Static variable in class io.netty.handler.codec.compression.ZlibCodecFactory
-
- NON_SERVER_CHANNEL_MATCHER - Static variable in class io.netty.channel.group.ChannelMatchers
-
- NONE - Static variable in class io.netty.util.concurrent.NonStickyEventExecutorGroup.NonStickyOrderedEventExecutor
-
- NonNotifyRunnable(Runnable) - Constructor for class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor.NonNotifyRunnable
-
- nonServerChannels - Variable in class io.netty.channel.group.DefaultChannelGroup
-
- 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
Runnable
s.
- 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.
- NonStickyEventExecutorGroup.NonStickyOrderedEventExecutor - Class in io.netty.util.concurrent
-
- NonStickyOrderedEventExecutor(EventExecutor, int) - Constructor for class io.netty.util.concurrent.NonStickyEventExecutorGroup.NonStickyOrderedEventExecutor
-
- 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 variable in class io.netty.handler.codec.smtp.SmtpRequests
-
- noop() - Static method in class io.netty.handler.codec.smtp.SmtpRequests
-
Creates a NOOP
request.
- NOOP - Static variable in class io.netty.util.internal.PlatformDependent
-
- NOOP - Static variable in class io.netty.util.internal.TypeParameterMatcher
-
- NOOP_HANDLE - Static variable in class io.netty.util.Recycler
-
- NOOP_TASK - Static variable in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- 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
-
- NoopAddressResolverGroup() - Constructor for class io.netty.resolver.NoopAddressResolverGroup
-
- NoopDnsCache - Class in io.netty.resolver.dns
-
A noop DNS cache that actually never caches anything.
- NoopDnsCache() - Constructor for class io.netty.resolver.dns.NoopDnsCache
-
Private singleton constructor.
- NoopDnsQueryLifecycleObserver - Class in io.netty.resolver.dns
-
- NoopDnsQueryLifecycleObserver() - Constructor for class io.netty.resolver.dns.NoopDnsQueryLifecycleObserver
-
- NoopDnsQueryLifecycleObserverFactory - Class in io.netty.resolver.dns
-
- NoopDnsQueryLifecycleObserverFactory() - Constructor for class io.netty.resolver.dns.NoopDnsQueryLifecycleObserverFactory
-
- NoOpTypeParameterMatcher - Class in io.netty.util.internal
-
- NoOpTypeParameterMatcher() - Constructor for class io.netty.util.internal.NoOpTypeParameterMatcher
-
- normalCacheSize - Variable in class io.netty.buffer.PooledByteBufAllocator
-
- normalCacheSize() - Method in class io.netty.buffer.PooledByteBufAllocator
-
- normalCacheSize() - Method in class io.netty.buffer.PooledByteBufAllocatorMetric
-
Return the size of the normal cache.
- normalDirectCaches - Variable in class io.netty.buffer.PoolThreadCache
-
- normalHeapCaches - Variable in class io.netty.buffer.PoolThreadCache
-
- normalize(String) - Method in class io.netty.resolver.DefaultHostsFileEntriesResolver
-
- normalizeAndValidate() - Method in class io.netty.handler.codec.DateFormatter
-
- normalizeCapacity(int) - Method in class io.netty.buffer.PoolArena
-
- normalizeHostname(String) - Static method in class io.netty.util.DomainNameMapping
-
IDNA ASCII conversion and case normalization
- normalizeTicksPerWheel(int) - Static method in class io.netty.util.HashedWheelTimer
-
- NormalMemoryRegionCache(int) - Constructor for class io.netty.buffer.PoolThreadCache.NormalMemoryRegionCache
-
- noSelectedMatchFound(String) - Method in class io.netty.handler.ssl.JdkBaseApplicationProtocolNegotiator.FailProtocolSelectionListener
-
- noSelectedMatchFound(String) - Method in class io.netty.handler.ssl.JdkBaseApplicationProtocolNegotiator.NoFailProtocolSelectionListener
-
- noSelectMatchFound() - Method in class io.netty.handler.ssl.JdkBaseApplicationProtocolNegotiator.FailProtocolSelector
-
- noSelectMatchFound() - Method in class io.netty.handler.ssl.JdkBaseApplicationProtocolNegotiator.NoFailProtocolSelector
-
- NOT_ENCRYPTED - Static variable in class io.netty.handler.ssl.SslUtils
-
data is not encrypted
- NOT_ENOUGH_DATA - Static variable in class io.netty.handler.ssl.SslUtils
-
Not enough data in buffer to parse the record length
- NOT_ENOUGH_INPUT - Static variable in class io.netty.handler.codec.compression.Snappy
-
- 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.
- Notification - Interface in com.sun.nio.sctp
-
- NotificationHandler<T> - Interface in com.sun.nio.sctp
-
- notificationHandler - Variable in class io.netty.channel.sctp.nio.NioSctpChannel
-
- notificationHandler - Variable in class io.netty.channel.sctp.oio.OioSctpChannel
-
- NOTIFY - Static variable in class io.netty.handler.codec.dns.DnsOpCode
-
The 'Notify' DNS OpCode, as defined in
RFC1996.
- notifyClosePromise(Throwable) - Method in class io.netty.handler.ssl.SslHandler
-
- notifyConnect(ChannelFuture, Promise<Channel>) - Method in class io.netty.channel.pool.SimpleChannelPool
-
- 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
-
- notifyHandlerException(Throwable) - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- notifyHandshakeFailure(Throwable) - Method in class io.netty.handler.ssl.SslHandler
-
- notifyHandshakeFailure(ChannelHandlerContext, Throwable) - Static method in class io.netty.handler.ssl.SslUtils
-
- notifyHealthCheck(Future<Boolean>, Channel, Promise<Channel>) - Method in class io.netty.channel.pool.SimpleChannelPool
-
- notifyingListeners - Variable in class io.netty.util.concurrent.DefaultPromise
-
Threading - synchronized(this).
- notifyListener(EventExecutor, Future<?>, GenericFutureListener<?>) - Static method in class io.netty.util.concurrent.DefaultPromise
-
Notify a listener that a future has completed.
- notifyListener0(Future, GenericFutureListener) - Static method in class io.netty.util.concurrent.DefaultPromise
-
- notifyListeners() - Method in class io.netty.util.concurrent.DefaultPromise
-
- notifyListeners0(DefaultFutureListeners) - Method in class io.netty.util.concurrent.DefaultPromise
-
- notifyListenersNow() - Method in class io.netty.util.concurrent.DefaultPromise
-
- notifyListenerWithStackOverFlowProtection(EventExecutor, Future<?>, GenericFutureListener<?>) - Static method in class io.netty.util.concurrent.DefaultPromise
-
The logic in this method should be identical to
DefaultPromise.notifyListeners()
but
cannot share code because the listener(s) cannot be cached for an instance of
DefaultPromise
since the
listener(s) may be changed and is protected by a synchronized operation.
- notifyOutboundHandlerException(Throwable, ChannelPromise) - Static method in class io.netty.channel.AbstractChannelHandlerContext
-
- notifyProgressiveListener0(ProgressiveFuture, GenericProgressiveFutureListener, long, long) - Static method in class io.netty.util.concurrent.DefaultPromise
-
- notifyProgressiveListeners(long, long) - Method in class io.netty.util.concurrent.DefaultPromise
-
Notify all progressive listeners.
- notifyProgressiveListeners0(ProgressiveFuture<?>, GenericProgressiveFutureListener<?>[], long, long) - Static method in class io.netty.util.concurrent.DefaultPromise
-
- notifyPromises() - Method in class io.netty.channel.ChannelFlushPromiseNotifier
-
- notifyPromises(Throwable) - Method in class io.netty.channel.ChannelFlushPromiseNotifier
-
- notifyPromises(Throwable, Throwable) - Method in class io.netty.channel.ChannelFlushPromiseNotifier
-
- notifyPromises0(Throwable) - Method in class io.netty.channel.ChannelFlushPromiseNotifier
-
- notifyWatchees() - Method in class io.netty.util.ThreadDeathWatcher.Watcher
-
- 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.
- nsName - Variable in class io.netty.resolver.dns.DnsNameResolverContext.AuthoritativeNameServer
-
- NUL - Static variable in class io.netty.handler.codec.stomp.StompConstants
-
- 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
-
- NULL_INSTANCE - Static variable in class io.netty.handler.codec.redis.FullBulkStringRedisMessage
-
- NULL_LENGTH - Static variable in class io.netty.handler.codec.redis.RedisConstants
-
- NULL_SHORT - Static variable in class io.netty.handler.codec.redis.RedisConstants
-
- NULL_VALUE - Static variable in class io.netty.handler.codec.redis.RedisConstants
-
- NULL_VALUE - Static variable in class io.netty.util.collection.ByteObjectHashMap
-
Placeholder for null values, so we can use the actual null to mean available.
- NULL_VALUE - Static variable in class io.netty.util.collection.CharObjectHashMap
-
Placeholder for null values, so we can use the actual null to mean available.
- NULL_VALUE - Static variable in class io.netty.util.collection.IntObjectHashMap
-
Placeholder for null values, so we can use the actual null to mean available.
- NULL_VALUE - Static variable in class io.netty.util.collection.LongObjectHashMap
-
Placeholder for null values, so we can use the actual null to mean available.
- NULL_VALUE - Static variable in class io.netty.util.collection.ShortObjectHashMap
-
Placeholder for null values, so we can use the actual null to mean available.
- numActiveAllocations() - Method in class io.netty.buffer.PoolArena
-
- numActiveAllocations() - Method in interface io.netty.buffer.PoolArenaMetric
-
Return the number of currently active allocations.
- numActiveBytes() - Method in class io.netty.buffer.PoolArena
-
- numActiveBytes() - Method in interface io.netty.buffer.PoolArenaMetric
-
Return the number of active bytes that are currently allocated by the arena.
- numActiveHugeAllocations() - Method in class io.netty.buffer.PoolArena
-
- numActiveHugeAllocations() - Method in interface io.netty.buffer.PoolArenaMetric
-
Return the number of currently active huge allocations.
- numActiveNormalAllocations() - Method in class io.netty.buffer.PoolArena
-
- numActiveNormalAllocations() - Method in interface io.netty.buffer.PoolArenaMetric
-
Return the number of currently active normal allocations.
- numActiveSmallAllocations() - Method in class io.netty.buffer.PoolArena
-
- numActiveSmallAllocations() - Method in interface io.netty.buffer.PoolArenaMetric
-
Return the number of currently active small allocations.
- numActiveTinyAllocations() - Method in class io.netty.buffer.PoolArena
-
- numActiveTinyAllocations() - Method in interface io.netty.buffer.PoolArenaMetric
-
Return the number of currently active tiny allocations.
- numAllocations() - Method in class io.netty.buffer.PoolArena
-
- numAllocations() - Method in interface io.netty.buffer.PoolArenaMetric
-
Return the number of allocations done via the arena.
- numAvail - Variable in class io.netty.buffer.PoolSubpage
-
- numAvailable() - Method in class io.netty.buffer.PoolSubpage
-
- numAvailable() - Method in interface io.netty.buffer.PoolSubpageMetric
-
Return the number of available elements to be allocated.
- numberBytesPending - Variable in class io.netty.channel.kqueue.KQueueRecvByteAllocatorHandle
-
- numberBytesPending(long) - Method in class io.netty.channel.kqueue.KQueueRecvByteAllocatorHandle
-
- numberOfBytesConsumed - Variable in class io.netty.handler.codec.mqtt.MqttDecoder.Result
-
- numberToBytes(long) - Method in class io.netty.handler.codec.redis.RedisEncoder
-
- numChunkLists() - Method in class io.netty.buffer.PoolArena
-
- 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
- numComponents() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- numDeallocations() - Method in class io.netty.buffer.PoolArena
-
- 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 class io.netty.buffer.PoolArena
-
- numHugeAllocations() - Method in interface io.netty.buffer.PoolArenaMetric
-
Return the number of huge allocations done via the arena.
- numHugeDeallocations() - Method in class io.netty.buffer.PoolArena
-
- numHugeDeallocations() - Method in interface io.netty.buffer.PoolArenaMetric
-
Return the number of huge deallocations done via the arena.
- numNormalAllocations() - Method in class io.netty.buffer.PoolArena
-
- numNormalAllocations() - Method in interface io.netty.buffer.PoolArenaMetric
-
Return the number of normal allocations done via the arena.
- numNormalDeallocations() - Method in class io.netty.buffer.PoolArena
-
- numNormalDeallocations() - Method in interface io.netty.buffer.PoolArenaMetric
-
Return the number of normal deallocations done via the arena.
- numReads - Variable in class io.netty.handler.codec.ByteToMessageDecoder
-
- numShiftsNormalDirect - Variable in class io.netty.buffer.PoolThreadCache
-
- numShiftsNormalHeap - Variable in class io.netty.buffer.PoolThreadCache
-
- numSmallAllocations() - Method in class io.netty.buffer.PoolArena
-
- numSmallAllocations() - Method in interface io.netty.buffer.PoolArenaMetric
-
Return the number of small allocations done via the arena.
- numSmallDeallocations() - Method in class io.netty.buffer.PoolArena
-
- numSmallDeallocations() - Method in interface io.netty.buffer.PoolArenaMetric
-
Return the number of small deallocations done via the arena.
- numSmallSubpagePools - Variable in class io.netty.buffer.PoolArena
-
- numSmallSubpages() - Method in class io.netty.buffer.PoolArena
-
- numSmallSubpages() - Method in interface io.netty.buffer.PoolArenaMetric
-
Returns the number of small sub-pages for the arena.
- numThreadCaches - Variable in class io.netty.buffer.PoolArena
-
- numThreadCaches() - Method in class io.netty.buffer.PoolArena
-
- 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
-
- numTinyAllocations() - Method in class io.netty.buffer.PoolArena
-
- numTinyAllocations() - Method in interface io.netty.buffer.PoolArenaMetric
-
Return the number of tiny allocations done via the arena.
- numTinyDeallocations() - Method in class io.netty.buffer.PoolArena
-
- numTinyDeallocations() - Method in interface io.netty.buffer.PoolArenaMetric
-
Return the number of tiny deallocations done via the arena.
- numTinySubpagePools - Static variable in class io.netty.buffer.PoolArena
-
- numTinySubpages() - Method in class io.netty.buffer.PoolArena
-
- 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.
- NXDOMAIN_QUERY_FAILED_EXCEPTION - Static variable in class io.netty.resolver.dns.DnsNameResolverContext
-
- NXRRSET - Static variable in class io.netty.handler.codec.dns.DnsResponseCode
-
The 'NXRRSet' DNS RCODE (8), as defined in
RFC2136.
- PACKAGE_SEPARATOR_CHAR - Static variable in class io.netty.util.internal.StringUtil
-
- packetId - Variable in class io.netty.handler.codec.mqtt.MqttPublishVariableHeader
-
- packetId() - Method in class io.netty.handler.codec.mqtt.MqttPublishVariableHeader
-
- packetLength - Variable in class io.netty.handler.ssl.SslHandler
-
- packIntoLong(int, int) - Static method in class io.netty.handler.codec.dns.AbstractDnsOptPseudoRrRecord
-
- pad0 - Variable in class io.netty.util.internal.ThreadLocalRandom
-
- pad1 - Variable in class io.netty.util.internal.ThreadLocalRandom
-
- pad2 - Variable in class io.netty.util.internal.ThreadLocalRandom
-
- pad3 - Variable in class io.netty.util.internal.ThreadLocalRandom
-
- pad4 - Variable in class io.netty.util.internal.ThreadLocalRandom
-
- pad5 - Variable in class io.netty.util.internal.ThreadLocalRandom
-
- pad6 - Variable in class io.netty.util.internal.ThreadLocalRandom
-
- pad7 - Variable in class io.netty.util.internal.ThreadLocalRandom
-
- padWithZeros(byte, int) - Static method in class io.netty.handler.codec.dns.DefaultDnsRecordEncoder
-
- pageShifts - Variable in class io.netty.buffer.PoolArena
-
- pageShifts - Variable in class io.netty.buffer.PoolChunk
-
- pageSize - Variable in class io.netty.buffer.PoolArena
-
- pageSize - Variable in class io.netty.buffer.PoolChunk
-
- pageSize - Variable in class io.netty.buffer.PoolSubpage
-
- pageSize() - Method in class io.netty.buffer.PoolSubpage
-
- pageSize() - Method in interface io.netty.buffer.PoolSubpageMetric
-
Return the size (in bytes) of this page.
- parameters - Variable in class io.netty.handler.codec.smtp.DefaultSmtpRequest
-
- 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 - Variable in class io.netty.buffer.AbstractPooledDerivedByteBuf
-
Deallocations of a pooled derived buffer should always propagate through the entire chain of derived buffers.
- parent(ByteBuf) - Method in class io.netty.buffer.AbstractPooledDerivedByteBuf
-
- parent - Variable in class io.netty.buffer.PoolArena
-
- parent - Variable in class io.netty.buffer.PoolChunk
-
- parent - Variable in class io.netty.channel.AbstractChannel
-
- 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.embedded.EmbeddedEventLoop
-
- 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.sctp.nio.NioSctpChannel
-
- parent() - Method in class io.netty.channel.sctp.oio.OioSctpChannel
-
- parent() - Method in interface io.netty.channel.sctp.SctpChannel
-
- 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 - Variable in class io.netty.channel.ThreadPerChannelEventLoop
-
- parent - Variable in class io.netty.handler.ssl.util.SimpleTrustManagerFactory.SimpleTrustManagerFactorySpi
-
- parent - Variable in class io.netty.resolver.dns.DnsNameResolverContext
-
- parent - Variable in class io.netty.resolver.dns.DnsQueryContext
-
- parent - Variable in class io.netty.util.concurrent.AbstractEventExecutor
-
- parent() - Method in class io.netty.util.concurrent.AbstractEventExecutor
-
- parent() - Method in interface io.netty.util.concurrent.EventExecutor
-
- parent() - Method in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor
-
- parent - Variable in class io.netty.util.Recycler.Stack
-
- parse(File...) - Static method in class io.netty.resolver.dns.UnixResolverDnsServerAddressStreamProvider
-
- 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.
- parse0(CharSequence, int, int) - Method in class io.netty.handler.codec.DateFormatter
-
- parse1(CharSequence, int, int) - Method in class io.netty.handler.codec.DateFormatter
-
- parseAddress(DnsRecord, String) - Method in class io.netty.resolver.dns.DnsNameResolverContext
-
- 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
-
- parseCode(ByteBuf) - Static method in class io.netty.handler.codec.smtp.SmtpResponseDecoder
-
Parses the io.netty.handler.codec.smtp code without any allocation, which is three digits.
- parseDouble() - Method in class io.netty.util.AsciiString
-
- parseDouble(int, int) - Method in class io.netty.util.AsciiString
-
- parseEtcResolverFirstNdots() - Static method in class io.netty.resolver.dns.UnixResolverDnsServerAddressStreamProvider
-
Parse a file of the format
/etc/resolv.conf and return the
value corresponding to the first ndots in an options configuration.
- parseEtcResolverFirstNdots(File) - Static method in class io.netty.resolver.dns.UnixResolverDnsServerAddressStreamProvider
-
Parse a file of the format
/etc/resolv.conf and return the
value corresponding to the first ndots in an options configuration.
- 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
-
- parseInt(int, int, int, boolean) - Method in class io.netty.util.AsciiString
-
- parseIso8601(String) - Static method in class io.netty.util.Version
-
- parseLevel(String) - Static method in enum io.netty.util.ResourceLeakDetector.Level
-
Returns level based on string value.
- 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
-
- parseLong(int, int, int, boolean) - 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[]
.
- parseNumber(byte) - Static method in class io.netty.handler.codec.smtp.SmtpResponseDecoder
-
- parsePositiveNumber(ByteBuf) - Method in class io.netty.handler.codec.redis.RedisDecoder
-
- parseRedisNumber(ByteBuf) - Method in class io.netty.handler.codec.redis.RedisDecoder
-
- 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.dns.UnixResolverDnsServerAddressStreamProvider
-
Attempt to parse /etc/resolv.conf
and files in the /etc/resolver
directory by default.
- parseSilently() - Static method in class io.netty.resolver.HostsFileParser
-
Parse hosts file at standard OS location.
- parseToken(CharSequence, int, int) - Method in class io.netty.handler.codec.DateFormatter
-
- PartitionResult(int, int) - Constructor for class io.netty.handler.codec.compression.Bzip2DivSufSort.PartitionResult
-
- PASSCODE - Static variable in interface io.netty.handler.codec.stomp.StompHeaders
-
- password - Variable in class io.netty.handler.codec.mqtt.MqttConnectPayload
-
- password() - Method in class io.netty.handler.codec.mqtt.MqttConnectPayload
-
- password - Variable in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
-
- password(String) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
-
- password(byte[]) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
-
- password - Variable in class io.netty.handler.codec.socks.SocksAuthRequest
-
- password() - Method in class io.netty.handler.codec.socks.SocksAuthRequest
-
Returns password that needs to be validated
- password - Variable in class io.netty.handler.codec.socksx.v5.DefaultSocks5PasswordAuthRequest
-
- password() - Method in class io.netty.handler.codec.socksx.v5.DefaultSocks5PasswordAuthRequest
-
- PASSWORD - Static variable in class io.netty.handler.codec.socksx.v5.Socks5AuthMethod
-
- password() - Method in interface io.netty.handler.codec.socksx.v5.Socks5PasswordAuthRequest
-
Returns the password of this request.
- 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 - Variable in class io.netty.handler.codec.mqtt.MqttMessage
-
- payload() - Method in class io.netty.handler.codec.mqtt.MqttMessage
-
- payload - Variable in class io.netty.handler.codec.mqtt.MqttMessageBuilders.PublishBuilder
-
- 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
-
- payloadProtocolID() - Method in class com.sun.nio.sctp.MessageInfo
-
- payloadProtocolID(int) - Method in class com.sun.nio.sctp.MessageInfo
-
- peek() - Method in class io.netty.util.internal.DefaultPriorityQueue
-
- peek() - Method in class io.netty.util.internal.EmptyPriorityQueue
-
- peekScheduledTask() - Method in class io.netty.util.concurrent.AbstractScheduledEventExecutor
-
- peekTask() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- peer - Variable in class io.netty.channel.local.LocalChannel
-
- PeerAddressChangeNotification - Class in com.sun.nio.sctp
-
- PeerAddressChangeNotification() - Constructor for class com.sun.nio.sctp.PeerAddressChangeNotification
-
- 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.
- PeerCredentials(int, int, int...) - Constructor for class io.netty.channel.unix.PeerCredentials
-
- PemEncoded - Interface in io.netty.handler.ssl
-
A marker interface for PEM encoded values.
- 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.
- PemPrivateKey(ByteBuf) - Constructor for class io.netty.handler.ssl.PemPrivateKey
-
- PemReader - Class in io.netty.handler.ssl
-
Reads a PEM file and converts it into a list of DERs so that they are imported into a KeyStore
easily.
- PemReader() - Constructor for class io.netty.handler.ssl.PemReader
-
- PemValue - Class in io.netty.handler.ssl
-
A PEM encoded value.
- PemValue(ByteBuf, boolean) - Constructor for class io.netty.handler.ssl.PemValue
-
- 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.
- PemX509Certificate(ByteBuf) - Constructor for class io.netty.handler.ssl.PemX509Certificate
-
- PENDING_WRITE_OVERHEAD - Static variable in class io.netty.channel.PendingWriteQueue
-
- pendingAcquireCount - Variable in class io.netty.channel.pool.FixedChannelPool
-
- pendingAcquireQueue - Variable in class io.netty.channel.pool.FixedChannelPool
-
- pendingEntries - Static variable in class io.netty.util.ThreadDeathWatcher
-
- PendingHandlerAddedTask(AbstractChannelHandlerContext) - Constructor for class io.netty.channel.DefaultChannelPipeline.PendingHandlerAddedTask
-
- PendingHandlerCallback(AbstractChannelHandlerContext) - Constructor for class io.netty.channel.DefaultChannelPipeline.PendingHandlerCallback
-
- pendingHandlerCallbackHead - Variable in class io.netty.channel.DefaultChannelPipeline
-
- PendingHandlerRemovedTask(AbstractChannelHandlerContext) - Constructor for class io.netty.channel.DefaultChannelPipeline.PendingHandlerRemovedTask
-
- pendingPromises - Variable in class io.netty.util.concurrent.PromiseAggregator
-
Deprecated.
- PendingRegistrationPromise(Channel) - Constructor for class io.netty.bootstrap.AbstractBootstrap.PendingRegistrationPromise
-
- pendingSize - Variable in class io.netty.channel.ChannelOutboundBuffer.Entry
-
- pendingTasks() - Method in class io.netty.channel.kqueue.KQueueEventLoop
-
- 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.
- pendingTasksCallable - Variable in class io.netty.channel.kqueue.KQueueEventLoop
-
- pendingTasksCallable - Variable in class io.netty.channel.nio.NioEventLoop
-
- pendingTimeouts - Variable in class io.netty.util.HashedWheelTimer
-
- pendingTimeouts() - Method in class io.netty.util.HashedWheelTimer
-
Returns the number of pending timeouts of this
Timer
.
- pendingUnencryptedWrites - Variable in class io.netty.handler.ssl.SslHandler
-
- PendingWrite(Recycler.Handle<PendingWriteQueue.PendingWrite>) - Constructor for class io.netty.channel.PendingWriteQueue.PendingWrite
-
- PendingWrite(Object, ChannelPromise) - Constructor for class io.netty.handler.stream.ChunkedWriteHandler.PendingWrite
-
- PendingWrite - Class in io.netty.util.internal
-
Some pending write which should be picked up later.
- PendingWrite(Recycler.Handle<PendingWrite>) - Constructor for class io.netty.util.internal.PendingWrite
-
- 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
-
- PendingWriteQueue.PendingWrite - Class in io.netty.channel
-
Holds all meta-data and construct the linked-list structure.
- PerChannel() - Constructor for class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler.PerChannel
-
- PerChannel() - Constructor for class io.netty.handler.traffic.GlobalTrafficShapingHandler.PerChannel
-
- periodNanos - Variable in class io.netty.util.concurrent.ScheduledFutureTask
-
- pid - Variable in class io.netty.channel.unix.PeerCredentials
-
- pid() - Method in class io.netty.channel.unix.PeerCredentials
-
Get the PID of the peer process.
- pinEventExecutor - Variable in class io.netty.channel.DefaultChannelConfig
-
- pipe() - Static method in class io.netty.channel.unix.FileDescriptor
-
- pipeline - Variable in class io.netty.channel.AbstractChannel
-
- pipeline() - Method in class io.netty.channel.AbstractChannel
-
- pipeline - Variable in class io.netty.channel.AbstractChannelHandlerContext
-
- pipeline() - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- pipeline() - Method in interface io.netty.channel.Channel
-
- pipeline() - Method in interface io.netty.channel.ChannelHandlerContext
-
- pipeline() - Method in class io.netty.channel.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- PKCS8_FORMAT - Static variable in class io.netty.handler.ssl.PemPrivateKey
-
- PLATFORM_UNSUPPORTED - Static variable in class io.netty.channel.kqueue.AcceptFilter
-
- platformDefault() - Static method in class io.netty.resolver.dns.DnsServerAddressStreamProviders
-
- 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.
- PlatformDependent() - Constructor for class io.netty.util.internal.PlatformDependent
-
- PlatformDependent.AtomicLongCounter - Class in io.netty.util.internal
-
- PlatformDependent.Mpsc - Class in io.netty.util.internal
-
- PlatformDependent.ThreadLocalRandomProvider - Interface in io.netty.util.internal
-
- PlatformDependent0 - Class in io.netty.util.internal
-
- PlatformDependent0() - Constructor for class io.netty.util.internal.PlatformDependent0
-
- pointNeighborsToThis() - Method in class io.netty.handler.codec.DefaultHeaders.HeaderEntry
-
- poll(Queue<Object>) - Static method in class io.netty.channel.embedded.EmbeddedChannel
-
- 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
-
- pollTimeout() - Method in class io.netty.util.HashedWheelTimer.HashedWheelBucket
-
- pool - Static variable in class io.netty.channel.ChannelOption
-
- pool - Static variable in class io.netty.util.AttributeKey
-
- pool - Static variable in error io.netty.util.Signal
-
- POOL_CLOSED_ON_ACQUIRE_EXCEPTION - Static variable in class io.netty.channel.pool.FixedChannelPool
-
- POOL_CLOSED_ON_RELEASE_EXCEPTION - Static variable in class io.netty.channel.pool.FixedChannelPool
-
- POOL_KEY - Static variable in class io.netty.channel.pool.SimpleChannelPool
-
- PoolArena<T> - Class in io.netty.buffer
-
- PoolArena(PooledByteBufAllocator, int, int, int, int, int) - Constructor for class io.netty.buffer.PoolArena
-
- PoolArena.DirectArena - Class in io.netty.buffer
-
- PoolArena.HeapArena - Class in io.netty.buffer
-
- PoolArena.SizeClass - Enum in io.netty.buffer
-
- PoolArenaMetric - Interface in io.netty.buffer
-
Expose metrics for an arena.
- PoolChunk<T> - Class in io.netty.buffer
-
Description of algorithm for PageRun/PoolSubpage allocation from PoolChunk
Notation: The following terms are important to understand the code
> page - a page is the smallest unit of memory chunk that can be allocated
> chunk - a chunk is a collection of pages
> in this code chunkSize = 2^{maxOrder} * pageSize
To begin we allocate a byte array of size = chunkSize
Whenever a ByteBuf of given size needs to be created we search for the first position
in the byte array that has enough empty space to accommodate the requested size and
return a (long) handle that encodes this offset information, (this memory segment is then
marked as reserved so it is always used by exactly one ByteBuf and no more)
For simplicity all sizes are normalized according to PoolArena#normalizeCapacity method
This ensures that when we request for memory segments of size >= pageSize the normalizedCapacity
equals the next nearest power of 2
To search for the first offset in chunk that has at least requested size available we construct a
complete balanced binary tree and store it in an array (just like heaps) - memoryMap
The tree looks like this (the size of each node being mentioned in the parenthesis)
depth=0 1 node (chunkSize)
depth=1 2 nodes (chunkSize/2)
..
- PoolChunk(PoolArena<T>, T, int, int, int, int, int) - Constructor for class io.netty.buffer.PoolChunk
-
- PoolChunk(PoolArena<T>, T, int, int) - Constructor for class io.netty.buffer.PoolChunk
-
Creates a special chunk that is not pooled.
- PoolChunkList<T> - Class in io.netty.buffer
-
- PoolChunkList(PoolArena<T>, PoolChunkList<T>, int, int, int) - Constructor for class io.netty.buffer.PoolChunkList
-
- PoolChunkListMetric - Interface in io.netty.buffer
-
Metrics for a list of chunks.
- PoolChunkMetric - Interface in io.netty.buffer
-
Metrics for a chunk.
- PooledByteBuf<T> - Class in io.netty.buffer
-
- PooledByteBuf(Recycler.Handle<? extends PooledByteBuf<T>>, int) - Constructor for class io.netty.buffer.PooledByteBuf
-
- 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
-
- PooledByteBufAllocator.PoolThreadLocalCache - Class in io.netty.buffer
-
- PooledByteBufAllocatorMetric - Class in io.netty.buffer
-
- PooledByteBufAllocatorMetric(PooledByteBufAllocator) - Constructor for class io.netty.buffer.PooledByteBufAllocatorMetric
-
- PooledDirectByteBuf - Class in io.netty.buffer
-
- PooledDirectByteBuf(Recycler.Handle<PooledDirectByteBuf>, int) - Constructor for class io.netty.buffer.PooledDirectByteBuf
-
- PooledDuplicatedByteBuf - Class in io.netty.buffer
-
- PooledDuplicatedByteBuf(Recycler.Handle<PooledDuplicatedByteBuf>) - Constructor for class io.netty.buffer.PooledDuplicatedByteBuf
-
- PooledHeapByteBuf - Class in io.netty.buffer
-
- PooledHeapByteBuf(Recycler.Handle<? extends PooledHeapByteBuf>, int) - Constructor for class io.netty.buffer.PooledHeapByteBuf
-
- PooledNonRetainedDuplicateByteBuf(ReferenceCounted, AbstractByteBuf) - Constructor for class io.netty.buffer.AbstractPooledDerivedByteBuf.PooledNonRetainedDuplicateByteBuf
-
- PooledNonRetainedSlicedByteBuf(ReferenceCounted, AbstractByteBuf, int, int) - Constructor for class io.netty.buffer.AbstractPooledDerivedByteBuf.PooledNonRetainedSlicedByteBuf
-
- PooledSlicedByteBuf - Class in io.netty.buffer
-
- PooledSlicedByteBuf(Recycler.Handle<PooledSlicedByteBuf>) - Constructor for class io.netty.buffer.PooledSlicedByteBuf
-
- PooledUnsafeDirectByteBuf - Class in io.netty.buffer
-
- PooledUnsafeDirectByteBuf(Recycler.Handle<PooledUnsafeDirectByteBuf>, int) - Constructor for class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- PooledUnsafeHeapByteBuf - Class in io.netty.buffer
-
- PooledUnsafeHeapByteBuf(Recycler.Handle<PooledUnsafeHeapByteBuf>, int) - Constructor for class io.netty.buffer.PooledUnsafeHeapByteBuf
-
- poolId - Static variable in class io.netty.util.concurrent.DefaultThreadFactory
-
- PoolSubpage<T> - Class in io.netty.buffer
-
- PoolSubpage(int) - Constructor for class io.netty.buffer.PoolSubpage
-
Special constructor that creates a linked list head
- PoolSubpage(PoolSubpage<T>, PoolChunk<T>, int, int, int, int) - Constructor for class io.netty.buffer.PoolSubpage
-
- PoolSubpageMetric - Interface in io.netty.buffer
-
Metrics for a sub-page.
- PoolThreadCache - Class in io.netty.buffer
-
Acts a Thread cache for allocations.
- PoolThreadCache(PoolArena<byte[]>, PoolArena<ByteBuffer>, int, int, int, int, int) - Constructor for class io.netty.buffer.PoolThreadCache
-
- PoolThreadCache.MemoryRegionCache<T> - Class in io.netty.buffer
-
- PoolThreadCache.MemoryRegionCache.Entry<T> - Class in io.netty.buffer
-
- PoolThreadCache.NormalMemoryRegionCache<T> - Class in io.netty.buffer
-
Cache used for buffers which are backed by NORMAL size.
- PoolThreadCache.SubPageMemoryRegionCache<T> - Class in io.netty.buffer
-
Cache used for buffers which are backed by TINY or SMALL size.
- PoolThreadLocalCache(boolean) - Constructor for class io.netty.buffer.PooledByteBufAllocator.PoolThreadLocalCache
-
- pop() - Method in class io.netty.util.Recycler.Stack
-
- port - Variable in class io.netty.handler.codec.socks.SocksCmdRequest
-
- port() - Method in class io.netty.handler.codec.socks.SocksCmdRequest
-
- port - Variable in class io.netty.handler.codec.socks.SocksCmdResponse
-
- port() - Method in class io.netty.handler.codec.socks.SocksCmdResponse
-
- PORT_ROW_LABEL - Static variable in class io.netty.resolver.dns.UnixResolverDnsServerAddressStreamProvider
-
- portStringToInt(String) - Static method in class io.netty.handler.codec.haproxy.HAProxyMessage
-
Convert port to integer
- pos - Variable in class io.netty.util.internal.AppendableCharSequence
-
- position - Variable in class io.netty.channel.DefaultFileRegion
-
- 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.
- POSITIVE_LONG_MAX_LENGTH - Static variable in class io.netty.handler.codec.redis.RedisConstants
-
- PowerOfTwoEventExecutorChooser(EventExecutor[]) - Constructor for class io.netty.util.concurrent.DefaultEventExecutorChooserFactory.PowerOfTwoEventExecutorChooser
-
- PREAMBLE_NOT_FULL - Static variable in class io.netty.handler.codec.compression.Snappy
-
- preferDirect - Variable in class io.netty.handler.codec.MessageToByteEncoder
-
- PreferHeapByteBufAllocator - Class in io.netty.channel.local
-
Wraps another
ByteBufAllocator
and use heapbuffers everywhere except when a direct buffer is explicit
requested.
- PreferHeapByteBufAllocator(ByteBufAllocator) - Constructor for class io.netty.channel.local.PreferHeapByteBufAllocator
-
- preferredAddressType - Variable in class io.netty.resolver.dns.DnsNameResolver
-
- preferredAddressType() - Method in class io.netty.resolver.dns.DnsNameResolver
-
- prefix - Variable in class io.netty.util.concurrent.DefaultThreadFactory
-
- PREFIX_MASK - Static variable in class io.netty.handler.codec.dns.DefaultDnsRecordEncoder
-
- prefixToSubnetMask(int) - Static method in class io.netty.handler.ipfilter.IpSubnetFilterRule.Ip4SubnetFilterRule
-
- prefixToSubnetMask(int) - Static method in class io.netty.handler.ipfilter.IpSubnetFilterRule.Ip6SubnetFilterRule
-
- 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
-
- prepareToClose() - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel.KQueueStreamUnsafe
-
- prepareToClose() - Method in class io.netty.channel.kqueue.KQueueSocketChannel.KQueueSocketChannelUnsafe
-
- prepareToClose() - Method in class io.netty.channel.socket.nio.NioSocketChannel.NioSocketChannelUnsafe
-
- 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, int, int) - Static method in class io.netty.buffer.ByteBufUtil.HexUtil
-
- 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
.
- prev - Variable in class io.netty.buffer.PoolChunk
-
- prev - Variable in class io.netty.buffer.PoolSubpage
-
- prev - Variable in class io.netty.channel.AbstractChannelHandlerContext
-
- prev - Variable in class io.netty.handler.timeout.WriteTimeoutHandler.WriteTimeoutTask
-
- prev - Variable in class io.netty.util.DefaultAttributeMap.DefaultAttribute
-
- prev - Variable in class io.netty.util.HashedWheelTimer.HashedWheelTimeout
-
- prev - Variable in class io.netty.util.Recycler.Stack
-
- prevIndex - Variable in class io.netty.util.collection.ByteObjectHashMap.PrimitiveIterator
-
- prevIndex - Variable in class io.netty.util.collection.CharObjectHashMap.PrimitiveIterator
-
- prevIndex - Variable in class io.netty.util.collection.IntObjectHashMap.PrimitiveIterator
-
- prevIndex - Variable in class io.netty.util.collection.LongObjectHashMap.PrimitiveIterator
-
- prevIndex - Variable in class io.netty.util.collection.ShortObjectHashMap.PrimitiveIterator
-
- prevList - Variable in class io.netty.buffer.PoolChunkList
-
- prevList(PoolChunkList<T>) - Method in class io.netty.buffer.PoolChunkList
-
- PrimitiveIterator() - Constructor for class io.netty.util.collection.ByteObjectHashMap.PrimitiveIterator
-
- PrimitiveIterator() - Constructor for class io.netty.util.collection.CharObjectHashMap.PrimitiveIterator
-
- PrimitiveIterator() - Constructor for class io.netty.util.collection.IntObjectHashMap.PrimitiveIterator
-
- PrimitiveIterator() - Constructor for class io.netty.util.collection.LongObjectHashMap.PrimitiveIterator
-
- PrimitiveIterator() - Constructor for class io.netty.util.collection.ShortObjectHashMap.PrimitiveIterator
-
- priority - Variable in class io.netty.util.concurrent.DefaultThreadFactory
-
- priority() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor.DefaultThreadProperties
-
- 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
-
- priorityQueueIndex(DefaultPriorityQueue<?>, int) - Method in interface io.netty.util.internal.PriorityQueueNode
-
- PriorityQueueIterator() - Constructor for class io.netty.util.internal.DefaultPriorityQueue.PriorityQueueIterator
-
- PriorityQueueNode - Interface in io.netty.util.internal
-
- privateKey - Variable in class io.netty.handler.ssl.util.SelfSignedCertificate
-
- privateKey() - Method in class io.netty.handler.ssl.util.SelfSignedCertificate
-
Returns the generated RSA private key file in PEM format.
- probeNext(int) - Method in class io.netty.util.collection.ByteObjectHashMap
-
Get the next sequential index after index
and wraps if necessary.
- probeNext(int) - Method in class io.netty.util.collection.CharObjectHashMap
-
Get the next sequential index after index
and wraps if necessary.
- probeNext(int) - Method in class io.netty.util.collection.IntObjectHashMap
-
Get the next sequential index after index
and wraps if necessary.
- probeNext(int) - Method in class io.netty.util.collection.LongObjectHashMap
-
Get the next sequential index after index
and wraps if necessary.
- probeNext(int) - Method in class io.netty.util.collection.ShortObjectHashMap
-
Get the next sequential index after index
and wraps if necessary.
- process(byte) - Method in class io.netty.handler.codec.base64.Base64.Decoder
-
- process(byte) - Method in class io.netty.handler.codec.redis.RedisDecoder.ToPositiveLongProcessor
-
- 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
-
- PROCESS_ID - Static variable in class io.netty.channel.DefaultChannelId
-
- PROCESS_ID_LEN - Static variable in class io.netty.channel.DefaultChannelId
-
- processCancelledTasks() - Method in class io.netty.util.HashedWheelTimer.Worker
-
- 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
-
- processReady(int) - Method in class io.netty.channel.kqueue.KQueueEventLoop
-
- processSelectedKey(SelectionKey, AbstractNioChannel) - Method in class io.netty.channel.nio.NioEventLoop
-
- processSelectedKey(SelectionKey, NioTask<SelectableChannel>) - Static method in class io.netty.channel.nio.NioEventLoop
-
- processSelectedKeys() - Method in class io.netty.channel.nio.NioEventLoop
-
- processSelectedKeysOptimized() - Method in class io.netty.channel.nio.NioEventLoop
-
- processSelectedKeysPlain(Set<SelectionKey>) - Method in class io.netty.channel.nio.NioEventLoop
-
- processWritten(int, long) - Method in class io.netty.channel.unix.IovArray
-
Process the written iov entries.
- progress - Variable in class io.netty.channel.ChannelOutboundBuffer.Entry
-
- 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
-
- progress(long, long) - Method in class io.netty.handler.stream.ChunkedWriteHandler.PendingWrite
-
- ProgressiveFuture<V> - Interface in io.netty.util.concurrent
-
A
Future
which is used to indicate the progress of an operation.
- progressiveListeners() - Method in class io.netty.util.concurrent.DefaultPromise
-
- ProgressivePromise<V> - Interface in io.netty.util.concurrent
-
- progressiveSize - Variable in class io.netty.util.concurrent.DefaultFutureListeners
-
- progressiveSize() - Method in class io.netty.util.concurrent.DefaultFutureListeners
-
- promise - Variable in class io.netty.channel.AbstractChannelHandlerContext.AbstractWriteTask
-
- promise() - Method in class io.netty.channel.ChannelFlushPromiseNotifier.DefaultFlushCheckpoint
-
- promise() - Method in interface io.netty.channel.ChannelFlushPromiseNotifier.FlushCheckpoint
-
- promise - Variable in class io.netty.channel.ChannelOutboundBuffer.Entry
-
- promise() - Method in class io.netty.channel.DefaultChannelProgressivePromise
-
- promise() - Method in class io.netty.channel.DefaultChannelPromise
-
- promise - Variable in class io.netty.channel.PendingWriteQueue.PendingWrite
-
- promise - Variable in class io.netty.channel.pool.FixedChannelPool.AcquireTask
-
- promise - Variable in class io.netty.handler.stream.ChunkedWriteHandler.PendingWrite
-
- promise - Variable in class io.netty.handler.timeout.WriteTimeoutHandler.WriteTimeoutTask
-
- promise - Variable in class io.netty.handler.traffic.ChannelTrafficShapingHandler.ToSend
-
- promise - Variable in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler.ToSend
-
- promise - Variable in class io.netty.handler.traffic.GlobalTrafficShapingHandler.ToSend
-
- promise - Variable in class io.netty.resolver.dns.DnsQueryContext
-
- Promise<V> - Interface in io.netty.util.concurrent
-
Special
Future
which is writable.
- promise - Variable in class io.netty.util.concurrent.UnaryPromiseNotifier
-
- promise - Variable in class io.netty.util.internal.PendingWrite
-
- promise() - Method in class io.netty.util.internal.PendingWrite
-
- PromiseAggregator<V,F extends Future<V>> - Class in io.netty.util.concurrent
-
- 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
Promise
s.
- PromiseNotificationUtil() - Constructor for class io.netty.util.internal.PromiseNotificationUtil
-
- PromiseNotifier<V,F extends Future<V>> - Class in io.netty.util.concurrent
-
- 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.
- promises - Variable in class io.netty.util.concurrent.PromiseNotifier
-
- PromiseTask<V> - Class in io.netty.util.concurrent
-
- PromiseTask(EventExecutor, Runnable, V) - Constructor for class io.netty.util.concurrent.PromiseTask
-
- PromiseTask(EventExecutor, Callable<V>) - Constructor for class io.netty.util.concurrent.PromiseTask
-
- PromiseTask.RunnableAdapter<T> - Class in io.netty.util.concurrent
-
- PROP_ACQUIRE_AND_RELEASE_ONLY - Static variable in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- PROP_BUILD_DATE - Static variable in class io.netty.util.Version
-
- PROP_COMMIT_DATE - Static variable in class io.netty.util.Version
-
- PROP_LEVEL - Static variable in class io.netty.util.ResourceLeakDetector
-
- PROP_LEVEL_OLD - Static variable in class io.netty.util.ResourceLeakDetector
-
- PROP_LONG_COMMIT_HASH - Static variable in class io.netty.util.Version
-
- PROP_MAX_RECORDS - Static variable in class io.netty.util.ResourceLeakDetector
-
- PROP_MODE - Static variable in class io.netty.buffer.AbstractByteBuf
-
- PROP_REPO_STATUS - Static variable in class io.netty.util.Version
-
- PROP_SHORT_COMMIT_HASH - Static variable in class io.netty.util.Version
-
- PROP_VERSION - Static variable in class io.netty.util.Version
-
- PROPERTIES_UPDATER - Static variable in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- protocol - Variable in class io.netty.handler.ssl.ApplicationProtocolConfig
-
- protocol() - Method in class io.netty.handler.ssl.ApplicationProtocolConfig
-
Get which application level protocol negotiation to use.
- Protocol() - Constructor for enum io.netty.handler.ssl.ApplicationProtocolConfig.Protocol
-
- PROTOCOL - Static variable in class io.netty.handler.ssl.JdkSslContext
-
- protocol() - Method in interface io.netty.handler.ssl.OpenSslApplicationProtocolNegotiator
-
- 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.
- ProtocolDetectionResult(ProtocolDetectionState, T) - Constructor for class io.netty.handler.codec.ProtocolDetectionResult
-
- ProtocolDetectionState - Enum in io.netty.handler.codec
-
The state of the current detection.
- ProtocolDetectionState() - Constructor for enum io.netty.handler.codec.ProtocolDetectionState
-
- ProtocolFamilyConverter - Class in io.netty.channel.socket.nio
-
- ProtocolFamilyConverter() - Constructor for class io.netty.channel.socket.nio.ProtocolFamilyConverter
-
- protocolIdentifier - Variable in class io.netty.channel.sctp.SctpMessage
-
- protocolIdentifier() - Method in class io.netty.channel.sctp.SctpMessage
-
Return the protocol-identifier
- protocolIdentifier - Variable in class io.netty.handler.codec.sctp.SctpInboundByteStreamHandler
-
- protocolIdentifier - Variable in class io.netty.handler.codec.sctp.SctpOutboundByteStreamHandler
-
- protocolLevel() - Method in enum io.netty.handler.codec.mqtt.MqttVersion
-
- protocolListenerFactory() - Method in interface io.netty.handler.ssl.JdkApplicationProtocolNegotiator
-
- protocolListenerFactory() - Method in class io.netty.handler.ssl.JdkBaseApplicationProtocolNegotiator
-
- protocolListenerFactory() - Method in class io.netty.handler.ssl.JdkDefaultApplicationProtocolNegotiator
-
- 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 - Variable in class io.netty.handler.ssl.JdkBaseApplicationProtocolNegotiator
-
- protocols() - Method in class io.netty.handler.ssl.JdkBaseApplicationProtocolNegotiator
-
- protocols() - Method in class io.netty.handler.ssl.JdkDefaultApplicationProtocolNegotiator
-
- protocols - Variable in class io.netty.handler.ssl.JdkSslContext
-
- protocols() - Method in class io.netty.handler.ssl.OpenSslDefaultApplicationProtocolNegotiator
-
- protocols - Variable in class io.netty.handler.ssl.OpenSslNpnApplicationProtocolNegotiator
-
Deprecated.
- protocols() - Method in class io.netty.handler.ssl.OpenSslNpnApplicationProtocolNegotiator
-
Deprecated.
- protocols - Variable in class io.netty.handler.ssl.SslContextBuilder
-
- 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
-
- protocolSelectorFactory() - Method in class io.netty.handler.ssl.JdkBaseApplicationProtocolNegotiator
-
- protocolSelectorFactory() - Method in class io.netty.handler.ssl.JdkDefaultApplicationProtocolNegotiator
-
- protocolVersion - Variable in class io.netty.handler.codec.haproxy.HAProxyMessage
-
- protocolVersion() - Method in class io.netty.handler.codec.haproxy.HAProxyMessage
-
- protocolVersion(MqttVersion) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
-
- protocolVersion - Variable in class io.netty.handler.codec.socks.SocksMessage
-
- protocolVersion() - Method in class io.netty.handler.codec.socks.SocksMessage
-
- provider - Variable in class io.netty.channel.nio.NioEventLoop
-
- provider() - Method in class io.netty.channel.nio.SelectedSelectionKeySetSelector
-
- provider - Variable in class io.netty.handler.ssl.SslContextBuilder
-
- PROVIDER - Static variable in class io.netty.handler.ssl.util.SimpleTrustManagerFactory
-
- providers - Variable in class io.netty.resolver.dns.MultiDnsServerAddressStreamProvider
-
- proxiedProtocol - Variable in class io.netty.handler.codec.haproxy.HAProxyMessage
-
- proxiedProtocol() - Method in class io.netty.handler.codec.haproxy.HAProxyMessage
-
- 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
-
- PublishBuilder() - Constructor for class io.netty.handler.codec.mqtt.MqttMessageBuilders.PublishBuilder
-
- push(Recycler.DefaultHandle<?>) - Method in class io.netty.util.Recycler.Stack
-
- pushLater(Recycler.DefaultHandle<?>, Thread) - Method in class io.netty.util.Recycler.Stack
-
- pushNow(Recycler.DefaultHandle<?>) - Method in class io.netty.util.Recycler.Stack
-
- put(K, V) - Method in class io.netty.handler.codec.serialization.ReferenceMap
-
- put(byte, Object) - Method in class io.netty.util.collection.ByteCollections.EmptyMap
-
- put(Byte, Object) - Method in class io.netty.util.collection.ByteCollections.EmptyMap
-
- put(byte, V) - Method in class io.netty.util.collection.ByteCollections.UnmodifiableMap
-
- put(Byte, V) - Method in class io.netty.util.collection.ByteCollections.UnmodifiableMap
-
- 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, Object) - Method in class io.netty.util.collection.CharCollections.EmptyMap
-
- put(Character, Object) - Method in class io.netty.util.collection.CharCollections.EmptyMap
-
- put(char, V) - Method in class io.netty.util.collection.CharCollections.UnmodifiableMap
-
- put(Character, V) - Method in class io.netty.util.collection.CharCollections.UnmodifiableMap
-
- 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, Object) - Method in class io.netty.util.collection.IntCollections.EmptyMap
-
- put(Integer, Object) - Method in class io.netty.util.collection.IntCollections.EmptyMap
-
- put(int, V) - Method in class io.netty.util.collection.IntCollections.UnmodifiableMap
-
- put(Integer, V) - Method in class io.netty.util.collection.IntCollections.UnmodifiableMap
-
- 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, Object) - Method in class io.netty.util.collection.LongCollections.EmptyMap
-
- put(Long, Object) - Method in class io.netty.util.collection.LongCollections.EmptyMap
-
- put(long, V) - Method in class io.netty.util.collection.LongCollections.UnmodifiableMap
-
- put(Long, V) - Method in class io.netty.util.collection.LongCollections.UnmodifiableMap
-
- 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, Object) - Method in class io.netty.util.collection.ShortCollections.EmptyMap
-
- put(Short, Object) - Method in class io.netty.util.collection.ShortCollections.EmptyMap
-
- put(short, V) - Method in class io.netty.util.collection.ShortCollections.UnmodifiableMap
-
- put(Short, V) - Method in class io.netty.util.collection.ShortCollections.UnmodifiableMap
-
- 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 K, ? extends V>) - Method in class io.netty.handler.codec.serialization.ReferenceMap
-
- putAll(Map<? extends Byte, ?>) - Method in class io.netty.util.collection.ByteCollections.EmptyMap
-
- putAll(Map<? extends Byte, ? extends V>) - Method in class io.netty.util.collection.ByteCollections.UnmodifiableMap
-
- putAll(Map<? extends Byte, ? extends V>) - Method in class io.netty.util.collection.ByteObjectHashMap
-
- putAll(Map<? extends Character, ?>) - Method in class io.netty.util.collection.CharCollections.EmptyMap
-
- putAll(Map<? extends Character, ? extends V>) - Method in class io.netty.util.collection.CharCollections.UnmodifiableMap
-
- putAll(Map<? extends Character, ? extends V>) - Method in class io.netty.util.collection.CharObjectHashMap
-
- putAll(Map<? extends Integer, ?>) - Method in class io.netty.util.collection.IntCollections.EmptyMap
-
- putAll(Map<? extends Integer, ? extends V>) - Method in class io.netty.util.collection.IntCollections.UnmodifiableMap
-
- putAll(Map<? extends Integer, ? extends V>) - Method in class io.netty.util.collection.IntObjectHashMap
-
- putAll(Map<? extends Long, ?>) - Method in class io.netty.util.collection.LongCollections.EmptyMap
-
- putAll(Map<? extends Long, ? extends V>) - Method in class io.netty.util.collection.LongCollections.UnmodifiableMap
-
- putAll(Map<? extends Long, ? extends V>) - Method in class io.netty.util.collection.LongObjectHashMap
-
- putAll(Map<? extends Short, ?>) - Method in class io.netty.util.collection.ShortCollections.EmptyMap
-
- putAll(Map<? extends Short, ? extends V>) - Method in class io.netty.util.collection.ShortCollections.UnmodifiableMap
-
- 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
-
- putByte(long, byte) - Static method in class io.netty.util.internal.PlatformDependent0
-
- putByte(byte[], int, byte) - Static method in class io.netty.util.internal.PlatformDependent0
-
- putIfAbsent(Map<String, DnsServerAddresses>, String, List<InetSocketAddress>) - Static method in class io.netty.resolver.dns.UnixResolverDnsServerAddressStreamProvider
-
- putIfAbsent(Map<String, DnsServerAddresses>, String, DnsServerAddresses) - Static method in class io.netty.resolver.dns.UnixResolverDnsServerAddressStreamProvider
-
- 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
-
- putInt(long, int) - Static method in class io.netty.util.internal.PlatformDependent0
-
- putInt(byte[], int, int) - Static method in class io.netty.util.internal.PlatformDependent0
-
- 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
-
- putLong(long, long) - Static method in class io.netty.util.internal.PlatformDependent0
-
- putLong(byte[], int, long) - Static method in class io.netty.util.internal.PlatformDependent0
-
- 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
-
- putShort(long, short) - Static method in class io.netty.util.internal.PlatformDependent0
-
- putShort(byte[], int, short) - Static method in class io.netty.util.internal.PlatformDependent0
-
- putValue(String, Object) - Method in class io.netty.handler.ssl.JdkSslSession
-
- r - Variable in class io.netty.util.concurrent.DefaultThreadFactory.DefaultRunnableDecorator
-
- raise() - Static method in exception com.sun.nio.sctp.UnsupportedOperatingSystemException
-
- random() - Static method in class io.netty.handler.ssl.util.ThreadLocalInsecureRandom
-
- random() - Method in class io.netty.util.internal.InternalThreadLocalMap
-
- random - Variable in class io.netty.util.internal.UnpaddedInternalThreadLocalMap
-
- RANDOM_LEN - Static variable in class io.netty.channel.DefaultChannelId
-
- RANDOM_PROVIDER - Static variable in class io.netty.util.internal.PlatformDependent
-
- randomCount - Variable in class io.netty.handler.codec.compression.Bzip2BlockDecompressor
-
If the current block is randomised, the remaining count at the current RNUMS position.
- randomIndex - Variable in class io.netty.handler.codec.compression.Bzip2BlockDecompressor
-
If the current block is randomised, the position within the RNUMS randomisation array.
- randomIndex(int) - Static method in class io.netty.resolver.RoundRobinInetAddressResolver
-
- RATIO - Static variable in class io.netty.util.Recycler
-
- ratioMask - Variable in class io.netty.util.Recycler
-
- ratioMask - Variable in class io.netty.util.Recycler.Stack
-
- 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
-
- rcvBufAllocator - Variable in class io.netty.channel.DefaultChannelConfig
-
- 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 class io.netty.channel.AbstractChannelHandlerContext
-
- 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
-
- read() - Method in class io.netty.channel.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- read(ChannelHandlerContext) - Method in class io.netty.channel.CombinedChannelDuplexHandler
-
- read(ChannelHandlerContext) - Method in class io.netty.channel.DefaultChannelPipeline.HeadContext
-
- 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() - Method in class io.netty.channel.nio.AbstractNioMessageChannel.NioMessageUnsafe
-
- read(ByteBuffer, int, int) - Method in class io.netty.channel.unix.FileDescriptor
-
- read(int, ByteBuffer, int, int) - Static method in class io.netty.channel.unix.FileDescriptor
-
- read() - Method in class io.netty.handler.codec.compression.Bzip2BlockDecompressor
-
Decodes a byte from the final Run-Length Encoding stage, pulling a new byte from the
Burrows-Wheeler Transform stage when required.
- 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
-
- READ_ADDRESS_CLOSED_CHANNEL_EXCEPTION - Static variable in class io.netty.channel.unix.FileDescriptor
-
- READ_ADDRESS_CONNECTION_RESET_EXCEPTION - Static variable in class io.netty.channel.unix.FileDescriptor
-
- READ_CLOSED_CHANNEL_EXCEPTION - Static variable in class io.netty.channel.unix.FileDescriptor
-
- READ_CONNECTION_RESET_EXCEPTION - Static variable in class io.netty.channel.unix.FileDescriptor
-
- READ_SUSPENDED - Static variable 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.buffer.WrappedByteBuf
-
- readableBytes() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- readableBytes - Variable in class io.netty.channel.CoalescingBufferQueue
-
- readableBytes() - Method in class io.netty.channel.CoalescingBufferQueue
-
The number of readable bytes.
- readableBytes() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- readAddress(long, int, int) - Method in class io.netty.channel.unix.FileDescriptor
-
- readAddress(int, long, int, int) - Static method in class io.netty.channel.unix.FileDescriptor
-
- readBits(int) - Method in class io.netty.handler.codec.compression.Bzip2BitReader
-
Reads up to 32 bits from the
ByteBuf
.
- readBoolean() - Method in class io.netty.buffer.AbstractByteBuf
-
- readBoolean() - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- readBoolean() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.buffer.WrappedByteBuf
-
- readBoolean() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- readBoolean() - Method in class io.netty.handler.codec.compression.Bzip2BitReader
-
Reads a single bit from the
ByteBuf
.
- readBoolean() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- readBoolean() - Method in class io.netty.handler.codec.serialization.ObjectDecoderInputStream
-
- readBuf - Variable in class io.netty.channel.nio.AbstractNioMessageChannel.NioMessageUnsafe
-
- readBuf - Variable in class io.netty.channel.oio.AbstractOioMessageChannel
-
- readByte() - Method in class io.netty.buffer.AbstractByteBuf
-
- readByte() - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- readByte() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.buffer.WrappedByteBuf
-
- readByte() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- readByte() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- 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.AdvancedLeakAwareByteBuf
-
- readBytes(ByteBuf) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- readBytes(ByteBuf, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- readBytes(ByteBuf, int, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- readBytes(byte[]) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- readBytes(byte[], int, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- readBytes(ByteBuffer) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- readBytes(OutputStream, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- readBytes(GatheringByteChannel, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- readBytes(FileChannel, long, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- readBytes(int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- readBytes(ByteBuf) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- readBytes(ByteBuf, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- readBytes(ByteBuf, int, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- readBytes(byte[]) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- readBytes(byte[], int, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- readBytes(ByteBuffer) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- readBytes(OutputStream, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- readBytes(GatheringByteChannel, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- readBytes(FileChannel, long, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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
-
- 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(byte[], int, int) - Method in class io.netty.buffer.PooledDirectByteBuf
-
- readBytes(ByteBuffer) - Method in class io.netty.buffer.PooledDirectByteBuf
-
- readBytes(OutputStream, int) - Method in class io.netty.buffer.PooledDirectByteBuf
-
- readBytes(GatheringByteChannel, int) - Method in class io.netty.buffer.PooledDirectByteBuf
-
- readBytes(FileChannel, long, int) - Method in class io.netty.buffer.PooledDirectByteBuf
-
- readBytes(GatheringByteChannel, int) - Method in class io.netty.buffer.PooledHeapByteBuf
-
- readBytes(FileChannel, long, int) - Method in class io.netty.buffer.PooledHeapByteBuf
-
- readBytes(ByteBuffer) - Method in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- readBytes(GatheringByteChannel, int) - Method in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- readBytes(FileChannel, long, int) - Method in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- 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
-
- readBytes(int) - Method in class io.netty.buffer.WrappedByteBuf
-
- readBytes(ByteBuf) - Method in class io.netty.buffer.WrappedByteBuf
-
- readBytes(ByteBuf, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- readBytes(ByteBuf, int, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- readBytes(byte[]) - Method in class io.netty.buffer.WrappedByteBuf
-
- readBytes(byte[], int, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- readBytes(ByteBuffer) - Method in class io.netty.buffer.WrappedByteBuf
-
- readBytes(OutputStream, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- readBytes(GatheringByteChannel, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- readBytes(FileChannel, long, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- readBytes(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- readBytes(GatheringByteChannel, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- readBytes(ByteBuf) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- readBytes(ByteBuf, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- readBytes(ByteBuf, int, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- readBytes(byte[]) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- readBytes(byte[], int, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- readBytes(ByteBuffer) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- readBytes(OutputStream, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- readBytes(FileChannel, long, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- readBytes(byte[], int, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- readBytes(byte[]) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- readBytes(ByteBuffer) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- readBytes(ByteBuf, int, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- readBytes(ByteBuf, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- readBytes(ByteBuf) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- readBytes(GatheringByteChannel, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- readBytes(FileChannel, long, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- readBytes(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- readBytes(OutputStream, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- readCertificates(File) - Static method in class io.netty.handler.ssl.PemReader
-
- readCertificates(InputStream) - Static method in class io.netty.handler.ssl.PemReader
-
- readChannelLimit - Variable in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
-
Limit in B/s to apply to read
- readChar() - Method in class io.netty.buffer.AbstractByteBuf
-
- readChar() - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- readChar() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.buffer.WrappedByteBuf
-
- readChar() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- readChar() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- 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.AdvancedLeakAwareByteBuf
-
- readCharSequence(int, Charset) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.
- readCharSequence(int, Charset) - Method in class io.netty.buffer.WrappedByteBuf
-
- readCharSequence(int, Charset) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- readCharSequence(int, Charset) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- 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
-
- 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
-
- readClassDescriptor() - Method in class io.netty.handler.codec.serialization.CompactObjectInputStream
-
- readCommand(ByteBuf) - Method in class io.netty.handler.codec.stomp.StompSubframeDecoder
-
- readComplete() - Method in class io.netty.channel.AdaptiveRecvByteBufAllocator.HandleImpl
-
- readComplete() - Method in class io.netty.channel.DefaultMaxBytesRecvByteBufAllocator.HandleImpl
-
- readComplete() - Method in class io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator.MaxMessageHandle
-
- readComplete() - Method in class io.netty.channel.kqueue.KQueueRecvByteAllocatorHandle
-
- readComplete() - Method in class io.netty.channel.RecvByteBufAllocator.DelegatingHandle
-
- readComplete() - Method in interface io.netty.channel.RecvByteBufAllocator.Handle
-
Deprecated.
The read has completed.
- readContent(InputStream) - Static method in class io.netty.handler.ssl.PemReader
-
- readDeviationActive - Variable in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
-
- readDouble() - Method in class io.netty.buffer.AbstractByteBuf
-
- readDouble() - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- readDouble() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.buffer.WrappedByteBuf
-
- readDouble() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- readDouble() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- readDouble() - Method in class io.netty.handler.codec.serialization.ObjectDecoderInputStream
-
- readDuringHandshake - Variable in class io.netty.handler.ssl.SslHandler
-
- readEndOfLine(ByteBuf) - Static method in class io.netty.handler.codec.redis.RedisDecoder
-
- readEOF() - Method in class io.netty.channel.kqueue.AbstractKQueueChannel.AbstractKQueueUnsafe
-
- readEOF - Variable in class io.netty.channel.kqueue.KQueueRecvByteAllocatorHandle
-
- readEOF() - Method in class io.netty.channel.kqueue.KQueueRecvByteAllocatorHandle
-
- reader - Variable in class io.netty.handler.codec.compression.Bzip2BlockDecompressor
-
A reader that provides bit-level reads.
- reader - Variable in class io.netty.handler.codec.compression.Bzip2Decoder
-
A reader that provides bit-level reads.
- reader - Variable in class io.netty.handler.codec.compression.Bzip2HuffmanStageDecoder
-
A reader that provides bit-level reads.
- READER_IDLE_STATE_EVENT - Static variable in class io.netty.handler.timeout.IdleStateEvent
-
- readerIdleTimeNanos - Variable in class io.netty.handler.timeout.IdleStateHandler
-
- readerIdleTimeout - Variable in class io.netty.handler.timeout.IdleStateHandler
-
- ReaderIdleTimeoutTask(ChannelHandlerContext) - Constructor for class io.netty.handler.timeout.IdleStateHandler.ReaderIdleTimeoutTask
-
- readerIndex - Variable in class io.netty.buffer.AbstractByteBuf
-
- 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.
- readerIndex() - Method in class io.netty.buffer.WrappedByteBuf
-
- readerIndex(int) - Method in class io.netty.buffer.WrappedByteBuf
-
- readerIndex() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- readerIndex(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- readerIndex() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- readerIndex(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- readFilter(boolean) - Method in class io.netty.channel.kqueue.AbstractKQueueChannel
-
- readFilterEnabled - Variable in class io.netty.channel.kqueue.AbstractKQueueChannel
-
- readFloat() - Method in class io.netty.buffer.AbstractByteBuf
-
- readFloat() - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- readFloat() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.buffer.WrappedByteBuf
-
- readFloat() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- readFloat() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- 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
-
- readGZIPFooter(ByteBuf) - Method in class io.netty.handler.codec.compression.JdkZlibDecoder
-
- readGZIPHeader(ByteBuf) - Method in class io.netty.handler.codec.compression.JdkZlibDecoder
-
- readHeaders(ByteBuf, StompHeaders) - Method in class io.netty.handler.codec.stomp.StompSubframeDecoder
-
- readIfIsAutoRead() - Method in class io.netty.channel.DefaultChannelPipeline.HeadContext
-
- readIfNeeded(ChannelHandlerContext) - Method in class io.netty.handler.ssl.SslHandler
-
- readInbound() - Method in class io.netty.channel.embedded.EmbeddedChannel
-
Return received data from this
Channel
- readIndex - Variable in class io.netty.util.Recycler.WeakOrderQueue.Link
-
- reading - Variable in class io.netty.handler.timeout.IdleStateHandler
-
- readingTime - Variable in class io.netty.handler.traffic.TrafficCounter
-
Last reading delay during current check interval
- readInProgress - Variable in class io.netty.channel.local.LocalChannel
-
- readInProgress - Variable in class io.netty.handler.flush.FlushConsolidationHandler
-
- readInt() - Method in class io.netty.buffer.AbstractByteBuf
-
- readInt() - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- readInt() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.buffer.WrappedByteBuf
-
- readInt() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- readInt() - Method in class io.netty.handler.codec.compression.Bzip2BitReader
-
Reads 32 bits of input as an integer.
- readInt() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- 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.AdvancedLeakAwareByteBuf
-
- readIntLE() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.
- readIntLE() - Method in class io.netty.buffer.WrappedByteBuf
-
- readIntLE() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- readIntLE() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- readLimit - Variable in class io.netty.handler.traffic.AbstractTrafficShapingHandler
-
Limit in B/s to apply to read
- readLine() - Method in class io.netty.buffer.ByteBufInputStream
-
- readLine(ByteBuf) - Static method in class io.netty.handler.codec.redis.RedisDecoder
-
- readLine() - Method in class io.netty.handler.codec.serialization.ObjectDecoderInputStream
-
- readLine(ByteBuf, int) - Static method in class io.netty.handler.codec.stomp.StompSubframeDecoder
-
- readLong() - Method in class io.netty.buffer.AbstractByteBuf
-
- readLong() - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- readLong() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.buffer.WrappedByteBuf
-
- readLong() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- readLong() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- 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.AdvancedLeakAwareByteBuf
-
- readLongLE() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.
- readLongLE() - Method in class io.netty.buffer.WrappedByteBuf
-
- readLongLE() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- readLongLE() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- readMedium() - Method in class io.netty.buffer.AbstractByteBuf
-
- readMedium() - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- readMedium() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.
- readMedium() - Method in class io.netty.buffer.WrappedByteBuf
-
- readMedium() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- readMedium() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- readMediumLE() - Method in class io.netty.buffer.AbstractByteBuf
-
- readMediumLE() - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- readMediumLE() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.
- readMediumLE() - Method in class io.netty.buffer.WrappedByteBuf
-
- readMediumLE() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- readMediumLE() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- readNextTLV(ByteBuf) - Static method in class io.netty.handler.codec.haproxy.HAProxyMessage
-
- readObject() - Method in class io.netty.handler.codec.serialization.ObjectDecoderInputStream
-
- ReadOnlyByteBuf - Class in io.netty.buffer
-
- ReadOnlyByteBuf(ByteBuf) - Constructor for class io.netty.buffer.ReadOnlyByteBuf
-
Deprecated.
- ReadOnlyByteBufferBuf - Class in io.netty.buffer
-
Read-only ByteBuf which wraps a read-only ByteBuffer.
- ReadOnlyByteBufferBuf(ByteBufAllocator, ByteBuffer) - Constructor for class io.netty.buffer.ReadOnlyByteBufferBuf
-
- readonlyChildren - Variable in class io.netty.util.concurrent.MultithreadEventExecutorGroup
-
- ReadOnlyIterator<T> - Class in io.netty.util.internal
-
- ReadOnlyIterator(Iterator<? extends T>) - Constructor for class io.netty.util.internal.ReadOnlyIterator
-
- ReadOnlyUnsafeDirectByteBuf - Class in io.netty.buffer
-
Read-only ByteBuf which wraps a read-only direct ByteBuffer and use unsafe for best performance.
- ReadOnlyUnsafeDirectByteBuf(ByteBufAllocator, ByteBuffer) - Constructor for class io.netty.buffer.ReadOnlyUnsafeDirectByteBuf
-
- readOutbound() - Method in class io.netty.channel.embedded.EmbeddedChannel
-
Read data from the outbound.
- readPending - Variable in class io.netty.channel.kqueue.AbstractKQueueChannel.AbstractKQueueUnsafe
-
- readPending - Variable in class io.netty.channel.nio.AbstractNioChannel
-
- readPending - Variable in class io.netty.channel.oio.AbstractOioChannel
-
- readPending - Variable in class io.netty.handler.ssl.AbstractSniHandler
-
- readPreamble(ByteBuf) - Static method in class io.netty.handler.codec.compression.Snappy
-
Reads the length varint (a series of bytes, where the lower 7 bits
are data and the upper bit is a flag to indicate more bytes to be
read).
- readPrivateKey(File) - Static method in class io.netty.handler.ssl.PemReader
-
- readPrivateKey(InputStream) - Static method in class io.netty.handler.ssl.PemReader
-
- readReady(long) - Method in class io.netty.channel.kqueue.AbstractKQueueChannel.AbstractKQueueUnsafe
-
- readReady(KQueueRecvByteAllocatorHandle) - Method in class io.netty.channel.kqueue.AbstractKQueueChannel.AbstractKQueueUnsafe
-
- readReady(KQueueRecvByteAllocatorHandle) - Method in class io.netty.channel.kqueue.AbstractKQueueServerChannel.KQueueServerSocketUnsafe
-
- readReady(KQueueRecvByteAllocatorHandle) - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel.KQueueStreamUnsafe
-
- readReady(KQueueRecvByteAllocatorHandle) - Method in class io.netty.channel.kqueue.KQueueDatagramChannel.KQueueDatagramChannelUnsafe
-
- readReady(KQueueRecvByteAllocatorHandle) - Method in class io.netty.channel.kqueue.KQueueDomainSocketChannel.KQueueDomainUnsafe
-
- readReadyBefore() - Method in class io.netty.channel.kqueue.AbstractKQueueChannel.AbstractKQueueUnsafe
-
- readReadyFd() - Method in class io.netty.channel.kqueue.KQueueDomainSocketChannel.KQueueDomainUnsafe
-
- readReadyFinally(ChannelConfig) - Method in class io.netty.channel.kqueue.AbstractKQueueChannel.AbstractKQueueUnsafe
-
- readReadyRunnable - Variable in class io.netty.channel.kqueue.AbstractKQueueChannel.AbstractKQueueUnsafe
-
- readReadyRunnablePending - Variable in class io.netty.channel.kqueue.AbstractKQueueChannel
-
- 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.AdvancedLeakAwareByteBuf
-
- readRetainedSlice(int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.SimpleLeakAwareByteBuf
-
- readRetainedSlice(int) - Method in class io.netty.buffer.SimpleLeakAwareCompositeByteBuf
-
- readRetainedSlice(int) - Method in class io.netty.buffer.SwappedByteBuf
-
Deprecated.
- readRetainedSlice(int) - Method in class io.netty.buffer.UnreleasableByteBuf
-
- readRetainedSlice(int) - Method in class io.netty.buffer.WrappedByteBuf
-
- readRetainedSlice(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- readRetainedSlice(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- readSelector - Variable in class io.netty.channel.sctp.oio.OioSctpChannel
-
- readShort() - Method in class io.netty.buffer.AbstractByteBuf
-
- readShort() - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- readShort() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.buffer.WrappedByteBuf
-
- readShort() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- readShort() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- 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.AdvancedLeakAwareByteBuf
-
- readShortLE() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.
- readShortLE() - Method in class io.netty.buffer.WrappedByteBuf
-
- readShortLE() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- readShortLE() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- readSlice(int) - Method in class io.netty.buffer.AbstractByteBuf
-
- readSlice(int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- readSlice(int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.SimpleLeakAwareByteBuf
-
- readSlice(int) - Method in class io.netty.buffer.SimpleLeakAwareCompositeByteBuf
-
- readSlice(int) - Method in class io.netty.buffer.SwappedByteBuf
-
Deprecated.
- readSlice(int) - Method in class io.netty.buffer.UnreleasableByteBuf
-
- readSlice(int) - Method in class io.netty.buffer.WrappedByteBuf
-
- readSlice(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- readSlice(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- readStreamHeader() - Method in class io.netty.handler.codec.serialization.CompactObjectInputStream
-
- readString(String, ByteBuf) - Static method in class io.netty.handler.codec.socksx.v4.Socks4ServerDecoder
-
Reads a variable-length NUL-terminated string as defined in SOCKS4.
- readTask - Variable in class io.netty.channel.local.LocalChannel
-
- readTask - Variable in class io.netty.channel.oio.AbstractOioChannel
-
- 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
-
- ReadTimeoutException() - Constructor for exception io.netty.handler.timeout.ReadTimeoutException
-
- ReadTimeoutHandler - Class in io.netty.handler.timeout
-
- 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.
- readTlvs(ByteBuf) - Static method in class io.netty.handler.codec.haproxy.HAProxyMessage
-
- readU16(byte[], int) - Static method in class io.netty.handler.codec.compression.FastLz
-
- readUnsignedByte() - Method in class io.netty.buffer.AbstractByteBuf
-
- readUnsignedByte() - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- readUnsignedByte() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.buffer.WrappedByteBuf
-
- readUnsignedByte() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- readUnsignedByte() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- 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.AdvancedLeakAwareByteBuf
-
- readUnsignedInt() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.
- readUnsignedInt() - Method in class io.netty.buffer.WrappedByteBuf
-
- readUnsignedInt() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- readUnsignedInt() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- readUnsignedIntLE() - Method in class io.netty.buffer.AbstractByteBuf
-
- readUnsignedIntLE() - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- readUnsignedIntLE() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.
- readUnsignedIntLE() - Method in class io.netty.buffer.WrappedByteBuf
-
- readUnsignedIntLE() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- readUnsignedIntLE() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- readUnsignedMedium() - Method in class io.netty.buffer.AbstractByteBuf
-
- readUnsignedMedium() - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- readUnsignedMedium() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.
- readUnsignedMedium() - Method in class io.netty.buffer.WrappedByteBuf
-
- readUnsignedMedium() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- readUnsignedMedium() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- readUnsignedMediumLE() - Method in class io.netty.buffer.AbstractByteBuf
-
- readUnsignedMediumLE() - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- readUnsignedMediumLE() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.
- readUnsignedMediumLE() - Method in class io.netty.buffer.WrappedByteBuf
-
- readUnsignedMediumLE() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- readUnsignedMediumLE() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- readUnsignedShort() - Method in class io.netty.buffer.AbstractByteBuf
-
- readUnsignedShort() - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- readUnsignedShort() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.buffer.WrappedByteBuf
-
- readUnsignedShort() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- readUnsignedShort() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- 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.AdvancedLeakAwareByteBuf
-
- readUnsignedShortLE() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.
- readUnsignedShortLE() - Method in class io.netty.buffer.WrappedByteBuf
-
- readUnsignedShortLE() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- readUnsignedShortLE() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- readUsAscii(ByteBuf, int) - Static method in class io.netty.handler.codec.socks.SocksCommonUtils
-
- readUTF() - Method in class io.netty.buffer.ByteBufInputStream
-
- readUTF() - Method in class io.netty.handler.codec.serialization.ObjectDecoderInputStream
-
- realloc(boolean) - Method in class io.netty.channel.kqueue.KQueueEventArray
-
- realloc() - Method in class io.netty.channel.kqueue.NativeLongArray
-
- reallocate(PooledByteBuf<T>, int, boolean) - Method in class io.netty.buffer.PoolArena
-
- reallocateDirect(ByteBuffer, int) - Method in class io.netty.buffer.UnpooledByteBufAllocator.InstrumentedUnpooledUnsafeNoCleanerDirectByteBuf
-
- reallocateDirect(ByteBuffer, int) - Method in class io.netty.buffer.UnpooledUnsafeNoCleanerDirectByteBuf
-
- reallocateDirectNoCleaner(ByteBuffer, int) - Static method in class io.netty.util.internal.PlatformDependent
-
Reallocate a new ByteBuffer
with the given capacity
.
- reallocateDirectNoCleaner(ByteBuffer, int) - Static method in class io.netty.util.internal.PlatformDependent0
-
- reallocateMemory(long, long) - Static method in class io.netty.util.internal.PlatformDependent
-
- reallocateMemory(long, long) - Static method in class io.netty.util.internal.PlatformDependent0
-
- realWriteThroughput - Variable in class io.netty.handler.traffic.TrafficCounter
-
Real writing bandwidth
- realWrittenBytes - Variable in class io.netty.handler.traffic.TrafficCounter
-
Real written bytes
- rebuildSelector() - Method in class io.netty.channel.nio.NioEventLoop
-
Replaces the current Selector
of this event loop with newly created Selector
s to work
around the infamous epoll 100% CPU bug.
- rebuildSelector0() - Method in class io.netty.channel.nio.NioEventLoop
-
- rebuildSelectors() - Method in class io.netty.channel.nio.NioEventLoopGroup
-
Replaces the current Selector
s of the child event loops with newly created Selector
s 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
-
- receive(ByteBuffer, T, NotificationHandler<T>) - Method in class com.sun.nio.sctp.SctpChannel
-
- receivedAmount - Variable in class io.netty.channel.unix.DatagramSocketAddress
-
- 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 - Variable in class io.netty.channel.DefaultAddressedEnvelope
-
- recipient() - Method in class io.netty.channel.DefaultAddressedEnvelope
-
- recipient - Variable in class io.netty.handler.codec.dns.DatagramDnsQuery
-
- recipient() - Method in class io.netty.handler.codec.dns.DatagramDnsQuery
-
- recipient - Variable in class io.netty.handler.codec.dns.DatagramDnsResponse
-
- recipient() - Method in class io.netty.handler.codec.dns.DatagramDnsResponse
-
- reclaimSpace(int) - Method in class io.netty.util.Recycler.WeakOrderQueue
-
- record(int) - Method in class io.netty.channel.AdaptiveRecvByteBufAllocator.HandleImpl
-
- 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 class io.netty.util.ResourceLeakDetector.DefaultResourceLeak
-
- record(Object) - Method in class io.netty.util.ResourceLeakDetector.DefaultResourceLeak
-
- 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.
- record0(Object, int) - Method in class io.netty.util.ResourceLeakDetector.DefaultResourceLeak
-
- recordAt(DnsSection) - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
-
- recordAt(int) - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
-
- recordAt(DnsSection, int) - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
-
- recordAt(int, 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.
- recordDecoder - Variable in class io.netty.handler.codec.dns.DatagramDnsQueryDecoder
-
- recordDecoder - Variable in class io.netty.handler.codec.dns.DatagramDnsResponseDecoder
-
- recordEncoder - Variable in class io.netty.handler.codec.dns.DatagramDnsQueryEncoder
-
- recordEncoder - Variable in class io.netty.handler.codec.dns.DatagramDnsResponseEncoder
-
- recordException(ChannelFuture) - Method in class io.netty.channel.embedded.EmbeddedChannel
-
- recordException(Throwable) - Method in class io.netty.channel.embedded.EmbeddedChannel
-
- recordExceptionListener - Variable in class io.netty.channel.embedded.EmbeddedChannel
-
- recordLeakNonRefCountingOperation(ResourceLeakTracker<ByteBuf>) - Static method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- recursionAvailable - Variable in class io.netty.handler.codec.dns.DefaultDnsResponse
-
- recursionDesired - Variable in class io.netty.handler.codec.dns.AbstractDnsMessage
-
- recursionDesired - Variable in class io.netty.resolver.dns.DnsNameResolver
-
- recursionDesired - Variable in class io.netty.resolver.dns.DnsNameResolverBuilder
-
- 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.
- recursionDesired - Variable in class io.netty.resolver.dns.DnsQueryContext
-
- recvBufAllocHandle() - Method in class io.netty.channel.AbstractChannel.AbstractUnsafe
-
- recvBufAllocHandle() - Method in interface io.netty.channel.Channel.Unsafe
-
- recvBufAllocHandle() - Method in class io.netty.channel.kqueue.AbstractKQueueChannel.AbstractKQueueUnsafe
-
- 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
-
- RecvByteBufAllocator.ExtendedHandle - Interface in io.netty.channel
-
- RecvByteBufAllocator.Handle - Interface in io.netty.channel
-
- recvFd() - Method in class io.netty.channel.unix.Socket
-
- recvFd(int) - Static method in class io.netty.channel.unix.Socket
-
- recvFrom(ByteBuffer, int, int) - Method in class io.netty.channel.unix.Socket
-
- recvFrom(int, ByteBuffer, int, int) - Static method in class io.netty.channel.unix.Socket
-
- recvFromAddress(long, int, int) - Method in class io.netty.channel.unix.Socket
-
- recvFromAddress(int, long, int, int) - Static method in class io.netty.channel.unix.Socket
-
- recvHandle - Variable in class io.netty.channel.AbstractChannel.AbstractUnsafe
-
- RecyclableArrayDeque(int, Recycler.Handle<FlowControlHandler.RecyclableArrayDeque>) - Constructor for class io.netty.handler.flow.FlowControlHandler.RecyclableArrayDeque
-
- RecyclableArrayList - Class in io.netty.util.internal
-
A simple list which is recyclable.
- RecyclableArrayList(Recycler.Handle<RecyclableArrayList>) - Constructor for class io.netty.util.internal.RecyclableArrayList
-
- RecyclableArrayList(Recycler.Handle<RecyclableArrayList>, int) - Constructor for class io.netty.util.internal.RecyclableArrayList
-
- recycle() - Method in class io.netty.buffer.PooledByteBuf
-
- recycle() - Method in class io.netty.buffer.PoolThreadCache.MemoryRegionCache.Entry
-
- recycle() - Method in class io.netty.channel.ChannelOutboundBuffer.Entry
-
- recycle() - Method in class io.netty.channel.ChannelOutboundBuffer
-
Deprecated.
- recycle() - Method in class io.netty.channel.PendingWriteQueue.PendingWrite
-
- recycle(PendingWriteQueue.PendingWrite, boolean) - Method in class io.netty.channel.PendingWriteQueue
-
- recycle() - Method in class io.netty.handler.codec.CodecOutputList
-
Recycle the array which will clear it and null out all entries in the internal storage.
- recycle() - Method in class io.netty.handler.flow.FlowControlHandler.RecyclableArrayDeque
-
- 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(Object) - Method in class io.netty.util.Recycler.DefaultHandle
-
- 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
.
- recycleAndGetNext() - Method in class io.netty.channel.ChannelOutboundBuffer.Entry
-
- recycleId - Variable in class io.netty.util.Recycler.DefaultHandle
-
- RECYCLER - Static variable in class io.netty.buffer.ByteBufUtil.ThreadLocalDirectByteBuf
-
- RECYCLER - Static variable in class io.netty.buffer.ByteBufUtil.ThreadLocalUnsafeDirectByteBuf
-
- RECYCLER - Static variable in class io.netty.buffer.PooledDirectByteBuf
-
- RECYCLER - Static variable in class io.netty.buffer.PooledDuplicatedByteBuf
-
- RECYCLER - Static variable in class io.netty.buffer.PooledHeapByteBuf
-
- RECYCLER - Static variable in class io.netty.buffer.PooledSlicedByteBuf
-
- RECYCLER - Static variable in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- RECYCLER - Static variable in class io.netty.buffer.PooledUnsafeHeapByteBuf
-
- RECYCLER - Static variable in class io.netty.buffer.PoolThreadCache.MemoryRegionCache
-
- RECYCLER - Static variable in class io.netty.channel.AbstractChannelHandlerContext.WriteAndFlushTask
-
- RECYCLER - Static variable in class io.netty.channel.AbstractChannelHandlerContext.WriteTask
-
- RECYCLER - Static variable in class io.netty.channel.ChannelOutboundBuffer.Entry
-
- RECYCLER - Static variable in class io.netty.channel.PendingWriteQueue.PendingWrite
-
- RECYCLER - Static variable in class io.netty.handler.codec.CodecOutputList
-
- RECYCLER - Static variable in class io.netty.handler.flow.FlowControlHandler.RecyclableArrayDeque
-
- RECYCLER - Static variable in class io.netty.util.internal.PendingWrite
-
- RECYCLER - Static variable in class io.netty.util.internal.RecyclableArrayList
-
- 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.DefaultHandle<T> - Class in io.netty.util
-
- Recycler.Handle<T> - Interface in io.netty.util
-
- Recycler.Stack<T> - Class in io.netty.util
-
- Recycler.WeakOrderQueue - Class in io.netty.util
-
- Recycler.WeakOrderQueue.Link - Class in io.netty.util
-
- recyclerHandle - Variable in class io.netty.buffer.AbstractPooledDerivedByteBuf
-
- recyclerHandle - Variable in class io.netty.buffer.PooledByteBuf
-
- recyclerHandle - Variable in class io.netty.buffer.PoolThreadCache.MemoryRegionCache.Entry
-
- REDIS_MESSAGE_MAX_LENGTH - Static variable in class io.netty.handler.codec.redis.RedisConstants
-
- RedisArrayAggregator - Class in io.netty.handler.codec.redis
-
- RedisArrayAggregator() - Constructor for class io.netty.handler.codec.redis.RedisArrayAggregator
-
- RedisArrayAggregator.AggregateState - Class in io.netty.handler.codec.redis
-
- RedisBulkStringAggregator - Class in io.netty.handler.codec.redis
-
- RedisBulkStringAggregator() - Constructor for class io.netty.handler.codec.redis.RedisBulkStringAggregator
-
Creates a new instance.
- RedisCodecException - Exception in io.netty.handler.codec.redis
-
- 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.
- RedisCodecUtil - Class in io.netty.handler.codec.redis
-
Utilities for codec-redis.
- RedisCodecUtil() - Constructor for class io.netty.handler.codec.redis.RedisCodecUtil
-
- RedisConstants - Class in io.netty.handler.codec.redis
-
Constant values for Redis encoder/decoder.
- RedisConstants() - Constructor for class io.netty.handler.codec.redis.RedisConstants
-
- RedisDecoder - Class in io.netty.handler.codec.redis
-
- 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.
- RedisDecoder.State - Enum in io.netty.handler.codec.redis
-
- RedisDecoder.ToPositiveLongProcessor - Class in io.netty.handler.codec.redis
-
- 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
-
- RedisMessageType - Enum in io.netty.handler.codec.redis
-
- RedisMessageType(byte, boolean) - Constructor for enum io.netty.handler.codec.redis.RedisMessageType
-
- refCnt() - Method in class io.netty.buffer.AbstractDerivedByteBuf
-
Deprecated.
- refCnt - Variable in class io.netty.buffer.AbstractReferenceCountedByteBuf
-
- 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.buffer.WrappedByteBuf
-
- refCnt() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- 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.ReplayingDecoderByteBuf
-
- refCnt() - Method in class io.netty.handler.codec.stomp.DefaultStompFrame
-
- refCnt() - Method in class io.netty.handler.ssl.PemX509Certificate
-
- refCnt - Variable in class io.netty.util.AbstractReferenceCounted
-
- 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
-
- refCnt0() - Method in class io.netty.buffer.AbstractDerivedByteBuf
-
Deprecated.
- refCnt0() - Method in class io.netty.buffer.AbstractPooledDerivedByteBuf.PooledNonRetainedDuplicateByteBuf
-
- refCnt0() - Method in class io.netty.buffer.AbstractPooledDerivedByteBuf.PooledNonRetainedSlicedByteBuf
-
- refCntUpdater - Static variable in class io.netty.buffer.AbstractReferenceCountedByteBuf
-
- refCntUpdater - Static variable in class io.netty.util.AbstractReferenceCounted
-
- referenceCountDelegate - Variable in class io.netty.buffer.AbstractPooledDerivedByteBuf.PooledNonRetainedDuplicateByteBuf
-
- referenceCountDelegate - Variable in class io.netty.buffer.AbstractPooledDerivedByteBuf.PooledNonRetainedSlicedByteBuf
-
- ReferenceCounted - Interface in io.netty.util
-
A reference-counted object that requires explicit deallocation.
- ReferenceCountUtil - Class in io.netty.util
-
- ReferenceCountUtil() - Constructor for class io.netty.util.ReferenceCountUtil
-
- ReferenceCountUtil.ReleasingTask - Class in io.netty.util
-
- ReferenceMap<K,V> - Class in io.netty.handler.codec.serialization
-
- ReferenceMap(Map<K, Reference<V>>) - Constructor for class io.netty.handler.codec.serialization.ReferenceMap
-
- refill() - Method in class io.netty.handler.codec.compression.Bzip2BitReader
-
- ReflectionUtil - Class in io.netty.util.internal
-
- ReflectionUtil() - Constructor for class io.netty.util.internal.ReflectionUtil
-
- ReflectiveByteBufChecksum(Checksum, Method) - Constructor for class io.netty.handler.codec.compression.ByteBufChecksum.ReflectiveByteBufChecksum
-
- ReflectiveChannelFactory<T extends Channel> - Class in io.netty.channel
-
- ReflectiveChannelFactory(Class<? extends T>) - Constructor for class io.netty.channel.ReflectiveChannelFactory
-
- ReflectiveMatcher(Class<?>) - Constructor for class io.netty.util.internal.TypeParameterMatcher.ReflectiveMatcher
-
- refQueue - Variable in class io.netty.util.ResourceLeakDetector
-
- 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
- regionMatchesCharSequences(CharSequence, int, CharSequence, int, int, AsciiString.CharEqualityComparator) - Static method in class io.netty.util.AsciiString
-
- register() - Method in class io.netty.bootstrap.AbstractBootstrap
-
- register(EventLoop, ChannelPromise) - Method in class io.netty.channel.AbstractChannel.AbstractUnsafe
-
- register(EventLoop, ChannelPromise) - Method in interface io.netty.channel.Channel.Unsafe
-
- register(Channel) - Method in class io.netty.channel.embedded.EmbeddedEventLoop
-
- register(ChannelPromise) - Method in class io.netty.channel.embedded.EmbeddedEventLoop
-
- register(Channel, ChannelPromise) - Method in class io.netty.channel.embedded.EmbeddedEventLoop
-
Deprecated.
- register(Channel) - Method in interface io.netty.channel.EventLoopGroup
-
- register(ChannelPromise) - Method in interface io.netty.channel.EventLoopGroup
-
- register(Channel, ChannelPromise) - Method in interface io.netty.channel.EventLoopGroup
-
- register(Channel, LocalAddress, SocketAddress) - Static method in class io.netty.channel.local.LocalChannelRegistry
-
- 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.
- register0(ChannelPromise) - Method in class io.netty.channel.AbstractChannel.AbstractUnsafe
-
- registered - Variable in class io.netty.bootstrap.AbstractBootstrap.PendingRegistrationPromise
-
- registered() - Method in class io.netty.bootstrap.AbstractBootstrap.PendingRegistrationPromise
-
- registered - Variable in class io.netty.channel.AbstractChannel
-
- registered - Variable in class io.netty.channel.DefaultChannelPipeline
-
Set to
true
once the
AbstractChannel
is registered.Once set to
true
the value will never
change.
- registerInProgress - Variable in class io.netty.channel.local.LocalChannel
-
- rehash(int) - Method in class io.netty.util.collection.ByteObjectHashMap
-
Rehashes the map for the given capacity.
- rehash(int) - Method in class io.netty.util.collection.CharObjectHashMap
-
Rehashes the map for the given capacity.
- rehash(int) - Method in class io.netty.util.collection.IntObjectHashMap
-
Rehashes the map for the given capacity.
- rehash(int) - Method in class io.netty.util.collection.LongObjectHashMap
-
Rehashes the map for the given capacity.
- rehash(int) - Method in class io.netty.util.collection.ShortObjectHashMap
-
Rehashes the map for the given capacity.
- reject() - Static method in class io.netty.channel.group.VoidChannelGroupFuture
-
- reject() - Static method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- REJECT - Static variable in class io.netty.util.concurrent.RejectedExecutionHandlers
-
- reject() - Static method in class io.netty.util.concurrent.RejectedExecutionHandlers
-
- reject() - Static method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- reject(Runnable) - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- rejected(Runnable, SingleThreadEventExecutor) - Method in interface io.netty.util.concurrent.RejectedExecutionHandler
-
- REJECTED_OR_FAILED - Static variable in class io.netty.handler.codec.socksx.v4.Socks4CommandStatus
-
- RejectedExecutionHandler - Interface in io.netty.util.concurrent
-
- rejectedExecutionHandler - Variable in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- RejectedExecutionHandlers - Class in io.netty.util.concurrent
-
- RejectedExecutionHandlers() - Constructor for class io.netty.util.concurrent.RejectedExecutionHandlers
-
- rejectedExecutionLogger - Static variable in class io.netty.util.concurrent.DefaultPromise
-
- relativeTimeAction - Variable in class io.netty.handler.traffic.ChannelTrafficShapingHandler.ToSend
-
- relativeTimeAction - Variable in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler.ToSend
-
- relativeTimeAction - Variable in class io.netty.handler.traffic.GlobalTrafficShapingHandler.ToSend
-
- 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.SimpleLeakAwareByteBuf
-
- release(int) - Method in class io.netty.buffer.SimpleLeakAwareByteBuf
-
- release() - Method in class io.netty.buffer.SimpleLeakAwareCompositeByteBuf
-
- release(int) - Method in class io.netty.buffer.SimpleLeakAwareCompositeByteBuf
-
- 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.buffer.UnreleasableByteBuf
-
- release(int) - Method in class io.netty.buffer.UnreleasableByteBuf
-
- release() - Method in class io.netty.buffer.WrappedByteBuf
-
- release(int) - Method in class io.netty.buffer.WrappedByteBuf
-
- release() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- release(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- 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(Channel, Promise<Void>) - Method in interface io.netty.channel.pool.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() - 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.ReplayingDecoderByteBuf
-
- release(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- 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
-
- release(Object, int) - Static method in class io.netty.util.ReferenceCountUtil
-
- release0() - Method in class io.netty.buffer.AbstractDerivedByteBuf
-
Deprecated.
- release0(int) - Method in class io.netty.buffer.AbstractDerivedByteBuf
-
Deprecated.
- release0() - Method in class io.netty.buffer.AbstractPooledDerivedByteBuf.PooledNonRetainedDuplicateByteBuf
-
- release0(int) - Method in class io.netty.buffer.AbstractPooledDerivedByteBuf.PooledNonRetainedDuplicateByteBuf
-
- release0() - Method in class io.netty.buffer.AbstractPooledDerivedByteBuf.PooledNonRetainedSlicedByteBuf
-
- release0(int) - Method in class io.netty.buffer.AbstractPooledDerivedByteBuf.PooledNonRetainedSlicedByteBuf
-
- release0(int) - Method in class io.netty.buffer.AbstractReferenceCountedByteBuf
-
- release0(int) - Method in class io.netty.util.AbstractReferenceCounted
-
- RELEASE_RESPONSE - Static variable in class io.netty.resolver.dns.DnsNameResolverContext
-
- releaseAll(Queue<Object>) - Static method in class io.netty.channel.embedded.EmbeddedChannel
-
- releaseAndCompleteAll(ChannelFuture) - Method in class io.netty.channel.CoalescingBufferQueue
-
- releaseAndFailAll(Throwable) - Method in class io.netty.channel.CoalescingBufferQueue
-
Release all buffers in the queue and complete all listeners and promises.
- releaseAndOffer(Channel, Promise<Void>) - Method in class io.netty.channel.pool.SimpleChannelPool
-
- releaseAndOfferIfHealthy(Channel, Promise<Void>, Future<Boolean>) - Method in class io.netty.channel.pool.SimpleChannelPool
-
Adds the channel back to the pool only if the channel is healthy.
- releaseCurrentMessage() - Method in class io.netty.handler.codec.MessageAggregator
-
- releaseHealthCheck - Variable in class io.netty.channel.pool.SimpleChannelPool
-
- 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.
- releaseInboundBuffers() - Method in class io.netty.channel.local.LocalChannel
-
- releaseLater(T) - Static method in class io.netty.util.ReferenceCountUtil
-
- releaseLater(T, int) - Static method in class io.netty.util.ReferenceCountUtil
-
- releaseMessages - Variable in class io.netty.handler.flow.FlowControlHandler
-
- releaseOnClose - Variable in class io.netty.buffer.ByteBufInputStream
-
To preserve backwards compatibility (which didn't transfer ownership) we support a conditional flag which
indicates if
ByteBufInputStream.buffer
should be released when this
InputStream
is closed.
- 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.
- releaseReadSuspended(ChannelHandlerContext) - Method in class io.netty.handler.traffic.AbstractTrafficShapingHandler
-
Release the Read suspension
- releaseWriteSuspended(ChannelHandlerContext) - Method in class io.netty.handler.traffic.AbstractTrafficShapingHandler
-
Explicitly release the Write suspended status.
- ReleasingTask(ReferenceCounted, int) - Constructor for class io.netty.util.ReferenceCountUtil.ReleasingTask
-
- remainingBulkLength - Variable in class io.netty.handler.codec.redis.RedisDecoder
-
- remainingLength - Variable in class io.netty.handler.codec.mqtt.MqttFixedHeader
-
- remainingLength() - Method in class io.netty.handler.codec.mqtt.MqttFixedHeader
-
- remainingRounds - Variable in class io.netty.util.HashedWheelTimer.HashedWheelTimeout
-
- remote - Variable in class io.netty.channel.kqueue.KQueueDatagramChannel
-
- remote - Variable in class io.netty.channel.kqueue.KQueueDomainSocketChannel
-
- remote - Variable in class io.netty.channel.kqueue.KQueueSocketChannel
-
- REMOTE_ADDRESS - Static variable in class io.netty.channel.embedded.EmbeddedChannel
-
- remoteAddress - Variable in class io.netty.bootstrap.Bootstrap
-
- remoteAddress(SocketAddress) - Method in class io.netty.bootstrap.Bootstrap
-
- 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.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 - Variable in class io.netty.channel.AbstractChannel
-
- 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.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 - Variable in class io.netty.channel.local.LocalChannel
-
- remoteAddress() - Method in class io.netty.channel.local.LocalChannel
-
- remoteAddress() - Method in class io.netty.channel.local.LocalServerChannel
-
- remoteAddress() - Method in class io.netty.channel.sctp.nio.NioSctpChannel
-
- remoteAddress() - Method in class io.netty.channel.sctp.nio.NioSctpServerChannel
-
- remoteAddress() - Method in class io.netty.channel.sctp.oio.OioSctpChannel
-
- remoteAddress() - Method in class io.netty.channel.sctp.oio.OioSctpServerChannel
-
- remoteAddress() - Method in interface io.netty.channel.sctp.SctpChannel
-
Return the (primary) remote address of the SCTP channel.
- 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(int) - Static method in class io.netty.channel.unix.Socket
-
- remoteAddress - Variable in exception io.netty.resolver.dns.DnsNameResolverException
-
- 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.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.sctp.nio.NioSctpChannel
-
- remoteAddress0() - Method in class io.netty.channel.sctp.nio.NioSctpServerChannel
-
- remoteAddress0() - Method in class io.netty.channel.sctp.oio.OioSctpChannel
-
- remoteAddress0() - Method in class io.netty.channel.sctp.oio.OioSctpServerChannel
-
- 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.buffer.CompositeByteBuf.CompositeByteBufIterator
-
- remove(PoolChunk<T>) - Method in class io.netty.buffer.PoolChunkList
-
- remove(ChannelHandlerContext) - Method in class io.netty.channel.ChannelInitializer
-
- 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
-
- 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
-
- remove(int, ChannelPromise) - Method in class io.netty.channel.CoalescingBufferQueue
-
Remove a
ByteBuf
from the queue with the specified number of bytes.
- remove() - Method in class io.netty.channel.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- 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(AbstractChannelHandlerContext) - Method in class io.netty.channel.DefaultChannelPipeline
-
- remove() - Method in class io.netty.channel.group.CombinedIterator
-
- remove(Object) - Method in class io.netty.channel.group.DefaultChannelGroup
-
- remove(AbstractKQueueChannel) - Method in class io.netty.channel.kqueue.KQueueEventLoop
-
- remove(Object) - Method in class io.netty.channel.nio.SelectedSelectionKeySet
-
- remove() - Method in class io.netty.channel.PendingWriteQueue
-
- remove(K) - Method in class io.netty.channel.pool.AbstractChannelPoolMap
-
- remove(int) - Method in class io.netty.handler.codec.CodecOutputList
-
- remove() - Method in class io.netty.handler.codec.DefaultHeaders.HeaderEntry
-
- remove() - Method in class io.netty.handler.codec.DefaultHeaders.HeaderIterator
-
- 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(Object) - Method in class io.netty.handler.codec.HeadersUtils.DelegatingStringSet
-
- remove() - Method in class io.netty.handler.codec.HeadersUtils.StringEntryIterator
-
- remove() - Method in class io.netty.handler.codec.HeadersUtils.StringIterator
-
- remove(Object) - Method in class io.netty.handler.codec.serialization.ReferenceMap
-
- remove(String) - Method in class io.netty.resolver.dns.DnsNameResolverContext.AuthoritativeNameServerList
-
- remove(InetSocketAddress, int) - Method in class io.netty.resolver.dns.DnsQueryContextManager
-
- remove() - Method in interface io.netty.util.Attribute
-
- remove(byte) - Method in class io.netty.util.collection.ByteCollections.EmptyMap
-
- remove(Object) - Method in class io.netty.util.collection.ByteCollections.EmptyMap
-
- remove() - Method in class io.netty.util.collection.ByteCollections.UnmodifiableMap.IteratorImpl
-
- remove(byte) - Method in class io.netty.util.collection.ByteCollections.UnmodifiableMap
-
- remove(Object) - Method in class io.netty.util.collection.ByteCollections.UnmodifiableMap
-
- remove(Object) - Method in class io.netty.util.collection.ByteObjectHashMap.KeySet
-
- remove() - Method in class io.netty.util.collection.ByteObjectHashMap.MapIterator
-
- remove() - Method in class io.netty.util.collection.ByteObjectHashMap.PrimitiveIterator
-
- 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.CharCollections.EmptyMap
-
- remove(Object) - Method in class io.netty.util.collection.CharCollections.EmptyMap
-
- remove() - Method in class io.netty.util.collection.CharCollections.UnmodifiableMap.IteratorImpl
-
- remove(char) - Method in class io.netty.util.collection.CharCollections.UnmodifiableMap
-
- remove(Object) - Method in class io.netty.util.collection.CharCollections.UnmodifiableMap
-
- remove(Object) - Method in class io.netty.util.collection.CharObjectHashMap.KeySet
-
- remove() - Method in class io.netty.util.collection.CharObjectHashMap.MapIterator
-
- remove() - Method in class io.netty.util.collection.CharObjectHashMap.PrimitiveIterator
-
- 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.IntCollections.EmptyMap
-
- remove(Object) - Method in class io.netty.util.collection.IntCollections.EmptyMap
-
- remove() - Method in class io.netty.util.collection.IntCollections.UnmodifiableMap.IteratorImpl
-
- remove(int) - Method in class io.netty.util.collection.IntCollections.UnmodifiableMap
-
- remove(Object) - Method in class io.netty.util.collection.IntCollections.UnmodifiableMap
-
- remove(Object) - Method in class io.netty.util.collection.IntObjectHashMap.KeySet
-
- remove() - Method in class io.netty.util.collection.IntObjectHashMap.MapIterator
-
- remove() - Method in class io.netty.util.collection.IntObjectHashMap.PrimitiveIterator
-
- 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.LongCollections.EmptyMap
-
- remove(Object) - Method in class io.netty.util.collection.LongCollections.EmptyMap
-
- remove() - Method in class io.netty.util.collection.LongCollections.UnmodifiableMap.IteratorImpl
-
- remove(long) - Method in class io.netty.util.collection.LongCollections.UnmodifiableMap
-
- remove(Object) - Method in class io.netty.util.collection.LongCollections.UnmodifiableMap
-
- remove(Object) - Method in class io.netty.util.collection.LongObjectHashMap.KeySet
-
- remove() - Method in class io.netty.util.collection.LongObjectHashMap.MapIterator
-
- remove() - Method in class io.netty.util.collection.LongObjectHashMap.PrimitiveIterator
-
- 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.ShortCollections.EmptyMap
-
- remove(Object) - Method in class io.netty.util.collection.ShortCollections.EmptyMap
-
- remove() - Method in class io.netty.util.collection.ShortCollections.UnmodifiableMap.IteratorImpl
-
- remove(short) - Method in class io.netty.util.collection.ShortCollections.UnmodifiableMap
-
- remove(Object) - Method in class io.netty.util.collection.ShortCollections.UnmodifiableMap
-
- remove(Object) - Method in class io.netty.util.collection.ShortObjectHashMap.KeySet
-
- remove() - Method in class io.netty.util.collection.ShortObjectHashMap.MapIterator
-
- remove() - Method in class io.netty.util.collection.ShortObjectHashMap.PrimitiveIterator
-
- 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(GenericFutureListener<? extends Future<?>>) - Method in class io.netty.util.concurrent.DefaultFutureListeners
-
- 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() - Method in class io.netty.util.DefaultAttributeMap.DefaultAttribute
-
- remove(HashedWheelTimer.HashedWheelTimeout) - Method in class io.netty.util.HashedWheelTimer.HashedWheelBucket
-
- remove() - Method in class io.netty.util.HashedWheelTimer.HashedWheelTimeout
-
- remove(Object) - Method in class io.netty.util.internal.ConcurrentSet
-
- remove() - Method in class io.netty.util.internal.DefaultPriorityQueue.PriorityQueueIterator
-
- 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
-
- remove0(Throwable, boolean) - Method in class io.netty.channel.ChannelOutboundBuffer
-
- remove0() - Method in class io.netty.channel.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- remove0(AbstractChannelHandlerContext) - Static method in class io.netty.channel.DefaultChannelPipeline
-
- remove0(int, int, K) - Method in class io.netty.handler.codec.DefaultHeaders
-
- remove0() - Method in class io.netty.util.DefaultAttributeMap.DefaultAttribute
-
- REMOVE_COMPLETE - Static variable in class io.netty.channel.AbstractChannelHandlerContext
-
- removeAfterEventLoopIterationTask(Runnable) - Method in class io.netty.channel.SingleThreadEventLoop
-
- removeAll(Collection<?>) - Method in class io.netty.handler.codec.HeadersUtils.DelegatingStringSet
-
- removeAll() - Static method in class io.netty.util.concurrent.FastThreadLocal
-
- 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
-
- removeAndWriteAll() - Method in class io.netty.channel.PendingWriteQueue
-
- removeAt(int) - Method in class io.netty.util.collection.ByteObjectHashMap
-
Removes entry at the given index position.
- removeAt(int) - Method in class io.netty.util.collection.CharObjectHashMap
-
Removes entry at the given index position.
- removeAt(int) - Method in class io.netty.util.collection.IntObjectHashMap
-
Removes entry at the given index position.
- removeAt(int) - Method in class io.netty.util.collection.LongObjectHashMap
-
Removes entry at the given index position.
- removeAt(int) - Method in class io.netty.util.collection.ShortObjectHashMap
-
Removes entry at the given index position.
- 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.AdvancedLeakAwareCompositeByteBuf
-
- removeComponent(int) - Method in class io.netty.buffer.CompositeByteBuf
-
Remove the
ByteBuf
from the given index.
- removeComponent(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- removeComponents(int, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- removeComponents(int, int) - Method in class io.netty.buffer.CompositeByteBuf
-
Remove the number of
ByteBuf
s starting from the given index.
- removeComponents(int, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- removed - Variable in class io.netty.channel.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- removed - Variable in class io.netty.resolver.dns.DnsNameResolverContext.AuthoritativeNameServer
-
- removed - Variable in class io.netty.util.DefaultAttributeMap.DefaultAttribute
-
- removedRecords - Variable in class io.netty.util.ResourceLeakDetector.DefaultResourceLeak
-
- removeEntry(ChannelOutboundBuffer.Entry) - Method in class io.netty.channel.ChannelOutboundBuffer
-
- removeFirst() - Method in interface io.netty.channel.ChannelPipeline
-
- removeFirst() - Method in class io.netty.channel.DefaultChannelPipeline
-
- removeFromPool() - Method in class io.netty.buffer.PoolSubpage
-
- removeFromVariablesToRemove(InternalThreadLocalMap, FastThreadLocal<?>) - Static method in class io.netty.util.concurrent.FastThreadLocal
-
- removeInboundHandler() - Method in class io.netty.channel.CombinedChannelDuplexHandler
-
- removeIndexedVariable(int) - Method in class io.netty.util.internal.InternalThreadLocalMap
-
- removeLast() - Method in interface io.netty.channel.ChannelPipeline
-
- 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.CompleteChannelFuture
-
- 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 Void>>) - Method in class io.netty.channel.group.DefaultChannelGroupFuture
-
- removeListener(GenericFutureListener<? extends Future<? super Void>>) - Method in class io.netty.channel.group.VoidChannelGroupFuture
-
- removeListener(GenericFutureListener<? extends Future<? super Void>>) - Method in class io.netty.channel.VoidChannelPromise
-
- 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
-
- removeListener0(GenericFutureListener<? extends Future<? super V>>) - Method in class io.netty.util.concurrent.DefaultPromise
-
- 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.CompleteChannelFuture
-
- 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 Void>>...) - Method in class io.netty.channel.group.DefaultChannelGroupFuture
-
- removeListeners(GenericFutureListener<? extends Future<? super Void>>...) - Method in class io.netty.channel.group.VoidChannelGroupFuture
-
- removeListeners(GenericFutureListener<? extends Future<? super Void>>...) - Method in class io.netty.channel.VoidChannelPromise
-
- 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
-
- remover - Variable in class io.netty.channel.group.DefaultChannelGroup
-
- removeReadOp() - Method in class io.netty.channel.nio.AbstractNioChannel.AbstractNioUnsafe
-
- removeRecord(DnsSection, int) - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
-
- removeRecord(int, 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.
- removeScheduled(ScheduledFutureTask<?>) - Method in class io.netty.util.concurrent.AbstractScheduledEventExecutor
-
- 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.
- removeValue(String) - Method in class io.netty.handler.ssl.JdkSslSession
-
- removeWriteTimeoutTask(WriteTimeoutHandler.WriteTimeoutTask) - Method in class io.netty.handler.timeout.WriteTimeoutHandler
-
- 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.
- REOPEN_TASK - Static variable in class io.netty.handler.traffic.AbstractTrafficShapingHandler
-
- ReopenReadTimerTask(ChannelHandlerContext) - Constructor for class io.netty.handler.traffic.AbstractTrafficShapingHandler.ReopenReadTimerTask
-
- repeatCount - Variable in class io.netty.handler.codec.compression.Bzip2BlockDecompressor
-
- repeatIncrement - Variable in class io.netty.handler.codec.compression.Bzip2BlockDecompressor
-
- 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(AbstractChannelHandlerContext, String, ChannelHandler) - Method in class io.netty.channel.DefaultChannelPipeline
-
- replace(ByteBuf) - Method in class io.netty.channel.sctp.SctpMessage
-
- 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(ByteBuf) - Method in class io.netty.handler.codec.haproxy.HAProxyTLV
-
- 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 interface io.netty.handler.ssl.PemEncoded
-
- replace(ByteBuf) - Method in class io.netty.handler.ssl.PemPrivateKey
-
- replace(ByteBuf) - Method in class io.netty.handler.ssl.PemValue
-
- 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.
- replace0(AbstractChannelHandlerContext, AbstractChannelHandlerContext) - Static method in class io.netty.channel.DefaultChannelPipeline
-
- 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
-
- REPLAY - Static variable in class io.netty.handler.codec.ReplayingDecoder
-
- REPLAY - Static variable in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- replayable - Variable in class io.netty.handler.codec.ReplayingDecoder
-
- 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.
- ReplayingDecoderByteBuf - Class in io.netty.handler.codec
-
- ReplayingDecoderByteBuf() - Constructor for class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- ReplayingDecoderByteBuf(ByteBuf) - Constructor for class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- reportedLeaks - Variable in class io.netty.util.ResourceLeakDetector
-
- reportInstancesLeak(String) - Method in class io.netty.util.ResourceLeakDetector
-
- reportLeak(ResourceLeakDetector.Level) - Method in class io.netty.util.ResourceLeakDetector
-
- reportTooManyInstances() - Static method in class io.netty.util.HashedWheelTimer
-
- 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 - Variable in class io.netty.util.Version
-
- repositoryStatus() - Method in class io.netty.util.Version
-
- REPR_CONST_PART_LENGTH - Static variable in class io.netty.util.DomainNameMappingBuilder.ImmutableDomainNameMapping
-
- REPR_HEADER - Static variable in class io.netty.util.DomainNameMappingBuilder.ImmutableDomainNameMapping
-
- REPR_MAP_CLOSING - Static variable in class io.netty.util.DomainNameMappingBuilder.ImmutableDomainNameMapping
-
- REPR_MAP_OPENING - Static variable in class io.netty.util.DomainNameMappingBuilder.ImmutableDomainNameMapping
-
- REQUEST_MAGIC_BYTE - Static variable in class io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheRequest
-
Default magic byte for a request.
- requestedRemote - Variable in class io.netty.channel.kqueue.KQueueSocketChannel
-
- requestedRemoteAddress - Variable in class io.netty.channel.kqueue.AbstractKQueueStreamChannel
-
- requestedRemoteAddress - Variable in class io.netty.channel.nio.AbstractNioChannel
-
- requestResponseCounter - Variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheClientCodec
-
- requestType - Variable in class io.netty.handler.codec.socks.SocksRequest
-
- requestType() - Method in class io.netty.handler.codec.socks.SocksRequest
-
Returns socks request type
- reserved() - Method in interface io.netty.handler.codec.memcache.binary.BinaryMemcacheRequest
-
Returns the reserved field value.
- reserved - Variable in class io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheRequest
-
- reserved() - Method in class io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheRequest
-
- reserveSpace(AtomicInteger, int) - Static method in class io.netty.util.Recycler.WeakOrderQueue
-
- reset() - Method in class io.netty.buffer.ByteBufInputStream
-
- reset(ChannelConfig) - Method in class io.netty.channel.DefaultMaxBytesRecvByteBufAllocator.HandleImpl
-
- reset(ChannelConfig) - Method in class io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator.MaxMessageHandle
-
- reset(ChannelConfig) - Method in class io.netty.channel.kqueue.KQueueRecvByteAllocatorHandle
-
- reset() - Method in class io.netty.channel.nio.SelectedSelectionKeySet
-
- reset(int) - Method in class io.netty.channel.nio.SelectedSelectionKeySet
-
- 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.ByteBufChecksum.SlowByteBufChecksum
-
- reset() - Method in class io.netty.handler.codec.compression.Crc32c
-
- 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.json.JsonObjectDecoder
-
- reset() - Method in class io.netty.handler.codec.redis.RedisDecoder.ToPositiveLongProcessor
-
- reset() - Method in class io.netty.handler.codec.serialization.ObjectDecoderInputStream
-
- reset() - Method in class io.netty.util.internal.AppendableCharSequence
-
- resetAccounting(long) - Method in class io.netty.handler.traffic.TrafficCounter
-
Reset the accounting on Read and Write.
- 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.
- resetDecoder() - Method in class io.netty.handler.codec.redis.RedisDecoder
-
- resetDecoder() - Method in class io.netty.handler.codec.stomp.StompSubframeDecoder
-
- resetInterval - Variable in class io.netty.handler.codec.serialization.CompatibleObjectEncoder
-
- resetReadAndFlushIfNeeded(ChannelHandlerContext) - Method in class io.netty.handler.flush.FlushConsolidationHandler
-
- 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.
- resetReaderIndex() - Method in class io.netty.buffer.WrappedByteBuf
-
- resetReaderIndex() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- resetReaderIndex() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- resetUnusedFields(MqttFixedHeader) - Static method in class io.netty.handler.codec.mqtt.MqttCodecUtil
-
- 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.
- resetWriterIndex() - Method in class io.netty.buffer.WrappedByteBuf
-
- resetWriterIndex() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- resetWriterIndex() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- resolve(String) - Method in class io.netty.handler.codec.serialization.CachingClassResolver
-
- resolve(String) - Method in class io.netty.handler.codec.serialization.ClassLoaderClassResolver
-
- 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(Promise<T>) - Method in class io.netty.resolver.dns.DnsNameResolverContext
-
- resolve(String) - Method in class io.netty.resolver.dns.InflightNameResolver
-
- resolve(String, Promise<T>) - Method in class io.netty.resolver.dns.InflightNameResolver
-
- resolve(ConcurrentMap<String, Promise<U>>, String, Promise<U>, boolean) - Method in class io.netty.resolver.dns.InflightNameResolver
-
- 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 class io.netty.resolver.dns.InflightNameResolver
-
- resolveAll(String, Promise<List<T>>) - Method in class io.netty.resolver.dns.InflightNameResolver
-
- 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
-
- resolveAllsInProgress - Variable in class io.netty.resolver.dns.DnsAddressResolverGroup
-
- resolveAllsInProgress - Variable in class io.netty.resolver.dns.InflightNameResolver
-
- resolveCache - Variable in class io.netty.resolver.dns.DefaultDnsCache
-
- resolveCache - Variable in class io.netty.resolver.dns.DnsNameResolver
-
- resolveCache() - Method in class io.netty.resolver.dns.DnsNameResolver
-
Returns the resolution cache.
- resolveCache - Variable in class io.netty.resolver.dns.DnsNameResolverBuilder
-
- resolveCache(DnsCache) - Method in class io.netty.resolver.dns.DnsNameResolverBuilder
-
Sets the cache for resolution results.
- resolveCache - Variable in class io.netty.resolver.dns.DnsNameResolverContext
-
- resolveClass(ObjectStreamClass) - Method in class io.netty.handler.codec.serialization.CompactObjectInputStream
-
- resolvedAddressTypes - Variable in class io.netty.resolver.dns.DnsNameResolver
-
- resolvedAddressTypes() - Method in class io.netty.resolver.dns.DnsNameResolver
-
- resolvedAddressTypes - Variable in class io.netty.resolver.dns.DnsNameResolverBuilder
-
- 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.
- ResolvedAddressTypes() - Constructor for enum io.netty.resolver.ResolvedAddressTypes
-
- resolvedEntries - Variable in class io.netty.resolver.dns.DnsNameResolverContext
-
- resolvedInternetProtocolFamilies - Variable in class io.netty.resolver.dns.DnsNameResolver
-
- resolvedInternetProtocolFamilies - Variable in class io.netty.resolver.dns.DnsNameResolverContext
-
- resolvedInternetProtocolFamiliesUnsafe() - Method in class io.netty.resolver.dns.DnsNameResolver
-
- resolveHostsFileEntry(String) - Method in class io.netty.resolver.dns.DnsNameResolver
-
- resolver - Variable in class io.netty.bootstrap.Bootstrap
-
- 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.Bootstrap
-
- resolver() - Method in class io.netty.bootstrap.BootstrapConfig
-
- resolveRecordTypes - Variable in class io.netty.resolver.dns.DnsNameResolver
-
- resolveRecordTypes() - Method in class io.netty.resolver.dns.DnsNameResolver
-
- resolvers - Variable in class io.netty.resolver.AddressResolverGroup
-
Note that we do not use a ConcurrentMap
here because it is usually expensive to instantiate a resolver.
- resolvers - Variable in class io.netty.resolver.CompositeNameResolver
-
- resolvesInProgress - Variable in class io.netty.resolver.dns.DnsAddressResolverGroup
-
- resolvesInProgress - Variable in class io.netty.resolver.dns.InflightNameResolver
-
- ResourceLeak - Interface in io.netty.util
-
- 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
-
- ResourceLeakDetector(String, int, long) - Constructor for class io.netty.util.ResourceLeakDetector
-
- ResourceLeakDetector.DefaultResourceLeak - Class in io.netty.util
-
- ResourceLeakDetector.LeakEntry - Class in io.netty.util
-
- ResourceLeakDetector.Level - Enum in io.netty.util
-
Represents the level of resource leak detection.
- ResourceLeakDetectorFactory - Class in io.netty.util
-
- ResourceLeakDetectorFactory() - Constructor for class io.netty.util.ResourceLeakDetectorFactory
-
- ResourceLeakDetectorFactory.DefaultResourceLeakDetectorFactory - Class in io.netty.util
-
Default implementation that loads custom leak detector via system property
- ResourceLeakException - Exception in io.netty.util
-
- 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
-
- resourceType - Variable in class io.netty.util.ResourceLeakDetector
-
- RESPONSE_MAGIC_BYTE - Static variable in class io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheResponse
-
Default magic byte for a request.
- responseType - Variable in class io.netty.handler.codec.socks.SocksResponse
-
- responseType() - Method in class io.netty.handler.codec.socks.SocksResponse
-
Returns socks response type
- Result(T, int) - Constructor for class io.netty.handler.codec.mqtt.MqttDecoder.Result
-
- result - Variable in class io.netty.handler.codec.ProtocolDetectionResult
-
- result - Variable in class io.netty.handler.codec.redis.RedisDecoder.ToPositiveLongProcessor
-
- result - Variable in class io.netty.util.concurrent.DefaultPromise
-
- result - Variable in class io.netty.util.concurrent.PromiseTask.RunnableAdapter
-
- result - Variable in class io.netty.util.concurrent.SucceededFuture
-
- RESULT_UPDATER - Static variable in class io.netty.util.concurrent.DefaultPromise
-
- 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() - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- retain(int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- retain() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- retain(int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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(int) - Method in class io.netty.buffer.UnreleasableByteBuf
-
- retain() - Method in class io.netty.buffer.UnreleasableByteBuf
-
- retain(int) - Method in class io.netty.buffer.WrappedByteBuf
-
- retain() - Method in class io.netty.buffer.WrappedByteBuf
-
- retain(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- retain() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- 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.sctp.SctpMessage
-
- retain(int) - Method in class io.netty.channel.sctp.SctpMessage
-
- 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.haproxy.HAProxyTLV
-
- retain(int) - Method in class io.netty.handler.codec.haproxy.HAProxyTLV
-
- 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.ReplayingDecoderByteBuf
-
- retain(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- 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 interface io.netty.handler.ssl.PemEncoded
-
- retain(int) - Method in interface io.netty.handler.ssl.PemEncoded
-
- 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.PemValue
-
- retain(int) - Method in class io.netty.handler.ssl.PemValue
-
- 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
-
- retain(T, int) - Static method in class io.netty.util.ReferenceCountUtil
-
- retain0() - Method in class io.netty.buffer.AbstractDerivedByteBuf
-
Deprecated.
- retain0(int) - Method in class io.netty.buffer.AbstractDerivedByteBuf
-
Deprecated.
- retain0() - Method in class io.netty.buffer.AbstractPooledDerivedByteBuf.PooledNonRetainedDuplicateByteBuf
-
- retain0(int) - Method in class io.netty.buffer.AbstractPooledDerivedByteBuf.PooledNonRetainedDuplicateByteBuf
-
- retain0() - Method in class io.netty.buffer.AbstractPooledDerivedByteBuf.PooledNonRetainedSlicedByteBuf
-
- retain0(int) - Method in class io.netty.buffer.AbstractPooledDerivedByteBuf.PooledNonRetainedSlicedByteBuf
-
- retain0(int) - Method in class io.netty.buffer.AbstractReferenceCountedByteBuf
-
- retain0(int) - Method in class io.netty.util.AbstractReferenceCounted
-
- retainAll(Collection<?>) - Method in class io.netty.handler.codec.HeadersUtils.DelegatingStringSet
-
- retainAll(Collection<?>) - Method in class io.netty.util.collection.ByteObjectHashMap.KeySet
-
- retainAll(Collection<?>) - Method in class io.netty.util.collection.CharObjectHashMap.KeySet
-
- retainAll(Collection<?>) - Method in class io.netty.util.collection.IntObjectHashMap.KeySet
-
- retainAll(Collection<?>) - Method in class io.netty.util.collection.LongObjectHashMap.KeySet
-
- retainAll(Collection<?>) - Method in class io.netty.util.collection.ShortObjectHashMap.KeySet
-
- retainAll(Collection<?>) - Method in class io.netty.util.internal.EmptyPriorityQueue
-
- retained - Variable in class io.netty.handler.codec.mqtt.MqttMessageBuilders.PublishBuilder
-
- 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.AbstractPooledDerivedByteBuf.PooledNonRetainedDuplicateByteBuf
-
- retainedDuplicate() - Method in class io.netty.buffer.AbstractPooledDerivedByteBuf.PooledNonRetainedSlicedByteBuf
-
- retainedDuplicate() - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- retainedDuplicate() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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
-
- retainedDuplicate() - Method in class io.netty.buffer.DefaultByteBufHolder
-
- retainedDuplicate() - Method in class io.netty.buffer.EmptyByteBuf
-
- retainedDuplicate() - Method in class io.netty.buffer.PooledByteBuf
-
- retainedDuplicate() - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- retainedDuplicate() - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- retainedDuplicate() - Method in class io.netty.buffer.SimpleLeakAwareByteBuf
-
- retainedDuplicate() - Method in class io.netty.buffer.SimpleLeakAwareCompositeByteBuf
-
- retainedDuplicate() - Method in class io.netty.buffer.SwappedByteBuf
-
Deprecated.
- retainedDuplicate() - Method in class io.netty.buffer.UnreleasableByteBuf
-
- retainedDuplicate() - Method in class io.netty.buffer.WrappedByteBuf
-
- retainedDuplicate() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- retainedDuplicate() - Method in class io.netty.channel.sctp.SctpMessage
-
- 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.haproxy.HAProxyTLV
-
- 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.ReplayingDecoderByteBuf
-
- 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 interface io.netty.handler.ssl.PemEncoded
-
- retainedDuplicate() - Method in class io.netty.handler.ssl.PemPrivateKey
-
- retainedDuplicate() - Method in class io.netty.handler.ssl.PemValue
-
- 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.AbstractPooledDerivedByteBuf.PooledNonRetainedDuplicateByteBuf
-
- retainedSlice(int, int) - Method in class io.netty.buffer.AbstractPooledDerivedByteBuf.PooledNonRetainedDuplicateByteBuf
-
- retainedSlice() - Method in class io.netty.buffer.AbstractPooledDerivedByteBuf.PooledNonRetainedSlicedByteBuf
-
- retainedSlice(int, int) - Method in class io.netty.buffer.AbstractPooledDerivedByteBuf.PooledNonRetainedSlicedByteBuf
-
- retainedSlice() - Method in class io.netty.buffer.AbstractPooledDerivedByteBuf
-
- retainedSlice() - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- retainedSlice(int, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- retainedSlice() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- retainedSlice(int, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.PooledByteBuf
-
- retainedSlice(int, int) - Method in class io.netty.buffer.PooledByteBuf
-
- retainedSlice(int, int) - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- retainedSlice(int, int) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- retainedSlice() - Method in class io.netty.buffer.SimpleLeakAwareByteBuf
-
- retainedSlice(int, int) - Method in class io.netty.buffer.SimpleLeakAwareByteBuf
-
- retainedSlice() - Method in class io.netty.buffer.SimpleLeakAwareCompositeByteBuf
-
- retainedSlice(int, int) - Method in class io.netty.buffer.SimpleLeakAwareCompositeByteBuf
-
- retainedSlice() - Method in class io.netty.buffer.SwappedByteBuf
-
Deprecated.
- retainedSlice(int, int) - Method in class io.netty.buffer.SwappedByteBuf
-
Deprecated.
- retainedSlice() - Method in class io.netty.buffer.UnreleasableByteBuf
-
- retainedSlice(int, int) - Method in class io.netty.buffer.UnreleasableByteBuf
-
- retainedSlice() - Method in class io.netty.buffer.WrappedByteBuf
-
- retainedSlice(int, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- retainedSlice() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- retainedSlice(int, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- retainedSlice() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- retainedSlice(int, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- rethrowIfFailed() - Method in class io.netty.util.concurrent.DefaultPromise
-
- returnCode - Variable in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnAckBuilder
-
- returnCode(MqttConnectReturnCode) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnAckBuilder
-
- reuse(int) - Method in class io.netty.buffer.PooledByteBuf
-
- rleAccumulator - Variable in class io.netty.handler.codec.compression.Bzip2BlockDecompressor
-
The number of previous identical output bytes decoded.
- rleCurrentValue - Variable in class io.netty.handler.codec.compression.Bzip2BlockCompressor
-
- rleLastDecodedByte - Variable in class io.netty.handler.codec.compression.Bzip2BlockDecompressor
-
The most recently RLE decoded byte.
- rleLength - Variable in class io.netty.handler.codec.compression.Bzip2BlockCompressor
-
The repeat count of the current RLE value.
- rleRepeat - Variable in class io.netty.handler.codec.compression.Bzip2BlockDecompressor
-
The RLE repeat count of the current decoded byte.
- rnd - Variable in class io.netty.util.internal.ThreadLocalRandom
-
The random seed.
- RNUMS - Static variable in class io.netty.handler.codec.compression.Bzip2Rand
-
The Bzip2 specification originally included the optional addition of a slight pseudo-random
perturbation to the input data, in order to work around the block sorting algorithm's non-
optimal performance on some types of input.
- rNums(int) - Static method in class io.netty.handler.codec.compression.Bzip2Rand
-
Return the random number at a specific index.
- ROOT - Static variable in class io.netty.handler.codec.dns.DefaultDnsRecordDecoder
-
- rootParent - Variable in class io.netty.buffer.AbstractPooledDerivedByteBuf
-
- 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.
- rotational0(InetSocketAddress[]) - Static method in class io.netty.resolver.dns.DnsServerAddresses
-
- RotationalDnsServerAddresses - Class in io.netty.resolver.dns
-
- RotationalDnsServerAddresses(InetSocketAddress[]) - Constructor for class io.netty.resolver.dns.RotationalDnsServerAddresses
-
- RoundRobinDnsAddressResolverGroup - Class in io.netty.resolver.dns
-
- 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
-
- 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 variable in class io.netty.handler.codec.smtp.SmtpRequests
-
- rset() - Static method in class io.netty.handler.codec.smtp.SmtpRequests
-
Creates a RSET
request.
- RuleBasedIpFilter - Class in io.netty.handler.ipfilter
-
This class allows one to filter new
Channel
s based on the
IpFilterRule
s passed to its constructor.
- RuleBasedIpFilter(IpFilterRule...) - Constructor for class io.netty.handler.ipfilter.RuleBasedIpFilter
-
- rules - Variable in class io.netty.handler.ipfilter.RuleBasedIpFilter
-
- ruleType() - Method in interface io.netty.handler.ipfilter.IpFilterRule
-
- ruleType - Variable in class io.netty.handler.ipfilter.IpSubnetFilterRule.Ip4SubnetFilterRule
-
- ruleType() - Method in class io.netty.handler.ipfilter.IpSubnetFilterRule.Ip4SubnetFilterRule
-
- ruleType - Variable in class io.netty.handler.ipfilter.IpSubnetFilterRule.Ip6SubnetFilterRule
-
- ruleType() - Method in class io.netty.handler.ipfilter.IpSubnetFilterRule.Ip6SubnetFilterRule
-
- ruleType() - Method in class io.netty.handler.ipfilter.IpSubnetFilterRule
-
- run() - Method in class io.netty.channel.AbstractChannelHandlerContext.AbstractWriteTask
-
- run() - Method in class io.netty.channel.DefaultChannelPipeline.PendingHandlerAddedTask
-
- run() - Method in class io.netty.channel.DefaultChannelPipeline.PendingHandlerRemovedTask
-
- run() - Method in class io.netty.channel.DefaultEventLoop
-
- run() - Method in class io.netty.channel.kqueue.KQueueEventLoop
-
- run() - Method in class io.netty.channel.nio.NioEventLoop
-
- run() - Method in class io.netty.channel.pool.FixedChannelPool.TimeoutTask
-
- run() - Method in class io.netty.channel.ThreadPerChannelEventLoop
-
- run() - Method in class io.netty.handler.timeout.IdleStateHandler.AbstractIdleTask
-
- run(ChannelHandlerContext) - Method in class io.netty.handler.timeout.IdleStateHandler.AbstractIdleTask
-
- run(ChannelHandlerContext) - Method in class io.netty.handler.timeout.IdleStateHandler.AllIdleTimeoutTask
-
- run(ChannelHandlerContext) - Method in class io.netty.handler.timeout.IdleStateHandler.ReaderIdleTimeoutTask
-
- run(ChannelHandlerContext) - Method in class io.netty.handler.timeout.IdleStateHandler.WriterIdleTimeoutTask
-
- run() - Method in class io.netty.handler.timeout.WriteTimeoutHandler.WriteTimeoutTask
-
- run() - Method in class io.netty.handler.traffic.AbstractTrafficShapingHandler.ReopenReadTimerTask
-
- run() - Method in class io.netty.handler.traffic.GlobalChannelTrafficCounter.MixedTrafficMonitoringTask
-
- run() - Method in class io.netty.handler.traffic.TrafficCounter.TrafficMonitoringTask
-
- run() - Method in class io.netty.util.concurrent.DefaultEventExecutor
-
- run() - Method in class io.netty.util.concurrent.DefaultThreadFactory.DefaultRunnableDecorator
-
- run() - Method in class io.netty.util.concurrent.GlobalEventExecutor.TaskRunner
-
- run() - Method in class io.netty.util.concurrent.NonStickyEventExecutorGroup.NonStickyOrderedEventExecutor
-
- run() - Method in class io.netty.util.concurrent.PromiseTask
-
- run() - Method in class io.netty.util.concurrent.ScheduledFutureTask
-
- run() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- run() - Method in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor.NonNotifyRunnable
-
- run() - Method in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor.RunnableScheduledFutureTask
-
- run() - Method in class io.netty.util.HashedWheelTimer.Worker
-
- run() - Method in class io.netty.util.ReferenceCountUtil.ReleasingTask
-
- run() - Method in class io.netty.util.ThreadDeathWatcher.Watcher
-
- run(Timeout) - Method in interface io.netty.util.TimerTask
-
- 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
.
- runDelegatedTasks() - Method in class io.netty.handler.ssl.SslHandler
-
- runFinishPeerReadTask(LocalChannel) - Method in class io.netty.channel.local.LocalChannel
-
- runLength(int) - Method in class io.netty.buffer.PoolChunk
-
- RunnableAdapter(Runnable, T) - Constructor for class io.netty.util.concurrent.PromiseTask.RunnableAdapter
-
- RunnableScheduledFutureTask(EventExecutor, Runnable, RunnableScheduledFuture<V>) - Constructor for class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor.RunnableScheduledFutureTask
-
- RunnableScheduledFutureTask(EventExecutor, Callable<V>, RunnableScheduledFuture<V>) - Constructor for class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor.RunnableScheduledFutureTask
-
- RUNNING - Static variable in class io.netty.util.concurrent.ImmediateEventExecutor
-
Set to true
if we are executing a runnable.
- RUNNING - Static variable in class io.netty.util.concurrent.NonStickyEventExecutorGroup.NonStickyOrderedEventExecutor
-
- runOffset(int) - Method in class io.netty.buffer.PoolChunk
-
- runOffset - Variable in class io.netty.buffer.PoolSubpage
-
- 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.
- runScheduledTasks() - Method in class io.netty.channel.embedded.EmbeddedEventLoop
-
- runShutdownHooks() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- runTaskQueue() - Method in class io.netty.channel.pool.FixedChannelPool
-
- runTasks() - Method in class io.netty.channel.embedded.EmbeddedEventLoop
-
- SA - Variable in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- safeClose(InputStream) - Static method in class io.netty.handler.ssl.PemReader
-
- safeClose(OutputStream) - Static method in class io.netty.handler.ssl.PemReader
-
- safeClose(ChannelHandlerContext, ChannelFuture, ChannelPromise) - Method in class io.netty.handler.ssl.SslHandler
-
- safeClose(File, OutputStream) - Static method in class io.netty.handler.ssl.util.SelfSignedCertificate
-
- safeDelete(File) - Static method in class io.netty.handler.ssl.util.SelfSignedCertificate
-
- safeDuplicate(Object) - Static method in class io.netty.channel.group.DefaultChannelGroup
-
- safeExecute(EventExecutor, Runnable, ChannelPromise, Object) - Static method in class io.netty.channel.AbstractChannelHandlerContext
-
- 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
.
- safeExecute(EventExecutor, Runnable) - Static method in class io.netty.util.concurrent.DefaultPromise
-
- safeFail(ChannelPromise, Throwable) - Static method in class io.netty.channel.ChannelOutboundBuffer
-
- safeFail(ChannelPromise, Throwable) - Static method in class io.netty.channel.PendingWriteQueue
-
- 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.
- safeNioBuffer(ByteBuf) - Static method in class io.netty.handler.codec.compression.CompressionUtil
-
- safeObjectAppend(StringBuilder, Object) - Static method in class io.netty.util.internal.logging.MessageFormatter
-
- safeRelease(Object) - Static method in class io.netty.util.ReferenceCountUtil
-
- safeRelease(Object, int) - Static method in class io.netty.util.ReferenceCountUtil
-
- 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.
- safeSuccess(ChannelPromise) - Static method in class io.netty.channel.ChannelOutboundBuffer
-
- samplingInterval - Variable in class io.netty.util.ResourceLeakDetector
-
- sanitize(Iterable<? extends InetSocketAddress>) - Static method in class io.netty.resolver.dns.DnsServerAddresses
-
- sanitize(InetSocketAddress[]) - Static method in class io.netty.resolver.dns.DnsServerAddresses
-
- 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
-
- sb - Variable in class io.netty.handler.codec.DateFormatter
-
- sbiCrop - Variable in class io.netty.handler.codec.base64.Base64.Decoder
-
- sbiDecode - Variable in class io.netty.handler.codec.base64.Base64.Decoder
-
- scanNext() - Method in class io.netty.util.collection.ByteObjectHashMap.PrimitiveIterator
-
- scanNext() - Method in class io.netty.util.collection.CharObjectHashMap.PrimitiveIterator
-
- scanNext() - Method in class io.netty.util.collection.IntObjectHashMap.PrimitiveIterator
-
- scanNext() - Method in class io.netty.util.collection.LongObjectHashMap.PrimitiveIterator
-
- scanNext() - Method in class io.netty.util.collection.ShortObjectHashMap.PrimitiveIterator
-
- scavenge() - Method in class io.netty.util.Recycler.Stack
-
- scavengeSome() - Method in class io.netty.util.Recycler.Stack
-
- sch - Variable in class io.netty.channel.sctp.oio.OioSctpServerChannel
-
- schedule(ChannelHandlerContext, Runnable, long, TimeUnit) - Method in class io.netty.handler.timeout.IdleStateHandler
-
This method is visible for testing!
- 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(ScheduledFutureTask<V>) - 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
-
- schedule(Thread, Runnable, boolean) - Static method in class io.netty.util.ThreadDeathWatcher
-
- SCHEDULE_PURGE_INTERVAL - Static variable in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- SCHEDULE_QUIET_PERIOD_INTERVAL - Static variable in class io.netty.util.concurrent.GlobalEventExecutor
-
- 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
-
- scheduleCacheExpiration(List<DnsCacheEntry>, DnsCacheEntry, int, EventLoop) - Method in class io.netty.resolver.dns.DefaultDnsCache
-
- scheduledFuture - Variable in class io.netty.handler.timeout.WriteTimeoutHandler.WriteTimeoutTask
-
- scheduledFuture - Variable in class io.netty.handler.traffic.TrafficCounter
-
used in stop() to cancel the timer
- ScheduledFuture<V> - Interface in io.netty.util.concurrent
-
The result of an scheduled asynchronous operation.
- ScheduledFutureTask<V> - Class in io.netty.util.concurrent
-
- ScheduledFutureTask(AbstractScheduledEventExecutor, Runnable, V, long) - Constructor for class io.netty.util.concurrent.ScheduledFutureTask
-
- ScheduledFutureTask(AbstractScheduledEventExecutor, Callable<V>, long, long) - Constructor for class io.netty.util.concurrent.ScheduledFutureTask
-
- ScheduledFutureTask(AbstractScheduledEventExecutor, Callable<V>, long) - Constructor for class io.netty.util.concurrent.ScheduledFutureTask
-
- scheduledTaskQueue - Variable in class io.netty.util.concurrent.AbstractScheduledEventExecutor
-
- scheduledTaskQueue() - Method in class io.netty.util.concurrent.AbstractScheduledEventExecutor
-
- scheduleExpiration(EventLoop, Runnable, long, TimeUnit) - Method in class io.netty.resolver.dns.DnsCacheEntry
-
- scheduleFlush(ChannelHandlerContext) - Method in class io.netty.handler.flush.FlushConsolidationHandler
-
- scheduleTimeout(ChannelHandlerContext, ChannelPromise) - Method in class io.netty.handler.timeout.WriteTimeoutHandler
-
- 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 - Variable in class io.netty.channel.unix.NativeInetAddress
-
- 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.
- scoreAddress(InetAddress) - Static method in class io.netty.util.internal.MacAddressUtil
-
- SCTP_DISABLE_FRAGMENTS - Static variable in class com.sun.nio.sctp.SctpStandardSocketOptions
-
- SCTP_DISABLE_FRAGMENTS - Static variable in class io.netty.channel.sctp.SctpChannelOption
-
- SCTP_EXPLICIT_COMPLETE - Static variable in class com.sun.nio.sctp.SctpStandardSocketOptions
-
- SCTP_EXPLICIT_COMPLETE - Static variable in class io.netty.channel.sctp.SctpChannelOption
-
- SCTP_FRAGMENT_INTERLEAVE - Static variable in class com.sun.nio.sctp.SctpStandardSocketOptions
-
- SCTP_FRAGMENT_INTERLEAVE - Static variable in class io.netty.channel.sctp.SctpChannelOption
-
- SCTP_INIT_MAXSTREAMS - Static variable in class com.sun.nio.sctp.SctpStandardSocketOptions
-
- SCTP_INIT_MAXSTREAMS - Static variable in class io.netty.channel.sctp.SctpChannelOption
-
- SCTP_NODELAY - Static variable in class com.sun.nio.sctp.SctpStandardSocketOptions
-
- SCTP_NODELAY - Static variable in class io.netty.channel.sctp.SctpChannelOption
-
- SCTP_PRIMARY_ADDR - Static variable in class com.sun.nio.sctp.SctpStandardSocketOptions
-
- SCTP_PRIMARY_ADDR - Static variable in class io.netty.channel.sctp.SctpChannelOption
-
- SCTP_SET_PEER_PRIMARY_ADDR - Static variable in class com.sun.nio.sctp.SctpStandardSocketOptions
-
- SCTP_SET_PEER_PRIMARY_ADDR - Static variable in class io.netty.channel.sctp.SctpChannelOption
-
- SctpChannel - Class in com.sun.nio.sctp
-
- SctpChannel(SelectorProvider) - Constructor for class com.sun.nio.sctp.SctpChannel
-
- SctpChannel - Interface in io.netty.channel.sctp
-
A SCTP/IP
Channel
interface for single SCTP association.
- sctpChannel - Variable in class io.netty.channel.sctp.SctpNotificationHandler
-
- SctpChannelConfig - Interface in io.netty.channel.sctp
-
- SctpChannelOption<T> - Class in io.netty.channel.sctp
-
Option for configuring the SCTP transport
- SctpChannelOption() - Constructor for class io.netty.channel.sctp.SctpChannelOption
-
- SctpInboundByteStreamHandler - Class in io.netty.handler.codec.sctp
-
A ChannelHandler which receives
SctpMessage
s which belong to a application protocol form a specific
SCTP Stream and decode it as
ByteBuf
.
- SctpInboundByteStreamHandler(int, int) - Constructor for class io.netty.handler.codec.sctp.SctpInboundByteStreamHandler
-
- SctpMessage - Class in io.netty.channel.sctp
-
Representation of SCTP Data Chunk
- SctpMessage(int, int, ByteBuf) - Constructor for class io.netty.channel.sctp.SctpMessage
-
Essential data that is being carried within SCTP Data Chunk
- SctpMessage(int, int, boolean, ByteBuf) - Constructor for class io.netty.channel.sctp.SctpMessage
-
Essential data that is being carried within SCTP Data Chunk
- SctpMessage(MessageInfo, ByteBuf) - Constructor for class io.netty.channel.sctp.SctpMessage
-
Essential data that is being carried within SCTP Data Chunk
- SctpMessageCompletionHandler - Class in io.netty.handler.codec.sctp
-
- SctpMessageCompletionHandler() - Constructor for class io.netty.handler.codec.sctp.SctpMessageCompletionHandler
-
- SctpMessageToMessageDecoder - Class in io.netty.handler.codec.sctp
-
- SctpMessageToMessageDecoder() - Constructor for class io.netty.handler.codec.sctp.SctpMessageToMessageDecoder
-
- SctpNotificationHandler - Class in io.netty.channel.sctp
-
- SctpNotificationHandler(SctpChannel) - Constructor for class io.netty.channel.sctp.SctpNotificationHandler
-
- SctpOutboundByteStreamHandler - Class in io.netty.handler.codec.sctp
-
A ChannelHandler which transform
ByteBuf
to
SctpMessage
and send it through a specific stream
with given protocol identifier.
- SctpOutboundByteStreamHandler(int, int) - Constructor for class io.netty.handler.codec.sctp.SctpOutboundByteStreamHandler
-
- SctpOutboundByteStreamHandler(int, int, boolean) - Constructor for class io.netty.handler.codec.sctp.SctpOutboundByteStreamHandler
-
- SctpServerChannel - Class in com.sun.nio.sctp
-
- SctpServerChannel(SelectorProvider) - Constructor for class com.sun.nio.sctp.SctpServerChannel
-
- SctpServerChannel - Interface in io.netty.channel.sctp
-
A SCTP/IP
ServerChannel
which accepts incoming SCTP/IP associations.
- SctpServerChannelConfig - Interface in io.netty.channel.sctp
-
- SctpSocketOption<T> - Interface in com.sun.nio.sctp
-
- SctpStandardSocketOptions - Class in com.sun.nio.sctp
-
- SctpStandardSocketOptions() - Constructor for class com.sun.nio.sctp.SctpStandardSocketOptions
-
- SctpStandardSocketOptions.InitMaxStreams - Class in com.sun.nio.sctp
-
- searchDomains - Variable in class io.netty.resolver.dns.DnsNameResolver
-
- searchDomains() - Method in class io.netty.resolver.dns.DnsNameResolver
-
- searchDomains - Variable in class io.netty.resolver.dns.DnsNameResolverBuilder
-
- searchDomains(Iterable<String>) - Method in class io.netty.resolver.dns.DnsNameResolverBuilder
-
Set the list of search domains of the resolver.
- SearchDomainUnknownHostException(Throwable, String) - Constructor for exception io.netty.resolver.dns.DnsNameResolverContext.SearchDomainUnknownHostException
-
- seconds - Variable in class io.netty.handler.codec.DateFormatter
-
- SECTION_COUNT - Static variable in class io.netty.handler.codec.dns.AbstractDnsMessage
-
- SECTION_QUESTION - Static variable in class io.netty.handler.codec.dns.AbstractDnsMessage
-
- sectionAt(int) - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
-
- sectionOrdinal(DnsSection) - Static method in class io.netty.handler.codec.dns.AbstractDnsMessage
-
- seedGeneratorEndTime - Static variable in class io.netty.util.internal.ThreadLocalRandom
-
- seedGeneratorStartTime - Static variable in class io.netty.util.internal.ThreadLocalRandom
-
- seedGeneratorThread - Static variable in class io.netty.util.internal.ThreadLocalRandom
-
- seedQueue - Static variable in class io.netty.util.internal.ThreadLocalRandom
-
- seedUniquifier - Static variable in class io.netty.util.internal.ThreadLocalRandom
-
- select(boolean) - Method in class io.netty.channel.nio.NioEventLoop
-
- select(long) - Method in class io.netty.channel.nio.SelectedSelectionKeySetSelector
-
- select() - Method in class io.netty.channel.nio.SelectedSelectionKeySetSelector
-
- SELECT - Static variable in interface io.netty.channel.SelectStrategy
-
Indicates a blocking select should follow.
- select(ChannelHandlerContext, String) - Method in class io.netty.handler.ssl.AbstractSniHandler
-
- select(List<String>) - Method in interface io.netty.handler.ssl.JdkApplicationProtocolNegotiator.ProtocolSelector
-
Callback invoked to select the application level protocol from the protocols
provided.
- select(List<String>) - Method in class io.netty.handler.ssl.JdkBaseApplicationProtocolNegotiator.NoFailProtocolSelector
-
- selectAgain() - Method in class io.netty.channel.nio.NioEventLoop
-
- selected(String) - Method in interface io.netty.handler.ssl.JdkApplicationProtocolNegotiator.ProtocolSelectionListener
-
Callback invoked to let this application know the protocol chosen by the peer.
- selected(String) - Method in class io.netty.handler.ssl.JdkBaseApplicationProtocolNegotiator.NoFailProtocolSelectionListener
-
- selectedBehavior - Variable in class io.netty.handler.ssl.ApplicationProtocolConfig
-
- selectedKeys - Variable in class io.netty.channel.nio.NioEventLoop
-
- selectedKeys() - Method in class io.netty.channel.nio.SelectedSelectionKeySetSelector
-
- selectedListenerFailureBehavior() - Method in class io.netty.handler.ssl.ApplicationProtocolConfig
-
Get the desired behavior for the peer who is notified of the selected protocol.
- SelectedListenerFailureBehavior() - Constructor for enum io.netty.handler.ssl.ApplicationProtocolConfig.SelectedListenerFailureBehavior
-
- 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.
- SelectedSelectionKeySet - Class in io.netty.channel.nio
-
- SelectedSelectionKeySet() - Constructor for class io.netty.channel.nio.SelectedSelectionKeySet
-
- SelectedSelectionKeySetSelector - Class in io.netty.channel.nio
-
- SelectedSelectionKeySetSelector(Selector, SelectedSelectionKeySet) - Constructor for class io.netty.channel.nio.SelectedSelectionKeySetSelector
-
- selectFilterRule(InetAddress, int, IpFilterRuleType) - Static method in class io.netty.handler.ipfilter.IpSubnetFilterRule
-
- selection - Variable in class io.netty.handler.ssl.SniHandler
-
- Selection(SslContext, String) - Constructor for class io.netty.handler.ssl.SniHandler.Selection
-
- selectionKey - Variable in class io.netty.channel.nio.AbstractNioChannel
-
- selectionKey() - Method in class io.netty.channel.nio.AbstractNioChannel
-
Return the current SelectionKey
- selectionKeys - Variable in class io.netty.channel.nio.SelectedSelectionKeySetSelector
-
- selectNow() - Method in class io.netty.channel.nio.NioEventLoop
-
- selectNow() - Method in class io.netty.channel.nio.SelectedSelectionKeySetSelector
-
- selectNowSupplier - Variable in class io.netty.channel.kqueue.KQueueEventLoop
-
- selectNowSupplier - Variable in class io.netty.channel.nio.NioEventLoop
-
- selector - Variable in class io.netty.channel.nio.NioEventLoop
-
The NIO Selector
.
- selector - Variable in class io.netty.channel.nio.NioEventLoop.SelectorTuple
-
- selector - Variable in class io.netty.channel.sctp.oio.OioSctpServerChannel
-
- SELECTOR_AUTO_REBUILD_THRESHOLD - Static variable in class io.netty.channel.nio.NioEventLoop
-
- selectorBehavior - Variable in class io.netty.handler.ssl.ApplicationProtocolConfig
-
- selectorFactory - Variable in class io.netty.handler.ssl.JdkBaseApplicationProtocolNegotiator
-
- selectorFailureBehavior() - Method in class io.netty.handler.ssl.ApplicationProtocolConfig
-
Get the desired behavior for the peer who selects the application protocol.
- SelectorFailureBehavior() - Constructor for enum io.netty.handler.ssl.ApplicationProtocolConfig.SelectorFailureBehavior
-
- 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
.
- selectors - Variable in class io.netty.handler.codec.compression.Bzip2HuffmanStageDecoder
-
The Huffman table number to use for each group of 50 symbols.
- selectors - Variable in class io.netty.handler.codec.compression.Bzip2HuffmanStageEncoder
-
The selectors for each segment.
- SelectorTuple(Selector) - Constructor for class io.netty.channel.nio.NioEventLoop.SelectorTuple
-
- SelectorTuple(Selector, Selector) - Constructor for class io.netty.channel.nio.NioEventLoop.SelectorTuple
-
- selectStrategy - Variable in class io.netty.channel.kqueue.KQueueEventLoop
-
- selectStrategy - Variable in class io.netty.channel.nio.NioEventLoop
-
- SelectStrategy - Interface in io.netty.channel
-
Select strategy interface.
- SelectStrategyFactory - Interface in io.netty.channel
-
- selectTableCount(int) - Static method in class io.netty.handler.codec.compression.Bzip2HuffmanStageEncoder
-
Selects an appropriate table count for a given MTF length.
- SELF - Static variable in class io.netty.util.internal.logging.JdkLogger
-
- selfCollection - Variable in class io.netty.util.concurrent.AbstractEventExecutor
-
- 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.
- send(ByteBuffer, MessageInfo) - Method in class com.sun.nio.sctp.SctpChannel
-
- SEND_TO_ADDRESS_CLOSED_CHANNEL_EXCEPTION - Static variable in class io.netty.channel.unix.Socket
-
- SEND_TO_ADDRESS_CONNECTION_RESET_EXCEPTION - Static variable in class io.netty.channel.unix.Socket
-
- SEND_TO_ADDRESSES_CLOSED_CHANNEL_EXCEPTION - Static variable in class io.netty.channel.unix.Socket
-
- SEND_TO_CLOSED_CHANNEL_EXCEPTION - Static variable in class io.netty.channel.unix.Socket
-
- SEND_TO_CONNECTION_RESET_EXCEPTION - Static variable in class io.netty.channel.unix.Socket
-
- sendAllValid(ChannelHandlerContext, long) - Method in class io.netty.handler.traffic.ChannelTrafficShapingHandler
-
- sendAllValid(ChannelHandlerContext, GlobalChannelTrafficShapingHandler.PerChannel, long) - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
-
- sendAllValid(ChannelHandlerContext, GlobalTrafficShapingHandler.PerChannel, long) - Method in class io.netty.handler.traffic.GlobalTrafficShapingHandler
-
- sender() - Method in interface io.netty.channel.AddressedEnvelope
-
Returns the address of the sender of this message.
- sender - Variable in class io.netty.channel.DefaultAddressedEnvelope
-
- sender() - Method in class io.netty.channel.DefaultAddressedEnvelope
-
- sender - Variable in class io.netty.handler.codec.dns.DatagramDnsQuery
-
- sender() - Method in class io.netty.handler.codec.dns.DatagramDnsQuery
-
- sender - Variable in class io.netty.handler.codec.dns.DatagramDnsResponse
-
- sender() - Method in class io.netty.handler.codec.dns.DatagramDnsResponse
-
- SendFailedNotification - Class in com.sun.nio.sctp
-
- SendFailedNotification() - Constructor for class com.sun.nio.sctp.SendFailedNotification
-
- sendFd(int) - Method in class io.netty.channel.unix.Socket
-
- sendFd(int, int) - Static method in class io.netty.channel.unix.Socket
-
- sendFile(DefaultFileRegion, long, long, long) - Method in class io.netty.channel.kqueue.BsdSocket
-
- sendFile(int, DefaultFileRegion, long, long, long) - Static method in class io.netty.channel.kqueue.BsdSocket
-
- SENDFILE_CLOSED_CHANNEL_EXCEPTION - Static variable in class io.netty.channel.kqueue.BsdSocket
-
- SENDFILE_CONNECTION_RESET_EXCEPTION - Static variable in class io.netty.channel.kqueue.BsdSocket
-
- sendQuery(DnsQuery, ChannelPromise) - Method in class io.netty.resolver.dns.DnsQueryContext
-
- sendTo(ByteBuffer, int, int, InetAddress, int) - Method in class io.netty.channel.unix.Socket
-
- sendTo(int, ByteBuffer, int, int, byte[], int, int) - Static method in class io.netty.channel.unix.Socket
-
- sendToAddress(long, int, int, InetAddress, int) - Method in class io.netty.channel.unix.Socket
-
- sendToAddress(int, long, int, int, byte[], int, int) - Static method in class io.netty.channel.unix.Socket
-
- sendToAddresses(long, int, InetAddress, int) - Method in class io.netty.channel.unix.Socket
-
- sendToAddresses(int, long, int, byte[], int, int) - Static method in class io.netty.channel.unix.Socket
-
- sensitive - Variable in class io.netty.handler.ssl.PemValue
-
- sentFirstMessage - Variable in class io.netty.handler.ssl.SslHandler
-
- separatorType - Variable in class io.netty.handler.codec.AsciiHeadersEncoder
-
- SeparatorType() - Constructor for enum io.netty.handler.codec.AsciiHeadersEncoder.SeparatorType
-
- SEQUENCE_LEN - Static variable in class io.netty.channel.DefaultChannelId
-
- sequential(Iterable<? extends InetSocketAddress>) - Static method in class io.netty.resolver.dns.DnsServerAddresses
-
- sequential(InetSocketAddress...) - Static method in class io.netty.resolver.dns.DnsServerAddresses
-
- sequential0(InetSocketAddress...) - Static method in class io.netty.resolver.dns.DnsServerAddresses
-
- SequentialDnsServerAddressStream - Class in io.netty.resolver.dns
-
- SequentialDnsServerAddressStream(InetSocketAddress[], int) - Constructor for class io.netty.resolver.dns.SequentialDnsServerAddressStream
-
- SequentialDnsServerAddressStreamProvider - Class in io.netty.resolver.dns
-
- 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.
- serialVersionUID - Static variable in exception com.sun.nio.sctp.UnsupportedOperatingSystemException
-
- serialVersionUID - Static variable in exception io.netty.channel.AbstractChannel.AnnotatedConnectException
-
- serialVersionUID - Static variable in exception io.netty.channel.AbstractChannel.AnnotatedNoRouteToHostException
-
- serialVersionUID - Static variable in exception io.netty.channel.AbstractChannel.AnnotatedSocketException
-
- serialVersionUID - Static variable in exception io.netty.channel.ChannelException
-
- serialVersionUID - Static variable in exception io.netty.channel.ChannelPipelineException
-
- serialVersionUID - Static variable in exception io.netty.channel.ConnectTimeoutException
-
- serialVersionUID - Static variable in class io.netty.channel.DefaultChannelId
-
- serialVersionUID - Static variable in class io.netty.channel.embedded.EmbeddedChannelId
-
- serialVersionUID - Static variable in class io.netty.channel.embedded.EmbeddedSocketAddress
-
- serialVersionUID - Static variable in exception io.netty.channel.EventLoopException
-
- serialVersionUID - Static variable in exception io.netty.channel.group.ChannelGroupException
-
- serialVersionUID - Static variable in class io.netty.channel.local.LocalAddress
-
- serialVersionUID - Static variable in class io.netty.channel.unix.DatagramSocketAddress
-
- serialVersionUID - Static variable in class io.netty.channel.unix.DomainSocketAddress
-
- serialVersionUID - Static variable in exception io.netty.channel.unix.Errors.NativeConnectException
-
- serialVersionUID - Static variable in exception io.netty.channel.unix.Errors.NativeIoException
-
- serialVersionUID - Static variable in exception io.netty.handler.codec.CodecException
-
- serialVersionUID - Static variable in exception io.netty.handler.codec.compression.CompressionException
-
- serialVersionUID - Static variable in exception io.netty.handler.codec.compression.DecompressionException
-
- serialVersionUID - Static variable in exception io.netty.handler.codec.CorruptedFrameException
-
- serialVersionUID - Static variable in exception io.netty.handler.codec.DecoderException
-
- serialVersionUID - Static variable in exception io.netty.handler.codec.EncoderException
-
- serialVersionUID - Static variable in exception io.netty.handler.codec.haproxy.HAProxyProtocolException
-
- serialVersionUID - Static variable in exception io.netty.handler.codec.MessageAggregationException
-
- serialVersionUID - Static variable in exception io.netty.handler.codec.mqtt.MqttIdentifierRejectedException
-
- serialVersionUID - Static variable in exception io.netty.handler.codec.mqtt.MqttUnacceptableProtocolVersionException
-
- serialVersionUID - Static variable in exception io.netty.handler.codec.PrematureChannelClosureException
-
- serialVersionUID - Static variable in exception io.netty.handler.codec.redis.RedisCodecException
-
- serialVersionUID - Static variable in exception io.netty.handler.codec.TooLongFrameException
-
- serialVersionUID - Static variable in exception io.netty.handler.codec.UnsupportedMessageTypeException
-
- serialVersionUID - Static variable in class io.netty.handler.flow.FlowControlHandler.RecyclableArrayDeque
-
- serialVersionUID - Static variable in exception io.netty.handler.ssl.NotSslRecordException
-
- serialVersionUID - Static variable in class io.netty.handler.ssl.util.ThreadLocalInsecureRandom
-
- serialVersionUID - Static variable in exception io.netty.handler.timeout.ReadTimeoutException
-
- serialVersionUID - Static variable in exception io.netty.handler.timeout.TimeoutException
-
- serialVersionUID - Static variable in exception io.netty.handler.timeout.WriteTimeoutException
-
- serialVersionUID - Static variable in exception io.netty.resolver.dns.DnsNameResolverException
-
- serialVersionUID - Static variable in exception io.netty.util.concurrent.BlockingOperationException
-
- serialVersionUID - Static variable in class io.netty.util.DefaultAttributeMap.DefaultAttribute
-
- serialVersionUID - Static variable in exception io.netty.util.IllegalReferenceCountException
-
- serialVersionUID - Static variable in class io.netty.util.internal.ConcurrentSet
-
- serialVersionUID - Static variable in class io.netty.util.internal.logging.AbstractInternalLogger
-
- serialVersionUID - Static variable in class io.netty.util.internal.logging.CommonsLogger
-
Deprecated.
- serialVersionUID - Static variable in class io.netty.util.internal.logging.JdkLogger
-
- serialVersionUID - Static variable in class io.netty.util.internal.logging.Log4JLogger
-
- serialVersionUID - Static variable in class io.netty.util.internal.logging.Slf4JLogger
-
- serialVersionUID - Static variable in error io.netty.util.internal.OutOfDirectMemoryError
-
- serialVersionUID - Static variable in class io.netty.util.internal.PlatformDependent.AtomicLongCounter
-
- serialVersionUID - Static variable in class io.netty.util.internal.RecyclableArrayList
-
- serialVersionUID - Static variable in class io.netty.util.internal.ThreadLocalRandom
-
- serialVersionUID - Static variable in exception io.netty.util.ResourceLeakException
-
Deprecated.
- serialVersionUID - Static variable in error io.netty.util.Signal
-
- serve(LocalChannel) - Method in class io.netty.channel.local.LocalServerChannel
-
- serve0(LocalChannel) - Method in class io.netty.channel.local.LocalServerChannel
-
- SERVER - Static variable in interface io.netty.handler.codec.stomp.StompHeaders
-
- SERVER_CHANNEL_MATCHER - Static variable in class io.netty.channel.group.ChannelMatchers
-
- ServerBootstrap - Class in io.netty.bootstrap
-
- ServerBootstrap() - Constructor for class io.netty.bootstrap.ServerBootstrap
-
- ServerBootstrap(ServerBootstrap) - Constructor for class io.netty.bootstrap.ServerBootstrap
-
- ServerBootstrap.ServerBootstrapAcceptor - Class in io.netty.bootstrap
-
- ServerBootstrapAcceptor(Channel, EventLoopGroup, ChannelHandler, Map.Entry<ChannelOption<?>, Object>[], Map.Entry<AttributeKey<?>, Object>[]) - Constructor for class io.netty.bootstrap.ServerBootstrap.ServerBootstrapAcceptor
-
- ServerBootstrapConfig - Class in io.netty.bootstrap
-
- ServerBootstrapConfig(ServerBootstrap) - Constructor for class io.netty.bootstrap.ServerBootstrapConfig
-
- ServerChannel - Interface in io.netty.channel
-
A
Channel
that accepts an incoming connection attempt and creates
its child
Channel
s by accepting them.
- serverChannels - Variable in class io.netty.channel.group.DefaultChannelGroup
-
- 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
-
- session - Variable in class io.netty.handler.ssl.JdkSslEngine
-
- 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 - Variable in class io.netty.handler.ssl.SslContextBuilder
-
- 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 - Variable in class io.netty.handler.codec.mqtt.MqttConnAckVariableHeader
-
- sessionPresent - Variable in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnAckBuilder
-
- 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 - Variable in class io.netty.handler.ssl.SslContextBuilder
-
- sessionTimeout(long) - Method in class io.netty.handler.ssl.SslContextBuilder
-
Set the timeout for the cached SSL session objects, in seconds.
- set(int, Object) - Method in class io.netty.handler.codec.CodecOutputList
-
- 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
-
- SET_OPTION - Static variable in class io.netty.channel.socket.nio.NioDatagramChannelConfig
-
- setAcceptFilter(AcceptFilter) - Method in class io.netty.channel.kqueue.BsdSocket
-
- setAcceptFilter(int, String, String) - Static method in class io.netty.channel.kqueue.BsdSocket
-
- setAcceptFilter(AcceptFilter) - Method in class io.netty.channel.kqueue.KQueueServerSocketChannelConfig
-
- setActiveOnOpen(boolean) - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
-
- setActiveOnOpen(boolean) - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
-
- setAddComplete() - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- setAddPending() - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- setAlgorithmConstraints(SSLParameters, Object) - Static method in class io.netty.handler.ssl.Java7SslParametersUtils
-
Utility method that is used by OpenSslEngine
and so allow use not not have any reference to
AlgorithmConstraints
in the code.
- 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
-
- setAllocator(ByteBufAllocator) - Method in class io.netty.channel.DefaultChannelConfig
-
- 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 class io.netty.channel.sctp.DefaultSctpChannelConfig
-
- setAllocator(ByteBufAllocator) - Method in class io.netty.channel.sctp.DefaultSctpServerChannelConfig
-
- setAllocator(ByteBufAllocator) - Method in interface io.netty.channel.sctp.SctpChannelConfig
-
- setAllocator(ByteBufAllocator) - Method in interface io.netty.channel.sctp.SctpServerChannelConfig
-
- 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.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.
- setApplicationProtocol(String) - Method in class io.netty.handler.ssl.JdkSslSession
-
- setArray(byte[]) - Method in class io.netty.buffer.UnpooledHeapByteBuf
-
- 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
-
- setAutoClose(boolean) - Method in class io.netty.channel.DefaultChannelConfig
-
- 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 class io.netty.channel.sctp.DefaultSctpChannelConfig
-
- setAutoClose(boolean) - Method in class io.netty.channel.sctp.DefaultSctpServerChannelConfig
-
- setAutoClose(boolean) - Method in interface io.netty.channel.sctp.SctpChannelConfig
-
- setAutoClose(boolean) - Method in interface io.netty.channel.sctp.SctpServerChannelConfig
-
- 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
-
- setAutoRead(boolean) - Method in class io.netty.channel.DefaultChannelConfig
-
- 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 class io.netty.channel.sctp.DefaultSctpChannelConfig
-
- setAutoRead(boolean) - Method in class io.netty.channel.sctp.DefaultSctpServerChannelConfig
-
- setAutoRead(boolean) - Method in interface io.netty.channel.sctp.SctpChannelConfig
-
- setAutoRead(boolean) - Method in interface io.netty.channel.sctp.SctpServerChannelConfig
-
- 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.nio.NioDatagramChannelConfig
-
- 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) - Method in class io.netty.util.NettyRuntime.AvailableProcessorsHolder
-
Set the number of available processors.
- setAvailableProcessors(int) - Static method in class io.netty.util.NettyRuntime
-
Set the number of available processors.
- 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.sctp.DefaultSctpServerChannelConfig
-
- setBacklog(int) - Method in interface io.netty.channel.sctp.SctpServerChannelConfig
-
Sets the backlog value to specify when the channel binds to a local address.
- 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.AdvancedLeakAwareByteBuf
-
- setBoolean(int, boolean) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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(int, boolean) - Method in class io.netty.buffer.WrappedByteBuf
-
- setBoolean(int, boolean) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- 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
.
- setBoolean(int, boolean) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- setBroadcast(boolean) - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
-
- setBroadcast(boolean) - Method in interface io.netty.channel.socket.DatagramChannelConfig
-
Sets the StandardSocketOptions.SO_BROADCAST
option.
- setBroadcast(boolean) - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
-
- setBroadcast(boolean) - Method in class io.netty.channel.unix.Socket
-
- setBroadcast(int, int) - Static 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.AbstractUnpooledSlicedByteBuf
-
- setByte(int, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- setByte(int, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.FixedCompositeByteBuf
-
- setByte(byte[], int, int) - Static method in class io.netty.buffer.HeapByteBufUtil
-
- setByte(int, int) - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- setByte(int, int) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- setByte(int, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
-
Deprecated.
- setByte(int, int) - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- 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(int, int) - Method in class io.netty.buffer.UnpooledUnsafeHeapByteBuf
-
- setByte(long, int) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- setByte(byte[], int, int) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- setByte(int, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- setByte(int, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- 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
.
- setByte(int, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- setByteBuf(ByteBuf) - Method in class io.netty.handler.codec.compression.Bzip2BitReader
-
Set the
ByteBuf
from which to read data.
- setByteBuffer(ByteBuffer) - Method in class io.netty.buffer.UnpooledDirectByteBuf
-
- setByteBuffer(ByteBuffer, boolean) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
-
- 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, byte[], int, int) - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- setBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- setBytes(int, ByteBuffer) - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- setBytes(int, InputStream, int) - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- setBytes(int, ScatteringByteChannel, int) - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- setBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- setBytes(int, ByteBuf) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- setBytes(int, ByteBuf, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- setBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- setBytes(int, byte[]) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- setBytes(int, byte[], int, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- setBytes(int, ByteBuffer) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- setBytes(int, InputStream, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- setBytes(int, ScatteringByteChannel, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- setBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- setBytes(int, ByteBuf) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- setBytes(int, ByteBuf, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- setBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- setBytes(int, byte[]) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- setBytes(int, byte[], int, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- setBytes(int, ByteBuffer) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- setBytes(int, InputStream, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- setBytes(int, ScatteringByteChannel, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- setBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.FixedCompositeByteBuf
-
- setBytes(int, byte[], int, int) - Method in class io.netty.buffer.FixedCompositeByteBuf
-
- setBytes(int, ByteBuffer) - Method in class io.netty.buffer.FixedCompositeByteBuf
-
- setBytes(int, InputStream, int) - Method in class io.netty.buffer.FixedCompositeByteBuf
-
- setBytes(int, ScatteringByteChannel, int) - Method in class io.netty.buffer.FixedCompositeByteBuf
-
- setBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.FixedCompositeByteBuf
-
- setBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.PooledDirectByteBuf
-
- setBytes(int, byte[], int, int) - Method in class io.netty.buffer.PooledDirectByteBuf
-
- setBytes(int, ByteBuffer) - Method in class io.netty.buffer.PooledDirectByteBuf
-
- setBytes(int, InputStream, int) - Method in class io.netty.buffer.PooledDirectByteBuf
-
- setBytes(int, ScatteringByteChannel, int) - Method in class io.netty.buffer.PooledDirectByteBuf
-
- setBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.PooledDirectByteBuf
-
- setBytes(int, byte[], int, int) - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- setBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- setBytes(int, ByteBuffer) - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- setBytes(int, InputStream, int) - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- setBytes(int, ScatteringByteChannel, int) - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- setBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- setBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.PooledHeapByteBuf
-
- setBytes(int, byte[], int, int) - Method in class io.netty.buffer.PooledHeapByteBuf
-
- setBytes(int, ByteBuffer) - Method in class io.netty.buffer.PooledHeapByteBuf
-
- setBytes(int, InputStream, int) - Method in class io.netty.buffer.PooledHeapByteBuf
-
- setBytes(int, ScatteringByteChannel, int) - Method in class io.netty.buffer.PooledHeapByteBuf
-
- setBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.PooledHeapByteBuf
-
- setBytes(int, byte[], int, int) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- setBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- setBytes(int, ByteBuffer) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- setBytes(int, InputStream, int) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- setBytes(int, ScatteringByteChannel, int) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- setBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- setBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- setBytes(int, byte[], int, int) - Method in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- setBytes(int, ByteBuffer) - Method in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- setBytes(int, InputStream, int) - Method in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- setBytes(int, ScatteringByteChannel, int) - Method in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- setBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.PooledUnsafeDirectByteBuf
-
- 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, int, int) - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- setBytes(int, byte[], int, int) - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- setBytes(int, ByteBuffer) - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- setBytes(int, InputStream, int) - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- setBytes(int, ScatteringByteChannel, int) - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- setBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- 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
-
- setBytes(AbstractByteBuf, long, int, InputStream, int) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- setBytes(AbstractByteBuf, long, int, ByteBuf, int, int) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- setBytes(AbstractByteBuf, long, int, byte[], int, int) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- setBytes(AbstractByteBuf, long, int, ByteBuffer) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- setBytes(int, ByteBuf) - Method in class io.netty.buffer.WrappedByteBuf
-
- setBytes(int, ByteBuf, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- setBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- setBytes(int, byte[]) - Method in class io.netty.buffer.WrappedByteBuf
-
- setBytes(int, byte[], int, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- setBytes(int, ByteBuffer) - Method in class io.netty.buffer.WrappedByteBuf
-
- setBytes(int, InputStream, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- setBytes(int, ScatteringByteChannel, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- setBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- setBytes(int, byte[], int, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- setBytes(int, ByteBuffer) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- setBytes(int, ByteBuf, int, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- setBytes(int, InputStream, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- setBytes(int, ScatteringByteChannel, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- setBytes(int, ByteBuf) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- setBytes(int, ByteBuf, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- setBytes(int, byte[]) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- setBytes(int, FileChannel, long, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- setBytes(int, byte[], int, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- setBytes(int, byte[]) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- setBytes(int, ByteBuffer) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- setBytes(int, ByteBuf, int, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- setBytes(int, ByteBuf, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- setBytes(int, ByteBuf) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- setBytes(int, InputStream, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- setBytes(int, ScatteringByteChannel, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- setBytes(int, FileChannel, long, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- 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.
- setChannelOption(Channel, ChannelOption<?>, Object, InternalLogger) - Static method in class io.netty.bootstrap.AbstractBootstrap
-
- setChannelOptions(Channel, Map<ChannelOption<?>, Object>, InternalLogger) - Static method in class io.netty.bootstrap.AbstractBootstrap
-
- setChannelOptions(Channel, Map.Entry<ChannelOption<?>, Object>[], InternalLogger) - Static method in class io.netty.bootstrap.AbstractBootstrap
-
- setChar(int, int) - Method in class io.netty.buffer.AbstractByteBuf
-
- setChar(int, int) - Method in class io.netty.buffer.AbstractUnsafeSwappedByteBuf
-
- setChar(int, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- setChar(int, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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(int, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- setChar(int, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- 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
.
- setChar(int, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- setCharSequence(int, CharSequence, Charset) - Method in class io.netty.buffer.AbstractByteBuf
-
- setCharSequence(int, CharSequence, Charset) - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- setCharSequence(int, CharSequence, Charset) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- setCharSequence(int, CharSequence, Charset) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.
- setCharSequence(int, CharSequence, Charset) - Method in class io.netty.buffer.WrappedByteBuf
-
- setCharSequence(int, CharSequence, Charset) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- setCharSequence(int, CharSequence, Charset) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- setCheckInterval(long) - Method in class io.netty.handler.traffic.AbstractTrafficShapingHandler
-
- setChunkLength(ByteBuf, int) - Static method in class io.netty.handler.codec.compression.SnappyFrameEncoder
-
- setClosed() - Method in class io.netty.channel.AbstractChannel.CloseFuture
-
- 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.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 class io.netty.channel.sctp.DefaultSctpChannelConfig
-
- setConnectTimeoutMillis(int) - Method in class io.netty.channel.sctp.DefaultSctpServerChannelConfig
-
- setConnectTimeoutMillis(int) - Method in interface io.netty.channel.sctp.SctpChannelConfig
-
- setConnectTimeoutMillis(int) - Method in interface io.netty.channel.sctp.SctpServerChannelConfig
-
- 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
-
- setCumulation(ByteBuf) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- setCumulator(ByteToMessageDecoder.Cumulator) - Method in class io.netty.handler.codec.ByteToMessageDecoder
-
- 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.socksx.AbstractSocksMessage
-
- 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
-
- setDouble(int, double) - Method in class io.netty.buffer.AbstractByteBuf
-
- setDouble(int, double) - Method in class io.netty.buffer.AbstractUnsafeSwappedByteBuf
-
- setDouble(int, double) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- setDouble(int, double) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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(int, double) - Method in class io.netty.buffer.WrappedByteBuf
-
- setDouble(int, double) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- 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
.
- setDouble(int, double) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- setEnabled(boolean) - Static method in class io.netty.util.ResourceLeakDetector
-
- setEnabledCipherSuites(String[]) - Method in class io.netty.handler.ssl.JdkSslEngine
-
- setEnabledProtocols(String[]) - Method in class io.netty.handler.ssl.JdkSslEngine
-
- setEnableSessionCreation(boolean) - Method in class io.netty.handler.ssl.JdkSslEngine
-
- setExtendedParentPointers(int[]) - Static method in class io.netty.handler.codec.compression.Bzip2HuffmanAllocator
-
Fills the code array with extended parent pointers.
- 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.
- setExtrasLength(byte) - Method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
-
Set the extras length of the message.
- setFailure(Throwable) - Method in class io.netty.channel.AbstractChannel.CloseFuture
-
- 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.channel.group.DefaultChannelGroupFuture
-
- setFailure(Throwable) - Method in class io.netty.channel.VoidChannelPromise
-
- setFailure(String, Throwable) - Method in class io.netty.resolver.dns.DnsQueryContext
-
- 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.
- setFailure(Throwable) - Method in class io.netty.util.concurrent.PromiseTask
-
- setFailure0(ChannelGroupException) - Method in class io.netty.channel.group.DefaultChannelGroupFuture
-
- setFailure0(Throwable) - Method in class io.netty.util.concurrent.DefaultPromise
-
- setFailureInternal(Throwable) - Method in class io.netty.util.concurrent.PromiseTask
-
- setFloat(int, float) - Method in class io.netty.buffer.AbstractByteBuf
-
- setFloat(int, float) - Method in class io.netty.buffer.AbstractUnsafeSwappedByteBuf
-
- setFloat(int, float) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- setFloat(int, float) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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(int, float) - Method in class io.netty.buffer.WrappedByteBuf
-
- setFloat(int, float) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- 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
.
- setFloat(int, float) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- setFutureListenerStackDepth(int) - Method in class io.netty.util.internal.InternalThreadLocalMap
-
- setHandshakeFailure(ChannelHandlerContext, Throwable) - Method in class io.netty.handler.ssl.SslHandler
-
Notify all the handshake futures about the failure during the handshake.
- setHandshakeFailure(ChannelHandlerContext, Throwable, boolean) - Method in class io.netty.handler.ssl.SslHandler
-
Notify all the handshake futures about the failure during the handshake.
- setHandshakeSuccess() - Method in class io.netty.handler.ssl.SslHandler
-
Notify all the handshake futures about the successfully handshake
- setHandshakeSuccessIfStillHandshaking() - Method in class io.netty.handler.ssl.SslHandler
-
Works around some Android SSLEngine
implementations that skip SSLEngineResult.HandshakeStatus.FINISHED
and
go straight into SSLEngineResult.HandshakeStatus.NOT_HANDSHAKING
when handshake is finished.
- setHandshakeTimeout(long, TimeUnit) - Method in class io.netty.handler.ssl.SslHandler
-
- setHandshakeTimeoutMillis(long) - Method in class io.netty.handler.ssl.SslHandler
-
- setHead(Recycler.WeakOrderQueue) - Method in class io.netty.util.Recycler.Stack
-
- 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
.
- setIfAbsent(T) - Method in class io.netty.util.DefaultAttributeMap.DefaultAttribute
-
- 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.
- setIndex(int, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- setIndex(int, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- setIndex(int, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- setIndex0(int, int) - Method in class io.netty.buffer.AbstractByteBuf
-
- setIndexedVariable(int, Object) - Method in class io.netty.util.internal.InternalThreadLocalMap
-
- setInitialSeedUniquifier(long) - Static method in class io.netty.util.internal.ThreadLocalRandom
-
- setInitMaxStreams(SctpStandardSocketOptions.InitMaxStreams) - Method in class io.netty.channel.sctp.DefaultSctpChannelConfig
-
- setInitMaxStreams(SctpStandardSocketOptions.InitMaxStreams) - Method in class io.netty.channel.sctp.DefaultSctpServerChannelConfig
-
- setInitMaxStreams(SctpStandardSocketOptions.InitMaxStreams) - Method in interface io.netty.channel.sctp.SctpChannelConfig
-
- setInitMaxStreams(SctpStandardSocketOptions.InitMaxStreams) - Method in interface io.netty.channel.sctp.SctpServerChannelConfig
-
- setInt(int, int) - Method in class io.netty.buffer.AbstractByteBuf
-
- setInt(int, int) - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- setInt(int, int) - Method in class io.netty.buffer.AbstractUnsafeSwappedByteBuf
-
- setInt(int, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- setInt(int, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.FixedCompositeByteBuf
-
- setInt(byte[], int, int) - Static method in class io.netty.buffer.HeapByteBufUtil
-
- setInt(int, int) - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- setInt(int, int) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- setInt(int, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
-
Deprecated.
- setInt(int, int) - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- 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(int, int) - Method in class io.netty.buffer.UnpooledUnsafeHeapByteBuf
-
- setInt(long, int) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- setInt(byte[], int, int) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- setInt(int, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- setInt(int, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- 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
.
- setInt(int, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- 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
-
- setInterface(InetAddress) - Method in class io.netty.channel.socket.nio.NioDatagramChannelConfig
-
- setIntLE(int, int) - Method in class io.netty.buffer.AbstractByteBuf
-
- setIntLE(int, int) - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- setIntLE(int, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- setIntLE(int, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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(byte[], int, int) - Static method in class io.netty.buffer.HeapByteBufUtil
-
- setIntLE(int, int) - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- setIntLE(int, int) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- setIntLE(int, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
-
Deprecated.
- setIntLE(int, int) - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- setIntLE(int, int) - Method in class io.netty.buffer.SwappedByteBuf
-
Deprecated.
- setIntLE(int, int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
-
- setIntLE(int, int) - Method in class io.netty.buffer.UnpooledUnsafeHeapByteBuf
-
- setIntLE(long, int) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- setIntLE(byte[], int, int) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- setIntLE(int, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- setIntLE(int, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- setIntLE(int, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- setIoRatio(int) - Method in class io.netty.channel.kqueue.KQueueEventLoop
-
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.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.
- 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
-
Sets the StandardSocketOptions.SO_KEEPALIVE
option.
- setKeepAlive(boolean) - Method in class io.netty.channel.unix.Socket
-
- setKeepAlive(int, int) - Static 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.
- setKeyLength(short) - Method in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
-
Set the key length of the message.
- 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.AbstractUnpooledSlicedByteBuf
-
- setLong(int, long) - Method in class io.netty.buffer.AbstractUnsafeSwappedByteBuf
-
- setLong(int, long) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- setLong(int, long) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.FixedCompositeByteBuf
-
- setLong(byte[], int, long) - Static method in class io.netty.buffer.HeapByteBufUtil
-
- setLong(int, long) - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- setLong(int, long) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- setLong(int, long) - Method in class io.netty.buffer.ReadOnlyByteBuf
-
Deprecated.
- setLong(int, long) - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- 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(int, long) - Method in class io.netty.buffer.UnpooledUnsafeHeapByteBuf
-
- setLong(long, long) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- setLong(byte[], int, long) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- setLong(int, long) - Method in class io.netty.buffer.WrappedByteBuf
-
- setLong(int, long) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- 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
.
- setLong(int, long) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- setLongLE(int, long) - Method in class io.netty.buffer.AbstractByteBuf
-
- setLongLE(int, long) - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- setLongLE(int, long) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- setLongLE(int, long) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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(byte[], int, long) - Static method in class io.netty.buffer.HeapByteBufUtil
-
- setLongLE(int, long) - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- setLongLE(int, long) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- setLongLE(int, long) - Method in class io.netty.buffer.ReadOnlyByteBuf
-
Deprecated.
- setLongLE(int, long) - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- setLongLE(int, long) - Method in class io.netty.buffer.SwappedByteBuf
-
Deprecated.
- setLongLE(int, long) - Method in class io.netty.buffer.UnpooledHeapByteBuf
-
- setLongLE(int, long) - Method in class io.netty.buffer.UnpooledUnsafeHeapByteBuf
-
- setLongLE(long, long) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- setLongLE(byte[], int, long) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- setLongLE(int, long) - Method in class io.netty.buffer.WrappedByteBuf
-
- setLongLE(int, long) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- setLongLE(int, long) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- setLoopbackModeDisabled(boolean) - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
-
- setLoopbackModeDisabled(boolean) - Method in interface io.netty.channel.socket.DatagramChannelConfig
-
Sets the StandardSocketOptions.IP_MULTICAST_LOOP
option.
- setLoopbackModeDisabled(boolean) - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
-
- setLoopbackModeDisabled(boolean) - Method in class io.netty.channel.socket.nio.NioDatagramChannelConfig
-
- 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
-
- setMaxMessagesPerRead(int) - Method in class io.netty.channel.DefaultChannelConfig
-
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 class io.netty.channel.sctp.DefaultSctpChannelConfig
-
Deprecated.
- setMaxMessagesPerRead(int) - Method in class io.netty.channel.sctp.DefaultSctpServerChannelConfig
-
Deprecated.
- setMaxMessagesPerRead(int) - Method in interface io.netty.channel.sctp.SctpChannelConfig
-
Deprecated.
- setMaxMessagesPerRead(int) - Method in interface io.netty.channel.sctp.SctpServerChannelConfig
-
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.AbstractUnpooledSlicedByteBuf
-
- setMedium(int, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- setMedium(int, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.FixedCompositeByteBuf
-
- setMedium(byte[], int, int) - Static method in class io.netty.buffer.HeapByteBufUtil
-
- setMedium(int, int) - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- setMedium(int, int) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- setMedium(int, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
-
Deprecated.
- setMedium(int, int) - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- 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
-
- setMedium(int, int) - Method in class io.netty.buffer.UnpooledUnsafeHeapByteBuf
-
- setMedium(long, int) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- setMedium(byte[], int, int) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- setMedium(int, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- setMedium(int, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- setMedium(int, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- setMediumLE(int, int) - Method in class io.netty.buffer.AbstractByteBuf
-
- setMediumLE(int, int) - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- setMediumLE(int, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- setMediumLE(int, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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(byte[], int, int) - Static method in class io.netty.buffer.HeapByteBufUtil
-
- setMediumLE(int, int) - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- setMediumLE(int, int) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- setMediumLE(int, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
-
Deprecated.
- setMediumLE(int, int) - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- setMediumLE(int, int) - Method in class io.netty.buffer.SwappedByteBuf
-
Deprecated.
- setMediumLE(int, int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
-
- setMediumLE(int, int) - Method in class io.netty.buffer.UnpooledUnsafeHeapByteBuf
-
- setMediumLE(long, int) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- setMediumLE(byte[], int, int) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- setMediumLE(int, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- setMediumLE(int, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- setMediumLE(int, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- 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
-
- setMemory(long, long, byte) - Static method in class io.netty.util.internal.PlatformDependent0
-
- setMemory(Object, long, long, byte) - Static method in class io.netty.util.internal.PlatformDependent0
-
- setMessageSizeEstimator(MessageSizeEstimator) - Method in interface io.netty.channel.ChannelConfig
-
- setMessageSizeEstimator(MessageSizeEstimator) - Method in class io.netty.channel.DefaultChannelConfig
-
- 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 class io.netty.channel.sctp.DefaultSctpChannelConfig
-
- setMessageSizeEstimator(MessageSizeEstimator) - Method in class io.netty.channel.sctp.DefaultSctpServerChannelConfig
-
- setMessageSizeEstimator(MessageSizeEstimator) - Method in interface io.netty.channel.sctp.SctpChannelConfig
-
- setMessageSizeEstimator(MessageSizeEstimator) - Method in interface io.netty.channel.sctp.SctpServerChannelConfig
-
- 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
-
- setNeedClientAuth(boolean) - Method in class io.netty.handler.ssl.JdkSslEngine
-
- setNetworkInterface(NetworkInterface) - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
-
- setNetworkInterface(NetworkInterface) - Method in interface io.netty.channel.socket.DatagramChannelConfig
-
Sets the StandardSocketOptions.IP_MULTICAST_IF
option.
- setNetworkInterface(NetworkInterface) - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
-
- setNetworkInterface(NetworkInterface) - Method in class io.netty.channel.socket.nio.NioDatagramChannelConfig
-
- setNext(Recycler.WeakOrderQueue) - Method in class io.netty.util.Recycler.WeakOrderQueue
-
- setNextAvail(int) - Method in class io.netty.buffer.PoolSubpage
-
- 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(SctpSocketOption<T>, T) - Method in class com.sun.nio.sctp.SctpChannel
-
- setOption(SctpSocketOption<T>, T) - Method in class com.sun.nio.sctp.SctpServerChannel
-
- 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.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.sctp.DefaultSctpChannelConfig
-
- setOption(ChannelOption<T>, T) - Method in class io.netty.channel.sctp.DefaultSctpServerChannelConfig
-
- 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
-
- setOption0(Object, Object) - Method in class io.netty.channel.socket.nio.NioDatagramChannelConfig
-
- 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.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)
.
- setPinEventExecutorPerGroup(boolean) - Method in class io.netty.channel.DefaultChannelConfig
-
- 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
-
- 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.kqueue.KQueueDomainSocketChannelConfig
-
- setReadMode(DomainSocketReadMode) - Method in interface io.netty.channel.unix.DomainSocketChannelConfig
-
- setReadPending(boolean) - Method in class io.netty.channel.nio.AbstractNioChannel
-
- setReadPending(boolean) - Method in class io.netty.channel.oio.AbstractOioChannel
-
- 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.
- setReadPending0(boolean) - Method in class io.netty.channel.nio.AbstractNioChannel
-
- 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 class io.netty.channel.sctp.DefaultSctpChannelConfig
-
- setReceiveBufferSize(int) - Method in class io.netty.channel.sctp.DefaultSctpServerChannelConfig
-
- setReceiveBufferSize(int) - Method in interface io.netty.channel.sctp.SctpChannelConfig
-
- setReceiveBufferSize(int) - Method in interface io.netty.channel.sctp.SctpServerChannelConfig
-
- setReceiveBufferSize(int) - Method in interface io.netty.channel.socket.DatagramChannelConfig
-
Sets the StandardSocketOptions.SO_RCVBUF
option.
- 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
-
Gets the StandardSocketOptions.SO_SNDBUF
option.
- setReceiveBufferSize(int) - Method in interface io.netty.channel.socket.SocketChannelConfig
-
Sets the StandardSocketOptions.SO_RCVBUF
option.
- setReceiveBufferSize(int) - Method in class io.netty.channel.unix.Socket
-
- setReceiveBufferSize(int, int) - Static method in class io.netty.channel.unix.Socket
-
- setRecord(DnsSection, DnsRecord) - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
-
- setRecord(int, DnsRecord) - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
-
- setRecord(DnsSection, int, DnsRecord) - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
-
- setRecord(int, 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
-
- setRecvByteBufAllocator(RecvByteBufAllocator) - Method in class io.netty.channel.DefaultChannelConfig
-
- setRecvByteBufAllocator(RecvByteBufAllocator, ChannelMetadata) - Method in class io.netty.channel.DefaultChannelConfig
-
- 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 class io.netty.channel.sctp.DefaultSctpChannelConfig
-
- setRecvByteBufAllocator(RecvByteBufAllocator) - Method in class io.netty.channel.sctp.DefaultSctpServerChannelConfig
-
- setRecvByteBufAllocator(RecvByteBufAllocator) - Method in interface io.netty.channel.sctp.SctpChannelConfig
-
- setRecvByteBufAllocator(RecvByteBufAllocator) - Method in interface io.netty.channel.sctp.SctpServerChannelConfig
-
- 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
- setRemoved() - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- 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.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
-
Gets the StandardSocketOptions.SO_REUSEADDR
option.
- 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
-
Sets the StandardSocketOptions.SO_REUSEADDR
option.
- setReuseAddress(boolean) - Method in interface io.netty.channel.socket.SocketChannelConfig
-
Sets the StandardSocketOptions.SO_REUSEADDR
option.
- setReuseAddress(boolean) - Method in class io.netty.channel.unix.Socket
-
- setReuseAddress(int, int) - Static method in class io.netty.channel.unix.Socket
-
- 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
-
- setReusePort(int, int) - Static method in class io.netty.channel.unix.Socket
-
- setSctpNoDelay(boolean) - Method in class io.netty.channel.sctp.DefaultSctpChannelConfig
-
- setSctpNoDelay(boolean) - Method in interface io.netty.channel.sctp.SctpChannelConfig
-
- setSection(int, Object) - Method in class io.netty.handler.codec.dns.AbstractDnsMessage
-
- setSeed(byte[]) - Method in class io.netty.handler.ssl.util.ThreadLocalInsecureRandom
-
- setSeed(long) - Method in class io.netty.handler.ssl.util.ThreadLocalInsecureRandom
-
- setSeed(long) - Method in class io.netty.util.internal.ThreadLocalRandom
-
Throws UnsupportedOperationException
.
- setSendBufferSize(int) - Method in class io.netty.channel.kqueue.KQueueDatagramChannelConfig
-
- setSendBufferSize(int) - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
-
- setSendBufferSize(int) - Method in class io.netty.channel.sctp.DefaultSctpChannelConfig
-
- setSendBufferSize(int) - Method in class io.netty.channel.sctp.DefaultSctpServerChannelConfig
-
- setSendBufferSize(int) - Method in interface io.netty.channel.sctp.SctpChannelConfig
-
- setSendBufferSize(int) - Method in interface io.netty.channel.sctp.SctpServerChannelConfig
-
- setSendBufferSize(int) - Method in interface io.netty.channel.socket.DatagramChannelConfig
-
Sets the StandardSocketOptions.SO_SNDBUF
option.
- 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
-
Sets the StandardSocketOptions.SO_SNDBUF
option.
- setSendBufferSize(int) - Method in class io.netty.channel.unix.Socket
-
- setSendBufferSize(int, int) - Static 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.AbstractUnpooledSlicedByteBuf
-
- setShort(int, int) - Method in class io.netty.buffer.AbstractUnsafeSwappedByteBuf
-
- setShort(int, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- setShort(int, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.FixedCompositeByteBuf
-
- setShort(byte[], int, int) - Static method in class io.netty.buffer.HeapByteBufUtil
-
- setShort(int, int) - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- setShort(int, int) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- setShort(int, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
-
Deprecated.
- setShort(int, int) - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- 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(int, int) - Method in class io.netty.buffer.UnpooledUnsafeHeapByteBuf
-
- setShort(long, int) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- setShort(byte[], int, int) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- setShort(int, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- setShort(int, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- 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
.
- setShort(int, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- setShortLE(int, int) - Method in class io.netty.buffer.AbstractByteBuf
-
- setShortLE(int, int) - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- setShortLE(int, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- setShortLE(int, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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(byte[], int, int) - Static method in class io.netty.buffer.HeapByteBufUtil
-
- setShortLE(int, int) - Method in class io.netty.buffer.PooledDuplicatedByteBuf
-
- setShortLE(int, int) - Method in class io.netty.buffer.PooledSlicedByteBuf
-
- setShortLE(int, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
-
Deprecated.
- setShortLE(int, int) - Method in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- setShortLE(int, int) - Method in class io.netty.buffer.SwappedByteBuf
-
Deprecated.
- setShortLE(int, int) - Method in class io.netty.buffer.UnpooledHeapByteBuf
-
- setShortLE(int, int) - Method in class io.netty.buffer.UnpooledUnsafeHeapByteBuf
-
- setShortLE(long, int) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- setShortLE(byte[], int, int) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- setShortLE(int, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- setShortLE(int, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- setShortLE(int, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- setSingleDecode(boolean) - Method in class io.netty.handler.codec.ByteToMessageDecoder
-
- setSndLowAt(int) - Method in class io.netty.channel.kqueue.BsdSocket
-
- setSndLowAt(int, int) - Static method in class io.netty.channel.kqueue.BsdSocket
-
- setSndLowAt(int) - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
-
- setSniHostNames(SSLParameters, List<String>) - Static method in class io.netty.handler.ssl.Java8SslUtils
-
- setSNIMatchers(SSLParameters, Collection<?>) - Static method in class io.netty.handler.ssl.Java8SslUtils
-
- 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
-
Sets the StandardSocketOptions.SO_LINGER
option.
- setSoLinger(int) - Method in class io.netty.channel.unix.Socket
-
- setSoLinger(int, int) - Static 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.
- setSSLParameters(SSLParameters) - Method in class io.netty.handler.ssl.JdkSslEngine
-
- 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() - Method in class io.netty.channel.AbstractChannel.CloseFuture
-
- 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(Void) - Method in class io.netty.channel.group.DefaultChannelGroupFuture
-
- setSuccess() - Method in class io.netty.channel.VoidChannelPromise
-
- setSuccess(Void) - Method in class io.netty.channel.VoidChannelPromise
-
- setSuccess(AddressedEnvelope<? extends DnsResponse, InetSocketAddress>) - Method in class io.netty.resolver.dns.DnsQueryContext
-
- 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.
- setSuccess(V) - Method in class io.netty.util.concurrent.PromiseTask
-
- setSuccess0() - Method in class io.netty.channel.group.DefaultChannelGroupFuture
-
- setSuccess0(V) - Method in class io.netty.util.concurrent.DefaultPromise
-
- setSuccessInternal(V) - Method in class io.netty.util.concurrent.PromiseTask
-
- 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
-
Sets the StandardSocketOptions.TCP_NODELAY
option.
- setTcpNoDelay(boolean) - Method in class io.netty.channel.unix.Socket
-
- setTcpNoDelay(int, int) - Static method in class io.netty.channel.unix.Socket
-
- setTcpNoPush(boolean) - Method in class io.netty.channel.kqueue.BsdSocket
-
- setTcpNoPush(int, int) - Static method in class io.netty.channel.kqueue.BsdSocket
-
- setTcpNoPush(boolean) - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
-
- 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.kqueue.KQueueDatagramChannelConfig
-
- setTimeToLive(int) - Method in interface io.netty.channel.socket.DatagramChannelConfig
-
Sets the StandardSocketOptions.IP_MULTICAST_TTL
option.
- setTimeToLive(int) - Method in class io.netty.channel.socket.DefaultDatagramChannelConfig
-
- setTimeToLive(int) - Method in class io.netty.channel.socket.nio.NioDatagramChannelConfig
-
- 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.kqueue.KQueueDatagramChannelConfig
-
- setTrafficClass(int) - Method in class io.netty.channel.kqueue.KQueueSocketChannelConfig
-
- setTrafficClass(int) - Method in interface io.netty.channel.socket.DatagramChannelConfig
-
Sets the StandardSocketOptions.IP_TOS
option.
- 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
-
Sets the StandardSocketOptions.IP_TOS
option.
- setTrafficClass(int) - Method in class io.netty.channel.unix.Socket
-
- setTrafficClass(int, int) - Static method in class io.netty.channel.unix.Socket
-
- setTrafficCounter(TrafficCounter) - Method in class io.netty.handler.traffic.AbstractTrafficShapingHandler
-
- 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.channel.VoidChannelPromise
-
- setUncancellable() - Method in class io.netty.util.concurrent.DefaultPromise
-
- setUncancellable() - Method in interface io.netty.util.concurrent.Promise
-
Make this future impossible to cancel.
- setUncancellable() - Method in class io.netty.util.concurrent.PromiseTask
-
- setUncancellableInternal() - Method in class io.netty.util.concurrent.PromiseTask
-
- setUnwritable(boolean) - Method in class io.netty.channel.ChannelOutboundBuffer
-
- setup(ChannelHandler...) - Method in class io.netty.channel.embedded.EmbeddedChannel
-
- setup() - Method in class io.netty.channel.unix.tests.SocketTest
-
- setUseCipherSuitesOrder(SSLParameters, boolean) - Static method in class io.netty.handler.ssl.Java8SslUtils
-
- setUseClientMode(boolean) - Method in class io.netty.handler.ssl.JdkSslEngine
-
- setUserDefinedWritability(int, boolean) - Method in class io.netty.channel.ChannelOutboundBuffer
-
Sets a user-defined writability flag at the specified index.
- setUserDefinedWritability(int) - Method in class io.netty.channel.ChannelOutboundBuffer
-
- setUserDefinedWritability(ChannelHandlerContext, boolean) - Method in class io.netty.handler.traffic.AbstractTrafficShapingHandler
-
- setValue(int, byte) - Method in class io.netty.buffer.PoolChunk
-
- setValue(V) - Method in class io.netty.channel.group.DefaultChannelGroupFuture.DefaultEntry
-
- setValue(V) - Method in class io.netty.handler.codec.DefaultHeaders.HeaderEntry
-
- setValue(String) - Method in class io.netty.handler.codec.HeadersUtils.StringEntry
-
- setValue(V) - Method in class io.netty.util.collection.ByteCollections.UnmodifiableMap.EntryImpl
-
- setValue(V) - Method in class io.netty.util.collection.ByteObjectHashMap.MapEntry
-
- setValue(V) - Method in class io.netty.util.collection.ByteObjectHashMap.PrimitiveIterator
-
- setValue(V) - Method in interface io.netty.util.collection.ByteObjectMap.PrimitiveEntry
-
Sets the value for this entry.
- setValue(V) - Method in class io.netty.util.collection.CharCollections.UnmodifiableMap.EntryImpl
-
- setValue(V) - Method in class io.netty.util.collection.CharObjectHashMap.MapEntry
-
- setValue(V) - Method in class io.netty.util.collection.CharObjectHashMap.PrimitiveIterator
-
- setValue(V) - Method in interface io.netty.util.collection.CharObjectMap.PrimitiveEntry
-
Sets the value for this entry.
- setValue(V) - Method in class io.netty.util.collection.IntCollections.UnmodifiableMap.EntryImpl
-
- setValue(V) - Method in class io.netty.util.collection.IntObjectHashMap.MapEntry
-
- setValue(V) - Method in class io.netty.util.collection.IntObjectHashMap.PrimitiveIterator
-
- setValue(V) - Method in interface io.netty.util.collection.IntObjectMap.PrimitiveEntry
-
Sets the value for this entry.
- setValue(V) - Method in class io.netty.util.collection.LongCollections.UnmodifiableMap.EntryImpl
-
- setValue(V) - Method in class io.netty.util.collection.LongObjectHashMap.MapEntry
-
- setValue(V) - Method in class io.netty.util.collection.LongObjectHashMap.PrimitiveIterator
-
- setValue(V) - Method in interface io.netty.util.collection.LongObjectMap.PrimitiveEntry
-
Sets the value for this entry.
- setValue(V) - Method in class io.netty.util.collection.ShortCollections.UnmodifiableMap.EntryImpl
-
- setValue(V) - Method in class io.netty.util.collection.ShortObjectHashMap.MapEntry
-
- setValue(V) - Method in class io.netty.util.collection.ShortObjectHashMap.PrimitiveIterator
-
- setValue(V) - Method in interface io.netty.util.collection.ShortObjectMap.PrimitiveEntry
-
Sets the value for this entry.
- setValue0(Object) - Method in class io.netty.util.concurrent.DefaultPromise
-
- setWantClientAuth(boolean) - Method in class io.netty.handler.ssl.JdkSslEngine
-
- setWritable(boolean) - Method in class io.netty.channel.ChannelOutboundBuffer
-
- 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.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.sctp.DefaultSctpChannelConfig
-
- setWriteBufferHighWaterMark(int) - Method in class io.netty.channel.sctp.DefaultSctpServerChannelConfig
-
- setWriteBufferHighWaterMark(int) - Method in interface io.netty.channel.sctp.SctpChannelConfig
-
- setWriteBufferHighWaterMark(int) - Method in interface io.netty.channel.sctp.SctpServerChannelConfig
-
- 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.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.sctp.DefaultSctpChannelConfig
-
- setWriteBufferLowWaterMark(int) - Method in class io.netty.channel.sctp.DefaultSctpServerChannelConfig
-
- setWriteBufferLowWaterMark(int) - Method in interface io.netty.channel.sctp.SctpChannelConfig
-
- setWriteBufferLowWaterMark(int) - Method in interface io.netty.channel.sctp.SctpServerChannelConfig
-
- 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.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 class io.netty.channel.sctp.DefaultSctpChannelConfig
-
- setWriteBufferWaterMark(WriteBufferWaterMark) - Method in class io.netty.channel.sctp.DefaultSctpServerChannelConfig
-
- setWriteBufferWaterMark(WriteBufferWaterMark) - Method in interface io.netty.channel.sctp.SctpChannelConfig
-
- setWriteBufferWaterMark(WriteBufferWaterMark) - Method in interface io.netty.channel.sctp.SctpServerChannelConfig
-
- 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.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 class io.netty.channel.sctp.DefaultSctpChannelConfig
-
- setWriteSpinCount(int) - Method in class io.netty.channel.sctp.DefaultSctpServerChannelConfig
-
- setWriteSpinCount(int) - Method in interface io.netty.channel.sctp.SctpChannelConfig
-
- setWriteSpinCount(int) - Method in interface io.netty.channel.sctp.SctpServerChannelConfig
-
- 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.AdvancedLeakAwareByteBuf
-
- setZero(int, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.PooledUnsafeDirectByteBuf
-
- setZero(int, int) - Method in class io.netty.buffer.PooledUnsafeHeapByteBuf
-
- setZero(int, int) - Method in class io.netty.buffer.SwappedByteBuf
-
Deprecated.
- setZero(int, int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
-
- setZero(int, int) - Method in class io.netty.buffer.UnpooledUnsafeHeapByteBuf
-
- setZero(byte[], int, int) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- setZero(AbstractByteBuf, long, int, int) - Static method in class io.netty.buffer.UnsafeByteBufUtil
-
- setZero(int, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- setZero(int, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- setZero(int, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- SHA1_BYTE_LEN - Static variable in class io.netty.handler.ssl.util.FingerprintTrustManagerFactory
-
- SHA1_HEX_LEN - Static variable in class io.netty.handler.ssl.util.FingerprintTrustManagerFactory
-
- shortArrayAppend(StringBuilder, short[]) - Static method in class io.netty.util.internal.logging.MessageFormatter
-
- shortBE(ByteBuf, int) - Static method in class io.netty.handler.ssl.SslUtils
-
- shortBE(ByteBuffer, int) - Static method in class io.netty.handler.ssl.SslUtils
-
- ShortCollections - Class in io.netty.util.collection
-
Utilities for short-based primitive collections.
- ShortCollections() - Constructor for class io.netty.util.collection.ShortCollections
-
- ShortCollections.EmptyMap - Class in io.netty.util.collection
-
An empty map.
- ShortCollections.UnmodifiableMap<V> - Class in io.netty.util.collection
-
- ShortCollections.UnmodifiableMap.EntryImpl - Class in io.netty.util.collection
-
Unmodifiable wrapper for an entry.
- ShortCollections.UnmodifiableMap.IteratorImpl - Class in io.netty.util.collection
-
Unmodifiable wrapper for an iterator.
- shortCommitHash - Variable in class io.netty.util.Version
-
- 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
-
- ShortObjectHashMap.EntrySet - Class in io.netty.util.collection
-
Set implementation for iterating over the entries of the map.
- ShortObjectHashMap.KeySet - Class in io.netty.util.collection
-
Set implementation for iterating over the keys.
- ShortObjectHashMap.MapEntry - Class in io.netty.util.collection
-
A single entry in the map.
- ShortObjectHashMap.MapIterator - Class in io.netty.util.collection
-
Iterator used by the Map
interface.
- ShortObjectHashMap.PrimitiveIterator - Class in io.netty.util.collection
-
Iterator over primitive entries.
- ShortObjectMap<V> - Interface in io.netty.util.collection
-
Interface for a primitive map that uses short
s as keys.
- ShortObjectMap.PrimitiveEntry<V> - Interface in io.netty.util.collection
-
- shortToBytes(short) - Static method in class io.netty.handler.codec.redis.RedisCodecUtil
-
Returns a byte[]
of short
value.
- shortValue - Variable in class io.netty.channel.DefaultChannelId
-
- shouldBreakReadReady(ChannelConfig) - Method in class io.netty.channel.kqueue.AbstractKQueueChannel
-
- shouldConsume - Variable in class io.netty.handler.flow.FlowControlHandler
-
- shuffle() - Method in class io.netty.resolver.dns.ShuffledDnsServerAddressStream
-
- shuffled(Iterable<? extends InetSocketAddress>) - Static method in class io.netty.resolver.dns.DnsServerAddresses
-
- shuffled(InetSocketAddress...) - Static method in class io.netty.resolver.dns.DnsServerAddresses
-
- shuffled0(InetSocketAddress[]) - Static method in class io.netty.resolver.dns.DnsServerAddresses
-
- ShuffledDnsServerAddressStream - Class in io.netty.resolver.dns
-
- ShuffledDnsServerAddressStream(InetSocketAddress[]) - Constructor for class io.netty.resolver.dns.ShuffledDnsServerAddressStream
-
Create a new instance.
- ShuffledDnsServerAddressStream(InetSocketAddress[], int) - Constructor for class io.netty.resolver.dns.ShuffledDnsServerAddressStream
-
- shutdown() - Method in class io.netty.channel.embedded.EmbeddedEventLoop
-
Deprecated.
- 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(int, boolean, boolean) - Static 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.NonStickyOrderedEventExecutor
-
- 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
-
- shutdown0(ChannelPromise) - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel
-
- shutdown0(ChannelPromise) - Method in class io.netty.channel.socket.nio.NioSocketChannel
-
- shutdown0(ChannelPromise) - Method in class io.netty.channel.socket.oio.OioSocketChannel
-
- SHUTDOWN_CLOSED_CHANNEL_EXCEPTION - Static variable in class io.netty.channel.unix.Socket
-
- shutdownGracefully(long, long, TimeUnit) - Method in class io.netty.channel.embedded.EmbeddedEventLoop
-
- 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
-
- 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(long, long, TimeUnit) - Method in class io.netty.util.concurrent.NonStickyEventExecutorGroup.NonStickyOrderedEventExecutor
-
- 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
-
- shutdownHook - Variable in class io.netty.channel.local.LocalChannel
-
- shutdownHook - Variable in class io.netty.channel.local.LocalServerChannel
-
- shutdownHooks - Variable in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- shutdownInput(boolean) - Method in class io.netty.channel.kqueue.AbstractKQueueChannel.AbstractKQueueUnsafe
-
Shutdown the input side of the channel.
- 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
-
- 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
-
- shutdownInput0(ChannelPromise) - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel
-
- shutdownInput0(ChannelPromise) - Method in class io.netty.channel.socket.nio.NioSocketChannel
-
- shutdownInput0() - Method in class io.netty.channel.socket.nio.NioSocketChannel
-
- shutdownInput0(ChannelPromise) - Method in class io.netty.channel.socket.oio.OioSocketChannel
-
- shutdownLock - Variable in class io.netty.channel.socket.oio.OioServerSocketChannel
-
- ShutdownNotification - Class in com.sun.nio.sctp
-
- ShutdownNotification() - Constructor for class com.sun.nio.sctp.ShutdownNotification
-
- 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.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
-
- 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
-
- shutdownOutput0(ChannelPromise) - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel
-
- shutdownOutput0(ChannelPromise) - Method in class io.netty.channel.socket.nio.NioSocketChannel
-
- shutdownOutput0() - Method in class io.netty.channel.socket.nio.NioSocketChannel
-
- shutdownOutput0(ChannelPromise) - Method in class io.netty.channel.socket.oio.OioSocketChannel
-
- shuttingDown - Variable in class io.netty.channel.ThreadPerChannelEventLoopGroup
-
- 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(int, String) - Constructor for error io.netty.util.Signal
-
Creates a new
Signal
with the specified
name
.
- Signal.SignalConstant - Class in io.netty.util
-
- SIGNAL_SUCCESS - Static variable in class io.netty.handler.codec.DecoderResult
-
- SIGNAL_UNFINISHED - Static variable in class io.netty.handler.codec.DecoderResult
-
- SignalConstant(int, String) - Constructor for class io.netty.util.Signal.SignalConstant
-
- SimpleChannelInboundHandler<I> - Class in io.netty.channel
-
- 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
Channel
s 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
-
- 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
.
- SimpleLeakAwareByteBuf - Class in io.netty.buffer
-
- SimpleLeakAwareByteBuf(ByteBuf, ByteBuf, ResourceLeakTracker<ByteBuf>) - Constructor for class io.netty.buffer.SimpleLeakAwareByteBuf
-
- SimpleLeakAwareByteBuf(ByteBuf, ResourceLeakTracker<ByteBuf>) - Constructor for class io.netty.buffer.SimpleLeakAwareByteBuf
-
- SimpleLeakAwareCompositeByteBuf - Class in io.netty.buffer
-
- SimpleLeakAwareCompositeByteBuf(CompositeByteBuf, ResourceLeakTracker<ByteBuf>) - Constructor for class io.netty.buffer.SimpleLeakAwareCompositeByteBuf
-
- SimpleNameResolver<T> - Class in io.netty.resolver
-
- SimpleNameResolver(EventExecutor) - Constructor for class io.netty.resolver.SimpleNameResolver
-
- SimpleStringRedisMessage - Class in io.netty.handler.codec.redis
-
- SimpleStringRedisMessage(String) - Constructor for class io.netty.handler.codec.redis.SimpleStringRedisMessage
-
- 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.
- SimpleTrustManagerFactory.SimpleTrustManagerFactorySpi - Class in io.netty.handler.ssl.util
-
- SimpleTrustManagerFactorySpi() - Constructor for class io.netty.handler.ssl.util.SimpleTrustManagerFactory.SimpleTrustManagerFactorySpi
-
- SINGLE_EVENTEXECUTOR_PER_GROUP - Static variable in class io.netty.channel.ChannelOption
-
- singleBuffer - Variable in class io.netty.handler.ssl.SslHandler
-
Used if
SSLEngine.wrap(ByteBuffer[], ByteBuffer)
and
SSLEngine.unwrap(ByteBuffer, ByteBuffer[])
should be called with a
ByteBuf
that is only backed by one
ByteBuffer
to reduce the object
creation.
- singleDecode - Variable in class io.netty.handler.codec.ByteToMessageDecoder
-
- SingleResolverContext(DnsNameResolver, String, DnsRecord[], DnsCache, DnsServerAddressStream) - Constructor for class io.netty.resolver.dns.DnsNameResolver.SingleResolverContext
-
- 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
- SingleThreadEventExecutor.DefaultThreadProperties - Class in io.netty.util.concurrent
-
- SingleThreadEventLoop - Class in io.netty.channel
-
Abstract base class for
EventLoop
s 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
-
- SingleThreadEventLoop.NonWakeupRunnable - Interface in io.netty.channel
-
- singleton(InetSocketAddress) - Static method in class io.netty.resolver.dns.DnsServerAddresses
-
- SingletonDnsServerAddresses - Class in io.netty.resolver.dns
-
- SingletonDnsServerAddresses(InetSocketAddress) - Constructor for class io.netty.resolver.dns.SingletonDnsServerAddresses
-
- SingletonDnsServerAddressStreamProvider - Class in io.netty.resolver.dns
-
- SingletonDnsServerAddressStreamProvider(InetSocketAddress) - Constructor for class io.netty.resolver.dns.SingletonDnsServerAddressStreamProvider
-
Create a new instance.
- size - Variable in class io.netty.buffer.CompositeByteBuf.CompositeByteBufIterator
-
- size - Variable in class io.netty.buffer.PoolThreadCache.MemoryRegionCache
-
- size - Variable in class io.netty.channel.AbstractChannelHandlerContext.AbstractWriteTask
-
- size() - Method in class io.netty.channel.ChannelOutboundBuffer
-
- size(Object) - Method in class io.netty.channel.DefaultMessageSizeEstimator.HandleImpl
-
- size() - Method in class io.netty.channel.group.DefaultChannelGroup
-
- size - Variable in class io.netty.channel.kqueue.KQueueEventArray
-
- size() - Method in class io.netty.channel.kqueue.KQueueEventArray
-
- size - Variable in class io.netty.channel.kqueue.NativeLongArray
-
- size(Object) - Method in interface io.netty.channel.MessageSizeEstimator.Handle
-
Calculate the size of the given message.
- size - Variable in class io.netty.channel.nio.SelectedSelectionKeySet
-
- size() - Method in class io.netty.channel.nio.SelectedSelectionKeySet
-
- size - Variable in class io.netty.channel.PendingWriteQueue.PendingWrite
-
- size - Variable in class io.netty.channel.PendingWriteQueue
-
- size() - Method in class io.netty.channel.PendingWriteQueue
-
Returns the number of pending write operations.
- size(Object) - Method in class io.netty.channel.PendingWriteQueue
-
- size() - Method in class io.netty.channel.pool.AbstractChannelPoolMap
-
- size - Variable in class io.netty.channel.unix.IovArray
-
- size() - Method in class io.netty.channel.unix.IovArray
-
Returns the size in bytes
- size - Variable in class io.netty.handler.codec.CodecOutputList
-
- size() - Method in class io.netty.handler.codec.CodecOutputList
-
- size - Variable in class io.netty.handler.codec.DefaultHeaders
-
- 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.HeadersUtils.DelegatingStringSet
-
- size() - Method in class io.netty.handler.codec.serialization.ObjectEncoderOutputStream
-
- size() - Method in class io.netty.handler.codec.serialization.ReferenceMap
-
- size - Variable in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler.ToSend
-
- size - Variable in class io.netty.handler.traffic.GlobalTrafficShapingHandler.ToSend
-
- size() - Method in class io.netty.resolver.dns.DnsNameResolverContext.AuthoritativeNameServerList
-
- size() - Method in interface io.netty.resolver.dns.DnsServerAddressStream
-
- size() - Method in class io.netty.resolver.dns.SequentialDnsServerAddressStream
-
- size() - Method in class io.netty.resolver.dns.ShuffledDnsServerAddressStream
-
- size() - Method in class io.netty.util.collection.ByteCollections.EmptyMap
-
- size() - Method in class io.netty.util.collection.ByteCollections.UnmodifiableMap
-
- size() - Method in class io.netty.util.collection.ByteObjectHashMap.EntrySet
-
- size() - Method in class io.netty.util.collection.ByteObjectHashMap.KeySet
-
- size - Variable in class io.netty.util.collection.ByteObjectHashMap
-
- size() - Method in class io.netty.util.collection.ByteObjectHashMap
-
- size() - Method in class io.netty.util.collection.CharCollections.EmptyMap
-
- size() - Method in class io.netty.util.collection.CharCollections.UnmodifiableMap
-
- size() - Method in class io.netty.util.collection.CharObjectHashMap.EntrySet
-
- size() - Method in class io.netty.util.collection.CharObjectHashMap.KeySet
-
- size - Variable in class io.netty.util.collection.CharObjectHashMap
-
- size() - Method in class io.netty.util.collection.CharObjectHashMap
-
- size() - Method in class io.netty.util.collection.IntCollections.EmptyMap
-
- size() - Method in class io.netty.util.collection.IntCollections.UnmodifiableMap
-
- size() - Method in class io.netty.util.collection.IntObjectHashMap.EntrySet
-
- size() - Method in class io.netty.util.collection.IntObjectHashMap.KeySet
-
- size - Variable in class io.netty.util.collection.IntObjectHashMap
-
- size() - Method in class io.netty.util.collection.IntObjectHashMap
-
- size() - Method in class io.netty.util.collection.LongCollections.EmptyMap
-
- size() - Method in class io.netty.util.collection.LongCollections.UnmodifiableMap
-
- size() - Method in class io.netty.util.collection.LongObjectHashMap.EntrySet
-
- size() - Method in class io.netty.util.collection.LongObjectHashMap.KeySet
-
- size - Variable in class io.netty.util.collection.LongObjectHashMap
-
- size() - Method in class io.netty.util.collection.LongObjectHashMap
-
- size() - Method in class io.netty.util.collection.ShortCollections.EmptyMap
-
- size() - Method in class io.netty.util.collection.ShortCollections.UnmodifiableMap
-
- size() - Method in class io.netty.util.collection.ShortObjectHashMap.EntrySet
-
- size() - Method in class io.netty.util.collection.ShortObjectHashMap.KeySet
-
- size - Variable in class io.netty.util.collection.ShortObjectHashMap
-
- size() - Method in class io.netty.util.collection.ShortObjectHashMap
-
- size - Variable in class io.netty.util.concurrent.DefaultFutureListeners
-
- size() - Method in class io.netty.util.concurrent.DefaultFutureListeners
-
- 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 - Variable in class io.netty.util.internal.DefaultPriorityQueue
-
- 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
-
- size - Variable in class io.netty.util.Recycler.Stack
-
- SIZE_CACHED_INTEGER_NUMBER - Static variable in class io.netty.handler.codec.redis.FixedRedisMessagePool
-
- SIZE_TABLE - Static variable in class io.netty.channel.AdaptiveRecvByteBufAllocator
-
- sizeClass(int) - Method in class io.netty.buffer.PoolArena
-
- SizeClass() - Constructor for enum io.netty.buffer.PoolArena.SizeClass
-
- sizeClass - Variable in class io.netty.buffer.PoolThreadCache.MemoryRegionCache
-
- SIZEOF_JLONG - Static variable in class io.netty.channel.unix.Limits
-
- sizeOfjlong() - Static method in class io.netty.channel.unix.LimitsStaticallyReferencedJniMethods
-
- sizeofKEvent() - Static method in class io.netty.channel.kqueue.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.AdvancedLeakAwareByteBuf
-
- skipBytes(int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.buffer.WrappedByteBuf
-
- skipBytes(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- skipBytes(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- skipBytes(int) - Method in class io.netty.handler.codec.serialization.ObjectDecoderInputStream
-
- skipControlCharacters(ByteBuf) - Static method in class io.netty.handler.codec.stomp.StompSubframeDecoder
-
- skipNullCharacter(ByteBuf) - Static method in class io.netty.handler.codec.stomp.StompSubframeDecoder
-
- Slf4JLogger - Class in io.netty.util.internal.logging
-
- Slf4JLogger(Logger) - Constructor for class io.netty.util.internal.logging.Slf4JLogger
-
- 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
-
- Slf4JLoggerFactory(boolean) - Constructor for class io.netty.util.internal.logging.Slf4JLoggerFactory
-
- slice() - Method in class io.netty.buffer.AbstractByteBuf
-
- slice(int, int) - Method in class io.netty.buffer.AbstractByteBuf
-
- slice(int, int) - Method in class io.netty.buffer.AbstractPooledDerivedByteBuf.PooledNonRetainedDuplicateByteBuf
-
- slice(int, int) - Method in class io.netty.buffer.AbstractPooledDerivedByteBuf.PooledNonRetainedSlicedByteBuf
-
- slice(int, int) - Method in class io.netty.buffer.AbstractPooledDerivedByteBuf
-
- slice(int, int) - Method in class io.netty.buffer.AbstractUnpooledSlicedByteBuf
-
- slice() - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- slice(int, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- slice() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- slice(int, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.PooledSlicedByteBuf
-
- slice(int, int) - Method in class io.netty.buffer.ReadOnlyByteBuf
-
Deprecated.
- slice() - Method in class io.netty.buffer.SimpleLeakAwareByteBuf
-
- slice(int, int) - Method in class io.netty.buffer.SimpleLeakAwareByteBuf
-
- slice() - Method in class io.netty.buffer.SimpleLeakAwareCompositeByteBuf
-
- slice(int, int) - Method in class io.netty.buffer.SimpleLeakAwareCompositeByteBuf
-
- slice() - Method in class io.netty.buffer.SwappedByteBuf
-
Deprecated.
- slice(int, int) - Method in class io.netty.buffer.SwappedByteBuf
-
Deprecated.
- slice() - Method in class io.netty.buffer.UnreleasableByteBuf
-
- slice(int, int) - Method in class io.netty.buffer.UnreleasableByteBuf
-
- slice() - Method in class io.netty.buffer.WrappedByteBuf
-
- slice(int, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- slice() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- slice(int, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- slice() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- slice(int, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- SlicedByteBuf - Class in io.netty.buffer
-
- SlicedByteBuf(ByteBuf, int, int) - Constructor for class io.netty.buffer.SlicedByteBuf
-
Deprecated.
- SlowByteBufChecksum(Checksum) - Constructor for class io.netty.handler.codec.compression.ByteBufChecksum.SlowByteBufChecksum
-
- slowDownFactor - Variable in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
-
- slowDownFactor() - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
-
- slowGet() - Static method in class io.netty.util.internal.InternalThreadLocalMap
-
- slowThreadLocalMap - Static variable in class io.netty.util.internal.UnpaddedInternalThreadLocalMap
-
- smallCacheSize - Variable in class io.netty.buffer.PooledByteBufAllocator
-
- smallCacheSize() - Method in class io.netty.buffer.PooledByteBufAllocator
-
- smallCacheSize() - Method in class io.netty.buffer.PooledByteBufAllocatorMetric
-
Return the size of the small cache.
- smallIdx(int) - Static method in class io.netty.buffer.PoolArena
-
- smallSubPageDirectCaches - Variable in class io.netty.buffer.PoolThreadCache
-
- smallSubPageHeapCaches - Variable in class io.netty.buffer.PoolThreadCache
-
- smallSubpagePools - Variable in class io.netty.buffer.PoolArena
-
- smallSubpages() - Method in class io.netty.buffer.PoolArena
-
- smallSubpages() - Method in interface io.netty.buffer.PoolArenaMetric
-
- SmtpCommand - Class in io.netty.handler.codec.smtp
-
- SmtpCommand(AsciiString, boolean) - Constructor for class io.netty.handler.codec.smtp.SmtpCommand
-
- 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
-
- SmtpRequests() - Constructor for class io.netty.handler.codec.smtp.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
.
- SmtpUtils - Class in io.netty.handler.codec.smtp
-
- SmtpUtils() - Constructor for class io.netty.handler.codec.smtp.SmtpUtils
-
- 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
-
- snappy - Variable in class io.netty.handler.codec.compression.SnappyFrameDecoder
-
- snappy - Variable in class io.netty.handler.codec.compression.SnappyFrameEncoder
-
- Snappy.State - Enum in io.netty.handler.codec.compression
-
- SNAPPY_IDENTIFIER_LEN - Static variable in class io.netty.handler.codec.compression.SnappyFrameDecoder
-
- SnappyFramedDecoder - Class in io.netty.handler.codec.compression
-
- 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.
- SnappyFrameDecoder.ChunkType - Enum in io.netty.handler.codec.compression
-
- SnappyFramedEncoder - Class in io.netty.handler.codec.compression
-
- 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
-
- SniHandler - Class in io.netty.handler.ssl
-
- SniHandler(Mapping<? super String, ? extends SslContext>) - Constructor for class io.netty.handler.ssl.SniHandler
-
- SniHandler(DomainNameMapping<? extends SslContext>) - Constructor for class io.netty.handler.ssl.SniHandler
-
- SniHandler(AsyncMapping<? super String, ? extends SslContext>) - Constructor for class io.netty.handler.ssl.SniHandler
-
- SniHandler.AsyncMappingAdapter - Class in io.netty.handler.ssl
-
- SniHandler.Selection - Class in io.netty.handler.ssl
-
- 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 com.sun.nio.sctp.SctpStandardSocketOptions
-
- SO_LINGER - Static variable in class io.netty.channel.ChannelOption
-
- SO_RCVBUF - Static variable in class com.sun.nio.sctp.SctpStandardSocketOptions
-
- 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 com.sun.nio.sctp.SctpStandardSocketOptions
-
- 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 - Variable in class io.netty.channel.kqueue.AbstractKQueueChannel
-
- socket - Variable in class io.netty.channel.socket.oio.OioDatagramChannel
-
- socket - Variable in class io.netty.channel.socket.oio.OioServerSocketChannel
-
- socket - Variable in class io.netty.channel.socket.oio.OioSocketChannel
-
- 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
-
- SocketChannelConfig - Interface in io.netty.channel.socket
-
- socketPath - Variable in class io.netty.channel.unix.DomainSocketAddress
-
- 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.
- SocketUtils() - Constructor for class io.netty.util.internal.SocketUtils
-
- SocketWritableByteChannel - Class in io.netty.channel.unix
-
- SocketWritableByteChannel(FileDescriptor) - Constructor for class io.netty.channel.unix.SocketWritableByteChannel
-
- Socks4ClientDecoder - Class in io.netty.handler.codec.socksx.v4
-
- Socks4ClientDecoder() - Constructor for class io.netty.handler.codec.socksx.v4.Socks4ClientDecoder
-
- Socks4ClientDecoder.State - Enum in io.netty.handler.codec.socksx.v4
-
- Socks4ClientEncoder - Class in io.netty.handler.codec.socksx.v4
-
- Socks4ClientEncoder() - Constructor for class io.netty.handler.codec.socksx.v4.Socks4ClientEncoder
-
- Socks4CommandRequest - Interface in io.netty.handler.codec.socksx.v4
-
A SOCKS4a CONNECT
or BIND
request.
- Socks4CommandResponse - Interface in io.netty.handler.codec.socksx.v4
-
A SOCKS4a response.
- Socks4CommandStatus - Class in io.netty.handler.codec.socksx.v4
-
- Socks4CommandStatus(int) - Constructor for class io.netty.handler.codec.socksx.v4.Socks4CommandStatus
-
- Socks4CommandStatus(int, String) - Constructor for class io.netty.handler.codec.socksx.v4.Socks4CommandStatus
-
- Socks4CommandType - Class in io.netty.handler.codec.socksx.v4
-
- Socks4CommandType(int) - Constructor for class io.netty.handler.codec.socksx.v4.Socks4CommandType
-
- Socks4CommandType(int, String) - Constructor for class io.netty.handler.codec.socksx.v4.Socks4CommandType
-
- Socks4Message - Interface in io.netty.handler.codec.socksx.v4
-
A tag interface that all SOCKS4a protocol messages implement.
- Socks4ServerDecoder - Class in io.netty.handler.codec.socksx.v4
-
- Socks4ServerDecoder() - Constructor for class io.netty.handler.codec.socksx.v4.Socks4ServerDecoder
-
- Socks4ServerDecoder.State - Enum in io.netty.handler.codec.socksx.v4
-
- Socks4ServerEncoder - Class in io.netty.handler.codec.socksx.v4
-
- Socks4ServerEncoder() - Constructor for class io.netty.handler.codec.socksx.v4.Socks4ServerEncoder
-
- Socks5AddressDecoder - Interface in io.netty.handler.codec.socksx.v5
-
Decodes a SOCKS5 address field into its string representation.
- Socks5AddressEncoder - Interface in io.netty.handler.codec.socksx.v5
-
Encodes a SOCKS5 address into binary representation.
- Socks5AddressType - Class in io.netty.handler.codec.socksx.v5
-
- Socks5AddressType(int) - Constructor for class io.netty.handler.codec.socksx.v5.Socks5AddressType
-
- Socks5AddressType(int, String) - Constructor for class io.netty.handler.codec.socksx.v5.Socks5AddressType
-
- Socks5AuthMethod - Class in io.netty.handler.codec.socksx.v5
-
The authentication method of SOCKS5.
- Socks5AuthMethod(int) - Constructor for class io.netty.handler.codec.socksx.v5.Socks5AuthMethod
-
- Socks5AuthMethod(int, String) - Constructor for class io.netty.handler.codec.socksx.v5.Socks5AuthMethod
-
- Socks5ClientEncoder - Class in io.netty.handler.codec.socksx.v5
-
- Socks5ClientEncoder() - Constructor for class io.netty.handler.codec.socksx.v5.Socks5ClientEncoder
-
- Socks5ClientEncoder(Socks5AddressEncoder) - Constructor for class io.netty.handler.codec.socksx.v5.Socks5ClientEncoder
-
- Socks5CommandRequest - Interface in io.netty.handler.codec.socksx.v5
-
- Socks5CommandRequestDecoder - Class in io.netty.handler.codec.socksx.v5
-
- Socks5CommandRequestDecoder() - Constructor for class io.netty.handler.codec.socksx.v5.Socks5CommandRequestDecoder
-
- Socks5CommandRequestDecoder(Socks5AddressDecoder) - Constructor for class io.netty.handler.codec.socksx.v5.Socks5CommandRequestDecoder
-
- Socks5CommandRequestDecoder.State - Enum in io.netty.handler.codec.socksx.v5
-
- Socks5CommandResponse - Interface in io.netty.handler.codec.socksx.v5
-
- Socks5CommandResponseDecoder - Class in io.netty.handler.codec.socksx.v5
-
- Socks5CommandResponseDecoder() - Constructor for class io.netty.handler.codec.socksx.v5.Socks5CommandResponseDecoder
-
- Socks5CommandResponseDecoder(Socks5AddressDecoder) - Constructor for class io.netty.handler.codec.socksx.v5.Socks5CommandResponseDecoder
-
- Socks5CommandResponseDecoder.State - Enum in io.netty.handler.codec.socksx.v5
-
- Socks5CommandStatus - Class in io.netty.handler.codec.socksx.v5
-
- Socks5CommandStatus(int) - Constructor for class io.netty.handler.codec.socksx.v5.Socks5CommandStatus
-
- Socks5CommandStatus(int, String) - Constructor for class io.netty.handler.codec.socksx.v5.Socks5CommandStatus
-
- Socks5CommandType - Class in io.netty.handler.codec.socksx.v5
-
- Socks5CommandType(int) - Constructor for class io.netty.handler.codec.socksx.v5.Socks5CommandType
-
- Socks5CommandType(int, String) - Constructor for class io.netty.handler.codec.socksx.v5.Socks5CommandType
-
- socks5encoder - Variable in class io.netty.handler.codec.socksx.SocksPortUnificationServerHandler
-
- Socks5InitialRequest - Interface in io.netty.handler.codec.socksx.v5
-
- Socks5InitialRequestDecoder - Class in io.netty.handler.codec.socksx.v5
-
- Socks5InitialRequestDecoder() - Constructor for class io.netty.handler.codec.socksx.v5.Socks5InitialRequestDecoder
-
- Socks5InitialRequestDecoder.State - Enum in io.netty.handler.codec.socksx.v5
-
- Socks5InitialResponse - Interface in io.netty.handler.codec.socksx.v5
-
- Socks5InitialResponseDecoder - Class in io.netty.handler.codec.socksx.v5
-
- Socks5InitialResponseDecoder() - Constructor for class io.netty.handler.codec.socksx.v5.Socks5InitialResponseDecoder
-
- Socks5InitialResponseDecoder.State - Enum in io.netty.handler.codec.socksx.v5
-
- Socks5Message - Interface in io.netty.handler.codec.socksx.v5
-
A tag interface that all SOCKS5 protocol messages implement.
- Socks5PasswordAuthRequest - Interface in io.netty.handler.codec.socksx.v5
-
- Socks5PasswordAuthRequestDecoder - Class in io.netty.handler.codec.socksx.v5
-
- Socks5PasswordAuthRequestDecoder() - Constructor for class io.netty.handler.codec.socksx.v5.Socks5PasswordAuthRequestDecoder
-
- Socks5PasswordAuthRequestDecoder.State - Enum in io.netty.handler.codec.socksx.v5
-
- Socks5PasswordAuthResponse - Interface in io.netty.handler.codec.socksx.v5
-
- Socks5PasswordAuthResponseDecoder - Class in io.netty.handler.codec.socksx.v5
-
- Socks5PasswordAuthResponseDecoder() - Constructor for class io.netty.handler.codec.socksx.v5.Socks5PasswordAuthResponseDecoder
-
- Socks5PasswordAuthResponseDecoder.State - Enum in io.netty.handler.codec.socksx.v5
-
- Socks5PasswordAuthStatus - Class in io.netty.handler.codec.socksx.v5
-
- Socks5PasswordAuthStatus(int) - Constructor for class io.netty.handler.codec.socksx.v5.Socks5PasswordAuthStatus
-
- Socks5PasswordAuthStatus(int, String) - Constructor for class io.netty.handler.codec.socksx.v5.Socks5PasswordAuthStatus
-
- Socks5ServerEncoder - Class in io.netty.handler.codec.socksx.v5
-
- Socks5ServerEncoder() - Constructor for class io.netty.handler.codec.socksx.v5.Socks5ServerEncoder
-
- Socks5ServerEncoder(Socks5AddressEncoder) - Constructor for class io.netty.handler.codec.socksx.v5.Socks5ServerEncoder
-
- SocksAddressType - Enum in io.netty.handler.codec.socks
-
- SocksAddressType(byte) - Constructor for enum io.netty.handler.codec.socks.SocksAddressType
-
- SocksAuthRequest - Class in io.netty.handler.codec.socks
-
An socks auth request.
- SocksAuthRequest(String, String) - Constructor for class io.netty.handler.codec.socks.SocksAuthRequest
-
- SocksAuthRequestDecoder - Class in io.netty.handler.codec.socks
-
- SocksAuthRequestDecoder() - Constructor for class io.netty.handler.codec.socks.SocksAuthRequestDecoder
-
- SocksAuthRequestDecoder.State - Enum in io.netty.handler.codec.socks
-
- SocksAuthResponse - Class in io.netty.handler.codec.socks
-
An socks auth response.
- SocksAuthResponse(SocksAuthStatus) - Constructor for class io.netty.handler.codec.socks.SocksAuthResponse
-
- SocksAuthResponseDecoder - Class in io.netty.handler.codec.socks
-
- SocksAuthResponseDecoder() - Constructor for class io.netty.handler.codec.socks.SocksAuthResponseDecoder
-
- SocksAuthResponseDecoder.State - Enum in io.netty.handler.codec.socks
-
- SocksAuthScheme - Enum in io.netty.handler.codec.socks
-
- SocksAuthScheme(byte) - Constructor for enum io.netty.handler.codec.socks.SocksAuthScheme
-
- SocksAuthStatus - Enum in io.netty.handler.codec.socks
-
- SocksAuthStatus(byte) - Constructor for enum io.netty.handler.codec.socks.SocksAuthStatus
-
- SocksCmdRequest - Class in io.netty.handler.codec.socks
-
An socks cmd request.
- SocksCmdRequest(SocksCmdType, SocksAddressType, String, int) - Constructor for class io.netty.handler.codec.socks.SocksCmdRequest
-
- SocksCmdRequestDecoder - Class in io.netty.handler.codec.socks
-
- SocksCmdRequestDecoder() - Constructor for class io.netty.handler.codec.socks.SocksCmdRequestDecoder
-
- SocksCmdRequestDecoder.State - Enum in io.netty.handler.codec.socks
-
- SocksCmdResponse - Class in io.netty.handler.codec.socks
-
A socks cmd response.
- SocksCmdResponse(SocksCmdStatus, SocksAddressType) - Constructor for class io.netty.handler.codec.socks.SocksCmdResponse
-
- SocksCmdResponse(SocksCmdStatus, SocksAddressType, String, int) - Constructor for class io.netty.handler.codec.socks.SocksCmdResponse
-
Constructs new response and includes provided host and port as part of it.
- SocksCmdResponseDecoder - Class in io.netty.handler.codec.socks
-
- SocksCmdResponseDecoder() - Constructor for class io.netty.handler.codec.socks.SocksCmdResponseDecoder
-
- SocksCmdResponseDecoder.State - Enum in io.netty.handler.codec.socks
-
- SocksCmdStatus - Enum in io.netty.handler.codec.socks
-
- SocksCmdStatus(byte) - Constructor for enum io.netty.handler.codec.socks.SocksCmdStatus
-
- SocksCmdType - Enum in io.netty.handler.codec.socks
-
- SocksCmdType(byte) - Constructor for enum io.netty.handler.codec.socks.SocksCmdType
-
- SocksCommonUtils - Class in io.netty.handler.codec.socks
-
- SocksCommonUtils() - Constructor for class io.netty.handler.codec.socks.SocksCommonUtils
-
A constructor to stop this class being constructed.
- SocksInitRequest - Class in io.netty.handler.codec.socks
-
An socks init request.
- SocksInitRequest(List<SocksAuthScheme>) - Constructor for class io.netty.handler.codec.socks.SocksInitRequest
-
- SocksInitRequestDecoder - Class in io.netty.handler.codec.socks
-
- SocksInitRequestDecoder() - Constructor for class io.netty.handler.codec.socks.SocksInitRequestDecoder
-
- SocksInitRequestDecoder.State - Enum in io.netty.handler.codec.socks
-
- SocksInitResponse - Class in io.netty.handler.codec.socks
-
An socks init response.
- SocksInitResponse(SocksAuthScheme) - Constructor for class io.netty.handler.codec.socks.SocksInitResponse
-
- SocksInitResponseDecoder - Class in io.netty.handler.codec.socks
-
- SocksInitResponseDecoder() - Constructor for class io.netty.handler.codec.socks.SocksInitResponseDecoder
-
- SocksInitResponseDecoder.State - Enum in io.netty.handler.codec.socks
-
- SocksMessage - Class in io.netty.handler.codec.socks
-
- SocksMessage(SocksMessageType) - Constructor for class io.netty.handler.codec.socks.SocksMessage
-
- SocksMessage - Interface in io.netty.handler.codec.socksx
-
An interface that all SOCKS protocol messages implement.
- SocksMessageEncoder - Class in io.netty.handler.codec.socks
-
- SocksMessageEncoder() - Constructor for class io.netty.handler.codec.socks.SocksMessageEncoder
-
- SocksMessageType - Enum in io.netty.handler.codec.socks
-
- SocksMessageType() - Constructor for enum io.netty.handler.codec.socks.SocksMessageType
-
- SocksPortUnificationServerHandler - Class in io.netty.handler.codec.socksx
-
- SocksPortUnificationServerHandler() - Constructor for class io.netty.handler.codec.socksx.SocksPortUnificationServerHandler
-
Creates a new instance with the default configuration.
- SocksPortUnificationServerHandler(Socks5ServerEncoder) - Constructor for class io.netty.handler.codec.socksx.SocksPortUnificationServerHandler
-
- SocksProtocolVersion - Enum in io.netty.handler.codec.socks
-
- SocksProtocolVersion(byte) - Constructor for enum io.netty.handler.codec.socks.SocksProtocolVersion
-
- SocksRequest - Class in io.netty.handler.codec.socks
-
- SocksRequest(SocksRequestType) - Constructor for class io.netty.handler.codec.socks.SocksRequest
-
- SocksRequestType - Enum in io.netty.handler.codec.socks
-
Type of socks request
- SocksRequestType() - Constructor for enum io.netty.handler.codec.socks.SocksRequestType
-
- SocksResponse - Class in io.netty.handler.codec.socks
-
- SocksResponse(SocksResponseType) - Constructor for class io.netty.handler.codec.socks.SocksResponse
-
- SocksResponseType - Enum in io.netty.handler.codec.socks
-
Type of socks response
- SocksResponseType() - Constructor for enum io.netty.handler.codec.socks.SocksResponseType
-
- SocksSubnegotiationVersion - Enum in io.netty.handler.codec.socks
-
- SocksSubnegotiationVersion(byte) - Constructor for enum io.netty.handler.codec.socks.SocksSubnegotiationVersion
-
- SocksVersion - Enum in io.netty.handler.codec.socksx
-
The version of SOCKS protocol.
- SocksVersion(byte) - Constructor for enum io.netty.handler.codec.socksx.SocksVersion
-
- 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
- SoftReferenceMap<K,V> - Class in io.netty.handler.codec.serialization
-
- SoftReferenceMap(Map<K, Reference<V>>) - Constructor for class io.netty.handler.codec.serialization.SoftReferenceMap
-
- SOMAXCONN - Static variable in class io.netty.util.NetUtil
-
The SOMAXCONN value of the current machine.
- SORTLIST_ROW_LABEL - Static variable in class io.netty.resolver.dns.UnixResolverDnsServerAddressStreamProvider
-
- sortTypeBstar(int[], int[]) - Method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- sourceAddress - Variable in class io.netty.handler.codec.haproxy.HAProxyMessage
-
- sourceAddress() - Method in class io.netty.handler.codec.haproxy.HAProxyMessage
-
- sourcePort - Variable in class io.netty.handler.codec.haproxy.HAProxyMessage
-
- sourcePort() - Method in class io.netty.handler.codec.haproxy.HAProxyMessage
-
- 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.
- SP - Static variable in class io.netty.handler.codec.smtp.SmtpRequestEncoder
-
- 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.
- 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..
- srcPrefixLength - Variable in class io.netty.handler.codec.dns.DefaultDnsOptEcsRecord
-
- 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.
- SS_BLOCKSIZE - Static variable in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- ssBlockSwap(int[], int, int[], int, int) - Static method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- ssCompare(int, int, int) - Method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- ssCompareLast(int, int, int, int, int) - Method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- ssFixdown(int, int, int, int, int) - Method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- ssHeapSort(int, int, int, int) - Method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- 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.
- ssInsertionSort(int, int, int, int) - Method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- SSIZE_MAX - Static variable in class io.netty.channel.unix.Limits
-
- ssizeMax() - Static method in class io.netty.channel.unix.LimitsStaticallyReferencedJniMethods
-
- SSL_CONTENT_TYPE_ALERT - Static variable in class io.netty.handler.ssl.SslUtils
-
alert
- SSL_CONTENT_TYPE_APPLICATION_DATA - Static variable in class io.netty.handler.ssl.SslUtils
-
application data
- SSL_CONTENT_TYPE_CHANGE_CIPHER_SPEC - Static variable in class io.netty.handler.ssl.SslUtils
-
change cipher spec
- SSL_CONTENT_TYPE_EXTENSION_HEARTBEAT - Static variable in class io.netty.handler.ssl.SslUtils
-
HeartBeat Extension
- SSL_CONTENT_TYPE_HANDSHAKE - Static variable in class io.netty.handler.ssl.SslUtils
-
handshake
- SSL_RECORD_HEADER_LENGTH - Static variable in class io.netty.handler.ssl.SslUtils
-
the length of the ssl record header (in bytes)
- 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() - Constructor for class io.netty.handler.ssl.SslCloseCompletionEvent
-
Creates a new event that indicates a successful receiving of close_notify.
- 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.
- sslClosePromise - Variable in class io.netty.handler.ssl.SslHandler
-
- SslCompletionEvent - Class in io.netty.handler.ssl
-
- SslCompletionEvent() - Constructor for class io.netty.handler.ssl.SslCompletionEvent
-
- SslCompletionEvent(Throwable) - Constructor for class io.netty.handler.ssl.SslCompletionEvent
-
- sslContext - Variable in class io.netty.handler.ssl.JdkSslContext
-
- sslContext - Variable in class io.netty.handler.ssl.OptionalSslHandler
-
- 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.
- SslContextBuilder(boolean) - Constructor for class io.netty.handler.ssl.SslContextBuilder
-
- sslContextProvider - Variable in class io.netty.handler.ssl.SslContextBuilder
-
- sslContextProvider(Provider) - Method in class io.netty.handler.ssl.SslContextBuilder
-
The SSLContext Provider
to use.
- SSLENGINE_CLOSED - Static variable in class io.netty.handler.ssl.SslHandler
-
- SslEngineType(boolean, ByteToMessageDecoder.Cumulator) - Constructor for enum io.netty.handler.ssl.SslHandler.SslEngineType
-
- SslHandler - Class in io.netty.handler.ssl
-
- 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
-
- SslHandler(SSLEngine, boolean, Executor) - Constructor for class io.netty.handler.ssl.SslHandler
-
- SslHandler.LazyChannelPromise - Class in io.netty.handler.ssl
-
- SslHandler.SslEngineType - Enum in io.netty.handler.ssl
-
- 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() - Constructor for class io.netty.handler.ssl.SslHandshakeCompletionEvent
-
Creates a new event that indicates a successful handshake.
- SslHandshakeCompletionEvent(Throwable) - Constructor for class io.netty.handler.ssl.SslHandshakeCompletionEvent
-
Creates a new event that indicates an unsuccessful handshake.
- ssLog(int) - Static method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- sslProvider(SslProvider) - Method in class io.netty.handler.ssl.SslContextBuilder
-
- SslProvider - Enum in io.netty.handler.ssl
-
An enumeration of SSL/TLS protocol providers.
- SslProvider() - Constructor for enum io.netty.handler.ssl.SslProvider
-
- SslUtils - Class in io.netty.handler.ssl
-
Constants for SSL packets.
- SslUtils() - Constructor for class io.netty.handler.ssl.SslUtils
-
- ssMedian3(int, int, int, int, int) - Method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- ssMedian5(int, int, int, int, int, int, int) - Method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- ssMerge(int, int, int, int, int[], int, int, int) - Method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- ssMergeBackward(int, int[], int, int, int, int, int) - Method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- ssMergeCheckEqual(int, int, int) - Method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- ssMergeForward(int, int[], int, int, int, int, int) - Method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- ssMultiKeyIntroSort(int, int, int, int) - Method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- ssPivot(int, int, int, int) - Method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- ssSubstringPartition(int, int, int, int) - Method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- ST_CANCELLED - Static variable in class io.netty.util.HashedWheelTimer.HashedWheelTimeout
-
- ST_CORRUPTED - Static variable in class io.netty.handler.codec.json.JsonObjectDecoder
-
- ST_DECODING_ARRAY_STREAM - Static variable in class io.netty.handler.codec.json.JsonObjectDecoder
-
- ST_DECODING_NORMAL - Static variable in class io.netty.handler.codec.json.JsonObjectDecoder
-
- ST_EXPIRED - Static variable in class io.netty.util.HashedWheelTimer.HashedWheelTimeout
-
- ST_INIT - Static variable in class io.netty.handler.codec.json.JsonObjectDecoder
-
- ST_INIT - Static variable in class io.netty.util.HashedWheelTimer.HashedWheelTimeout
-
- ST_NOT_STARTED - Static variable in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- ST_SHUTDOWN - Static variable in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- ST_SHUTTING_DOWN - Static variable in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- ST_STARTED - Static variable in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- ST_TERMINATED - Static variable in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- stack - Variable in class io.netty.util.Recycler.DefaultHandle
-
- Stack(Recycler<T>, Thread, int, int, int, int) - Constructor for class io.netty.util.Recycler.Stack
-
- STACK_SIZE - Static variable in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- STACK_TRACE_ELEMENT_EXCLUSIONS - Static variable in class io.netty.util.ResourceLeakDetector
-
- StackEntry(int, int, int, int) - Constructor for class io.netty.handler.codec.compression.Bzip2DivSufSort.StackEntry
-
- stackTrace() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor.DefaultThreadProperties
-
- 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.
- START_TIME - Static variable in class io.netty.util.concurrent.ScheduledFutureTask
-
- started - Variable in class io.netty.handler.codec.compression.SnappyFrameDecoder
-
- started - Variable in class io.netty.handler.codec.compression.SnappyFrameEncoder
-
- started - Variable in class io.netty.util.concurrent.GlobalEventExecutor
-
- started - Static variable in class io.netty.util.ThreadDeathWatcher
-
- startIdx - Variable in class io.netty.resolver.dns.RotationalDnsServerAddresses
-
- startIdxUpdater - Static variable in class io.netty.resolver.dns.RotationalDnsServerAddresses
-
- startIndex - Variable in class io.netty.buffer.ByteBufInputStream
-
- startIndex - Variable in class io.netty.buffer.ByteBufOutputStream
-
- startOffset - Variable in class io.netty.handler.stream.ChunkedFile
-
- startOffset() - Method in class io.netty.handler.stream.ChunkedFile
-
Returns the offset in the file where the transfer began.
- startOffset - Variable in class io.netty.handler.stream.ChunkedNioFile
-
- 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.
- startThread() - Method in class io.netty.util.concurrent.GlobalEventExecutor
-
- startThread() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- startTime - Variable in class io.netty.util.HashedWheelTimer
-
- startTimeInitialized - Variable in class io.netty.util.HashedWheelTimer
-
- startTls - Variable in class io.netty.handler.ssl.SslContext
-
- startTls - Variable in class io.netty.handler.ssl.SslContextBuilder
-
- startTls(boolean) - Method in class io.netty.handler.ssl.SslContextBuilder
-
true
if the first write request shouldn't be encrypted.
- startTls - Variable in class io.netty.handler.ssl.SslHandler
-
- STAT - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
-
- state - Variable in class io.netty.channel.embedded.EmbeddedChannel
-
- State() - Constructor for enum io.netty.channel.embedded.EmbeddedChannel.State
-
- state - Variable in class io.netty.channel.local.LocalChannel
-
- State() - Constructor for enum io.netty.channel.local.LocalChannel.State
-
- state - Variable in class io.netty.channel.local.LocalServerChannel
-
- state - Variable in class io.netty.channel.unix.FileDescriptor
-
Bit map = [Output Shutdown | Input Shutdown | Closed]
- State() - Constructor for enum io.netty.handler.codec.compression.Bzip2Decoder.State
-
- State() - Constructor for enum io.netty.handler.codec.compression.Bzip2Encoder.State
-
- State() - Constructor for enum io.netty.handler.codec.compression.FastLzFrameDecoder.State
-
- state - Variable in class io.netty.handler.codec.compression.Snappy
-
- State() - Constructor for enum io.netty.handler.codec.compression.Snappy.State
-
- state - Variable in class io.netty.handler.codec.json.JsonObjectDecoder
-
- state - Variable in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheDecoder
-
- State() - Constructor for enum io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheDecoder.State
-
- state - Variable in class io.netty.handler.codec.ProtocolDetectionResult
-
- state() - Method in class io.netty.handler.codec.ProtocolDetectionResult
-
- state - Variable in class io.netty.handler.codec.redis.RedisDecoder
-
- State() - Constructor for enum io.netty.handler.codec.redis.RedisDecoder.State
-
- state - Variable in class io.netty.handler.codec.ReplayingDecoder
-
- 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() - Constructor for enum io.netty.handler.codec.socks.SocksAuthRequestDecoder.State
-
- State() - Constructor for enum io.netty.handler.codec.socks.SocksAuthResponseDecoder.State
-
- State() - Constructor for enum io.netty.handler.codec.socks.SocksCmdRequestDecoder.State
-
- State() - Constructor for enum io.netty.handler.codec.socks.SocksCmdResponseDecoder.State
-
- State() - Constructor for enum io.netty.handler.codec.socks.SocksInitRequestDecoder.State
-
- State() - Constructor for enum io.netty.handler.codec.socks.SocksInitResponseDecoder.State
-
- State() - Constructor for enum io.netty.handler.codec.socksx.v4.Socks4ClientDecoder.State
-
- State() - Constructor for enum io.netty.handler.codec.socksx.v4.Socks4ServerDecoder.State
-
- State() - Constructor for enum io.netty.handler.codec.socksx.v5.Socks5CommandRequestDecoder.State
-
- State() - Constructor for enum io.netty.handler.codec.socksx.v5.Socks5CommandResponseDecoder.State
-
- State() - Constructor for enum io.netty.handler.codec.socksx.v5.Socks5InitialRequestDecoder.State
-
- State() - Constructor for enum io.netty.handler.codec.socksx.v5.Socks5InitialResponseDecoder.State
-
- State() - Constructor for enum io.netty.handler.codec.socksx.v5.Socks5PasswordAuthRequestDecoder.State
-
- State() - Constructor for enum io.netty.handler.codec.socksx.v5.Socks5PasswordAuthResponseDecoder.State
-
- State() - Constructor for enum io.netty.handler.codec.stomp.StompSubframeDecoder.State
-
- state - Variable in class io.netty.handler.timeout.IdleStateEvent
-
- state() - Method in class io.netty.handler.timeout.IdleStateEvent
-
Returns the idle state.
- state - Variable in class io.netty.handler.timeout.IdleStateHandler
-
- state - Variable in class io.netty.util.concurrent.NonStickyEventExecutorGroup.NonStickyOrderedEventExecutor
-
- state() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor.DefaultThreadProperties
-
- state - Variable in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- state() - Method in interface io.netty.util.concurrent.ThreadProperties
-
- state - Variable in class io.netty.util.HashedWheelTimer.HashedWheelTimeout
-
- state() - Method in class io.netty.util.HashedWheelTimer.HashedWheelTimeout
-
- STATE_ALL_MASK - Static variable in class io.netty.channel.unix.FileDescriptor
-
- STATE_CALLING_CHILD_DECODE - Static variable in class io.netty.handler.codec.ByteToMessageDecoder
-
- STATE_CLOSED_MASK - Static variable in class io.netty.channel.unix.FileDescriptor
-
- STATE_HANDLER_REMOVED_PENDING - Static variable in class io.netty.handler.codec.ByteToMessageDecoder
-
- STATE_INIT - Static variable in class io.netty.handler.codec.ByteToMessageDecoder
-
- STATE_INPUT_SHUTDOWN_MASK - Static variable in class io.netty.channel.unix.FileDescriptor
-
- STATE_OUTPUT_SHUTDOWN_MASK - Static variable in class io.netty.channel.unix.FileDescriptor
-
- STATE_UPDATER - Static variable in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- STATE_UPDATER - Static variable in class io.netty.util.HashedWheelTimer.HashedWheelTimeout
-
- stateUpdater - Static variable in class io.netty.channel.unix.FileDescriptor
-
- 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 - Variable in class io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheResponse
-
- status() - Method in class io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheResponse
-
- status - Variable in class io.netty.handler.codec.socksx.v4.DefaultSocks4CommandResponse
-
- status() - Method in class io.netty.handler.codec.socksx.v4.DefaultSocks4CommandResponse
-
- status() - Method in interface io.netty.handler.codec.socksx.v4.Socks4CommandResponse
-
Returns the status of this response.
- status - Variable in class io.netty.handler.codec.socksx.v5.DefaultSocks5CommandResponse
-
- status() - Method in class io.netty.handler.codec.socksx.v5.DefaultSocks5CommandResponse
-
- status - Variable in class io.netty.handler.codec.socksx.v5.DefaultSocks5PasswordAuthResponse
-
- status() - Method in class io.netty.handler.codec.socksx.v5.DefaultSocks5PasswordAuthResponse
-
- status() - Method in interface io.netty.handler.codec.socksx.v5.Socks5CommandResponse
-
Returns the status of this response.
- status() - Method in interface io.netty.handler.codec.socksx.v5.Socks5PasswordAuthResponse
-
Returns the status of this response.
- stayClosed - Variable in class io.netty.channel.group.DefaultChannelGroup
-
- StompCommand - Enum in io.netty.handler.codec.stomp
-
STOMP command
- StompCommand() - Constructor for enum io.netty.handler.codec.stomp.StompCommand
-
- StompConstants - Class in io.netty.handler.codec.stomp
-
- StompConstants() - Constructor for class io.netty.handler.codec.stomp.StompConstants
-
- 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
-
- 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
-
- 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
-
- StompSubframeDecoder.State - Enum in io.netty.handler.codec.stomp
-
- StompSubframeEncoder - Class in io.netty.handler.codec.stomp
-
- 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.
- str - Variable in class io.netty.buffer.EmptyByteBuf
-
- stream() - Method in class io.netty.resolver.dns.DnsServerAddresses
-
Starts a new infinite stream of DNS server addresses.
- stream() - Method in class io.netty.resolver.dns.RotationalDnsServerAddresses
-
- stream - Variable in class io.netty.resolver.dns.SingletonDnsServerAddresses
-
- stream() - Method in class io.netty.resolver.dns.SingletonDnsServerAddresses
-
- STREAM_START - Static variable in class io.netty.handler.codec.compression.SnappyFrameEncoder
-
All streams should start with the "Stream identifier", containing chunk
type 0xff, a length field of 0x6, and 'sNaPpY' in ASCII.
- streamArrayElements - Variable in class io.netty.handler.codec.json.JsonObjectDecoder
-
- streamBlockSize - Variable in class io.netty.handler.codec.compression.Bzip2Encoder
-
The declared maximum block size of the stream (before final run-length decoding).
- streamCRC - Variable in class io.netty.handler.codec.compression.Bzip2Decoder
-
The merged CRC of all blocks decompressed so far.
- streamCRC - Variable in class io.netty.handler.codec.compression.Bzip2Encoder
-
The merged CRC of all blocks compressed so far.
- streamIdentifier - Variable in class io.netty.channel.sctp.SctpMessage
-
- streamIdentifier() - Method in class io.netty.channel.sctp.SctpMessage
-
Return the stream-identifier
- streamIdentifier - Variable in class io.netty.handler.codec.sctp.SctpInboundByteStreamHandler
-
- streamIdentifier - Variable in class io.netty.handler.codec.sctp.SctpOutboundByteStreamHandler
-
- streamNumber() - Method in class com.sun.nio.sctp.MessageInfo
-
- streamNumber(int) - Method in class com.sun.nio.sctp.MessageInfo
-
- strError(int) - Static method in class io.netty.channel.unix.ErrorsStaticallyReferencedJniMethods
-
- string - Variable in class io.netty.util.AsciiString
-
- stringBuilder() - Method in class io.netty.util.internal.InternalThreadLocalMap
-
- stringBuilder - Variable in class io.netty.util.internal.UnpaddedInternalThreadLocalMap
-
- 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.
- StringEntry(Map.Entry<CharSequence, CharSequence>) - Constructor for class io.netty.handler.codec.HeadersUtils.StringEntry
-
- StringEntryIterator(Iterator<Map.Entry<CharSequence, CharSequence>>) - Constructor for class io.netty.handler.codec.HeadersUtils.StringEntryIterator
-
- StringIterator(Iterator<T>) - Constructor for class io.netty.handler.codec.HeadersUtils.StringIterator
-
- stringToErrors - Variable in class io.netty.handler.codec.redis.FixedRedisMessagePool
-
- stringToSimpleStrings - Variable in class io.netty.handler.codec.redis.FixedRedisMessagePool
-
- StringUtil - Class in io.netty.util.internal
-
String utility class.
- StringUtil() - Constructor for class io.netty.util.internal.StringUtil
-
- stripDelimiter - Variable in class io.netty.handler.codec.DelimiterBasedFrameDecoder
-
- stripDelimiter - Variable in class io.netty.handler.codec.LineBasedFrameDecoder
-
- strVal - Variable in class io.netty.channel.AbstractChannel
-
- strVal - Variable in class io.netty.channel.local.LocalAddress
-
- strVal - Variable in class io.netty.resolver.dns.DefaultDnsServerAddresses
-
- strValActive - Variable in class io.netty.channel.AbstractChannel
-
Cache for the string representation of this channel
- 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
-
- SUBMITTED - Static variable in class io.netty.util.concurrent.NonStickyEventExecutorGroup.NonStickyOrderedEventExecutor
-
- 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.AbstractTrafficShapingHandler
-
- submitWrite(ChannelHandlerContext, Object, long, long, long, ChannelPromise) - Method in class io.netty.handler.traffic.ChannelTrafficShapingHandler
-
- submitWrite(ChannelHandlerContext, Object, long, long, long, ChannelPromise) - Method in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
-
- submitWrite(ChannelHandlerContext, Object, long, long, long, ChannelPromise) - Method in class io.netty.handler.traffic.GlobalTrafficShapingHandler
-
- SUBNEGOTIATION_VERSION - Static variable in class io.netty.handler.codec.socks.SocksAuthRequest
-
- SUBNEGOTIATION_VERSION - Static variable in class io.netty.handler.codec.socks.SocksAuthResponse
-
- subnetMask - Variable in class io.netty.handler.ipfilter.IpSubnetFilterRule.Ip4SubnetFilterRule
-
- subnetMask - Variable in class io.netty.handler.ipfilter.IpSubnetFilterRule.Ip6SubnetFilterRule
-
- subpageIdx(int) - Method in class io.netty.buffer.PoolChunk
-
- SubPageMemoryRegionCache(int, PoolArena.SizeClass) - Constructor for class io.netty.buffer.PoolThreadCache.SubPageMemoryRegionCache
-
- subPageMetricList(PoolSubpage<?>[]) - Static method in class io.netty.buffer.PoolArena
-
- subpageOverflowMask - Variable in class io.netty.buffer.PoolArena
-
- subpageOverflowMask - Variable in class io.netty.buffer.PoolChunk
-
Used to determine if the requested capacity is equal to or greater than pageSize.
- subpages - Variable in class io.netty.buffer.PoolChunk
-
- subscribe() - Static method in class io.netty.handler.codec.mqtt.MqttMessageBuilders
-
- SubscribeBuilder() - Constructor for class io.netty.handler.codec.mqtt.MqttMessageBuilders.SubscribeBuilder
-
- SUBSCRIPTION - Static variable in interface io.netty.handler.codec.stomp.StompHeaders
-
- subscriptions - Variable in class io.netty.handler.codec.mqtt.MqttMessageBuilders.SubscribeBuilder
-
- 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).
- subStringSort(int, int, int, int[], int, int, int, boolean, int) - Method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- subStringUnsafe(int, int) - Method in class io.netty.util.internal.AppendableCharSequence
-
Create a new String
from the given start to end.
- SucceededChannelFuture - Class in io.netty.channel
-
- SucceededChannelFuture(Channel, EventExecutor) - Constructor for class io.netty.channel.SucceededChannelFuture
-
Creates a new instance.
- succeededFuture - Variable in class io.netty.channel.AbstractChannelHandlerContext
-
- succeededFuture - Variable in class io.netty.channel.DefaultChannelPipeline
-
- SucceededFuture<V> - Class in io.netty.util.concurrent
-
- 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.codec.socksx.v4.Socks4CommandStatus
-
- SUCCESS - Static variable in class io.netty.handler.codec.socksx.v5.Socks5CommandStatus
-
- SUCCESS - Static variable in class io.netty.handler.codec.socksx.v5.Socks5PasswordAuthStatus
-
- SUCCESS - Static variable in class io.netty.handler.ssl.SslCloseCompletionEvent
-
- SUCCESS - Static variable in class io.netty.handler.ssl.SslHandshakeCompletionEvent
-
- success(long) - Method in class io.netty.handler.stream.ChunkedWriteHandler.PendingWrite
-
- SUCCESS - Static variable in class io.netty.util.concurrent.DefaultPromise
-
- successAndRecycle() - Method in class io.netty.util.internal.PendingWrite
-
Mark the underlying
Promise
successfully and recycle this instance.
- successCount - Variable in class io.netty.channel.group.DefaultChannelGroupFuture
-
- SUPER - Static variable in class io.netty.util.internal.logging.JdkLogger
-
- SUPPORTED_CIPHERS - Static variable in class io.netty.handler.ssl.JdkSslContext
-
- SupportedCipherSuiteFilter - Class in io.netty.handler.ssl
-
This class will filter all requested ciphers out that are not supported by the current SSLEngine
.
- SupportedCipherSuiteFilter() - Constructor for class io.netty.handler.ssl.SupportedCipherSuiteFilter
-
- supportedOptions() - Method in class com.sun.nio.sctp.SctpChannel
-
- supportedProtocols - Variable in class io.netty.handler.ssl.ApplicationProtocolConfig
-
- supportedProtocols() - Method in class io.netty.handler.ssl.ApplicationProtocolConfig
-
The application level protocols supported.
- supportedProtocols - Variable in class io.netty.handler.ssl.JdkBaseApplicationProtocolNegotiator.NoFailProtocolSelectionListener
-
- supportedProtocols - Variable in class io.netty.handler.ssl.JdkBaseApplicationProtocolNegotiator.NoFailProtocolSelector
-
- supportsAAAARecords - Variable in class io.netty.resolver.dns.DnsNameResolver
-
- supportsAAAARecords() - Method in class io.netty.resolver.dns.DnsNameResolver
-
- supportsARecords - Variable in class io.netty.resolver.dns.DnsNameResolver
-
- supportsARecords() - Method in class io.netty.resolver.dns.DnsNameResolver
-
- supportsWindowSizeAndMemLevel - Static variable in class io.netty.handler.codec.compression.ZlibCodecFactory
-
- SuppressForbidden - Annotation Type in io.netty.util
-
Annotation to suppress forbidden-apis errors inside a whole class, a method, or a field.
- suppressRead - Variable in class io.netty.handler.ssl.AbstractSniHandler
-
- swapElements(int[], int, int[], int) - Static method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- 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.
- swapped - Variable in class io.netty.buffer.EmptyByteBuf
-
- swapped - Variable in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- swappedBuf - Variable in class io.netty.buffer.UnreleasableByteBuf
-
- SwappedByteBuf - Class in io.netty.buffer
-
- 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.
- symbolMTF - Variable in class io.netty.handler.codec.compression.Bzip2BlockDecompressor
-
Table for Move To Front transformations.
- 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.CompleteChannelFuture
-
- sync() - Method in class io.netty.channel.DefaultChannelProgressivePromise
-
- sync() - Method in class io.netty.channel.DefaultChannelPromise
-
- sync() - Method in class io.netty.channel.FailedChannelFuture
-
- sync() - Method in interface io.netty.channel.group.ChannelGroupFuture
-
- sync() - Method in class io.netty.channel.group.DefaultChannelGroupFuture
-
- sync() - Method in class io.netty.channel.group.VoidChannelGroupFuture
-
- sync() - Method in class io.netty.channel.VoidChannelPromise
-
- 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.CompleteChannelFuture
-
- syncUninterruptibly() - Method in class io.netty.channel.DefaultChannelProgressivePromise
-
- syncUninterruptibly() - Method in class io.netty.channel.DefaultChannelPromise
-
- syncUninterruptibly() - Method in class io.netty.channel.FailedChannelFuture
-
- syncUninterruptibly() - Method in interface io.netty.channel.group.ChannelGroupFuture
-
- syncUninterruptibly() - Method in class io.netty.channel.group.DefaultChannelGroupFuture
-
- syncUninterruptibly() - Method in class io.netty.channel.group.VoidChannelGroupFuture
-
- syncUninterruptibly() - Method in class io.netty.channel.VoidChannelPromise
-
- 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
-
- sysctlGetInt(String) - Static method in class io.netty.util.NetUtil
-
This will execute
sysctl with the
sysctlKey
which is expected to return the numeric value for for
sysctlKey
.
- SystemPropertyUtil - Class in io.netty.util.internal
-
A collection of utility methods to retrieve and parse the values of the Java system properties.
- SystemPropertyUtil() - Constructor for class io.netty.util.internal.SystemPropertyUtil
-
- T - Variable in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- t - Variable in class io.netty.util.concurrent.SingleThreadEventExecutor.DefaultThreadProperties
-
- 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
-
- tableCodeLengths - Variable in class io.netty.handler.codec.compression.Bzip2HuffmanStageDecoder
-
The Canonical Huffman code lengths for each table.
- tableMTF - Variable in class io.netty.handler.codec.compression.Bzip2HuffmanStageDecoder
-
Table for Move To Front transformations.
- tag - Variable in class io.netty.handler.codec.compression.Snappy
-
- tail - Variable in class io.netty.channel.DefaultChannelPipeline
-
- tail - Variable in class io.netty.channel.PendingWriteQueue
-
- tail - Variable in class io.netty.util.HashedWheelTimer.HashedWheelBucket
-
- tail - Variable in class io.netty.util.Recycler.WeakOrderQueue
-
- TAIL_NAME - Static variable in class io.netty.channel.DefaultChannelPipeline
-
- TailContext(DefaultChannelPipeline) - Constructor for class io.netty.channel.DefaultChannelPipeline.TailContext
-
- tailEntry - Variable in class io.netty.channel.ChannelOutboundBuffer
-
- tailTasks - Variable in class io.netty.channel.SingleThreadEventLoop
-
- takeTask() - Method in class io.netty.util.concurrent.GlobalEventExecutor
-
Take the next Runnable
from the task queue and so will block if no task is currently present.
- 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 - Variable in class io.netty.util.concurrent.PromiseTask.RunnableAdapter
-
- task - Variable in class io.netty.util.concurrent.PromiseTask
-
- task - Variable in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor.NonNotifyRunnable
-
- task - Variable in class io.netty.util.HashedWheelTimer.HashedWheelTimeout
-
- task() - Method in class io.netty.util.HashedWheelTimer.HashedWheelTimeout
-
- task - Variable in class io.netty.util.ThreadDeathWatcher.Entry
-
- task() - Method in interface io.netty.util.Timeout
-
Returns the
TimerTask
which is associated with this handle.
- taskQueue - Variable in class io.netty.util.concurrent.GlobalEventExecutor
-
- taskQueue - Variable in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- taskRunner - Variable in class io.netty.util.concurrent.GlobalEventExecutor
-
- TaskRunner() - Constructor for class io.netty.util.concurrent.GlobalEventExecutor.TaskRunner
-
- tasks - Variable in class io.netty.channel.embedded.EmbeddedEventLoop
-
- tasks - Variable in class io.netty.util.concurrent.NonStickyEventExecutorGroup.NonStickyOrderedEventExecutor
-
- TCP_NODELAY - Static variable in class io.netty.channel.ChannelOption
-
- TCP_NOPUSH - Static variable in class io.netty.channel.kqueue.KQueueChannelOption
-
- tearDown() - Method in class io.netty.channel.unix.tests.SocketTest
-
- terminate() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- terminated - Variable in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- terminatedChildren - Variable in class io.netty.util.concurrent.MultithreadEventExecutorGroup
-
- terminationFuture() - Method in class io.netty.channel.embedded.EmbeddedEventLoop
-
- terminationFuture - Variable in class io.netty.channel.ThreadPerChannelEventLoopGroup
-
- terminationFuture() - Method in class io.netty.channel.ThreadPerChannelEventLoopGroup
-
- terminationFuture() - Method in interface io.netty.util.concurrent.EventExecutorGroup
-
- terminationFuture - Variable in class io.netty.util.concurrent.GlobalEventExecutor
-
- terminationFuture() - Method in class io.netty.util.concurrent.GlobalEventExecutor
-
- terminationFuture - Variable in class io.netty.util.concurrent.ImmediateEventExecutor
-
- terminationFuture() - Method in class io.netty.util.concurrent.ImmediateEventExecutor
-
- terminationFuture - Variable in class io.netty.util.concurrent.MultithreadEventExecutorGroup
-
- terminationFuture() - Method in class io.netty.util.concurrent.MultithreadEventExecutorGroup
-
- terminationFuture() - Method in class io.netty.util.concurrent.NonStickyEventExecutorGroup.NonStickyOrderedEventExecutor
-
- terminationFuture() - Method in class io.netty.util.concurrent.NonStickyEventExecutorGroup
-
- terminationFuture - Variable in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- terminationFuture() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- terminationFuture - Variable in class io.netty.util.concurrent.UnorderedThreadPoolEventExecutor
-
- 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
-
- text - Variable in class io.netty.handler.codec.dns.DnsOpCode
-
- text - Variable in class io.netty.handler.codec.dns.DnsRecordType
-
- text - Variable in class io.netty.handler.codec.dns.DnsResponseCode
-
- text - Variable in class io.netty.handler.codec.socksx.v4.Socks4CommandStatus
-
- text - Variable in class io.netty.handler.codec.socksx.v4.Socks4CommandType
-
- text - Variable in class io.netty.handler.codec.socksx.v5.Socks5AddressType
-
- text - Variable in class io.netty.handler.codec.socksx.v5.Socks5AuthMethod
-
- text - Variable in class io.netty.handler.codec.socksx.v5.Socks5CommandStatus
-
- text - Variable in class io.netty.handler.codec.socksx.v5.Socks5CommandType
-
- text - Variable in class io.netty.handler.codec.socksx.v5.Socks5PasswordAuthStatus
-
- TEXT_PREFIX - Static variable in class io.netty.handler.codec.haproxy.HAProxyMessageDecoder
-
- thisT() - Method in class io.netty.handler.codec.DefaultHeaders
-
- thisT() - Method in class io.netty.handler.codec.EmptyHeaders
-
- thread - Variable in class io.netty.util.concurrent.GlobalEventExecutor
-
- thread - Variable in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- thread - Variable in class io.netty.util.Recycler.Stack
-
- thread - Variable in class io.netty.util.ThreadDeathWatcher.Entry
-
- THREAD_LOCAL_BUFFER_SIZE - Static variable in class io.netty.buffer.ByteBufUtil
-
- threadCache - Variable in class io.netty.buffer.PooledByteBufAllocator
-
- threadCache() - Method in class io.netty.buffer.PooledByteBufAllocator
-
- ThreadDeathWatcher - Class in io.netty.util
-
Checks if a thread is alive periodically and runs a task when a thread dies.
- ThreadDeathWatcher() - Constructor for class io.netty.util.ThreadDeathWatcher
-
- ThreadDeathWatcher.Entry - Class in io.netty.util
-
- ThreadDeathWatcher.Watcher - Class in io.netty.util
-
- threadFactory - Variable in class io.netty.util.concurrent.GlobalEventExecutor
-
- threadFactory - Variable in class io.netty.util.concurrent.ThreadPerTaskExecutor
-
- threadFactory - Static variable in class io.netty.util.ThreadDeathWatcher
-
- threadGroup - Variable in class io.netty.util.concurrent.DefaultThreadFactory
-
- threadLocal - Variable in class io.netty.util.Recycler
-
- threadLocalCapacity() - Method in class io.netty.util.Recycler
-
- threadLocalDirectBuffer() - Static method in class io.netty.buffer.ByteBufUtil
-
Returns a cached thread-local direct buffer, if available.
- ThreadLocalDirectByteBuf(Recycler.Handle<ByteBufUtil.ThreadLocalDirectByteBuf>) - Constructor for class io.netty.buffer.ByteBufUtil.ThreadLocalDirectByteBuf
-
- ThreadLocalInsecureRandom - Class in io.netty.handler.ssl.util
-
- ThreadLocalInsecureRandom() - Constructor for class io.netty.handler.ssl.util.ThreadLocalInsecureRandom
-
- threadLocalMap - Variable in class io.netty.util.concurrent.FastThreadLocalThread
-
- 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.
- ThreadLocalRandom() - Constructor for class io.netty.util.internal.ThreadLocalRandom
-
Constructor called only by localRandom.initialValue.
- threadLocalSize() - Method in class io.netty.util.Recycler
-
- ThreadLocalUnsafeDirectByteBuf(Recycler.Handle<ByteBufUtil.ThreadLocalUnsafeDirectByteBuf>) - Constructor for class io.netty.buffer.ByteBufUtil.ThreadLocalUnsafeDirectByteBuf
-
- threadLock - Variable in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- ThreadPerChannelEventLoop - Class in io.netty.channel
-
- ThreadPerChannelEventLoop(ThreadPerChannelEventLoopGroup) - Constructor for class io.netty.channel.ThreadPerChannelEventLoop
-
- ThreadPerChannelEventLoopGroup - Class in io.netty.channel
-
- ThreadPerChannelEventLoopGroup() - Constructor for class io.netty.channel.ThreadPerChannelEventLoopGroup
-
- 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 - Variable in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- threadProperties() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- ThreadProperties - Interface in io.netty.util.concurrent
-
Expose details for a Thread
.
- throwable - Variable in class io.netty.util.internal.logging.FormattingTuple
-
- ThrowableUtil - Class in io.netty.util.internal
-
- ThrowableUtil() - Constructor for class io.netty.util.internal.ThrowableUtil
-
- throwConnectException(String, Errors.NativeConnectException, int) - Static method in class io.netty.channel.unix.Errors
-
- throwException(Throwable) - Static method in class io.netty.util.internal.PlatformDependent
-
Raises an exception bypassing compiler checks for checked exceptions.
- throwException(Throwable) - Static method in class io.netty.util.internal.PlatformDependent0
-
- throwException0(Throwable) - Static method in class io.netty.util.internal.PlatformDependent
-
- throwIfInEventLoop(String) - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- tick - Variable in class io.netty.util.HashedWheelTimer.Worker
-
- tickDuration - Variable in class io.netty.util.HashedWheelTimer
-
- ticksInNanos() - Method in class io.netty.handler.timeout.IdleStateHandler
-
This method is visible for testing!
- timeFound - Variable in class io.netty.handler.codec.DateFormatter
-
- Timeout - Interface in io.netty.util
-
- TIMEOUT_EXCEPTION - Static variable in class io.netty.channel.pool.FixedChannelPool
-
- TimeoutException - Exception in io.netty.handler.timeout
-
A
TimeoutException
when no data was either read or written within a
certain period of time.
- TimeoutException() - Constructor for exception io.netty.handler.timeout.TimeoutException
-
- timeoutFuture - Variable in class io.netty.channel.pool.FixedChannelPool.AcquireTask
-
- timeoutFuture - Variable in class io.netty.resolver.dns.DnsQueryContext
-
- timeoutNanos - Variable in class io.netty.handler.timeout.WriteTimeoutHandler
-
- timeouts - Variable in class io.netty.util.HashedWheelTimer
-
- timeoutTask - Variable in class io.netty.channel.pool.FixedChannelPool
-
- TimeoutTask() - Constructor for class io.netty.channel.pool.FixedChannelPool.TimeoutTask
-
- timer - Variable in class io.netty.util.HashedWheelTimer.HashedWheelTimeout
-
- timer() - Method in class io.netty.util.HashedWheelTimer.HashedWheelTimeout
-
- timer() - Method in interface io.netty.util.Timeout
-
Returns the
Timer
that created this handle.
- Timer - Interface in io.netty.util
-
Schedules
TimerTask
s for one-time future execution in a background
thread.
- TimerTask - Interface in io.netty.util
-
- TIMESTAMP_LEN - Static variable in class io.netty.channel.DefaultChannelId
-
- timeToLive - Variable in class io.netty.handler.codec.dns.AbstractDnsRecord
-
- 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 - Variable in class io.netty.buffer.PooledByteBufAllocator
-
- tinyCacheSize() - Method in class io.netty.buffer.PooledByteBufAllocator
-
- tinyCacheSize() - Method in class io.netty.buffer.PooledByteBufAllocatorMetric
-
Return the size of the tiny cache.
- tinyIdx(int) - Static method in class io.netty.buffer.PoolArena
-
- tinySubPageDirectCaches - Variable in class io.netty.buffer.PoolThreadCache
-
- tinySubPageHeapCaches - Variable in class io.netty.buffer.PoolThreadCache
-
- tinySubpagePools - Variable in class io.netty.buffer.PoolArena
-
- tinySubpages() - Method in class io.netty.buffer.PoolArena
-
- tinySubpages() - Method in interface io.netty.buffer.PoolArenaMetric
-
- 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..
- tlmd - Static variable in class io.netty.handler.ssl.util.FingerprintTrustManagerFactory
-
- 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).
- tlvs - Variable in class io.netty.handler.codec.haproxy.HAProxyMessage
-
- tlvs() - Method in class io.netty.handler.codec.haproxy.HAProxyMessage
-
Returns a list of
HAProxyTLV
or an empty list if no TLVs are present.
- tlvs - Variable in class io.netty.handler.codec.haproxy.HAProxySSLTLV
-
- tm - Variable in class io.netty.handler.ssl.util.FingerprintTrustManagerFactory
-
- tm - Static variable in class io.netty.handler.ssl.util.InsecureTrustManagerFactory
-
- tmpdir() - Static method in class io.netty.util.internal.NativeLibraryLoader
-
- TMPDIR - Static variable in class io.netty.util.internal.PlatformDependent
-
- tmpdir() - Static method in class io.netty.util.internal.PlatformDependent
-
Returns the temporary directory.
- tmpdir0() - Static method in class io.netty.util.internal.PlatformDependent
-
- tmpNioBuf - Variable in class io.netty.buffer.PooledByteBuf
-
- tmpNioBuf - Variable in class io.netty.buffer.ReadOnlyByteBufferBuf
-
- tmpNioBuf - Variable in class io.netty.buffer.UnpooledDirectByteBuf
-
- tmpNioBuf - Variable in class io.netty.buffer.UnpooledHeapByteBuf
-
- tmpNioBuf - Variable in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
-
- tmpPacket - Variable in class io.netty.channel.socket.oio.OioDatagramChannel
-
- 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
.
- toAddressString(byte[], int, boolean) - Static method in class io.netty.util.NetUtil
-
- toApplicationProtocolConfig(Iterable<String>) - Static method in class io.netty.handler.ssl.SslContext
-
- 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.handler.codec.HeadersUtils.DelegatingStringSet
-
- toArray(X[]) - Method in class io.netty.handler.codec.HeadersUtils.DelegatingStringSet
-
- toArray(Iterable<DnsRecord>, boolean) - Static method in class io.netty.resolver.dns.DnsNameResolver
-
- 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
-
- toAsciiStringArray(String[]) - Static method in class io.netty.util.AsciiString
-
- toBase64(ByteBufAllocator, ByteBuf) - Static method in class io.netty.handler.ssl.SslUtils
-
- 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.
- toByteBuffer(ByteBuf, int, int) - Static method in class io.netty.handler.ssl.SslHandler
-
- toByteIndex(int) - Method in class io.netty.buffer.CompositeByteBuf
-
- toByteIndex(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- toCallable(Runnable, T) - Static method in class io.netty.util.concurrent.PromiseTask
-
- 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.
- toCompactAddress(Inet4Address) - Static method in class io.netty.resolver.dns.DnsQueryContextManager
-
- toComponentIndex(int) - Method in class io.netty.buffer.CompositeByteBuf
-
Return the index for the given offset
- toComponentIndex(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- toDirectory(String) - Static method in class io.netty.util.internal.NativeLibraryLoader
-
- toDirectory(String) - Static method in class io.netty.util.internal.PlatformDependent
-
- toExternal(T) - Static method in class io.netty.util.collection.ByteObjectHashMap
-
- toExternal(T) - Static method in class io.netty.util.collection.CharObjectHashMap
-
- toExternal(T) - Static method in class io.netty.util.collection.IntObjectHashMap
-
- toExternal(T) - Static method in class io.netty.util.collection.LongObjectHashMap
-
- toExternal(T) - Static method in class io.netty.util.collection.ShortObjectHashMap
-
- toFingerprintArray(Iterable<String>) - Static method in class io.netty.handler.ssl.util.FingerprintTrustManagerFactory
-
- toFullRequest(BinaryMemcacheRequest, ByteBuf) - Static method in class io.netty.handler.codec.memcache.binary.BinaryMemcacheObjectAggregator
-
- toFullResponse(BinaryMemcacheResponse, ByteBuf) - Static method in class io.netty.handler.codec.memcache.binary.BinaryMemcacheObjectAggregator
-
- toHandle(int) - Method in class io.netty.buffer.PoolSubpage
-
- 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 class io.netty.channel.AbstractChannelHandlerContext
-
- toHintString() - Method in interface io.netty.util.ResourceLeakHint
-
Returns a human-readable message that potentially enables easier resource leak tracking.
- toInt(byte) - Static method in class io.netty.handler.codec.base64.Base64
-
- toIntBE(short) - Static method in class io.netty.handler.codec.base64.Base64
-
- toIntBE(int) - Static method in class io.netty.handler.codec.base64.Base64
-
- toInternal(T) - Static method in class io.netty.util.collection.ByteObjectHashMap
-
- toInternal(T) - Static method in class io.netty.util.collection.CharObjectHashMap
-
- toInternal(T) - Static method in class io.netty.util.collection.IntObjectHashMap
-
- toInternal(T) - Static method in class io.netty.util.collection.LongObjectHashMap
-
- toInternal(T) - Static method in class io.netty.util.collection.ShortObjectHashMap
-
- toInternalLevel() - Method in enum io.netty.handler.logging.LogLevel
-
For internal use only.
- toIntLE(short) - Static method in class io.netty.handler.codec.base64.Base64
-
- toIntLE(int) - Static method in class io.netty.handler.codec.base64.Base64
-
- toIPv4Address(Inet6Address) - Static method in class io.netty.resolver.dns.DnsQueryContextManager
-
- toJava(String, String) - Static method in class io.netty.handler.ssl.CipherSuiteConverter
-
Convert from OpenSSL cipher suite name convention to java cipher suite name convention.
- toJavaBulkCipher(String, boolean) - Static method in class io.netty.handler.ssl.CipherSuiteConverter
-
- toJavaHandshakeAlgo(String, boolean) - Static method in class io.netty.handler.ssl.CipherSuiteConverter
-
- toJavaHmacAlgo(String) - Static method in class io.netty.handler.ssl.CipherSuiteConverter
-
- toJavaUncached(String) - Static method in class io.netty.handler.ssl.CipherSuiteConverter
-
- toLeakAwareBuffer(ByteBuf) - Static method in class io.netty.buffer.AbstractByteBufAllocator
-
- toLeakAwareBuffer(CompositeByteBuf) - Static method in class io.netty.buffer.AbstractByteBufAllocator
-
- toList(Iterable<String>) - Static method in class io.netty.handler.ssl.ApplicationProtocolUtil
-
- toList(int, Iterable<String>) - Static method in class io.netty.handler.ssl.ApplicationProtocolUtil
-
- toList(String...) - Static method in class io.netty.handler.ssl.ApplicationProtocolUtil
-
- toList(int, String...) - Static method in class io.netty.handler.ssl.ApplicationProtocolUtil
-
- toLowerCase() - Method in class io.netty.util.AsciiString
-
Converts the characters in this string to lowercase, using the default Locale.
- toLowerCase(byte) - Static method in class io.netty.util.AsciiString
-
- toLowerCase(char) - Static method in class io.netty.util.AsciiString
-
- 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
-
- toNegotiator(ApplicationProtocolConfig, boolean) - Static method in class io.netty.handler.ssl.JdkSslContext
-
- 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.
- tooLongFrameLength - Variable in class io.netty.handler.codec.DelimiterBasedFrameDecoder
-
- tooLongFrameLength - Variable in class io.netty.handler.codec.LengthFieldBasedFrameDecoder
-
- tooManyChannels - Variable in class io.netty.channel.ThreadPerChannelEventLoopGroup
-
- toOpenSsl(Iterable<String>) - Static method in class io.netty.handler.ssl.CipherSuiteConverter
-
Converts the specified Java cipher suites to the colon-separated OpenSSL cipher suite specification.
- toOpenSsl(String) - Static method in class io.netty.handler.ssl.CipherSuiteConverter
-
Converts the specified Java cipher suite to its corresponding OpenSSL cipher suite name.
- toOpenSslBulkCipher(String) - Static method in class io.netty.handler.ssl.CipherSuiteConverter
-
- toOpenSslHandshakeAlgo(String) - Static method in class io.netty.handler.ssl.CipherSuiteConverter
-
- toOpenSslHmacAlgo(String) - Static method in class io.netty.handler.ssl.CipherSuiteConverter
-
- toOpenSslUncached(String) - Static method in class io.netty.handler.ssl.CipherSuiteConverter
-
- toPEM(ByteBufAllocator, boolean, PrivateKey) - Static method in class io.netty.handler.ssl.PemPrivateKey
-
- toPEM(ByteBufAllocator, boolean, X509Certificate...) - Static method in class io.netty.handler.ssl.PemX509Certificate
-
Creates a
PemEncoded
value from the
X509Certificate
s.
- topic - Variable in class io.netty.handler.codec.mqtt.MqttMessageBuilders.PublishBuilder
-
- TOPIC_WILDCARDS - Static variable in class io.netty.handler.codec.mqtt.MqttCodecUtil
-
- topicFilter - Variable in class io.netty.handler.codec.mqtt.MqttTopicSubscription
-
- topicFilters - Variable in class io.netty.handler.codec.mqtt.MqttMessageBuilders.UnsubscribeBuilder
-
- topicName(String) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.PublishBuilder
-
- topicName - Variable in class io.netty.handler.codec.mqtt.MqttPublishVariableHeader
-
- topicName() - Method in class io.netty.handler.codec.mqtt.MqttPublishVariableHeader
-
- topicName() - Method in class io.netty.handler.codec.mqtt.MqttTopicSubscription
-
- topics - Variable in class io.netty.handler.codec.mqtt.MqttUnsubscribePayload
-
- topics() - Method in class io.netty.handler.codec.mqtt.MqttUnsubscribePayload
-
- topicSubscriptions - Variable in class io.netty.handler.codec.mqtt.MqttSubscribePayload
-
- topicSubscriptions() - Method in class io.netty.handler.codec.mqtt.MqttSubscribePayload
-
- toPoolName(Class<?>) - Static method in class io.netty.util.concurrent.DefaultThreadFactory
-
- toPositiveLongProcessor - Variable in class io.netty.handler.codec.redis.RedisDecoder
-
- ToPositiveLongProcessor() - Constructor for class io.netty.handler.codec.redis.RedisDecoder.ToPositiveLongProcessor
-
- toPrivateKey(File, String) - Static method in class io.netty.handler.ssl.SslContext
-
- toPrivateKey(InputStream, String) - Static method in class io.netty.handler.ssl.SslContext
-
- toPrivateKeyInternal(File, String) - Static method in class io.netty.handler.ssl.SslContext
-
- ToSend(long, Object, ChannelPromise) - Constructor for class io.netty.handler.traffic.ChannelTrafficShapingHandler.ToSend
-
- toSend - Variable in class io.netty.handler.traffic.ChannelTrafficShapingHandler.ToSend
-
- ToSend(long, Object, long, ChannelPromise) - Constructor for class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler.ToSend
-
- toSend - Variable in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler.ToSend
-
- ToSend(long, Object, long, ChannelPromise) - Constructor for class io.netty.handler.traffic.GlobalTrafficShapingHandler.ToSend
-
- toSend - Variable in class io.netty.handler.traffic.GlobalTrafficShapingHandler.ToSend
-
- 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.
- toSSLHandshakeException(Throwable) - Static method in class io.netty.handler.ssl.SslUtils
-
Converts the given exception to a SSLHandshakeException
, if it isn't already.
- 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.AdvancedLeakAwareByteBuf
-
- toString(int, int, Charset) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- toString(Charset) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- toString(int, int, Charset) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.FixedCompositeByteBuf
-
- toString() - Method in class io.netty.buffer.PoolArena
-
- toString() - Method in class io.netty.buffer.PoolChunk
-
- toString() - Method in class io.netty.buffer.PoolChunkList
-
- toString() - Method in class io.netty.buffer.PooledByteBufAllocatorMetric
-
- toString() - Method in class io.netty.buffer.PoolSubpage
-
- 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.buffer.UnpooledByteBufAllocator.UnpooledByteBufAllocatorMetric
-
- toString(Charset) - Method in class io.netty.buffer.WrappedByteBuf
-
- toString(int, int, Charset) - Method in class io.netty.buffer.WrappedByteBuf
-
- toString() - Method in class io.netty.buffer.WrappedByteBuf
-
- toString(Charset) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- toString(int, int, Charset) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- toString() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- toString() - Method in class io.netty.channel.AbstractChannel
-
Returns the String
representation of this channel.
- toString() - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- 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.embedded.EmbeddedChannelId
-
- toString() - Method in class io.netty.channel.embedded.EmbeddedSocketAddress
-
- 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.kqueue.NativeLongArray
-
- toString() - Method in class io.netty.channel.local.LocalAddress
-
- toString() - Method in class io.netty.channel.ReflectiveChannelFactory
-
- toString() - Method in class io.netty.channel.sctp.SctpMessage
-
- 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
-
- toString() - Method in class io.netty.handler.codec.EmptyHeaders
-
- toString() - Method in class io.netty.handler.codec.HeadersUtils.StringEntry
-
- 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(int, int, Charset) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- toString(Charset) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- toString() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- 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.socksx.v4.DefaultSocks4CommandRequest
-
- toString() - Method in class io.netty.handler.codec.socksx.v4.DefaultSocks4CommandResponse
-
- toString() - Method in class io.netty.handler.codec.socksx.v4.Socks4CommandStatus
-
- toString() - Method in class io.netty.handler.codec.socksx.v4.Socks4CommandType
-
- toString() - Method in class io.netty.handler.codec.socksx.v5.DefaultSocks5CommandRequest
-
- toString() - Method in class io.netty.handler.codec.socksx.v5.DefaultSocks5CommandResponse
-
- toString() - Method in class io.netty.handler.codec.socksx.v5.DefaultSocks5InitialRequest
-
- toString() - Method in class io.netty.handler.codec.socksx.v5.DefaultSocks5InitialResponse
-
- toString() - Method in class io.netty.handler.codec.socksx.v5.DefaultSocks5PasswordAuthRequest
-
- toString() - Method in class io.netty.handler.codec.socksx.v5.DefaultSocks5PasswordAuthResponse
-
- toString() - Method in class io.netty.handler.codec.socksx.v5.Socks5AddressType
-
- toString() - Method in class io.netty.handler.codec.socksx.v5.Socks5AuthMethod
-
- toString() - Method in class io.netty.handler.codec.socksx.v5.Socks5CommandStatus
-
- toString() - Method in class io.netty.handler.codec.socksx.v5.Socks5CommandType
-
- toString() - Method in class io.netty.handler.codec.socksx.v5.Socks5PasswordAuthStatus
-
- 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.OpenSslJavaxX509Certificate
-
- toString() - Method in class io.netty.handler.ssl.OpenSslX509Certificate
-
- 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.DefaultDnsServerAddresses
-
- toString() - Method in class io.netty.resolver.dns.DnsCacheEntry
-
- toString() - Method in class io.netty.resolver.dns.InflightNameResolver
-
- toString() - Method in class io.netty.resolver.dns.NoopDnsCache
-
- toString() - Method in class io.netty.resolver.dns.SequentialDnsServerAddressStream
-
- toString(String, int, InetSocketAddress[]) - Static method in class io.netty.resolver.dns.SequentialDnsServerAddressStream
-
- toString() - Method in class io.netty.resolver.dns.ShuffledDnsServerAddressStream
-
- toString() - Method in class io.netty.resolver.dns.SingletonDnsServerAddresses
-
- 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.concurrent.PromiseTask.RunnableAdapter
-
- toString() - Method in class io.netty.util.DomainNameMapping
-
- toString() - Method in class io.netty.util.DomainNameMappingBuilder.ImmutableDomainNameMapping
-
- toString() - Method in class io.netty.util.HashedWheelTimer.HashedWheelTimeout
-
- 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 class io.netty.util.ReferenceCountUtil.ReleasingTask
-
- toString() - Method in class io.netty.util.ResourceLeakDetector.DefaultResourceLeak
-
- toString() - Method in error io.netty.util.Signal
-
- toString() - Method in class io.netty.util.Version
-
- toStringBuilder() - Method in class io.netty.handler.codec.dns.AbstractDnsOptPseudoRrRecord
-
- toStringBuilder() - Method in class io.netty.util.concurrent.DefaultPromise
-
- toStringBuilder() - Method in class io.netty.util.concurrent.PromiseTask
-
- toStringBuilder() - Method in class io.netty.util.concurrent.ScheduledFutureTask
-
- total - Variable in class io.netty.channel.ChannelOutboundBuffer.Entry
-
- total(Object) - Static method in class io.netty.channel.ChannelOutboundBuffer
-
- TOTAL_PENDING_SIZE_UPDATER - Static variable in class io.netty.channel.ChannelOutboundBuffer
-
- totalBodyLength - Variable in class io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
-
- 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 - Variable in class io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator.MaxMessageHandle
-
- totalBytesRead() - Method in class io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator.MaxMessageHandle
-
- totalMessages - Variable in class io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator.MaxMessageHandle
-
- totalPendingSize - Variable in class io.netty.channel.ChannelOutboundBuffer
-
- totalPendingWriteBytes() - Method in class io.netty.channel.ChannelOutboundBuffer
-
- totalTables - Variable in class io.netty.handler.codec.compression.Bzip2HuffmanStageDecoder
-
Total number of used Huffman tables in range 2..6.
- 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.AdvancedLeakAwareByteBuf
-
- touch(Object) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- touch() - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- touch(Object) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.SimpleLeakAwareByteBuf
-
- touch(Object) - Method in class io.netty.buffer.SimpleLeakAwareByteBuf
-
- touch() - Method in class io.netty.buffer.SwappedByteBuf
-
Deprecated.
- touch(Object) - Method in class io.netty.buffer.SwappedByteBuf
-
Deprecated.
- touch() - Method in class io.netty.buffer.UnreleasableByteBuf
-
- touch(Object) - Method in class io.netty.buffer.UnreleasableByteBuf
-
- touch() - Method in class io.netty.buffer.WrappedByteBuf
-
- touch(Object) - Method in class io.netty.buffer.WrappedByteBuf
-
- touch() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- touch(Object) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- 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 - Variable in class io.netty.channel.DefaultChannelPipeline
-
- touch(Object, AbstractChannelHandlerContext) - Method in class io.netty.channel.DefaultChannelPipeline
-
- 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.sctp.SctpMessage
-
- touch(Object) - Method in class io.netty.channel.sctp.SctpMessage
-
- 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.haproxy.HAProxyTLV
-
- touch(Object) - Method in class io.netty.handler.codec.haproxy.HAProxyTLV
-
- 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.ReplayingDecoderByteBuf
-
- touch(Object) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- 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 interface io.netty.handler.ssl.PemEncoded
-
- touch(Object) - Method in interface io.netty.handler.ssl.PemEncoded
-
- 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.PemValue
-
- touch(Object) - Method in class io.netty.handler.ssl.PemValue
-
- 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
-
- touch(T, Object) - Static method in class io.netty.util.ReferenceCountUtil
-
- touch0() - Method in class io.netty.buffer.AbstractDerivedByteBuf
-
Deprecated.
- touch0(Object) - Method in class io.netty.buffer.AbstractDerivedByteBuf
-
Deprecated.
- touch0() - Method in class io.netty.buffer.AbstractPooledDerivedByteBuf.PooledNonRetainedDuplicateByteBuf
-
- touch0(Object) - Method in class io.netty.buffer.AbstractPooledDerivedByteBuf.PooledNonRetainedDuplicateByteBuf
-
- touch0() - Method in class io.netty.buffer.AbstractPooledDerivedByteBuf.PooledNonRetainedSlicedByteBuf
-
- touch0(Object) - Method in class io.netty.buffer.AbstractPooledDerivedByteBuf.PooledNonRetainedSlicedByteBuf
-
- toUnmodifiableList(CharSequence...) - Static method in class io.netty.handler.codec.smtp.SmtpUtils
-
- toUpperCase() - Method in class io.netty.util.AsciiString
-
Converts the characters in this string to uppercase, using the default Locale.
- toUpperCase(byte) - Static method in class io.netty.util.AsciiString
-
- toX509Certificates(File) - Static method in class io.netty.handler.ssl.SslContext
-
- toX509Certificates(InputStream) - Static method in class io.netty.handler.ssl.SslContext
-
- toX509CertificatesInternal(File) - Static method in class io.netty.handler.ssl.SslContext
-
- TPAF_TCP4_BYTE - Static variable in class io.netty.handler.codec.haproxy.HAProxyConstants
-
- TPAF_TCP6_BYTE - Static variable in class io.netty.handler.codec.haproxy.HAProxyConstants
-
- TPAF_UDP4_BYTE - Static variable in class io.netty.handler.codec.haproxy.HAProxyConstants
-
- TPAF_UDP6_BYTE - Static variable in class io.netty.handler.codec.haproxy.HAProxyConstants
-
- TPAF_UNIX_DGRAM_BYTE - Static variable in class io.netty.handler.codec.haproxy.HAProxyConstants
-
- TPAF_UNIX_STREAM_BYTE - Static variable in class io.netty.handler.codec.haproxy.HAProxyConstants
-
- TPAF_UNKNOWN_BYTE - Static variable in class io.netty.handler.codec.haproxy.HAProxyConstants
-
Transport protocol and address family byte constants
- trace(Throwable) - Method in class io.netty.util.internal.logging.AbstractInternalLogger
-
- trace(String) - Method in class io.netty.util.internal.logging.CommonsLogger
-
Deprecated.
Delegates to the Log.trace(Object)
method of the underlying
Log
instance.
- trace(String, Object) - Method in class io.netty.util.internal.logging.CommonsLogger
-
Deprecated.
Delegates to the Log.trace(Object)
method of the underlying
Log
instance.
- trace(String, Object, Object) - Method in class io.netty.util.internal.logging.CommonsLogger
-
Deprecated.
Delegates to the Log.trace(Object)
method of the underlying
Log
instance.
- trace(String, Object...) - Method in class io.netty.util.internal.logging.CommonsLogger
-
Deprecated.
Delegates to the Log.trace(Object)
method of the underlying
Log
instance.
- trace(String, Throwable) - Method in class io.netty.util.internal.logging.CommonsLogger
-
Deprecated.
Delegates to the Log.trace(Object, Throwable)
method of
the underlying Log
instance.
- 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.
- trace(String) - Method in class io.netty.util.internal.logging.JdkLogger
-
Log a message object at level FINEST.
- trace(String, Object) - Method in class io.netty.util.internal.logging.JdkLogger
-
Log a message at level FINEST according to the specified format and
argument.
- trace(String, Object, Object) - Method in class io.netty.util.internal.logging.JdkLogger
-
Log a message at level FINEST according to the specified format and
arguments.
- trace(String, Object...) - Method in class io.netty.util.internal.logging.JdkLogger
-
Log a message at level FINEST according to the specified format and
arguments.
- trace(String, Throwable) - Method in class io.netty.util.internal.logging.JdkLogger
-
Log an exception (throwable) at level FINEST with an accompanying message.
- trace(String) - Method in class io.netty.util.internal.logging.Log4JLogger
-
Log a message object at level TRACE.
- trace(String, Object) - Method in class io.netty.util.internal.logging.Log4JLogger
-
Log a message at level TRACE according to the specified format and
argument.
- trace(String, Object, Object) - Method in class io.netty.util.internal.logging.Log4JLogger
-
Log a message at level TRACE according to the specified format and
arguments.
- trace(String, Object...) - Method in class io.netty.util.internal.logging.Log4JLogger
-
Log a message at level TRACE according to the specified format and
arguments.
- trace(String, Throwable) - Method in class io.netty.util.internal.logging.Log4JLogger
-
Log an exception (throwable) at level TRACE with an accompanying message.
- trace(String) - Method in class io.netty.util.internal.logging.Slf4JLogger
-
- trace(String, Object) - Method in class io.netty.util.internal.logging.Slf4JLogger
-
- trace(String, Object, Object) - Method in class io.netty.util.internal.logging.Slf4JLogger
-
- trace(String, Object...) - Method in class io.netty.util.internal.logging.Slf4JLogger
-
- trace(String, Throwable) - Method in class io.netty.util.internal.logging.Slf4JLogger
-
- traceCapable - Variable in class io.netty.util.internal.logging.Log4JLogger
-
- TraceDnsQueryLifecycleObserver - Class in io.netty.resolver.dns
-
- TraceDnsQueryLifecycleObserver(DnsQuestion, InternalLogger, InternalLogLevel) - Constructor for class io.netty.resolver.dns.TraceDnsQueryLifecycleObserver
-
- TraceDnsQueryLifeCycleObserverFactory - Class in io.netty.resolver.dns
-
- TraceDnsQueryLifeCycleObserverFactory() - Constructor for class io.netty.resolver.dns.TraceDnsQueryLifeCycleObserverFactory
-
- TraceDnsQueryLifeCycleObserverFactory(InternalLogger, InternalLogLevel) - Constructor for class io.netty.resolver.dns.TraceDnsQueryLifeCycleObserverFactory
-
- traceEnabled - Variable in class io.netty.resolver.dns.DnsNameResolverBuilder
-
- 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
-
- track0(T) - Method in class io.netty.util.ResourceLeakDetector
-
- trackedByteBuf - Variable in class io.netty.buffer.SimpleLeakAwareByteBuf
-
- trackedHash - Variable in class io.netty.util.ResourceLeakDetector.DefaultResourceLeak
-
- 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.
- TrafficCounter.TrafficMonitoringTask - Class in io.netty.handler.traffic
-
Class to implement monitoring at fix delay
- TrafficMonitoringTask() - Constructor for class io.netty.handler.traffic.TrafficCounter.TrafficMonitoringTask
-
- trafficShapingHandler - Variable in class io.netty.handler.traffic.TrafficCounter
-
The associated TrafficShapingHandler
- trafficShapingHandler1 - Variable in class io.netty.handler.traffic.GlobalChannelTrafficCounter.MixedTrafficMonitoringTask
-
The associated TrafficShapingHandler
- TRANSACTION - Static variable in interface io.netty.handler.codec.stomp.StompHeaders
-
- transfer(Recycler.Stack<?>) - Method in class io.netty.util.Recycler.WeakOrderQueue
-
- transfered() - Method in class io.netty.channel.DefaultFileRegion
-
Deprecated.
- transfered() - Method in interface io.netty.channel.FileRegion
-
- transferred - Variable in class io.netty.channel.DefaultFileRegion
-
- 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.
- transferResult(Future<T>, Promise<T>) - Static method in class io.netty.resolver.dns.InflightNameResolver
-
- transferTimeoutsToBuckets() - Method in class io.netty.util.HashedWheelTimer.Worker
-
- 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.
- TRANSPORT_DGRAM_BYTE - Static variable in class io.netty.handler.codec.haproxy.HAProxyConstants
-
- TRANSPORT_MASK - Static variable in enum io.netty.handler.codec.haproxy.HAProxyProxiedProtocol.TransportProtocol
-
The transport protocol is specified in the lowest 4 bits of the transport protocol and address family byte
- TRANSPORT_STREAM_BYTE - Static variable in class io.netty.handler.codec.haproxy.HAProxyConstants
-
- TRANSPORT_UNSPEC_BYTE - Static variable in class io.netty.handler.codec.haproxy.HAProxyConstants
-
Transport protocol byte constants
- transportByte - Variable in enum io.netty.handler.codec.haproxy.HAProxyProxiedProtocol.TransportProtocol
-
- transportProtocol - Variable in enum io.netty.handler.codec.haproxy.HAProxyProxiedProtocol
-
- transportProtocol() - Method in enum io.netty.handler.codec.haproxy.HAProxyProxiedProtocol
-
- TransportProtocol(byte) - Constructor for enum io.netty.handler.codec.haproxy.HAProxyProxiedProtocol.TransportProtocol
-
Creates a new instance.
- transportProvidesGuess - Variable in class io.netty.channel.kqueue.KQueueChannelConfig
-
- TRBudget(int, int) - Constructor for class io.netty.handler.codec.compression.Bzip2DivSufSort.TRBudget
-
- trCopy(int, int, int, int, int, int, int) - Method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- trFixdown(int, int, int, int, int, int) - Method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- trGetC(int, int, int, int) - Method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- trHeapSort(int, int, int, int, int) - Method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- triedCNAME - Variable in class io.netty.resolver.dns.DnsNameResolverContext
-
- trim() - Method in class io.netty.buffer.PoolThreadCache.MemoryRegionCache
-
Free up cached
PoolChunk
s if not allocated frequently enough.
- trim() - Method in class io.netty.buffer.PoolThreadCache
-
- trim(PoolThreadCache.MemoryRegionCache<?>[]) - Static method in class io.netty.buffer.PoolThreadCache
-
- trim(PoolThreadCache.MemoryRegionCache<?>) - Static method in class io.netty.buffer.PoolThreadCache
-
- 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.
- trInsertionSort(int, int, int, int, int) - Method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- trIntroSort(int, int, int, int, int, Bzip2DivSufSort.TRBudget, int) - Method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- trLog(int) - Static method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- trMedian3(int, int, int, int, int, int) - Method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- trMedian5(int, int, int, int, int, int, int, int) - Method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- trPartition(int, int, int, int, int, int) - Method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- trPivot(int, int, int, int, int) - Method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- trSort(int, int, int) - Method in class io.netty.handler.codec.compression.Bzip2DivSufSort
-
- 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.
- truncated - Variable in class io.netty.handler.codec.dns.DefaultDnsResponse
-
- trustCertCollection - Variable in class io.netty.handler.ssl.SslContextBuilder
-
- 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.
- trustManagerFactory - Variable in class io.netty.handler.ssl.SslContextBuilder
-
- trustManagers - Variable in class io.netty.handler.ssl.util.SimpleTrustManagerFactory.SimpleTrustManagerFactorySpi
-
- 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.
- tryClose(boolean) - Method in class io.netty.channel.local.LocalChannel
-
- tryFailure(Throwable) - Method in class io.netty.channel.AbstractChannel.CloseFuture
-
- tryFailure(Throwable) - Method in class io.netty.channel.group.DefaultChannelGroupFuture
-
- tryFailure(Throwable) - Method in class io.netty.channel.VoidChannelPromise
-
- tryFailure(Promise<?>, Throwable) - Static method in class io.netty.resolver.dns.DnsNameResolver
-
- 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(Throwable) - Method in class io.netty.util.concurrent.PromiseTask
-
- 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.
- tryFailureInternal(Throwable) - Method in class io.netty.util.concurrent.PromiseTask
-
- tryNotify - Variable in class io.netty.channel.ChannelFlushPromiseNotifier
-
- tryParseDayOfMonth(CharSequence, int, int) - Method in class io.netty.handler.codec.DateFormatter
-
- tryParseMonth(CharSequence, int, int) - Method in class io.netty.handler.codec.DateFormatter
-
- tryParseTime(CharSequence, int, int) - Method in class io.netty.handler.codec.DateFormatter
-
- tryParseYear(CharSequence, int, int) - Method in class io.netty.handler.codec.DateFormatter
-
- tryProgress(long, long) - Method in class io.netty.util.concurrent.DefaultProgressivePromise
-
- tryProgress(long, long) - Method in interface io.netty.util.concurrent.ProgressivePromise
-
- tryPromise() - Method in class io.netty.util.concurrent.PromiseCombiner
-
- trySetAccessible(AccessibleObject) - Static method in class io.netty.util.internal.ReflectionUtil
-
Try to call AccessibleObject.setAccessible(boolean)
but will catch any SecurityException
and
java.lang.reflect.InaccessibleObjectException
and return it.
- trySuccess() - Method in class io.netty.channel.AbstractChannel.CloseFuture
-
- 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(Void) - Method in class io.netty.channel.group.DefaultChannelGroupFuture
-
- trySuccess() - Method in class io.netty.channel.VoidChannelPromise
-
- trySuccess(Void) - Method in class io.netty.channel.VoidChannelPromise
-
- trySuccess(Promise<T>, T) - Static method in class io.netty.resolver.dns.DnsNameResolver
-
- 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(V) - Method in class io.netty.util.concurrent.PromiseTask
-
- 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.
- trySuccessInternal(V) - Method in class io.netty.util.concurrent.PromiseTask
-
- tryToFinishResolve(DnsServerAddressStream, int, DnsQuestion, DnsQueryLifecycleObserver, Promise<T>) - Method in class io.netty.resolver.dns.DnsNameResolverContext
-
- tryToLoadClass(ClassLoader, Class<?>) - Static method in class io.netty.util.internal.NativeLibraryLoader
-
Try to load the helper Class
into specified ClassLoader
.
- 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).
- TTL_EXPIRED - Static variable in class io.netty.handler.codec.socksx.v5.Socks5CommandStatus
-
- 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 interface com.sun.nio.sctp.SctpSocketOption
-
- type - Variable in class io.netty.handler.codec.dns.AbstractDnsRecord
-
- 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.
- type - Variable in class io.netty.handler.codec.haproxy.HAProxyTLV
-
- type() - Method in class io.netty.handler.codec.haproxy.HAProxyTLV
-
- Type() - Constructor for enum io.netty.handler.codec.haproxy.HAProxyTLV.Type
-
- type - Variable in class io.netty.handler.codec.redis.RedisDecoder
-
- type - Variable in class io.netty.handler.codec.socks.SocksMessage
-
- type() - Method in class io.netty.handler.codec.socks.SocksMessage
-
- type - Variable in class io.netty.handler.codec.socksx.v4.DefaultSocks4CommandRequest
-
- type() - Method in class io.netty.handler.codec.socksx.v4.DefaultSocks4CommandRequest
-
- type() - Method in interface io.netty.handler.codec.socksx.v4.Socks4CommandRequest
-
Returns the type of this request.
- type - Variable in class io.netty.handler.codec.socksx.v4.Socks4ServerDecoder
-
- type - Variable in class io.netty.handler.codec.socksx.v5.DefaultSocks5CommandRequest
-
- type() - Method in class io.netty.handler.codec.socksx.v5.DefaultSocks5CommandRequest
-
- type() - Method in interface io.netty.handler.codec.socksx.v5.Socks5CommandRequest
-
Returns the type of this request.
- type - Variable in class io.netty.util.internal.TypeParameterMatcher.ReflectiveMatcher
-
- TYPE_FAT_DESCRIPTOR - Static variable in class io.netty.handler.codec.serialization.CompactObjectOutputStream
-
- TYPE_LENGTH - Static variable in class io.netty.handler.codec.redis.RedisConstants
-
- TYPE_THIN_DESCRIPTOR - Static variable in class io.netty.handler.codec.serialization.CompactObjectOutputStream
-
- typeByteValue - Variable in class io.netty.handler.codec.haproxy.HAProxyTLV
-
- typeByteValue() - Method in class io.netty.handler.codec.haproxy.HAProxyTLV
-
Returns the type of the TLV as byte
- typeForByteValue(byte) - Static method in enum io.netty.handler.codec.haproxy.HAProxyTLV.Type
-
Returns the the
HAProxyTLV.Type
for a specific byte value as defined in the PROXY protocol 1.5 spec
- TypeParameterMatcher - Class in io.netty.util.internal
-
- TypeParameterMatcher() - Constructor for class io.netty.util.internal.TypeParameterMatcher
-
- TypeParameterMatcher.ReflectiveMatcher - Class in io.netty.util.internal
-
- typeParameterMatcherFindCache() - Method in class io.netty.util.internal.InternalThreadLocalMap
-
- typeParameterMatcherFindCache - Variable in class io.netty.util.internal.UnpaddedInternalThreadLocalMap
-
- typeParameterMatcherGetCache() - Method in class io.netty.util.internal.InternalThreadLocalMap
-
- typeParameterMatcherGetCache - Variable in class io.netty.util.internal.UnpaddedInternalThreadLocalMap
-
- V1_MAX_LENGTH - Static variable in class io.netty.handler.codec.haproxy.HAProxyMessageDecoder
-
Maximum possible length of a v1 proxy protocol header per spec
- V1_UNKNOWN_MSG - Static variable in class io.netty.handler.codec.haproxy.HAProxyMessage
-
Version 1 proxy protocol message for 'UNKNOWN' proxied protocols.
- V2_LOCAL_MSG - Static variable in class io.netty.handler.codec.haproxy.HAProxyMessage
-
Version 2 proxy protocol message for local requests.
- V2_MAX_LENGTH - Static variable in class io.netty.handler.codec.haproxy.HAProxyMessageDecoder
-
Maximum possible length of a v2 proxy protocol header (fixed 16 bytes + max unsigned short)
- V2_MAX_TLV - Static variable in class io.netty.handler.codec.haproxy.HAProxyMessageDecoder
-
Maximum possible length for v2 additional TLV data (max unsigned short - max v2 address info space)
- V2_MIN_LENGTH - Static variable in class io.netty.handler.codec.haproxy.HAProxyMessageDecoder
-
Minimum possible length of a fully functioning v2 proxy protocol header (fixed 16 bytes + v2 address info space)
- V2_UNKNOWN_MSG - Static variable in class io.netty.handler.codec.haproxy.HAProxyMessage
-
Version 2 proxy protocol message for 'UNKNOWN' proxied protocols.
- v2MaxHeaderSize - Variable in class io.netty.handler.codec.haproxy.HAProxyMessageDecoder
-
The latest v2 spec (2014/05/18) allows for additional data to be sent in the proxy protocol header beyond the
address information block so now we need a configurable max header size
- 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(int, int) - Static method in class io.netty.buffer.AbstractByteBufAllocator
-
- validate(T) - Method in class io.netty.channel.ChannelOption
-
- validate(I, O) - Method in class io.netty.channel.CombinedChannelDuplexHandler
-
- validate(ChannelOption<T>, T) - Method in class io.netty.channel.DefaultChannelConfig
-
- validateAdditional(DnsRecord, boolean) - Static method in class io.netty.resolver.dns.DnsNameResolver
-
- validateAndCalculateChunkSize(int, int) - Static method in class io.netty.buffer.PooledByteBufAllocator
-
- validateAndCalculatePageShifts(int) - Static method in class io.netty.buffer.PooledByteBufAllocator
-
- validateChecksum(int, ByteBuf) - Static method in class io.netty.handler.codec.compression.Snappy
-
Computes the CRC32C checksum of the supplied data, performs the "mask" operation
on the computed checksum, and then compares the resulting masked checksum to the
supplied checksum.
- validateChecksum(int, ByteBuf, int, int) - Static method in class io.netty.handler.codec.compression.Snappy
-
Computes the CRC32C checksum of the supplied data, performs the "mask" operation
on the computed checksum, and then compares the resulting masked checksum to the
supplied checksum.
- validateChecksums - Variable in class io.netty.handler.codec.compression.SnappyFrameDecoder
-
- validateCsvFormat(CharSequence) - Static method in class io.netty.util.internal.StringUtil
-
Validate if value
is a valid csv field without double-quotes.
- validateDelimiter(ByteBuf) - Static method in class io.netty.handler.codec.DelimiterBasedFrameDecoder
-
- validateFixedHeader(MqttFixedHeader) - Static method in class io.netty.handler.codec.mqtt.MqttCodecUtil
-
- validateMacSeparator(char) - Static method in class io.netty.util.internal.MacAddressUtil
-
- validateMaxContentLength(int) - Static method in class io.netty.handler.codec.MessageAggregator
-
- validateMaxFrameLength(int) - Static method in class io.netty.handler.codec.DelimiterBasedFrameDecoder
-
- validateName(K) - Method in interface io.netty.handler.codec.DefaultHeaders.NameValidator
-
Verify that name
is valid.
- validateOffset(int, int) - Static method in class io.netty.handler.codec.compression.Snappy
-
Validates that the offset extracted from a compressed reference is within
the permissible bounds of an offset (4 <= offset <= 32768), and does not
exceed the length of the chunk currently read so far.
- validateQuestion(DnsQuestion) - Static method in exception io.netty.resolver.dns.DnsNameResolverException
-
- validateRemoteAddress(InetSocketAddress) - Static method in exception io.netty.resolver.dns.DnsNameResolverException
-
- validIpV4ToBytes(String) - Static method in class io.netty.util.NetUtil
-
- value(int) - Method in class io.netty.buffer.PoolChunk
-
- value - Variable in class io.netty.channel.group.DefaultChannelGroupFuture.DefaultEntry
-
- value - Variable in class io.netty.handler.codec.DefaultHeaders.HeaderEntry
-
- value - Variable in class io.netty.handler.codec.HeadersUtils.StringEntry
-
- value - Variable in class io.netty.handler.codec.mqtt.MqttDecoder.Result
-
- value - Variable in enum io.netty.handler.codec.mqtt.MqttMessageType
-
- value() - Method in enum io.netty.handler.codec.mqtt.MqttMessageType
-
- value - Variable in enum io.netty.handler.codec.mqtt.MqttQoS
-
- value() - Method in enum io.netty.handler.codec.mqtt.MqttQoS
-
- value - Variable in class io.netty.handler.codec.redis.IntegerRedisMessage
-
- value() - Method in class io.netty.handler.codec.redis.IntegerRedisMessage
-
- value - Variable in enum io.netty.handler.codec.redis.RedisMessageType
-
- value() - Method in enum io.netty.handler.codec.redis.RedisMessageType
-
Returns prefix byte
for this type.
- value - Variable in class io.netty.handler.codec.string.LineSeparator
-
- value() - Method in class io.netty.handler.codec.string.LineSeparator
-
Return the string value of this line separator.
- value - Variable in class io.netty.util.AsciiString
-
- value() - Method in class io.netty.util.collection.ByteCollections.UnmodifiableMap.EntryImpl
-
- value() - Method in class io.netty.util.collection.ByteObjectHashMap.PrimitiveIterator
-
- value() - Method in interface io.netty.util.collection.ByteObjectMap.PrimitiveEntry
-
Gets the value for this entry.
- value() - Method in class io.netty.util.collection.CharCollections.UnmodifiableMap.EntryImpl
-
- value() - Method in class io.netty.util.collection.CharObjectHashMap.PrimitiveIterator
-
- value() - Method in interface io.netty.util.collection.CharObjectMap.PrimitiveEntry
-
Gets the value for this entry.
- value() - Method in class io.netty.util.collection.IntCollections.UnmodifiableMap.EntryImpl
-
- value() - Method in class io.netty.util.collection.IntObjectHashMap.PrimitiveIterator
-
- value() - Method in interface io.netty.util.collection.IntObjectMap.PrimitiveEntry
-
Gets the value for this entry.
- value() - Method in class io.netty.util.collection.LongCollections.UnmodifiableMap.EntryImpl
-
- value() - Method in class io.netty.util.collection.LongObjectHashMap.PrimitiveIterator
-
- value() - Method in interface io.netty.util.collection.LongObjectMap.PrimitiveEntry
-
Gets the value for this entry.
- value() - Method in class io.netty.util.collection.ShortCollections.UnmodifiableMap.EntryImpl
-
- value() - Method in class io.netty.util.collection.ShortObjectHashMap.PrimitiveIterator
-
- 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 class io.netty.util.internal.LongAdderCounter
-
- value() - Method in interface io.netty.util.internal.LongCounter
-
- value() - Method in class io.netty.util.internal.PlatformDependent.AtomicLongCounter
-
- value - Variable in class io.netty.util.Recycler.DefaultHandle
-
- VALUE_TO_CODE_MAP - Static variable in enum io.netty.handler.codec.mqtt.MqttConnectReturnCode
-
- valueConverter - Variable in class io.netty.handler.codec.DefaultHeaders
-
- 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 enum com.sun.nio.sctp.HandlerResult
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.netty.buffer.PoolArena.SizeClass
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in class io.netty.channel.ChannelOption
-
- valueOf(Class<?>, String) - Static method in class io.netty.channel.ChannelOption
-
- valueOf(String) - Static method in enum io.netty.channel.embedded.EmbeddedChannel.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.netty.channel.local.LocalChannel.State
-
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.Bzip2Decoder.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.netty.handler.codec.compression.Bzip2Encoder.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.netty.handler.codec.compression.FastLzFrameDecoder.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.netty.handler.codec.compression.JdkZlibDecoder.GzipState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.netty.handler.codec.compression.Snappy.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.netty.handler.codec.compression.SnappyFrameDecoder.ChunkType
-
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
-
- 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.haproxy.HAProxyCommand
-
Returns the enum constant of this type with the specified name.
- valueOf(byte) - Static method in enum io.netty.handler.codec.haproxy.HAProxyCommand
-
Returns the
HAProxyCommand
represented by the lowest 4 bits of the specified byte.
- valueOf(String) - Static method in enum io.netty.handler.codec.haproxy.HAProxyProtocolVersion
-
Returns the enum constant of this type with the specified name.
- valueOf(byte) - Static method in enum io.netty.handler.codec.haproxy.HAProxyProtocolVersion
-
- valueOf(String) - Static method in enum io.netty.handler.codec.haproxy.HAProxyProxiedProtocol.AddressFamily
-
Returns the enum constant of this type with the specified name.
- valueOf(byte) - Static method in enum io.netty.handler.codec.haproxy.HAProxyProxiedProtocol.AddressFamily
-
- valueOf(String) - Static method in enum io.netty.handler.codec.haproxy.HAProxyProxiedProtocol.TransportProtocol
-
Returns the enum constant of this type with the specified name.
- valueOf(byte) - Static method in enum io.netty.handler.codec.haproxy.HAProxyProxiedProtocol.TransportProtocol
-
- valueOf(String) - Static method in enum io.netty.handler.codec.haproxy.HAProxyProxiedProtocol
-
Returns the enum constant of this type with the specified name.
- valueOf(byte) - Static method in enum io.netty.handler.codec.haproxy.HAProxyProxiedProtocol
-
- valueOf(String) - Static method in enum io.netty.handler.codec.haproxy.HAProxyTLV.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheDecoder.State
-
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.MqttDecoder.DecoderState
-
Returns the enum constant of this type with the specified name.
- 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.RedisDecoder.State
-
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
-
- valueOf(CharSequence) - Static method in class io.netty.handler.codec.smtp.SmtpCommand
-
- valueOf(String) - Static method in enum io.netty.handler.codec.socks.SocksAddressType
-
Returns the enum constant of this type with the specified name.
- valueOf(byte) - Static method in enum io.netty.handler.codec.socks.SocksAddressType
-
- valueOf(String) - Static method in enum io.netty.handler.codec.socks.SocksAuthRequestDecoder.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.netty.handler.codec.socks.SocksAuthResponseDecoder.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.netty.handler.codec.socks.SocksAuthScheme
-
Returns the enum constant of this type with the specified name.
- valueOf(byte) - Static method in enum io.netty.handler.codec.socks.SocksAuthScheme
-
- valueOf(String) - Static method in enum io.netty.handler.codec.socks.SocksAuthStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(byte) - Static method in enum io.netty.handler.codec.socks.SocksAuthStatus
-
- valueOf(String) - Static method in enum io.netty.handler.codec.socks.SocksCmdRequestDecoder.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.netty.handler.codec.socks.SocksCmdResponseDecoder.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.netty.handler.codec.socks.SocksCmdStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(byte) - Static method in enum io.netty.handler.codec.socks.SocksCmdStatus
-
- valueOf(String) - Static method in enum io.netty.handler.codec.socks.SocksCmdType
-
Returns the enum constant of this type with the specified name.
- valueOf(byte) - Static method in enum io.netty.handler.codec.socks.SocksCmdType
-
- valueOf(String) - Static method in enum io.netty.handler.codec.socks.SocksInitRequestDecoder.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.netty.handler.codec.socks.SocksInitResponseDecoder.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.netty.handler.codec.socks.SocksMessageType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.netty.handler.codec.socks.SocksProtocolVersion
-
Returns the enum constant of this type with the specified name.
- valueOf(byte) - Static method in enum io.netty.handler.codec.socks.SocksProtocolVersion
-
- valueOf(String) - Static method in enum io.netty.handler.codec.socks.SocksRequestType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.netty.handler.codec.socks.SocksResponseType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.netty.handler.codec.socks.SocksSubnegotiationVersion
-
Returns the enum constant of this type with the specified name.
- valueOf(byte) - Static method in enum io.netty.handler.codec.socks.SocksSubnegotiationVersion
-
- valueOf(String) - Static method in enum io.netty.handler.codec.socksx.SocksVersion
-
Returns the enum constant of this type with the specified name.
- valueOf(byte) - Static method in enum io.netty.handler.codec.socksx.SocksVersion
-
Returns the
SocksVersion
that corresponds to the specified version field value,
as defined in the protocol specification.
- valueOf(String) - Static method in enum io.netty.handler.codec.socksx.v4.Socks4ClientDecoder.State
-
Returns the enum constant of this type with the specified name.
- valueOf(byte) - Static method in class io.netty.handler.codec.socksx.v4.Socks4CommandStatus
-
- valueOf(byte) - Static method in class io.netty.handler.codec.socksx.v4.Socks4CommandType
-
- valueOf(String) - Static method in enum io.netty.handler.codec.socksx.v4.Socks4ServerDecoder.State
-
Returns the enum constant of this type with the specified name.
- valueOf(byte) - Static method in class io.netty.handler.codec.socksx.v5.Socks5AddressType
-
- valueOf(byte) - Static method in class io.netty.handler.codec.socksx.v5.Socks5AuthMethod
-
- valueOf(String) - Static method in enum io.netty.handler.codec.socksx.v5.Socks5CommandRequestDecoder.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.netty.handler.codec.socksx.v5.Socks5CommandResponseDecoder.State
-
Returns the enum constant of this type with the specified name.
- valueOf(byte) - Static method in class io.netty.handler.codec.socksx.v5.Socks5CommandStatus
-
- valueOf(byte) - Static method in class io.netty.handler.codec.socksx.v5.Socks5CommandType
-
- valueOf(String) - Static method in enum io.netty.handler.codec.socksx.v5.Socks5InitialRequestDecoder.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.netty.handler.codec.socksx.v5.Socks5InitialResponseDecoder.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.netty.handler.codec.socksx.v5.Socks5PasswordAuthRequestDecoder.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.netty.handler.codec.socksx.v5.Socks5PasswordAuthResponseDecoder.State
-
Returns the enum constant of this type with the specified name.
- valueOf(byte) - Static method in class io.netty.handler.codec.socksx.v5.Socks5PasswordAuthStatus
-
- 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.codec.stomp.StompSubframeDecoder.State
-
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
-
- valueOf(ByteBuf) - Static method in class io.netty.handler.ssl.PemPrivateKey
-
- valueOf(byte[]) - Static method in class io.netty.handler.ssl.PemX509Certificate
-
- valueOf(ByteBuf) - Static method in class io.netty.handler.ssl.PemX509Certificate
-
- valueOf(String) - Static method in enum io.netty.handler.ssl.SslHandler.SslEngineType
-
Returns the enum constant of this type with the specified name.
- 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 com.sun.nio.sctp.HandlerResult
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum io.netty.buffer.PoolArena.SizeClass
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum io.netty.channel.embedded.EmbeddedChannel.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum io.netty.channel.local.LocalChannel.State
-
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.Bzip2Decoder.State
-
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.Bzip2Encoder.State
-
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.FastLzFrameDecoder.State
-
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.JdkZlibDecoder.GzipState
-
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.Snappy.State
-
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.SnappyFrameDecoder.ChunkType
-
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.haproxy.HAProxyCommand
-
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.haproxy.HAProxyProtocolVersion
-
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.haproxy.HAProxyProxiedProtocol.AddressFamily
-
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.haproxy.HAProxyProxiedProtocol.TransportProtocol
-
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.haproxy.HAProxyProxiedProtocol
-
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.haproxy.HAProxyTLV.Type
-
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.memcache.binary.AbstractBinaryMemcacheDecoder.State
-
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.MqttDecoder.DecoderState
-
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.RedisDecoder.State
-
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() - Method in class io.netty.handler.codec.serialization.ReferenceMap
-
- values() - Static method in enum io.netty.handler.codec.socks.SocksAddressType
-
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.socks.SocksAuthRequestDecoder.State
-
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.socks.SocksAuthResponseDecoder.State
-
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.socks.SocksAuthScheme
-
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.socks.SocksAuthStatus
-
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.socks.SocksCmdRequestDecoder.State
-
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.socks.SocksCmdResponseDecoder.State
-
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.socks.SocksCmdStatus
-
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.socks.SocksCmdType
-
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.socks.SocksInitRequestDecoder.State
-
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.socks.SocksInitResponseDecoder.State
-
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.socks.SocksMessageType
-
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.socks.SocksProtocolVersion
-
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.socks.SocksRequestType
-
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.socks.SocksResponseType
-
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.socks.SocksSubnegotiationVersion
-
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.socksx.SocksVersion
-
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.socksx.v4.Socks4ClientDecoder.State
-
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.socksx.v4.Socks4ServerDecoder.State
-
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.socksx.v5.Socks5CommandRequestDecoder.State
-
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.socksx.v5.Socks5CommandResponseDecoder.State
-
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.socksx.v5.Socks5InitialRequestDecoder.State
-
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.socksx.v5.Socks5InitialResponseDecoder.State
-
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.socksx.v5.Socks5PasswordAuthRequestDecoder.State
-
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.socksx.v5.Socks5PasswordAuthResponseDecoder.State
-
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.codec.stomp.StompSubframeDecoder.State
-
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.SslHandler.SslEngineType
-
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.ByteCollections.EmptyMap
-
- values - Variable in class io.netty.util.collection.ByteCollections.UnmodifiableMap
-
- values() - Method in class io.netty.util.collection.ByteCollections.UnmodifiableMap
-
- values - Variable in class io.netty.util.collection.ByteObjectHashMap
-
- values() - Method in class io.netty.util.collection.ByteObjectHashMap
-
- values() - Method in class io.netty.util.collection.CharCollections.EmptyMap
-
- values - Variable in class io.netty.util.collection.CharCollections.UnmodifiableMap
-
- values() - Method in class io.netty.util.collection.CharCollections.UnmodifiableMap
-
- values - Variable in class io.netty.util.collection.CharObjectHashMap
-
- values() - Method in class io.netty.util.collection.CharObjectHashMap
-
- values() - Method in class io.netty.util.collection.IntCollections.EmptyMap
-
- values - Variable in class io.netty.util.collection.IntCollections.UnmodifiableMap
-
- values() - Method in class io.netty.util.collection.IntCollections.UnmodifiableMap
-
- values - Variable in class io.netty.util.collection.IntObjectHashMap
-
- values() - Method in class io.netty.util.collection.IntObjectHashMap
-
- values() - Method in class io.netty.util.collection.LongCollections.EmptyMap
-
- values - Variable in class io.netty.util.collection.LongCollections.UnmodifiableMap
-
- values() - Method in class io.netty.util.collection.LongCollections.UnmodifiableMap
-
- values - Variable in class io.netty.util.collection.LongObjectHashMap
-
- values() - Method in class io.netty.util.collection.LongObjectHashMap
-
- values() - Method in class io.netty.util.collection.ShortCollections.EmptyMap
-
- values - Variable in class io.netty.util.collection.ShortCollections.UnmodifiableMap
-
- values() - Method in class io.netty.util.collection.ShortCollections.UnmodifiableMap
-
- values - Variable in class io.netty.util.collection.ShortObjectHashMap
-
- values() - Method in class io.netty.util.collection.ShortObjectHashMap
-
- values - Variable in class io.netty.util.DomainNameMappingBuilder.ImmutableDomainNameMapping
-
- 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.
- valueToFront(byte) - Method in class io.netty.handler.codec.compression.Bzip2MoveToFrontTable
-
Moves a value to the head of the MTF list (forward Move To Front transform).
- variableHeader() - Method in class io.netty.handler.codec.mqtt.MqttConnAckMessage
-
- variableHeader() - Method in class io.netty.handler.codec.mqtt.MqttConnectMessage
-
- variableHeader - Variable in class io.netty.handler.codec.mqtt.MqttDecoder
-
- variableHeader - Variable in class io.netty.handler.codec.mqtt.MqttMessage
-
- 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
-
- variablesToRemoveIndex - Static variable in class io.netty.util.concurrent.FastThreadLocal
-
- verify - Variable in class io.netty.handler.codec.haproxy.HAProxySSLTLV
-
- verify() - Method in class io.netty.handler.codec.haproxy.HAProxySSLTLV
-
Returns the verification result
- verify(PublicKey) - Method in class io.netty.handler.ssl.OpenSslJavaxX509Certificate
-
- verify(PublicKey, String) - Method in class io.netty.handler.ssl.OpenSslJavaxX509Certificate
-
- verify(PublicKey) - Method in class io.netty.handler.ssl.OpenSslX509Certificate
-
- verify(PublicKey, String) - Method in class io.netty.handler.ssl.OpenSslX509Certificate
-
- verify(PublicKey) - Method in class io.netty.handler.ssl.PemX509Certificate
-
- verify(PublicKey, String) - Method in class io.netty.handler.ssl.PemX509Certificate
-
- verify(EventExecutorGroup) - Static method in class io.netty.util.concurrent.NonStickyEventExecutorGroup
-
- verifyAddress(byte[]) - Static method in class io.netty.handler.codec.dns.DefaultDnsOptEcsRecord
-
- verifyCrc(ByteBuf) - Method in class io.netty.handler.codec.compression.JdkZlibDecoder
-
- verifyExists() - Method in class io.netty.util.collection.ByteObjectHashMap.MapEntry
-
- verifyExists() - Method in class io.netty.util.collection.CharObjectHashMap.MapEntry
-
- verifyExists() - Method in class io.netty.util.collection.IntObjectHashMap.MapEntry
-
- verifyExists() - Method in class io.netty.util.collection.LongObjectHashMap.MapEntry
-
- verifyExists() - Method in class io.netty.util.collection.ShortObjectHashMap.MapEntry
-
- verifyNullSslContextProvider(SslProvider, Provider) - Static method in class io.netty.handler.ssl.SslContext
-
- version() - Method in class io.netty.handler.codec.dns.AbstractDnsOptPseudoRrRecord
-
- version() - Method in interface io.netty.handler.codec.dns.DnsOptPseudoRecord
-
- version - Variable in class io.netty.handler.codec.haproxy.HAProxyMessageDecoder
-
Protocol specification version
- VERSION - Static variable in class io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
-
- version - Variable in class io.netty.handler.codec.mqtt.MqttConnectVariableHeader
-
- version() - Method in class io.netty.handler.codec.mqtt.MqttConnectVariableHeader
-
- version - Variable in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
-
- version() - Method in interface io.netty.handler.codec.socksx.SocksMessage
-
Returns the protocol version of this message.
- version() - Method in class io.netty.handler.codec.socksx.v4.AbstractSocks4Message
-
- version() - Method in class io.netty.handler.codec.socksx.v5.AbstractSocks5Message
-
- 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.
- Version(String, String, long, long, String, String, String) - Constructor for class io.netty.util.Version
-
- VERSION_MASK - Static variable in enum io.netty.handler.codec.haproxy.HAProxyProtocolVersion
-
The highest 4 bits of the protocol version and command byte contain the version
- VERSION_ONE_BYTE - Static variable in class io.netty.handler.codec.haproxy.HAProxyConstants
-
Version byte constants
- VERSION_TWO_BYTE - Static variable in class io.netty.handler.codec.haproxy.HAProxyConstants
-
- VoidChannelGroupFuture - Class in io.netty.channel.group
-
- VoidChannelGroupFuture(ChannelGroup) - Constructor for class io.netty.channel.group.VoidChannelGroupFuture
-
- VoidChannelPromise - Class in io.netty.channel
-
- VoidChannelPromise(Channel, boolean) - Constructor for class io.netty.channel.VoidChannelPromise
-
Creates a new instance.
- voidFuture - Variable in class io.netty.channel.group.DefaultChannelGroup
-
- voidPromise() - Method in class io.netty.channel.AbstractChannel.AbstractUnsafe
-
- voidPromise() - Method in class io.netty.channel.AbstractChannel
-
- voidPromise() - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- 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.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- voidPromise - Variable in class io.netty.channel.DefaultChannelPipeline
-
- 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.
- waiters - Variable in class io.netty.util.concurrent.DefaultPromise
-
Threading - synchronized(this).
- waitForNextTick() - Method in class io.netty.util.HashedWheelTimer.Worker
-
calculate goal nanoTime from startTime and current tick number,
then wait until that goal has been reached.
- WAKEN_UP_UPDATER - Static variable in class io.netty.channel.kqueue.KQueueEventLoop
-
- wakenUp - Variable in class io.netty.channel.kqueue.KQueueEventLoop
-
- wakenUp - Variable in class io.netty.channel.nio.NioEventLoop
-
Boolean that controls determines if a blocked Selector.select should
break out of its selection process.
- 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.kqueue.KQueueEventLoop
-
- wakeup() - Method in class io.netty.channel.kqueue.KQueueEventLoop
-
- wakeup(boolean) - Method in class io.netty.channel.nio.NioEventLoop
-
- wakeup() - Method in class io.netty.channel.nio.SelectedSelectionKeySetSelector
-
- wakeup(boolean) - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- WAKEUP_TASK - Static variable in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- wantsDirectBuffer - Variable in enum io.netty.handler.ssl.SslHandler.SslEngineType
-
true
if and only if SSLEngine
expects a direct buffer.
- warn(Throwable) - Method in class io.netty.util.internal.logging.AbstractInternalLogger
-
- warn(String) - Method in class io.netty.util.internal.logging.CommonsLogger
-
Deprecated.
Delegates to the Log.warn(Object)
method of the underlying
Log
instance.
- warn(String, Object) - Method in class io.netty.util.internal.logging.CommonsLogger
-
Deprecated.
Delegates to the Log.warn(Object)
method of the underlying
Log
instance.
- warn(String, Object, Object) - Method in class io.netty.util.internal.logging.CommonsLogger
-
Deprecated.
Delegates to the Log.warn(Object)
method of the underlying
Log
instance.
- warn(String, Object...) - Method in class io.netty.util.internal.logging.CommonsLogger
-
Deprecated.
Delegates to the Log.warn(Object)
method of the underlying
Log
instance.
- warn(String, Throwable) - Method in class io.netty.util.internal.logging.CommonsLogger
-
Deprecated.
Delegates to the Log.warn(Object, Throwable)
method of
the underlying Log
instance.
- 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.
- warn(String) - Method in class io.netty.util.internal.logging.JdkLogger
-
Log a message object at the WARNING level.
- warn(String, Object) - Method in class io.netty.util.internal.logging.JdkLogger
-
Log a message at the WARNING level according to the specified format and
argument.
- warn(String, Object, Object) - Method in class io.netty.util.internal.logging.JdkLogger
-
Log a message at the WARNING level according to the specified format and
arguments.
- warn(String, Object...) - Method in class io.netty.util.internal.logging.JdkLogger
-
Log a message at level WARNING according to the specified format and
arguments.
- warn(String, Throwable) - Method in class io.netty.util.internal.logging.JdkLogger
-
Log an exception (throwable) at the WARNING level with an accompanying
message.
- warn(String) - Method in class io.netty.util.internal.logging.Log4JLogger
-
Log a message object at the WARN level.
- warn(String, Object) - Method in class io.netty.util.internal.logging.Log4JLogger
-
Log a message at the WARN level according to the specified format and
argument.
- warn(String, Object, Object) - Method in class io.netty.util.internal.logging.Log4JLogger
-
Log a message at the WARN level according to the specified format and
arguments.
- warn(String, Object...) - Method in class io.netty.util.internal.logging.Log4JLogger
-
Log a message at level WARN according to the specified format and
arguments.
- warn(String, Throwable) - Method in class io.netty.util.internal.logging.Log4JLogger
-
Log an exception (throwable) at the WARN level with an accompanying
message.
- warn(String) - Method in class io.netty.util.internal.logging.Slf4JLogger
-
- warn(String, Object) - Method in class io.netty.util.internal.logging.Slf4JLogger
-
- warn(String, Object...) - Method in class io.netty.util.internal.logging.Slf4JLogger
-
- warn(String, Object, Object) - Method in class io.netty.util.internal.logging.Slf4JLogger
-
- warn(String, Throwable) - Method in class io.netty.util.internal.logging.Slf4JLogger
-
- WARNED_TOO_MANY_INSTANCES - Static variable in class io.netty.util.HashedWheelTimer
-
- watch(Thread, Runnable) - Static method in class io.netty.util.ThreadDeathWatcher
-
Schedules the specified task
to run when the specified thread
dies.
- watchees - Variable in class io.netty.util.ThreadDeathWatcher.Watcher
-
- watcher - Static variable in class io.netty.util.ThreadDeathWatcher
-
- Watcher() - Constructor for class io.netty.util.ThreadDeathWatcher.Watcher
-
- watcherThread - Static variable in class io.netty.util.ThreadDeathWatcher
-
- WATERMARK_UPDATER - Static variable in class io.netty.channel.DefaultChannelConfig
-
- 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
- WeakOrderQueue() - Constructor for class io.netty.util.Recycler.WeakOrderQueue
-
- WeakOrderQueue(Recycler.Stack<?>, Thread) - Constructor for class io.netty.util.Recycler.WeakOrderQueue
-
- WeakReferenceMap<K,V> - Class in io.netty.handler.codec.serialization
-
- WeakReferenceMap(Map<K, Reference<V>>) - Constructor for class io.netty.handler.codec.serialization.WeakReferenceMap
-
- wheel - Variable in class io.netty.util.HashedWheelTimer
-
- WHITE_SPACE_ENC - Static variable in class io.netty.handler.codec.base64.Base64
-
- WHITESPACES - Static variable in class io.netty.resolver.HostsFileParser
-
- willFlag - Variable in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
-
- willFlag(boolean) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
-
- willMessage - Variable in class io.netty.handler.codec.mqtt.MqttConnectPayload
-
- willMessage() - Method in class io.netty.handler.codec.mqtt.MqttConnectPayload
-
- willMessage - Variable in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
-
- 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 - Variable in class io.netty.handler.codec.mqtt.MqttConnectVariableHeader
-
- willQos() - Method in class io.netty.handler.codec.mqtt.MqttConnectVariableHeader
-
- willQos - Variable in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
-
- willQoS(MqttQoS) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
-
- willRetain - Variable in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
-
- willRetain(boolean) - Method in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
-
- willTopic - Variable in class io.netty.handler.codec.mqtt.MqttConnectPayload
-
- willTopic() - Method in class io.netty.handler.codec.mqtt.MqttConnectPayload
-
- willTopic - Variable in class io.netty.handler.codec.mqtt.MqttMessageBuilders.ConnectBuilder
-
- 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)
- WINDOWS_DEFAULT_SYSTEM_ROOT - Static variable in class io.netty.resolver.HostsFileParser
-
- WINDOWS_HOSTS_FILE_RELATIVE_PATH - Static variable in class io.netty.resolver.HostsFileParser
-
- WORKDIR - Static variable in class io.netty.util.internal.NativeLibraryLoader
-
- worker - Variable in class io.netty.util.HashedWheelTimer
-
- Worker() - Constructor for class io.netty.util.HashedWheelTimer.Worker
-
- 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
-
- WORKER_STATE_UPDATER - Static variable in class io.netty.util.HashedWheelTimer
-
- workerState - Variable in class io.netty.util.HashedWheelTimer
-
- workerThread - Variable in class io.netty.util.HashedWheelTimer
-
- wrap(ByteBuffer, ByteBuffer) - Method in class io.netty.handler.ssl.JdkSslEngine
-
- wrap(ByteBuffer[], ByteBuffer) - Method in class io.netty.handler.ssl.JdkSslEngine
-
- wrap(ByteBuffer[], int, int, ByteBuffer) - Method in class io.netty.handler.ssl.JdkSslEngine
-
- wrap(ChannelHandlerContext, boolean) - Method in class io.netty.handler.ssl.SslHandler
-
- wrap(ByteBufAllocator, SSLEngine, ByteBuf, ByteBuf) - Method in class io.netty.handler.ssl.SslHandler
-
- wrapAndFlush(ChannelHandlerContext) - Method in class io.netty.handler.ssl.SslHandler
-
- wrapChecksum(Checksum) - Static method in class io.netty.handler.codec.compression.ByteBufChecksum
-
- wrapNonAppData(ChannelHandlerContext, boolean) - Method in class io.netty.handler.ssl.SslHandler
-
- wrapped - Variable in class io.netty.buffer.AbstractUnsafeSwappedByteBuf
-
- wrapped - Variable in class io.netty.buffer.WrappedCompositeByteBuf
-
- wrapped - Variable in class io.netty.handler.ssl.OpenSslJavaxX509Certificate
-
- wrapped - Variable in class io.netty.handler.ssl.OpenSslX509Certificate
-
- 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.
- WrappedByteBuf - Class in io.netty.buffer
-
- WrappedByteBuf(ByteBuf) - Constructor for class io.netty.buffer.WrappedByteBuf
-
- WrappedCompositeByteBuf - Class in io.netty.buffer
-
- WrappedCompositeByteBuf(CompositeByteBuf) - Constructor for class io.netty.buffer.WrappedCompositeByteBuf
-
- WrappedUnpooledUnsafeDirectByteBuf - Class in io.netty.buffer
-
- WrappedUnpooledUnsafeDirectByteBuf(ByteBufAllocator, long, int, boolean) - Constructor for class io.netty.buffer.WrappedUnpooledUnsafeDirectByteBuf
-
- wrapper - Variable in class io.netty.handler.codec.compression.JdkZlibEncoder
-
- wrapperFactory() - Method in interface io.netty.handler.ssl.JdkApplicationProtocolNegotiator
-
- wrapperFactory - Variable in class io.netty.handler.ssl.JdkBaseApplicationProtocolNegotiator
-
- wrapperFactory() - Method in class io.netty.handler.ssl.JdkBaseApplicationProtocolNegotiator
-
- wrapperFactory() - Method in class io.netty.handler.ssl.JdkDefaultApplicationProtocolNegotiator
-
- wrapperOverhead - Variable in class io.netty.handler.codec.compression.JZlibEncoder
-
- wrapperOverhead(ZlibWrapper) - Static method in class io.netty.handler.codec.compression.ZlibUtil
-
- wrapSslEngine(SSLEngine, JdkApplicationProtocolNegotiator, boolean) - Method in class io.netty.handler.ssl.JdkAlpnApplicationProtocolNegotiator.AlpnWrapper
-
- wrapSslEngine(SSLEngine, JdkApplicationProtocolNegotiator, boolean) - Method in class io.netty.handler.ssl.JdkAlpnApplicationProtocolNegotiator.FailureWrapper
-
- wrapSslEngine(SSLEngine, JdkApplicationProtocolNegotiator, boolean) - Method in interface io.netty.handler.ssl.JdkApplicationProtocolNegotiator.SslEngineWrapperFactory
-
Abstract factory pattern for wrapping an SSLEngine
object.
- writabilityMask(int) - Static method in class io.netty.channel.ChannelOutboundBuffer
-
- 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.
- writableBytes() - Method in class io.netty.buffer.WrappedByteBuf
-
- writableBytes() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- writableBytes() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- 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(AbstractChannelHandlerContext, Object, ChannelPromise) - Method in class io.netty.channel.AbstractChannelHandlerContext.AbstractWriteTask
-
- write(Object) - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- write(Object, ChannelPromise) - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- write(Object, boolean, ChannelPromise) - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- write(AbstractChannelHandlerContext, Object, ChannelPromise) - Method in class io.netty.channel.AbstractChannelHandlerContext.WriteAndFlushTask
-
- 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
-
- write(Object, ChannelPromise) - Method in interface io.netty.channel.ChannelOutboundInvoker
-
- write(Object) - Method in class io.netty.channel.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- write(Object, ChannelPromise) - Method in class io.netty.channel.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- write(ChannelHandlerContext, Object, ChannelPromise) - Method in class io.netty.channel.CombinedChannelDuplexHandler
-
- write(ChannelHandlerContext, Object, ChannelPromise) - Method in class io.netty.channel.DefaultChannelPipeline.HeadContext
-
- 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
Channel
s in this
group.
- write(Object, ChannelMatcher) - Method in interface io.netty.channel.group.ChannelGroup
-
- write(Object, ChannelMatcher, boolean) - Method in interface io.netty.channel.group.ChannelGroup
-
- 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(int, ByteBuffer, int, int) - Static 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(int) - Method in class io.netty.handler.codec.compression.Bzip2BlockCompressor
-
Writes a byte to the block, accumulating to an RLE run where possible.
- write(ByteBuf, int, int) - Method in class io.netty.handler.codec.compression.Bzip2BlockCompressor
-
Writes an array to the block.
- 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_ADDRESS_CLOSED_CHANNEL_EXCEPTION - Static variable in class io.netty.channel.unix.FileDescriptor
-
- WRITE_ADDRESS_CONNECTION_RESET_EXCEPTION - Static variable in class io.netty.channel.unix.FileDescriptor
-
- 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_CLOSED_CHANNEL_EXCEPTION - Static variable in class io.netty.channel.AbstractChannel
-
- WRITE_CLOSED_CHANNEL_EXCEPTION - Static variable in class io.netty.channel.unix.FileDescriptor
-
- WRITE_CONNECTION_RESET_EXCEPTION - Static variable in class io.netty.channel.unix.FileDescriptor
-
- WRITE_SPIN_COUNT - Static variable in class io.netty.channel.ChannelOption
-
- WRITE_TASK_OVERHEAD - Static variable in class io.netty.channel.AbstractChannelHandlerContext.AbstractWriteTask
-
- WRITE_UTF_UNKNOWN - Static variable in class io.netty.buffer.ByteBufUtil
-
- writeAddress(long, int, int) - Method in class io.netty.channel.unix.FileDescriptor
-
- writeAddress(int, long, int, int) - Static 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 class io.netty.channel.AbstractChannelHandlerContext
-
- writeAndFlush(Object) - Method in class io.netty.channel.AbstractChannelHandlerContext
-
- 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.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- writeAndFlush(Object) - Method in class io.netty.channel.CombinedChannelDuplexHandler.DelegatingChannelHandlerContext
-
- 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
-
- writeAndFlush(Object, ChannelMatcher, boolean) - Method in interface io.netty.channel.group.ChannelGroup
-
- 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
-
- WriteAndFlushTask(Recycler.Handle<AbstractChannelHandlerContext.WriteAndFlushTask>) - Constructor for class io.netty.channel.AbstractChannelHandlerContext.WriteAndFlushTask
-
- writeArrayHeader(ByteBufAllocator, ArrayHeaderRedisMessage, List<Object>) - Method in class io.netty.handler.codec.redis.RedisEncoder
-
Write array header only without body.
- writeArrayHeader(ByteBufAllocator, boolean, long, List<Object>) - Method in class io.netty.handler.codec.redis.RedisEncoder
-
- writeArrayMessage(ByteBufAllocator, ArrayRedisMessage, List<Object>) - Method in class io.netty.handler.codec.redis.RedisEncoder
-
Write full constructed array message.
- 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
-
- writeAscii(AbstractByteBuf, int, CharSequence, int) - Static method in class io.netty.buffer.ByteBufUtil
-
- writeAscii(ByteBuf, int, CharSequence) - Static method in class io.netty.handler.codec.AsciiHeadersEncoder
-
- writeBits(ByteBuf, int, long) - Method in class io.netty.handler.codec.compression.Bzip2BitWriter
-
Writes up to 32 bits to the output
ByteBuf
.
- writeBlockData(ByteBuf) - Method in class io.netty.handler.codec.compression.Bzip2HuffmanStageEncoder
-
Writes out the encoded block data.
- writeBoolean(boolean) - Method in class io.netty.buffer.AbstractByteBuf
-
- writeBoolean(boolean) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- writeBoolean(boolean) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.buffer.WrappedByteBuf
-
- writeBoolean(boolean) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- writeBoolean(ByteBuf, boolean) - Method in class io.netty.handler.codec.compression.Bzip2BitWriter
-
Writes a single bit to the output
ByteBuf
.
- writeBoolean(boolean) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- writeBoolean(boolean) - Method in class io.netty.handler.codec.serialization.ObjectEncoderOutputStream
-
- writeBufferWaterMark - Variable in class io.netty.channel.DefaultChannelConfig
-
- 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.
- WriteBufferWaterMark(int, int, boolean) - Constructor for class io.netty.channel.WriteBufferWaterMark
-
This constructor is needed to keep backward-compatibility.
- writeBulkStringContent(ByteBufAllocator, BulkStringRedisContent, List<Object>) - Static method in class io.netty.handler.codec.redis.RedisEncoder
-
- writeBulkStringHeader(ByteBufAllocator, BulkStringHeaderRedisMessage, List<Object>) - Method in class io.netty.handler.codec.redis.RedisEncoder
-
- writeByte(int) - Method in class io.netty.buffer.AbstractByteBuf
-
- writeByte(int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- writeByte(int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.buffer.WrappedByteBuf
-
- writeByte(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- writeByte(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- 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.AdvancedLeakAwareByteBuf
-
- writeBytes(ByteBuf, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- writeBytes(ByteBuf, int, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- writeBytes(byte[]) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- writeBytes(byte[], int, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- writeBytes(ByteBuffer) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- writeBytes(InputStream, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- writeBytes(ScatteringByteChannel, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- writeBytes(FileChannel, long, int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- writeBytes(ByteBuf) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- writeBytes(ByteBuf, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- writeBytes(ByteBuf, int, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- writeBytes(byte[]) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- writeBytes(byte[], int, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- writeBytes(ByteBuffer) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- writeBytes(InputStream, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- writeBytes(ScatteringByteChannel, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- writeBytes(FileChannel, long, int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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(ByteBuf) - Method in class io.netty.buffer.WrappedByteBuf
-
- writeBytes(ByteBuf, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- writeBytes(ByteBuf, int, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- writeBytes(byte[]) - Method in class io.netty.buffer.WrappedByteBuf
-
- writeBytes(byte[], int, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- writeBytes(ByteBuffer) - Method in class io.netty.buffer.WrappedByteBuf
-
- writeBytes(InputStream, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- writeBytes(ScatteringByteChannel, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- writeBytes(FileChannel, long, int) - Method in class io.netty.buffer.WrappedByteBuf
-
- writeBytes(InputStream, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- writeBytes(ScatteringByteChannel, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- writeBytes(FileChannel, long, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- writeBytes(ByteBuf) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- writeBytes(ByteBuf, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- writeBytes(ByteBuf, int, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- writeBytes(byte[]) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- writeBytes(byte[], int, int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- writeBytes(ByteBuffer) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- writeBytes(ChannelOutboundBuffer, ByteBuf, int) - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel
-
Write bytes form the given
ByteBuf
to the underlying
Channel
.
- writeBytes(byte[], int, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- writeBytes(byte[]) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- writeBytes(ByteBuffer) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- writeBytes(ByteBuf, int, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- writeBytes(ByteBuf, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- writeBytes(ByteBuf) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- writeBytes(InputStream, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- writeBytes(ScatteringByteChannel, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- writeBytes(FileChannel, long, int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- writeBytes(String) - Method in class io.netty.handler.codec.serialization.ObjectEncoderOutputStream
-
- writeBytesMultiple(ChannelOutboundBuffer, IovArray, int) - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel
-
- writeBytesMultiple(ChannelOutboundBuffer, ByteBuffer[], int, long, int) - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel
-
- writeChannelLimit - Variable in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
-
Limit in B/s to apply to write
- writeChar(int) - Method in class io.netty.buffer.AbstractByteBuf
-
- writeChar(int) - Method in class io.netty.buffer.AbstractUnsafeSwappedByteBuf
-
- writeChar(int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- writeChar(int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.buffer.WrappedByteBuf
-
- writeChar(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- writeChar(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- 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.AdvancedLeakAwareByteBuf
-
- writeCharSequence(CharSequence, Charset) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.
- writeCharSequence(CharSequence, Charset) - Method in class io.netty.buffer.WrappedByteBuf
-
- writeCharSequence(CharSequence, Charset) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- writeCharSequence(CharSequence, Charset) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- writeChunkLength(ByteBuf, int) - Static method in class io.netty.handler.codec.compression.SnappyFrameEncoder
-
Writes the 2-byte chunk length to the output buffer.
- writeClassDescriptor(ObjectStreamClass) - Method in class io.netty.handler.codec.serialization.CompactObjectOutputStream
-
- writeCounter - Variable in class io.netty.channel.ChannelFlushPromiseNotifier
-
- writeCounter() - Method in class io.netty.channel.ChannelFlushPromiseNotifier
-
- writeDefaultFileRegion(ChannelOutboundBuffer, DefaultFileRegion, int) - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel
-
- writeDeviationActive - Variable in class io.netty.handler.traffic.GlobalChannelTrafficShapingHandler
-
- writeDouble(double) - Method in class io.netty.buffer.AbstractByteBuf
-
- writeDouble(double) - Method in class io.netty.buffer.AbstractUnsafeSwappedByteBuf
-
- writeDouble(double) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- writeDouble(double) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.buffer.WrappedByteBuf
-
- writeDouble(double) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- writeDouble(double) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- writeDouble(double) - Method in class io.netty.handler.codec.serialization.ObjectEncoderOutputStream
-
- writeErrorMessage(ByteBufAllocator, ErrorRedisMessage, List<Object>) - Static method in class io.netty.handler.codec.redis.RedisEncoder
-
- writeFileRegion(ChannelOutboundBuffer, FileRegion, int) - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel
-
- writeFilter(boolean) - Method in class io.netty.channel.kqueue.AbstractKQueueChannel
-
- writeFilterEnabled - Variable in class io.netty.channel.kqueue.AbstractKQueueChannel
-
- writeFloat(float) - Method in class io.netty.buffer.AbstractByteBuf
-
- writeFloat(float) - Method in class io.netty.buffer.AbstractUnsafeSwappedByteBuf
-
- writeFloat(float) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- writeFloat(float) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.buffer.WrappedByteBuf
-
- writeFloat(float) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- writeFloat(float) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- writeFloat(float) - Method in class io.netty.handler.codec.serialization.ObjectEncoderOutputStream
-
- writeFullBulkStringMessage(ByteBufAllocator, FullBulkStringRedisMessage, List<Object>) - Method in class io.netty.handler.codec.redis.RedisEncoder
-
- writeHeader - Variable in class io.netty.handler.codec.compression.JdkZlibEncoder
-
- writeInbound(Object...) - Method in class io.netty.channel.embedded.EmbeddedChannel
-
Write messages to the inbound of this
Channel
.
- writeInProgress - Variable in class io.netty.channel.local.LocalChannel
-
- writeInt(int) - Method in class io.netty.buffer.AbstractByteBuf
-
- writeInt(int) - Method in class io.netty.buffer.AbstractUnsafeSwappedByteBuf
-
- writeInt(int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- writeInt(int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.buffer.WrappedByteBuf
-
- writeInt(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- writeInt(int, int) - Method in class io.netty.channel.DefaultChannelId
-
- writeInt(ByteBuf, int) - Method in class io.netty.handler.codec.compression.Bzip2BitWriter
-
Writes an integer as 32 bits to the output
ByteBuf
.
- writeInt(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- writeInt(int) - Method in class io.netty.handler.codec.serialization.ObjectEncoderOutputStream
-
- writeIntegerMessage(ByteBufAllocator, IntegerRedisMessage, List<Object>) - Method in class io.netty.handler.codec.redis.RedisEncoder
-
- writeIntLE(int) - Method in class io.netty.buffer.AbstractByteBuf
-
- writeIntLE(int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- writeIntLE(int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.
- writeIntLE(int) - Method in class io.netty.buffer.WrappedByteBuf
-
- writeIntLE(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- writeIntLE(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- writeLimit - Variable in class io.netty.handler.traffic.AbstractTrafficShapingHandler
-
Limit in B/s to apply to write
- writeListener - Variable in class io.netty.handler.timeout.IdleStateHandler
-
- writeLong(long) - Method in class io.netty.buffer.AbstractByteBuf
-
- writeLong(long) - Method in class io.netty.buffer.AbstractUnsafeSwappedByteBuf
-
- writeLong(long) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- writeLong(long) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.buffer.WrappedByteBuf
-
- writeLong(long) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- writeLong(int, long) - Method in class io.netty.channel.DefaultChannelId
-
- writeLong(long) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- 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.AdvancedLeakAwareByteBuf
-
- writeLongLE(long) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.
- writeLongLE(long) - Method in class io.netty.buffer.WrappedByteBuf
-
- writeLongLE(long) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- writeLongLE(long) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- writeMedium(int) - Method in class io.netty.buffer.AbstractByteBuf
-
- writeMedium(int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- writeMedium(int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.
- writeMedium(int) - Method in class io.netty.buffer.WrappedByteBuf
-
- writeMedium(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- writeMedium(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- writeMediumLE(int) - Method in class io.netty.buffer.AbstractByteBuf
-
- writeMediumLE(int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- writeMediumLE(int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.
- writeMediumLE(int) - Method in class io.netty.buffer.WrappedByteBuf
-
- writeMediumLE(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- writeMediumLE(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- 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
.
- writeParameters(List<CharSequence>, ByteBuf) - Static method in class io.netty.handler.codec.smtp.SmtpRequestEncoder
-
- writeProcessor - Variable in class io.netty.handler.codec.compression.Bzip2BlockCompressor
-
- writeQuery(DnsQuery, ChannelPromise) - Method in class io.netty.resolver.dns.DnsQueryContext
-
- writer - Variable in class io.netty.handler.codec.compression.Bzip2BlockCompressor
-
A writer that provides bit-level writes.
- writer - Variable in class io.netty.handler.codec.compression.Bzip2Encoder
-
A writer that provides bit-level writes.
- writer - Variable in class io.netty.handler.codec.compression.Bzip2HuffmanStageEncoder
-
- WRITER_IDLE_STATE_EVENT - Static variable in class io.netty.handler.timeout.IdleStateEvent
-
- writeReady() - Method in class io.netty.channel.kqueue.AbstractKQueueChannel.AbstractKQueueUnsafe
-
- writeReady() - Method in class io.netty.channel.kqueue.AbstractKQueueStreamChannel.KQueueStreamUnsafe
-
- writeRedisMessage(ByteBufAllocator, RedisMessage, List<Object>) - Method in class io.netty.handler.codec.redis.RedisEncoder
-
- writerIdleTimeNanos - Variable in class io.netty.handler.timeout.IdleStateHandler
-
- writerIdleTimeout - Variable in class io.netty.handler.timeout.IdleStateHandler
-
- WriterIdleTimeoutTask(ChannelHandlerContext) - Constructor for class io.netty.handler.timeout.IdleStateHandler.WriterIdleTimeoutTask
-
- writerIndex - Variable in class io.netty.buffer.AbstractByteBuf
-
- 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.
- writerIndex() - Method in class io.netty.buffer.WrappedByteBuf
-
- writerIndex(int) - Method in class io.netty.buffer.WrappedByteBuf
-
- writerIndex() - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- writerIndex(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- writerIndex() - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- writerIndex(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- writeRun(int, int) - Method in class io.netty.handler.codec.compression.Bzip2BlockCompressor
-
Writes an RLE run to the block array, updating the block CRC and present values array as required.
- writeSelector - Variable in class io.netty.channel.sctp.oio.OioSctpChannel
-
- writeSelectorsAndHuffmanTables(ByteBuf) - Method in class io.netty.handler.codec.compression.Bzip2HuffmanStageEncoder
-
Write out the selector list and Huffman tables.
- writeShort(int) - Method in class io.netty.buffer.AbstractByteBuf
-
- writeShort(int) - Method in class io.netty.buffer.AbstractUnsafeSwappedByteBuf
-
- writeShort(int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- writeShort(int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.buffer.WrappedByteBuf
-
- writeShort(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- writeShort(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- 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.AdvancedLeakAwareByteBuf
-
- writeShortLE(int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.
- writeShortLE(int) - Method in class io.netty.buffer.WrappedByteBuf
-
- writeShortLE(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- writeShortLE(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- writeSimpleStringMessage(ByteBufAllocator, SimpleStringRedisMessage, List<Object>) - Static method in class io.netty.handler.codec.redis.RedisEncoder
-
- writeSpinCount - Variable in class io.netty.channel.DefaultChannelConfig
-
- writeStreamHeader() - Method in class io.netty.handler.codec.serialization.CompactObjectOutputStream
-
- writeString(ByteBufAllocator, byte, String, List<Object>) - Static method in class io.netty.handler.codec.redis.RedisEncoder
-
- writeSymbolMap(ByteBuf) - Method in class io.netty.handler.codec.compression.Bzip2BlockCompressor
-
Write the Huffman symbol to output byte map.
- WriteTask(Recycler.Handle<AbstractChannelHandlerContext.WriteTask>) - Constructor for class io.netty.channel.AbstractChannelHandlerContext.WriteTask
-
- 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
-
- WriteTimeoutException() - Constructor for exception io.netty.handler.timeout.WriteTimeoutException
-
- WriteTimeoutHandler - Class in io.netty.handler.timeout
-
- 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.
- WriteTimeoutHandler.WriteTimeoutTask - Class in io.netty.handler.timeout
-
- WriteTimeoutTask(ChannelHandlerContext, ChannelPromise) - Constructor for class io.netty.handler.timeout.WriteTimeoutHandler.WriteTimeoutTask
-
- 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.
- writeUnary(ByteBuf, int) - Method in class io.netty.handler.codec.compression.Bzip2BitWriter
-
Writes a zero-terminated unary number to the output
ByteBuf
.
- writeUnencodedChunk(ByteBuf, ByteBuf, int) - Static method in class io.netty.handler.codec.compression.SnappyFrameEncoder
-
- 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
-
- writeUtf8(AbstractByteBuf, int, CharSequence, int) - Static method in class io.netty.buffer.ByteBufUtil
-
- writev(ByteBuffer[], int, int) - Method in class io.netty.channel.unix.FileDescriptor
-
- writev(int, ByteBuffer[], int, int) - Static method in class io.netty.channel.unix.FileDescriptor
-
- WRITEV_ADDRESSES_CLOSED_CHANNEL_EXCEPTION - Static variable in class io.netty.channel.unix.FileDescriptor
-
- WRITEV_ADDRESSES_CONNECTION_RESET_EXCEPTION - Static variable in class io.netty.channel.unix.FileDescriptor
-
- WRITEV_CLOSED_CHANNEL_EXCEPTION - Static variable in class io.netty.channel.unix.FileDescriptor
-
- WRITEV_CONNECTION_RESET_EXCEPTION - Static variable in class io.netty.channel.unix.FileDescriptor
-
- writevAddresses(long, int) - Method in class io.netty.channel.unix.FileDescriptor
-
- writevAddresses(int, long, int) - Static method in class io.netty.channel.unix.FileDescriptor
-
- writeVariableLengthInt(ByteBuf, int) - Static method in class io.netty.handler.codec.mqtt.MqttEncoder
-
- writeZero(int) - Method in class io.netty.buffer.AbstractByteBuf
-
- writeZero(int) - Method in class io.netty.buffer.AdvancedLeakAwareByteBuf
-
- writeZero(int) - Method in class io.netty.buffer.AdvancedLeakAwareCompositeByteBuf
-
- 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.PooledUnsafeDirectByteBuf
-
- writeZero(int) - Method in class io.netty.buffer.PooledUnsafeHeapByteBuf
-
- writeZero(int) - Method in class io.netty.buffer.SwappedByteBuf
-
Deprecated.
- writeZero(int) - Method in class io.netty.buffer.UnpooledUnsafeDirectByteBuf
-
- writeZero(int) - Method in class io.netty.buffer.UnpooledUnsafeHeapByteBuf
-
- writeZero(int) - Method in class io.netty.buffer.WrappedByteBuf
-
- writeZero(int) - Method in class io.netty.buffer.WrappedCompositeByteBuf
-
- writeZero(int) - Method in class io.netty.handler.codec.ReplayingDecoderByteBuf
-
- writingTime - Variable in class io.netty.handler.traffic.TrafficCounter
-
Last writing time during current check interval
- written - Variable in class io.netty.handler.codec.compression.Snappy
-
- writtenBytes() - Method in class io.netty.buffer.ByteBufOutputStream
-
Returns the number of written bytes by this stream so far.
- writtenObjects - Variable in class io.netty.handler.codec.serialization.CompatibleObjectEncoder
-