All Classes Interface Summary Class Summary Enum Summary Exception Summary Error Summary Annotation Types Summary
Class |
Description |
AbstractAddressResolver<T extends SocketAddress> |
|
AbstractBinaryMemcacheDecoder<M extends BinaryMemcacheMessage> |
|
AbstractBinaryMemcacheEncoder<M extends BinaryMemcacheMessage> |
|
AbstractBinaryMemcacheMessage |
|
AbstractBootstrap<B extends AbstractBootstrap<B,C>,C extends Channel> |
|
AbstractBootstrapConfig<B extends AbstractBootstrap<B,C>,C extends Channel> |
|
AbstractByteBuf |
A skeletal implementation of a buffer.
|
AbstractByteBufAllocator |
|
AbstractChannel |
|
AbstractChannelPoolHandler |
|
AbstractChannelPoolMap<K,P extends ChannelPool> |
|
AbstractCoalescingBufferQueue |
|
AbstractConstant<T extends AbstractConstant<T>> |
|
AbstractDerivedByteBuf |
Deprecated.
|
AbstractDiskHttpData |
Abstract Disk HttpData implementation
|
AbstractDnsMessage |
|
AbstractDnsOptPseudoRrRecord |
|
AbstractDnsRecord |
|
AbstractEventExecutor |
|
AbstractEventExecutor.LazyRunnable |
Marker interface for Runnable to indicate that it should be queued for execution
but does not need to run immediately.
|
AbstractEventExecutorGroup |
|
AbstractEventLoop |
|
AbstractEventLoopGroup |
|
AbstractFuture<V> |
Abstract Future implementation which does not allow for cancellation.
|
AbstractHttp2ConnectionHandlerBuilder<T extends Http2ConnectionHandler,B extends AbstractHttp2ConnectionHandlerBuilder<T,B>> |
|
AbstractHttp2StreamFrame |
|
AbstractHttpData |
Abstract HttpData implementation
|
AbstractInboundHttp2ToHttpAdapterBuilder<T extends InboundHttp2ToHttpAdapter,B extends AbstractInboundHttp2ToHttpAdapterBuilder<T,B>> |
|
AbstractInternalLogger |
|
AbstractMemcacheObject |
|
AbstractMemcacheObjectAggregator<H extends MemcacheMessage> |
|
AbstractMemcacheObjectDecoder |
Abstract super class for both ascii and binary decoders.
|
AbstractMemcacheObjectEncoder<M extends MemcacheMessage> |
|
AbstractMemoryHttpData |
Abstract Memory HttpData implementation
|
AbstractMultiSearchProcessorFactory |
|
AbstractNioByteChannel |
|
AbstractNioChannel |
Abstract base class for Channel implementations which use a Selector based approach.
|
AbstractNioChannel.NioUnsafe |
|
AbstractNioMessageChannel |
|
AbstractOioByteChannel |
Deprecated.
|
AbstractOioChannel |
Deprecated.
|
AbstractOioMessageChannel |
Deprecated.
|
AbstractReferenceCounted |
|
AbstractReferenceCountedByteBuf |
Abstract base class for ByteBuf implementations that count references.
|
AbstractRemoteAddressFilter<T extends SocketAddress> |
This class provides the functionality to either accept or reject new Channel s
based on their IP address.
|
AbstractScheduledEventExecutor |
Abstract base class for EventExecutor s that want to support scheduling.
|
AbstractSearchProcessorFactory |
|
AbstractServerChannel |
A skeletal server-side Channel implementation.
|
AbstractSniHandler<T> |
|
AbstractSocks4Message |
|
AbstractSocks5Message |
|
AbstractSocksMessage |
|
AbstractStringRedisMessage |
Abstract class for Simple Strings or Errors.
|
AbstractTrafficShapingHandler |
|
AdaptiveRecvByteBufAllocator |
The RecvByteBufAllocator that automatically increases and
decreases the predicted buffer size on feed back.
|
AddressedEnvelope<M,A extends SocketAddress> |
A message that wraps another message with a sender address and a recipient address.
|
AddressResolver<T extends SocketAddress> |
|
AddressResolverGroup<T extends SocketAddress> |
|
AhoCorasicSearchProcessorFactory |
|
AhoCorasicSearchProcessorFactory.Processor |
|
AppendableCharSequence |
|
ApplicationProtocolConfig |
|
ApplicationProtocolConfig.Protocol |
Defines which application level protocol negotiation to use.
|
ApplicationProtocolConfig.SelectedListenerFailureBehavior |
Defines the most common behaviors for the peer which is notified of the selected protocol.
|
ApplicationProtocolConfig.SelectorFailureBehavior |
Defines the most common behaviors for the peer that selects the application protocol.
|
ApplicationProtocolNames |
Provides a set of protocol names used in ALPN and NPN.
|
ApplicationProtocolNegotiationHandler |
|
ApplicationProtocolNegotiator |
Deprecated.
|
ArrayHeaderRedisMessage |
Header of Redis Array Message.
|
ArrayRedisMessage |
|
AsciiHeadersEncoder |
|
AsciiHeadersEncoder.NewlineType |
The newline characters to insert between header entries.
|
AsciiHeadersEncoder.SeparatorType |
The separator characters to insert between a header name and a header value.
|
AsciiString |
A string which has been encoded into a character encoding whose character always takes a single byte, similarly to
ASCII.
|
AsyncMapping<IN,OUT> |
|
Attribute |
Attribute interface
|
Attribute<T> |
An attribute which allows to store a value reference.
|
AttributeKey<T> |
|
AttributeMap |
|
AuthoritativeDnsServerCache |
Cache which stores the nameservers that should be used to resolve a specific hostname.
|
Base64 |
Utility class for ByteBuf that encodes and decodes to and from
Base64 notation.
|
Base64Decoder |
|
Base64Dialect |
Enumeration of supported Base64 dialects.
|
Base64Encoder |
|
BiDnsQueryLifecycleObserver |
|
BiDnsQueryLifecycleObserverFactory |
|
BinaryMemcacheClientCodec |
The client codec that combines the proper encoder and decoder.
|
BinaryMemcacheMessage |
|
BinaryMemcacheObjectAggregator |
An object aggregator for the memcache binary protocol.
|
BinaryMemcacheOpcodes |
|
BinaryMemcacheRequest |
|
BinaryMemcacheRequestDecoder |
The decoder part which takes care of decoding the request-specific headers.
|
BinaryMemcacheRequestEncoder |
The encoder part which takes care of encoding the request headers.
|
BinaryMemcacheResponse |
|
BinaryMemcacheResponseDecoder |
The decoder which takes care of decoding the response headers.
|
BinaryMemcacheResponseEncoder |
The encoder which takes care of encoding the response headers.
|
BinaryMemcacheResponseStatus |
|
BinaryMemcacheServerCodec |
The full server codec that combines the correct encoder and decoder.
|
BinaryWebSocketFrame |
Web Socket frame containing binary data.
|
BitapSearchProcessorFactory |
Implements Bitap string search algorithm.
|
BitapSearchProcessorFactory.Processor |
|
BlockingOperationException |
An IllegalStateException which is raised when a user performed a blocking operation
when the user is in an event loop thread.
|
BooleanSupplier |
Represents a supplier of boolean -valued results.
|
Bootstrap |
|
BootstrapConfig |
|
Buffer |
|
BulkStringHeaderRedisMessage |
The header of Bulk Strings in RESP.
|
BulkStringRedisContent |
A chunk of bulk strings which is used for Redis chunked transfer-encoding.
|
ByteArrayDecoder |
Decodes a received ByteBuf into an array of bytes.
|
ByteArrayEncoder |
Encodes the requested array of bytes into a ByteBuf .
|
ByteBuf |
A random and sequential accessible sequence of zero or more bytes (octets).
|
ByteBufAllocator |
Implementations are responsible to allocate buffers.
|
ByteBufAllocatorMetric |
|
ByteBufAllocatorMetricProvider |
|
ByteBufFormat |
|
ByteBufHolder |
A packet which is send or receive.
|
ByteBufInputStream |
|
ByteBufOutputStream |
|
ByteBufProcessor |
Deprecated.
|
ByteBufUtil |
A collection of utility methods that is related with handling ByteBuf ,
such as the generation of hex dump and swapping an integer's byte order.
|
ByteCollections |
Utilities for byte-based primitive collections.
|
ByteObjectHashMap<V> |
A hash map implementation of ByteObjectMap that uses open addressing for keys.
|
ByteObjectMap<V> |
Interface for a primitive map that uses byte s as keys.
|
ByteObjectMap.PrimitiveEntry<V> |
|
ByteProcessor |
Provides a mechanism to iterate over a collection of bytes.
|
ByteProcessor.IndexNotOfProcessor |
A ByteProcessor which finds the first appearance which is not of a specific byte.
|
ByteProcessor.IndexOfProcessor |
A ByteProcessor which finds the first appearance of a specific byte.
|
ByteToMessageCodec<I> |
A Codec for on-the-fly encoding/decoding of bytes to messages and vise-versa.
|
ByteToMessageDecoder |
|
ByteToMessageDecoder.Cumulator |
|
Bzip2Decoder |
Uncompresses a ByteBuf encoded with the Bzip2 format.
|
Bzip2Encoder |
Compresses a ByteBuf using the Bzip2 algorithm.
|
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.Unsafe |
Unsafe operations that should never be called from user-code.
|
ChannelConfig |
A set of configuration properties of a Channel .
|
ChannelDuplexHandler |
|
ChannelException |
|
ChannelFactory<T extends Channel> |
Deprecated.
|
ChannelFactory<T extends Channel> |
|
ChannelFlushPromiseNotifier |
This implementation allows to register ChannelFuture instances which will get notified once some amount of
data was written and so a checkpoint was reached.
|
ChannelFuture |
The result of an asynchronous Channel I/O operation.
|
ChannelFutureListener |
|
ChannelGroup |
A thread-safe Set that contains open Channel s and provides
various bulk operations on them.
|
ChannelGroupException |
|
ChannelGroupFuture |
|
ChannelGroupFutureListener |
|
ChannelHandler |
Handles an I/O event or intercepts an I/O operation, and forwards it to its next handler in
its ChannelPipeline .
|
ChannelHandler.Sharable |
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 |
|
ChannelHandlerContext |
|
ChannelHealthChecker |
|
ChannelId |
Represents the globally unique identifier of a Channel .
|
ChannelInboundHandler |
|
ChannelInboundHandlerAdapter |
Abstract base class for ChannelInboundHandler implementations which provide
implementations of all of their methods.
|
ChannelInboundInvoker |
|
ChannelInitializer<C extends Channel> |
|
ChannelInputShutdownEvent |
|
ChannelInputShutdownReadComplete |
User event that signifies the channel's input side is shutdown, and we tried to shut it down again.
|
ChannelMatcher |
|
ChannelMatchers |
Helper class which provides often used ChannelMatcher implementations.
|
ChannelMetadata |
Represents the properties of a Channel implementation.
|
ChannelOption<T> |
|
ChannelOutboundBuffer |
(Transport implementors only) an internal data structure used by AbstractChannel to store its pending
outbound write requests.
|
ChannelOutboundBuffer.MessageProcessor |
|
ChannelOutboundHandler |
|
ChannelOutboundHandlerAdapter |
|
ChannelOutboundInvoker |
|
ChannelOutputShutdownEvent |
|
ChannelOutputShutdownException |
Used to fail pending writes when a channel's output has been shutdown.
|
ChannelPipeline |
A list of ChannelHandler s which handles or intercepts inbound events and outbound operations of a
Channel .
|
ChannelPipelineException |
|
ChannelPool |
Allows to acquire and release Channel and so act as a pool of these.
|
ChannelPoolHandler |
Handler which is called for various actions done by the ChannelPool .
|
ChannelPoolMap<K,P extends ChannelPool> |
Allows to map ChannelPool implementations to a specific key.
|
ChannelProgressiveFuture |
|
ChannelProgressiveFutureListener |
An EventListener listener which will be called once the sending task associated with future is
being transferred.
|
ChannelProgressivePromise |
Special ChannelPromise which will be notified once the associated bytes is transferring.
|
ChannelPromise |
|
ChannelPromiseAggregator |
Deprecated.
|
ChannelPromiseNotifier |
ChannelFutureListener implementation which takes other ChannelPromise (s) and notifies them on completion.
|
ChannelTrafficShapingHandler |
This implementation of the AbstractTrafficShapingHandler is for channel
traffic shaping, that is to say a per channel limitation of the bandwidth.
|
ChannelUtils |
|
CharCollections |
Utilities for char-based primitive collections.
|
CharObjectHashMap<V> |
A hash map implementation of CharObjectMap that uses open addressing for keys.
|
CharObjectMap<V> |
Interface for a primitive map that uses char s as keys.
|
CharObjectMap.PrimitiveEntry<V> |
|
CharSequenceMap<V> |
Internal use only!
|
CharSequenceValueConverter |
|
CharsetUtil |
A utility class that provides various common operations and constants
related with Charset and its relevant classes.
|
ChunkedFile |
A ChunkedInput that fetches data from a file chunk by chunk.
|
ChunkedInput<B> |
|
ChunkedNioFile |
|
ChunkedNioStream |
|
ChunkedStream |
|
ChunkedWriteHandler |
|
CipherSuiteFilter |
Provides a means to filter the supplied cipher suite based upon the supported and default cipher suites.
|
ClassResolver |
|
ClassResolvers |
|
CleartextHttp2ServerUpgradeHandler |
Performing cleartext upgrade, by h2c HTTP upgrade or Prior Knowledge.
|
CleartextHttp2ServerUpgradeHandler.PriorKnowledgeUpgradeEvent |
User event that is fired to notify about HTTP/2 protocol is started.
|
ClientAuth |
Indicates the state of the SSLEngine with respect to client authentication.
|
ClientCookieDecoder |
A RFC6265 compliant cookie decoder to be used client side.
|
ClientCookieEncoder |
Deprecated. |
ClientCookieEncoder |
A RFC6265 compliant cookie encoder to be used client side, so
only name=value pairs are sent.
|
CloseWebSocketFrame |
Web Socket Frame for closing the connection.
|
CoalescingBufferQueue |
A FIFO queue of bytes where producers add bytes by repeatedly adding ByteBuf and consumers take bytes in
arbitrary lengths.
|
CodecException |
|
CombinedChannelDuplexHandler<I extends ChannelInboundHandler,O extends ChannelOutboundHandler> |
|
CombinedHttpHeaders |
Will add multiple values for the same header as single header with a comma separated list of values.
|
CommonsLoggerFactory |
Deprecated.
|
CompatibleObjectEncoder |
An encoder which serializes a Java object into a ByteBuf
(interoperability version).
|
CompleteFuture<V> |
A skeletal Future implementation which represents a Future which has been completed already.
|
CompositeByteBuf |
A virtual buffer which shows multiple buffers as a single merged buffer.
|
CompositeNameResolver<T> |
|
CompressionException |
|
CompressorHttp2ConnectionEncoder |
A decorating HTTP2 encoder that will compress data frames according to the content-encoding header for each
stream.
|
ConcurrentSet<E> |
Deprecated.
|
ConnectTimeoutException |
ConnectException which will be thrown if a connection could
not be established because of a connection timeout.
|
Constant<T extends Constant<T>> |
A singleton which is safe to compare via the == operator.
|
ConstantPool<T extends Constant<T>> |
|
ConstantTimeUtils |
|
ContinuationWebSocketFrame |
Web Socket continuation frame containing continuation text or binary data.
|
Cookie |
Deprecated.
|
Cookie |
|
CookieDecoder |
Parent of Client and Server side cookie decoders
|
CookieDecoder |
Deprecated.
|
CookieEncoder |
Parent of Client and Server side cookie encoders
|
CookieHeaderNames |
|
CookieHeaderNames.SameSite |
Possible values for the SameSite attribute.
|
CorruptedFrameException |
An DecoderException which is thrown when the received frame data could not be decoded by
an inbound handler.
|
CorruptedWebSocketFrameException |
|
CorsConfig |
Configuration for Cross-Origin Resource Sharing (CORS).
|
CorsConfig.Builder |
Deprecated.
|
CorsConfig.DateValueGenerator |
Deprecated.
|
CorsConfigBuilder |
Builder used to configure and build a CorsConfig instance.
|
CorsHandler |
|
DatagramChannel |
|
DatagramChannelConfig |
|
DatagramDnsQuery |
|
DatagramDnsQueryDecoder |
|
DatagramDnsQueryEncoder |
|
DatagramDnsResponse |
|
DatagramDnsResponseDecoder |
|
DatagramDnsResponseEncoder |
|
DatagramPacket |
The message container that is used for DatagramChannel to communicate with the remote peer.
|
DatagramPacketDecoder |
|
DatagramPacketEncoder<M> |
|
DatagramSocketAddress |
Act as special InetSocketAddress to be able to easily pass all needed data from JNI without the need
to create more objects then needed.
|
DateFormatter |
A formatter for HTTP header dates, such as "Expires" and "Date" headers, or "expires" field in "Set-Cookie".
|
DecoderException |
|
DecoderResult |
|
DecoderResultProvider |
Provides the accessor methods for the DecoderResult property of a decoded message.
|
DecompressionException |
|
DecoratingHttp2ConnectionDecoder |
|
DecoratingHttp2ConnectionEncoder |
|
DecoratingHttp2FrameWriter |
|
DefaultAddressedEnvelope<M,A extends SocketAddress> |
|
DefaultAddressResolverGroup |
|
DefaultAttributeMap |
Default AttributeMap implementation which not exibit any blocking behaviour on attribute lookup while using a
copy-on-write approach on the modify path. Attributes lookup and remove exibit O(logn) time worst-case
complexity, hence attribute::set(null) is to be preferred to remove .
|
DefaultAuthoritativeDnsServerCache |
|
DefaultBinaryMemcacheRequest |
|
DefaultBinaryMemcacheResponse |
|
DefaultBulkStringRedisContent |
|
DefaultByteBufHolder |
|
DefaultChannelConfig |
|
DefaultChannelGroup |
|
DefaultChannelId |
|
DefaultChannelPipeline |
|
DefaultChannelProgressivePromise |
|
DefaultChannelPromise |
|
DefaultCookie |
The default Cookie implementation.
|
DefaultCookie |
Deprecated.
|
DefaultDatagramChannelConfig |
|
DefaultDnsCache |
|
DefaultDnsCnameCache |
|
DefaultDnsOptEcsRecord |
|
DefaultDnsPtrRecord |
|
DefaultDnsQuery |
|
DefaultDnsQuestion |
|
DefaultDnsRawRecord |
The default DnsRawRecord implementation.
|
DefaultDnsRecordDecoder |
|
DefaultDnsRecordEncoder |
|
DefaultDnsResponse |
|
DefaultDnsServerAddressStreamProvider |
|
DefaultEventExecutor |
|
DefaultEventExecutorChooserFactory |
Default implementation which uses simple round-robin to choose next EventExecutor .
|
DefaultEventExecutorGroup |
|
DefaultEventLoop |
|
DefaultEventLoopGroup |
|
DefaultFileRegion |
|
DefaultFullBinaryMemcacheRequest |
|
DefaultFullBinaryMemcacheResponse |
|
DefaultFullHttpRequest |
|
DefaultFullHttpResponse |
|
DefaultHeaders<K,V,T extends Headers<K,V,T>> |
|
DefaultHeaders.HeaderEntry<K,V> |
|
DefaultHeaders.NameValidator<K> |
|
DefaultHeadersImpl<K,V> |
A concrete implementation of DefaultHeaders that allows for direct instantiation.
|
DefaultHostsFileEntriesResolver |
|
DefaultHttp2Connection |
|
DefaultHttp2ConnectionDecoder |
Provides the default implementation for processing inbound frame events and delegates to a
Http2FrameListener
|
DefaultHttp2ConnectionEncoder |
|
DefaultHttp2DataFrame |
|
DefaultHttp2FrameReader |
A Http2FrameReader that supports all frame types defined by the HTTP/2 specification.
|
DefaultHttp2FrameWriter |
A Http2FrameWriter that supports all frame types defined by the HTTP/2 specification.
|
DefaultHttp2GoAwayFrame |
|
DefaultHttp2Headers |
|
DefaultHttp2HeadersDecoder |
|
DefaultHttp2HeadersEncoder |
|
DefaultHttp2HeadersFrame |
|
DefaultHttp2LocalFlowController |
|
DefaultHttp2PingFrame |
|
DefaultHttp2PriorityFrame |
|
DefaultHttp2PushPromiseFrame |
|
DefaultHttp2RemoteFlowController |
|
DefaultHttp2ResetFrame |
|
DefaultHttp2SettingsFrame |
|
DefaultHttp2UnknownFrame |
|
DefaultHttp2WindowUpdateFrame |
|
DefaultHttpContent |
|
DefaultHttpDataFactory |
|
DefaultHttpHeaders |
|
DefaultHttpMessage |
|
DefaultHttpObject |
|
DefaultHttpRequest |
|
DefaultHttpResponse |
|
DefaultLastBulkStringRedisContent |
|
DefaultLastHttpContent |
|
DefaultLastMemcacheContent |
|
DefaultLastSmtpContent |
Default implementation of LastSmtpContent that does no validation of the raw data passed in.
|
DefaultLastStompContentSubframe |
|
DefaultMaxBytesRecvByteBufAllocator |
The RecvByteBufAllocator that yields a buffer size prediction based upon decrementing the value from
the max bytes per read.
|
DefaultMaxMessagesRecvByteBufAllocator |
|
DefaultMemcacheContent |
|
DefaultMessageSizeEstimator |
|
DefaultNameResolver |
A InetNameResolver that resolves using JDK's built-in domain name lookup mechanism.
|
DefaultOioServerSocketChannelConfig |
Deprecated.
|
DefaultOioSocketChannelConfig |
Deprecated.
|
DefaultPriorityQueue<T extends PriorityQueueNode> |
A priority queue which uses natural ordering of elements.
|
DefaultProgressivePromise<V> |
|
DefaultPromise<V> |
|
DefaultSelectStrategyFactory |
Factory which uses the default select strategy.
|
DefaultServerSocketChannelConfig |
|
DefaultSmtpContent |
Default implementation of SmtpContent that does no validation of the raw data passed in.
|
DefaultSmtpRequest |
|
DefaultSmtpResponse |
|
DefaultSocketChannelConfig |
|
DefaultSocks4CommandRequest |
|
DefaultSocks4CommandResponse |
|
DefaultSocks5CommandRequest |
|
DefaultSocks5CommandResponse |
|
DefaultSocks5InitialRequest |
|
DefaultSocks5InitialResponse |
|
DefaultSocks5PasswordAuthRequest |
|
DefaultSocks5PasswordAuthResponse |
|
DefaultSpdyDataFrame |
|
DefaultSpdyGoAwayFrame |
|
DefaultSpdyHeaders |
|
DefaultSpdyHeadersFrame |
|
DefaultSpdyPingFrame |
|
DefaultSpdyRstStreamFrame |
|
DefaultSpdySettingsFrame |
|
DefaultSpdyStreamFrame |
|
DefaultSpdySynReplyFrame |
|
DefaultSpdySynStreamFrame |
|
DefaultSpdyWindowUpdateFrame |
|
DefaultStompContentSubframe |
|
DefaultStompFrame |
|
DefaultStompHeaders |
|
DefaultStompHeadersSubframe |
|
DefaultThreadFactory |
|
DeflateFrameClientExtensionHandshaker |
|
DeflateFrameServerExtensionHandshaker |
|
DelegatingChannelPromiseNotifier |
|
DelegatingDecompressorFrameListener |
An HTTP2 frame listener that will decompress data frames according to the content-encoding header for each
stream.
|
DelegatingSslContext |
|
DelimiterBasedFrameDecoder |
A decoder that splits the received ByteBuf s by one or more
delimiters.
|
Delimiters |
|
DiskAttribute |
Disk implementation of Attributes
|
DiskFileUpload |
Disk FileUpload implementation that stores file into real files
|
DnsAddressResolverGroup |
|
DnsCache |
A cache for DNS resolution entries.
|
DnsCacheEntry |
Represents the results from a previous DNS query which can be cached.
|
DnsCnameCache |
A cache for CNAME s.
|
DnsMessage |
|
DnsNameResolver |
|
DnsNameResolverBuilder |
|
DnsNameResolverException |
|
DnsNameResolverTimeoutException |
|
DnsOpCode |
The DNS OpCode as defined in RFC2929.
|
DnsOptEcsRecord |
|
DnsOptPseudoRecord |
|
DnsPtrRecord |
|
DnsQuery |
A DNS query message.
|
DnsQueryLifecycleObserver |
This interface provides visibility into individual DNS queries.
|
DnsQueryLifecycleObserverFactory |
|
DnsQuestion |
A DNS question.
|
DnsRawRecord |
A generic DnsRecord that contains an undecoded RDATA .
|
DnsRecord |
A DNS resource record.
|
DnsRecordDecoder |
Decodes a DNS record into its object representation.
|
DnsRecordEncoder |
Encodes a DnsRecord into binary representation.
|
DnsRecordType |
Represents a DNS record type.
|
DnsResponse |
A DNS response message.
|
DnsResponseCode |
The DNS RCODE , as defined in RFC2929.
|
DnsSection |
|
DnsServerAddresses |
|
DnsServerAddressStream |
An infinite stream of DNS server addresses.
|
DnsServerAddressStreamProvider |
|
DnsServerAddressStreamProviders |
|
DomainMappingBuilder<V> |
Deprecated.
|
DomainNameMapping<V> |
Deprecated.
|
DomainNameMappingBuilder<V> |
Deprecated.
|
DomainSocketAddress |
|
DomainSocketChannel |
|
DomainSocketChannelConfig |
|
DomainSocketReadMode |
|
DomainWildcardMappingBuilder<V> |
|
DuplexChannel |
A duplex Channel that has two sides that can be shutdown independently.
|
DuplexChannelConfig |
|
DuplicatedByteBuf |
Deprecated.
|
DynamicAddressConnectHandler |
ChannelOutboundHandler implementation which allows to dynamically replace the used
remoteAddress and / or localAddress when making a connection attempt.
|
EmbeddedChannel |
Base class for Channel implementations that are used in an embedded fashion.
|
EmptyArrays |
|
EmptyByteBuf |
An empty ByteBuf whose capacity and maximum capacity are all 0 .
|
EmptyHeaders<K,V,T extends Headers<K,V,T>> |
|
EmptyHttp2Headers |
|
EmptyHttpHeaders |
|
EmptyPriorityQueue<T> |
|
EncoderException |
|
ErrorRedisMessage |
|
Errors |
Internal usage only!
|
Errors.NativeIoException |
Internal usage only!
|
EventExecutor |
|
EventExecutorChooserFactory |
|
EventExecutorChooserFactory.EventExecutorChooser |
|
EventExecutorGroup |
|
EventLoop |
Will handle all the I/O operations for a Channel once registered.
|
EventLoopException |
|
EventLoopGroup |
|
EventLoopTaskQueueFactory |
Factory used to create Queue instances that will be used to store tasks for an EventLoop .
|
FailedFuture<V> |
|
FastLzFrameDecoder |
|
FastLzFrameEncoder |
Compresses a ByteBuf using the FastLZ algorithm.
|
FastThreadLocal<V> |
|
FastThreadLocalThread |
|
FileDescriptor |
|
FileRegion |
|
FileUpload |
FileUpload interface that could be in memory, on temporary file or any other implementations.
|
FingerprintTrustManagerFactory |
|
FingerprintTrustManagerFactoryBuilder |
|
FixedChannelPool |
ChannelPool implementation that takes another ChannelPool implementation and enforce a maximum
number of concurrent connections.
|
FixedChannelPool.AcquireTimeoutAction |
|
FixedLengthFrameDecoder |
A decoder that splits the received ByteBuf s by the fixed number
of bytes.
|
FixedRecvByteBufAllocator |
|
FixedRedisMessagePool |
A default fixed redis message pool.
|
FlowControlHandler |
|
FlushConsolidationHandler |
|
FullBinaryMemcacheRequest |
|
FullBinaryMemcacheResponse |
|
FullBulkStringRedisMessage |
An aggregated bulk string of RESP.
|
FullHttpMessage |
|
FullHttpRequest |
|
FullHttpResponse |
|
FullMemcacheMessage |
|
Future<V> |
The result of an asynchronous operation.
|
FutureListener<V> |
|
GenericFutureListener<F extends Future<?>> |
Listens to the result of a Future .
|
GenericProgressiveFutureListener<F extends ProgressiveFuture<?>> |
|
GlobalChannelTrafficCounter |
|
GlobalChannelTrafficShapingHandler |
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.
|
GlobalEventExecutor |
|
GlobalTrafficShapingHandler |
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.
|
HAProxyCommand |
The command of an HAProxy proxy protocol header
|
HAProxyMessage |
Message container for decoded HAProxy proxy protocol parameters
|
HAProxyMessageDecoder |
Decodes an HAProxy proxy protocol header
|
HAProxyMessageEncoder |
Encodes an HAProxy proxy protocol message
|
HAProxyProtocolException |
A DecoderException which is thrown when an invalid HAProxy proxy protocol header is encountered
|
HAProxyProtocolVersion |
The HAProxy proxy protocol specification version.
|
HAProxyProxiedProtocol |
A protocol proxied by HAProxy which is represented by its transport protocol and address family.
|
HAProxyProxiedProtocol.AddressFamily |
The address family of an HAProxy proxy protocol header.
|
HAProxyProxiedProtocol.TransportProtocol |
The transport protocol of an HAProxy proxy protocol header
|
HAProxySSLTLV |
|
HAProxyTLV |
A Type-Length Value (TLV vector) that can be added to the PROXY protocol
to include additional information like SSL information.
|
HAProxyTLV.Type |
The registered types a TLV can have regarding the PROXY protocol 1.5 spec
|
HashedWheelTimer |
A Timer optimized for approximated I/O timeout scheduling.
|
HashingStrategy<T> |
Abstraction for hash code generation and equality comparison.
|
Headers<K,V,T extends Headers<K,V,T>> |
Common interface for Headers which represents a mapping of key to value.
|
HeadersUtils |
Provides utility methods related to Headers .
|
HostsFileEntries |
A container of hosts file entries
|
HostsFileEntriesResolver |
Resolves a hostname against the hosts file entries.
|
HostsFileParser |
A parser for hosts files.
|
Http2ChannelDuplexHandler |
|
Http2ClientUpgradeCodec |
Client-side cleartext upgrade codec from HTTP to HTTP/2.
|
Http2CodecUtil |
Constants and utility method used for encoding/decoding HTTP2 frames.
|
Http2Connection |
Manager for the state of an HTTP/2 connection with the remote end-point.
|
Http2Connection.Endpoint<F extends Http2FlowController> |
A view of the connection from one endpoint (local or remote).
|
Http2Connection.Listener |
Listener for life-cycle events for streams in this connection.
|
Http2Connection.PropertyKey |
A key to be used for associating application-defined properties with streams within this connection.
|
Http2ConnectionAdapter |
|
Http2ConnectionDecoder |
|
Http2ConnectionEncoder |
Handler for outbound HTTP/2 traffic.
|
Http2ConnectionHandler |
Provides the default implementation for processing inbound frame events and delegates to a
Http2FrameListener
|
Http2ConnectionHandlerBuilder |
|
Http2ConnectionPrefaceAndSettingsFrameWrittenEvent |
|
Http2DataFrame |
HTTP/2 DATA frame.
|
Http2DataWriter |
Interface that defines an object capable of producing HTTP/2 data frames.
|
Http2Error |
All error codes identified by the HTTP/2 spec.
|
Http2EventAdapter |
|
Http2Exception |
Exception thrown when an HTTP/2 error was encountered.
|
Http2Exception.ClosedStreamCreationException |
Used when a stream creation attempt fails but may be because the stream was previously closed.
|
Http2Exception.CompositeStreamException |
Provides the ability to handle multiple stream exceptions with one throw statement.
|
Http2Exception.HeaderListSizeException |
|
Http2Exception.ShutdownHint |
Provides a hint as to if shutdown is justified, what type of shutdown should be executed.
|
Http2Exception.StreamException |
Represents an exception that can be isolated to a single stream (as opposed to the entire connection).
|
Http2Flags |
Provides utility methods for accessing specific flags as defined by the HTTP/2 spec.
|
Http2FlowController |
Base interface for all HTTP/2 flow controllers.
|
Http2Frame |
An HTTP/2 frame.
|
Http2FrameAdapter |
Convenience class that provides no-op implementations for all methods of Http2FrameListener .
|
Http2FrameCodec |
This API is very immature. The Http2Connection-based API is currently preferred over this API.
|
Http2FrameCodecBuilder |
|
Http2FrameListener |
An listener of HTTP/2 frames.
|
Http2FrameListenerDecorator |
|
Http2FrameLogger |
Logs HTTP2 frames for debugging purposes.
|
Http2FrameLogger.Direction |
|
Http2FrameReader |
|
Http2FrameReader.Configuration |
|
Http2FrameSizePolicy |
|
Http2FrameStream |
A single stream within an HTTP/2 connection.
|
Http2FrameStreamEvent |
|
Http2FrameStreamException |
|
Http2FrameStreamVisitor |
|
Http2FrameTypes |
Registry of all standard frame types defined by the HTTP/2 specification.
|
Http2FrameWriter |
A writer responsible for marshaling HTTP/2 frames to the channel.
|
Http2FrameWriter.Configuration |
|
Http2GoAwayFrame |
HTTP/2 GOAWAY frame.
|
Http2Headers |
A collection of headers sent or received via HTTP/2.
|
Http2Headers.PseudoHeaderName |
HTTP/2 pseudo-headers names.
|
Http2HeadersDecoder |
|
Http2HeadersDecoder.Configuration |
|
Http2HeadersEncoder |
|
Http2HeadersEncoder.Configuration |
|
Http2HeadersEncoder.SensitivityDetector |
Determine if a header name/value pair is treated as
sensitive.
|
Http2HeadersFrame |
HTTP/2 HEADERS frame.
|
Http2InboundFrameLogger |
Decorator around a Http2FrameReader that logs all inbound frames before calling
back the listener.
|
Http2LifecycleManager |
Manager for the life cycle of the HTTP/2 connection.
|
Http2LocalFlowController |
A Http2FlowController for controlling the inbound flow of DATA frames from the remote endpoint.
|
Http2MultiplexCodec |
Deprecated.
|
Http2MultiplexCodecBuilder |
Deprecated.
|
Http2MultiplexHandler |
An HTTP/2 handler that creates child channels for each stream.
|
Http2NoMoreStreamIdsException |
This exception is thrown when there are no more stream IDs available for the current connection
|
Http2OutboundFrameLogger |
Decorator around a Http2FrameWriter that logs all outbound frames before calling the
writer.
|
Http2PingFrame |
HTTP/2 PING Frame.
|
Http2PriorityFrame |
HTTP/2 Priority Frame
|
Http2PromisedRequestVerifier |
Provides an extensibility point for users to define the validity of push requests.
|
Http2PushPromiseFrame |
HTTP/2 Push Promise Frame
|
Http2RemoteFlowController |
|
Http2RemoteFlowController.FlowControlled |
Implementations of this interface are used to progressively write chunks of the underlying
payload to the stream.
|
Http2RemoteFlowController.Listener |
Listener to the number of flow-controlled bytes written per stream.
|
Http2ResetFrame |
HTTP/2 RST_STREAM frame.
|
Http2SecurityUtil |
Provides utilities related to security requirements specific to HTTP/2.
|
Http2ServerUpgradeCodec |
Server-side codec for performing a cleartext upgrade from HTTP/1.x to HTTP/2.
|
Http2Settings |
Settings for one endpoint in an HTTP/2 connection.
|
Http2SettingsAckFrame |
|
Http2SettingsFrame |
HTTP/2 SETTINGS frame.
|
Http2SettingsReceivedConsumer |
Provides a Consumer like interface to consume remote settings received but not yet ACKed.
|
Http2Stream |
A single stream within an HTTP2 connection.
|
Http2Stream.State |
The allowed states of an HTTP2 stream.
|
Http2StreamChannel |
|
Http2StreamChannelBootstrap |
|
Http2StreamFrame |
A frame whose meaning may apply to a particular stream, instead of the entire connection.
|
Http2StreamFrameToHttpObjectCodec |
|
Http2StreamVisitor |
A visitor that allows iteration over a collection of streams.
|
Http2UnknownFrame |
|
Http2WindowUpdateFrame |
HTTP/2 WINDOW_UPDATE frame.
|
HttpChunkedInput |
A ChunkedInput that fetches data chunk by chunk for use with HTTP chunked transfers.
|
HttpClientCodec |
|
HttpClientUpgradeHandler |
Client-side handler for handling an HTTP upgrade handshake to another protocol.
|
HttpClientUpgradeHandler.SourceCodec |
The source codec that is used in the pipeline initially.
|
HttpClientUpgradeHandler.UpgradeCodec |
A codec that the source can be upgraded to.
|
HttpClientUpgradeHandler.UpgradeEvent |
User events that are fired to notify about upgrade status.
|
HttpConstants |
|
HttpContent |
An HTTP chunk which is used for HTTP chunked transfer-encoding.
|
HttpContentCompressor |
Compresses an HttpMessage and an HttpContent in gzip or
deflate encoding while respecting the "Accept-Encoding" header.
|
HttpContentDecoder |
|
HttpContentDecompressor |
|
HttpContentEncoder |
|
HttpContentEncoder.Result |
|
HttpConversionUtil |
Provides utility methods and constants for the HTTP/2 to HTTP conversion
|
HttpConversionUtil.ExtensionHeaderNames |
Provides the HTTP header extensions used to carry HTTP/2 information in HTTP objects
|
HttpData |
Extended interface for InterfaceHttpData
|
HttpDataFactory |
Interface to enable creation of InterfaceHttpData objects
|
HttpExpectationFailedEvent |
A user event designed to communicate that a expectation has failed and there should be no expectation that a
body will follow.
|
HttpHeaderDateFormat |
Deprecated.
|
HttpHeaderNames |
Standard HTTP header names.
|
HttpHeaders |
Provides the constants for the standard HTTP header names and values and
commonly used utility methods that accesses an HttpMessage .
|
HttpHeaders.Names |
Deprecated.
|
HttpHeaders.Values |
Deprecated.
|
HttpHeaderValues |
Standard HTTP header values.
|
HttpMessage |
|
HttpMethod |
The request method of HTTP or its derived protocols, such as
RTSP and
ICAP.
|
HttpObject |
|
HttpObjectAggregator |
|
HttpObjectDecoder |
|
HttpObjectEncoder<H extends HttpMessage> |
|
HttpPostMultipartRequestDecoder |
This decoder will decode Body and can handle POST BODY.
|
HttpPostRequestDecoder |
This decoder will decode Body and can handle POST BODY.
|
HttpPostRequestDecoder.EndOfDataDecoderException |
Exception when the body is fully decoded, even if there is still data
|
HttpPostRequestDecoder.ErrorDataDecoderException |
Exception when an error occurs while decoding
|
HttpPostRequestDecoder.MultiPartStatus |
states follow NOTSTARTED PREAMBLE ( (HEADERDELIMITER DISPOSITION (FIELD |
FILEUPLOAD))* (HEADERDELIMITER DISPOSITION MIXEDPREAMBLE (MIXEDDELIMITER
MIXEDDISPOSITION MIXEDFILEUPLOAD)+ MIXEDCLOSEDELIMITER)* CLOSEDELIMITER)+
EPILOGUE
First getStatus is: NOSTARTED
Content-type: multipart/form-data, boundary=AaB03x => PREAMBLE in Header
--AaB03x => HEADERDELIMITER content-disposition: form-data; name="field1"
=> DISPOSITION
Joe Blow => FIELD --AaB03x => HEADERDELIMITER content-disposition:
form-data; name="pics" => DISPOSITION Content-type: multipart/mixed,
boundary=BbC04y
--BbC04y => MIXEDDELIMITER Content-disposition: attachment;
filename="file1.txt" => MIXEDDISPOSITION Content-Type: text/plain
...
|
HttpPostRequestDecoder.NotEnoughDataDecoderException |
Exception when try reading data from request in chunked format, and not
enough data are available (need more chunks)
|
HttpPostRequestEncoder |
This encoder will help to encode Request for a FORM as POST.
|
HttpPostRequestEncoder.EncoderMode |
Different modes to use to encode form data.
|
HttpPostRequestEncoder.ErrorDataEncoderException |
Exception when an error occurs while encoding
|
HttpPostStandardRequestDecoder |
This decoder will decode Body and can handle POST BODY.
|
HttpProxyHandler |
|
HttpProxyHandler.HttpProxyConnectException |
Specific case of a connection failure, which may include headers from the proxy.
|
HttpRequest |
An HTTP request.
|
HttpRequestDecoder |
|
HttpRequestEncoder |
|
HttpResponse |
An HTTP response.
|
HttpResponseDecoder |
|
HttpResponseEncoder |
|
HttpResponseStatus |
The response code and its description of HTTP or its derived protocols, such as
RTSP and
ICAP.
|
HttpScheme |
Defines the common schemes used for the HTTP protocol as defined by
rfc7230.
|
HttpServerCodec |
|
HttpServerExpectContinueHandler |
|
HttpServerKeepAliveHandler |
HttpServerKeepAliveHandler helps close persistent connections when appropriate.
|
HttpServerUpgradeHandler |
A server-side handler that receives HTTP requests and optionally performs a protocol switch if
the requested protocol is supported.
|
HttpServerUpgradeHandler.SourceCodec |
The source codec that is used in the pipeline initially.
|
HttpServerUpgradeHandler.UpgradeCodec |
A codec that the source can be upgraded to.
|
HttpServerUpgradeHandler.UpgradeCodecFactory |
|
HttpServerUpgradeHandler.UpgradeEvent |
User event that is fired to notify about the completion of an HTTP upgrade
to another protocol.
|
HttpStatusClass |
The class of HTTP status.
|
HttpToHttp2ConnectionHandler |
Translates HTTP/1.x object writes into HTTP/2 frames.
|
HttpToHttp2ConnectionHandlerBuilder |
|
HttpUtil |
Utility methods useful in the HTTP context.
|
HttpVersion |
The version of HTTP or its derived protocols, such as
RTSP and
ICAP.
|
IdentityCipherSuiteFilter |
This class will not do any filtering of ciphers suites.
|
IdleState |
|
IdleStateEvent |
|
IdleStateHandler |
|
IllegalReferenceCountException |
|
ImmediateEventExecutor |
Executes Runnable objects in the caller's thread.
|
ImmediateExecutor |
Executor which execute tasks in the callers thread.
|
InboundHttp2ToHttpAdapter |
|
InboundHttp2ToHttpAdapterBuilder |
|
InboundHttpToHttp2Adapter |
Translates HTTP/1.x object reads into HTTP/2 frames.
|
InetNameResolver |
|
InetSocketAddressResolver |
|
InlineCommandRedisMessage |
|
InsecureTrustManagerFactory |
|
IntCollections |
Utilities for int-based primitive collections.
|
IntegerHolder |
Deprecated.
|
IntegerRedisMessage |
|
InterfaceHttpData |
Interface for all Objects that could be encoded/decoded using HttpPostRequestEncoder/Decoder
|
InterfaceHttpData.HttpDataType |
|
InterfaceHttpPostRequestDecoder |
This decoder will decode Body and can handle POST BODY.
|
InternalLogger |
Internal-use-only logger used by Netty.
|
InternalLoggerFactory |
Creates an InternalLogger or changes the default factory
implementation.
|
InternalLogLevel |
|
InternalThreadLocalMap |
The internal data structure that stores the thread-local variables for Netty and all FastThreadLocal s.
|
InternetProtocolFamily |
|
IntObjectHashMap<V> |
A hash map implementation of IntObjectMap that uses open addressing for keys.
|
IntObjectMap<V> |
Interface for a primitive map that uses int s as keys.
|
IntObjectMap.PrimitiveEntry<V> |
|
IntSupplier |
Represents a supplier of int -valued results.
|
IovArray |
Represent an array of struct array and so can be passed directly over via JNI without the need to do any more
array copies.
|
IpFilterRule |
Implement this interface to create new rules.
|
IpFilterRuleType |
Used in IpFilterRule to decide if a matching IP Address should be allowed or denied to connect.
|
IpSubnetFilter |
|
IpSubnetFilterRule |
Use this class to create rules for RuleBasedIpFilter that group IP addresses into subnets.
|
JdkAlpnApplicationProtocolNegotiator |
Deprecated.
|
JdkApplicationProtocolNegotiator |
Deprecated.
|
JdkApplicationProtocolNegotiator.AllocatorAwareSslEngineWrapperFactory |
|
JdkApplicationProtocolNegotiator.ProtocolSelectionListener |
A listener to be notified by which protocol was select by its peer.
|
JdkApplicationProtocolNegotiator.ProtocolSelectionListenerFactory |
|
JdkApplicationProtocolNegotiator.ProtocolSelector |
Interface to define the role of an application protocol selector in the SSL handshake process.
|
JdkApplicationProtocolNegotiator.ProtocolSelectorFactory |
|
JdkApplicationProtocolNegotiator.SslEngineWrapperFactory |
Abstract factory pattern for wrapping an SSLEngine object.
|
JdkLoggerFactory |
|
JdkNpnApplicationProtocolNegotiator |
Deprecated.
|
JdkSslClientContext |
Deprecated.
|
JdkSslContext |
An SslContext which uses JDK's SSL/TLS implementation.
|
JdkSslServerContext |
Deprecated.
|
JdkZlibDecoder |
Decompress a ByteBuf using the inflate algorithm.
|
JdkZlibEncoder |
Compresses a ByteBuf using the deflate algorithm.
|
JsonObjectDecoder |
Splits a byte stream of JSON objects and arrays into individual objects/arrays and passes them up the
ChannelPipeline .
|
JZlibDecoder |
|
JZlibEncoder |
Compresses a ByteBuf using the deflate algorithm.
|
KeyManagerFactoryWrapper |
|
KmpSearchProcessorFactory |
|
KmpSearchProcessorFactory.Processor |
|
LastBulkStringRedisContent |
A last chunk of Bulk Strings.
|
LastHttpContent |
|
LastMemcacheContent |
|
LastSmtpContent |
The last part of a sequence of SmtpContent s that are sent after a DATA request.
|
LastStompContentSubframe |
|
LazyJavaxX509Certificate |
|
LazyX509Certificate |
|
LengthFieldBasedFrameDecoder |
A decoder that splits the received ByteBuf s dynamically by the
value of the length field in the message.
|
LengthFieldPrepender |
An encoder that prepends the length of the message.
|
Limits |
|
LineBasedFrameDecoder |
A decoder that splits the received ByteBuf s on line endings.
|
LineEncoder |
Apply a line separator to the requested String and encode it into a ByteBuf .
|
LineSeparator |
A class to represent line separators in different environments.
|
LocalAddress |
An endpoint in the local transport.
|
LocalChannel |
|
LocalEventLoopGroup |
Deprecated.
|
LocalServerChannel |
A ServerChannel for the local transport which allows in VM communication.
|
LoggingDnsQueryLifeCycleObserverFactory |
|
LoggingHandler |
|
LogLevel |
|
LongCollections |
Utilities for long-based primitive collections.
|
LongCounter |
Counter for long.
|
LongObjectHashMap<V> |
A hash map implementation of LongObjectMap that uses open addressing for keys.
|
LongObjectMap<V> |
Interface for a primitive map that uses long s as keys.
|
LongObjectMap.PrimitiveEntry<V> |
|
MacAddressUtil |
|
Mapping<IN,OUT> |
Maintains the mapping from the objects of one type to the objects of the other type.
|
MathUtil |
Math utility methods.
|
MaxBytesRecvByteBufAllocator |
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.
|
MaxMessagesRecvByteBufAllocator |
RecvByteBufAllocator that limits the number of read operations that will be attempted when a read operation
is attempted by the event loop.
|
MemcacheContent |
An Memcache content chunk.
|
MemcacheMessage |
Marker interface for both ascii and binary messages.
|
MemcacheObject |
|
MemoryAttribute |
Memory implementation of Attributes
|
MemoryFileUpload |
Default FileUpload implementation that stores file into memory.
Warning: be aware of the memory limitation.
|
MessageAggregationException |
Raised by MessageAggregator when aggregation fails due to an unexpected message sequence.
|
MessageAggregator<I,S,C extends ByteBufHolder,O extends ByteBufHolder> |
An abstract ChannelHandler that aggregates a series of message objects into a single aggregated message.
|
MessageSizeEstimator |
Responsible to estimate the size of a message.
|
MessageSizeEstimator.Handle |
|
MessageToByteEncoder<I> |
|
MessageToMessageCodec<INBOUND_IN,OUTBOUND_IN> |
A Codec for on-the-fly encoding/decoding of message.
|
MessageToMessageDecoder<I> |
|
MessageToMessageEncoder<I> |
|
MixedAttribute |
Mixed implementation using both in Memory and in File with a limit of size
|
MixedFileUpload |
Mixed implementation using both in Memory and in File with a limit of size
|
MqttConnAckMessage |
|
MqttConnAckVariableHeader |
|
MqttConnectMessage |
|
MqttConnectPayload |
|
MqttConnectReturnCode |
|
MqttConnectVariableHeader |
|
MqttDecoder |
Decodes Mqtt messages from bytes, following
the MQTT protocol specification
v3.1
or
v5.0, depending on the
version specified in the CONNECT message that first goes through the channel.
|
MqttEncoder |
Encodes Mqtt messages into bytes following the protocol specification v3.1
as described here MQTTV3.1
or v5.0 as described here MQTTv5.0 -
depending on the version specified in the first CONNECT message that goes through the channel.
|
MqttFixedHeader |
|
MqttIdentifierRejectedException |
|
MqttMessage |
Base class for all MQTT message types.
|
MqttMessageBuilders |
|
MqttMessageBuilders.AuthBuilder |
|
MqttMessageBuilders.ConnAckBuilder |
|
MqttMessageBuilders.ConnAckPropertiesBuilder |
|
MqttMessageBuilders.ConnectBuilder |
|
MqttMessageBuilders.DisconnectBuilder |
|
MqttMessageBuilders.PropertiesInitializer<T> |
|
MqttMessageBuilders.PubAckBuilder |
|
MqttMessageBuilders.PublishBuilder |
|
MqttMessageBuilders.SubAckBuilder |
|
MqttMessageBuilders.SubscribeBuilder |
|
MqttMessageBuilders.UnsubAckBuilder |
|
MqttMessageBuilders.UnsubscribeBuilder |
|
MqttMessageFactory |
Utility class with factory methods to create different types of MQTT messages.
|
MqttMessageIdAndPropertiesVariableHeader |
Variable Header containing, Packet Id and Properties as in MQTT v5 spec.
|
MqttMessageIdVariableHeader |
|
MqttMessageType |
MQTT Message Types.
|
MqttProperties |
MQTT Properties container
|
MqttProperties.BinaryProperty |
|
MqttProperties.IntegerProperty |
|
MqttProperties.MqttProperty<T> |
MQTT property base class
|
MqttProperties.MqttPropertyType |
|
MqttProperties.StringPair |
|
MqttProperties.StringProperty |
|
MqttProperties.UserProperties |
|
MqttProperties.UserProperty |
|
MqttPubAckMessage |
|
MqttPublishMessage |
|
MqttPublishVariableHeader |
|
MqttPubReplyMessageVariableHeader |
Variable Header containing Packet Id, reason code and Properties as in MQTT v5 spec.
|
MqttQoS |
|
MqttReasonCodeAndPropertiesVariableHeader |
Variable Header for AUTH and DISCONNECT messages represented by MqttMessage
|
MqttSubAckMessage |
|
MqttSubAckPayload |
|
MqttSubscribeMessage |
|
MqttSubscribePayload |
|
MqttSubscriptionOption |
Model the SubscriptionOption used in Subscribe MQTT v5 packet
|
MqttSubscriptionOption.RetainedHandlingPolicy |
|
MqttTopicSubscription |
Contains a topic name and Qos Level.
|
MqttUnacceptableProtocolVersionException |
|
MqttUnsubAckMessage |
|
MqttUnsubAckPayload |
Payload for MQTT unsuback message as in V5.
|
MqttUnsubscribeMessage |
|
MqttUnsubscribePayload |
|
MqttVersion |
Mqtt version specific constant values used by multiple classes in mqtt-codec.
|
MultiDnsServerAddressStreamProvider |
|
MultiSearchProcessor |
Interface for SearchProcessor that implements simultaneous search for multiple strings.
|
MultiSearchProcessorFactory |
|
MultithreadEventExecutorGroup |
Abstract base class for EventExecutorGroup implementations that handles their tasks with multiple threads at
the same time.
|
MultithreadEventLoopGroup |
Abstract base class for EventLoopGroup implementations that handles their tasks with multiple threads at
the same time.
|
NameResolver<T> |
Resolves an arbitrary string that represents the name of an endpoint into an address.
|
NameServerComparator |
Special Comparator implementation to sort the nameservers to use when follow redirects.
|
NativeInetAddress |
Internal usage only!
|
NativeLibraryLoader |
Helper class to load JNI resources.
|
NettyRuntime |
A utility class for wrapping calls to Runtime .
|
NetUtil |
A class that holds a number of network-related constants.
|
NioChannelOption<T> |
|
NioDatagramChannel |
|
NioEventLoop |
|
NioEventLoopGroup |
|
NioServerSocketChannel |
A ServerSocketChannel implementation which uses
NIO selector based implementation to accept new connections.
|
NioSocketChannel |
|
NioTask<C extends SelectableChannel> |
|
NonStickyEventExecutorGroup |
|
NoopAddressResolver |
A AddressResolver that does not perform any resolution but always reports successful resolution.
|
NoopAddressResolverGroup |
|
NoopAuthoritativeDnsServerCache |
|
NoopDnsCache |
A noop DNS cache that actually never caches anything.
|
NoopDnsCnameCache |
|
NoopDnsQueryLifecycleObserverFactory |
|
NoOpTypeParameterMatcher |
|
NotSslRecordException |
Special SSLException which will get thrown if a packet is
received that not looks like a TLS/SSL record.
|
ObjectCleaner |
Allows a way to register some Runnable that will executed once there are no references to an Object
anymore.
|
ObjectDecoder |
A decoder which deserializes the received ByteBuf s into Java
objects.
|
ObjectDecoderInputStream |
|
ObjectEncoder |
An encoder which serializes a Java object into a ByteBuf .
|
ObjectEncoderOutputStream |
|
ObjectPool<T> |
Light-weight object pool.
|
ObjectPool.Handle<T> |
Handle for an pooled Object that will be used to notify the ObjectPool once it can
reuse the pooled Object again.
|
ObjectPool.ObjectCreator<T> |
|
ObjectUtil |
A grab-bag of useful utility methods.
|
OioByteStreamChannel |
Deprecated.
|
OioDatagramChannel |
Deprecated.
|
OioDatagramChannelConfig |
Deprecated.
|
OioEventLoopGroup |
Deprecated.
|
OioServerSocketChannel |
Deprecated.
|
OioServerSocketChannelConfig |
Deprecated.
|
OioSocketChannel |
Deprecated.
|
OioSocketChannelConfig |
Deprecated.
|
OpenSslApplicationProtocolNegotiator |
Deprecated.
|
OpenSslDefaultApplicationProtocolNegotiator |
Deprecated.
|
OpenSslNpnApplicationProtocolNegotiator |
Deprecated.
|
OptionalSslHandler |
OptionalSslHandler is a utility decoder to support both SSL and non-SSL handlers
based on the first message received.
|
OrderedEventExecutor |
Marker interface for EventExecutor s that will process all submitted tasks in an ordered / serial fashion.
|
OutOfDirectMemoryError |
|
PcapWriteHandler |
|
PeerCredentials |
User credentials discovered for the peer unix domain socket.
|
PemPrivateKey |
This is a special purpose implementation of a PrivateKey which allows the
user to pass PEM/PKCS#8 encoded key material straight into OpenSslContext
without having to parse and re-encode bytes in Java land.
|
PemX509Certificate |
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.
|
PendingWrite |
Some pending write which should be picked up later.
|
PendingWriteQueue |
A queue of write operations which are pending for later execution.
|
PerMessageDeflateClientExtensionHandshaker |
|
PerMessageDeflateServerExtensionHandshaker |
|
PingWebSocketFrame |
Web Socket frame containing binary data.
|
PlatformDependent |
Utility that detects various properties specific to the current runtime
environment, such as Java version and the availability of the
sun.misc.Unsafe object.
|
PongWebSocketFrame |
Web Socket frame containing binary data.
|
PoolArenaMetric |
Expose metrics for an arena.
|
PoolChunkListMetric |
Metrics for a list of chunks.
|
PoolChunkMetric |
Metrics for a chunk.
|
PooledByteBufAllocator |
|
PooledByteBufAllocatorMetric |
|
PoolSubpageMetric |
Metrics for a sub-page.
|
PreferHeapByteBufAllocator |
Wraps another ByteBufAllocator and use heapbuffers everywhere except when a direct buffer is explicit
requested.
|
PreferredDirectByteBufAllocator |
|
PrematureChannelClosureException |
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.
|
PriorityQueue<T> |
|
PriorityQueueNode |
|
ProgressiveFuture<V> |
A Future which is used to indicate the progress of an operation.
|
ProgressivePromise<V> |
|
Promise<V> |
Special Future which is writable.
|
PromiseAggregator<V,F extends Future<V>> |
Deprecated.
|
PromiseCombiner |
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.
|
PromiseNotificationUtil |
Internal utilities to notify Promise s.
|
PromiseNotifier<V,F extends Future<V>> |
|
ProtocolDetectionResult<T> |
Result of detecting a protocol.
|
ProtocolDetectionState |
The state of the current detection.
|
ProxyConnectException |
|
ProxyConnectionEvent |
|
ProxyHandler |
|
QueryStringDecoder |
Splits an HTTP query string into a path string and key-value parameter pairs.
|
QueryStringEncoder |
Creates a URL-encoded URI from a path string and key-value parameter pairs.
|
ReadOnlyByteBuf |
Deprecated.
|
ReadOnlyHttp2Headers |
A variant of Http2Headers which only supports read-only methods.
|
ReadOnlyHttpHeaders |
A variant of HttpHeaders which only supports read-only methods.
|
ReadOnlyIterator<T> |
|
ReadTimeoutException |
|
ReadTimeoutHandler |
|
RecvByteBufAllocator |
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 |
|
RecvByteBufAllocator.ExtendedHandle |
|
RecvByteBufAllocator.Handle |
Deprecated.
|
RecyclableArrayList |
A simple list which is recyclable.
|
Recycler<T> |
Light-weight object pool based on a thread-local stack.
|
Recycler.Handle<T> |
|
RedisArrayAggregator |
|
RedisBulkStringAggregator |
|
RedisCodecException |
|
RedisDecoder |
|
RedisEncoder |
|
RedisMessage |
RedisMessage is base interface for codec-redis.
|
RedisMessagePool |
|
RedisMessageType |
|
ReferenceCounted |
A reference-counted object that requires explicit deallocation.
|
ReferenceCountUpdater<T extends ReferenceCounted> |
|
ReferenceCountUtil |
|
ReflectionUtil |
|
ReflectiveChannelFactory<T extends Channel> |
|
RejectedExecutionHandler |
|
RejectedExecutionHandlers |
|
ReplayingDecoder<S> |
A specialized variation of ByteToMessageDecoder which enables implementation
of a non-blocking decoder in the blocking I/O paradigm.
|
ResolveAddressHandler |
|
ResolvedAddressTypes |
Defined resolved address types.
|
ResourceLeak |
Deprecated.
|
ResourceLeakDetector<T> |
|
ResourceLeakDetector.Level |
Represents the level of resource leak detection.
|
ResourceLeakDetectorFactory |
|
ResourceLeakException |
Deprecated.
|
ResourceLeakHint |
A hint object that provides human-readable message for easier resource leak tracking.
|
ResourceLeakTracker<T> |
|
ResourcesUtil |
A utility class that provides various common operations and constants
related to loading resources
|
RoundRobinDnsAddressResolverGroup |
|
RoundRobinInetAddressResolver |
|
RtspDecoder |
|
RtspEncoder |
|
RtspHeaderNames |
Standard RTSP header names.
|
RtspHeaders |
Deprecated.
|
RtspHeaders.Names |
Deprecated.
|
RtspHeaders.Values |
Deprecated.
|
RtspHeaderValues |
Standard RTSP header names.
|
RtspMethods |
The request getMethod of RTSP.
|
RtspObjectDecoder |
Deprecated.
|
RtspObjectEncoder<H extends HttpMessage> |
Deprecated.
|
RtspRequestDecoder |
Deprecated.
|
RtspRequestEncoder |
Deprecated.
|
RtspResponseDecoder |
Deprecated.
|
RtspResponseEncoder |
Deprecated.
|
RtspResponseStatuses |
The getStatus code and its description of a RTSP response.
|
RtspVersions |
The version of RTSP.
|
RuleBasedIpFilter |
This class allows one to filter new Channel s based on the
IpFilterRule s passed to its constructor.
|
ScheduledFuture<V> |
The result of an scheduled asynchronous operation.
|
SearchProcessor |
|
SearchProcessorFactory |
|
SelectStrategy |
Select strategy interface.
|
SelectStrategyFactory |
|
SelfSignedCertificate |
Generates a temporary self-signed certificate for testing purposes.
|
SequentialDnsServerAddressStreamProvider |
|
ServerBootstrap |
|
ServerBootstrapConfig |
|
ServerChannel |
A Channel that accepts an incoming connection attempt and creates
its child Channel s by accepting them.
|
ServerCookieDecoder |
A RFC6265 compliant cookie decoder to be used server side.
|
ServerCookieEncoder |
A RFC6265 compliant cookie encoder to be used server side,
so some fields are sent (Version is typically ignored).
|
ServerCookieEncoder |
Deprecated.
|
ServerDomainSocketChannel |
|
ServerSocketChannel |
A TCP/IP ServerChannel which accepts incoming TCP/IP connections.
|
ServerSocketChannelConfig |
|
ShortCollections |
Utilities for short-based primitive collections.
|
ShortObjectHashMap<V> |
A hash map implementation of ShortObjectMap that uses open addressing for keys.
|
ShortObjectMap<V> |
Interface for a primitive map that uses short s as keys.
|
ShortObjectMap.PrimitiveEntry<V> |
|
Signal |
A special Error which is used to signal some state or request by throwing it.
|
SimpleChannelInboundHandler<I> |
|
SimpleChannelPool |
Simple ChannelPool implementation which will create new Channel s if someone tries to acquire
a Channel but none is in the pool atm.
|
SimpleKeyManagerFactory |
|
SimpleNameResolver<T> |
|
SimpleStringRedisMessage |
|
SimpleTrustManagerFactory |
|
SimpleUserEventChannelHandler<I> |
|
SingleThreadEventExecutor |
Abstract base class for OrderedEventExecutor 's that execute all its submitted tasks in a single thread.
|
SingleThreadEventExecutor.NonWakeupRunnable |
Deprecated.
|
SingleThreadEventLoop |
Abstract base class for EventLoop s that execute all its submitted tasks in a single thread.
|
SingletonDnsServerAddressStreamProvider |
|
SizeClassesMetric |
Expose metrics for an SizeClasses.
|
Slf4JLoggerFactory |
Logger factory which creates a SLF4J
logger.
|
SlicedByteBuf |
Deprecated.
|
SmtpCommand |
|
SmtpContent |
Content that is sent after the DATA request.
|
SmtpRequest |
An SMTP request.
|
SmtpRequestEncoder |
Encoder for SMTP requests.
|
SmtpRequests |
|
SmtpResponse |
A SMTP response
|
SmtpResponseDecoder |
Decoder for SMTP responses.
|
Snappy |
Uncompresses an input ByteBuf encoded with Snappy compression into an
output ByteBuf .
|
SnappyFramedDecoder |
Deprecated.
|
SnappyFrameDecoder |
Uncompresses a ByteBuf encoded with the Snappy framing format.
|
SnappyFramedEncoder |
Deprecated.
|
SnappyFrameEncoder |
Compresses a ByteBuf using the Snappy framing format.
|
SniCompletionEvent |
Event that is fired once we did a selection of a SslContext based on the SNI hostname ,
which may be because it was successful or there was an error.
|
SniHandler |
|
Socket |
Provides a JNI bridge to native socket operations.
|
SocketChannel |
|
SocketChannelConfig |
|
SocketUtils |
Provides socket operations with privileges enabled.
|
SocketWritableByteChannel |
|
Socks4ClientDecoder |
|
Socks4ClientEncoder |
|
Socks4CommandRequest |
A SOCKS4a CONNECT or BIND request.
|
Socks4CommandResponse |
A SOCKS4a response.
|
Socks4CommandStatus |
|
Socks4CommandType |
|
Socks4Message |
A tag interface that all SOCKS4a protocol messages implement.
|
Socks4ProxyHandler |
|
Socks4ServerDecoder |
|
Socks4ServerEncoder |
|
Socks5AddressDecoder |
Decodes a SOCKS5 address field into its string representation.
|
Socks5AddressEncoder |
Encodes a SOCKS5 address into binary representation.
|
Socks5AddressType |
|
Socks5AuthMethod |
The authentication method of SOCKS5.
|
Socks5ClientEncoder |
|
Socks5CommandRequest |
|
Socks5CommandRequestDecoder |
|
Socks5CommandResponse |
|
Socks5CommandResponseDecoder |
|
Socks5CommandStatus |
|
Socks5CommandType |
|
Socks5InitialRequest |
|
Socks5InitialRequestDecoder |
|
Socks5InitialResponse |
|
Socks5InitialResponseDecoder |
|
Socks5Message |
A tag interface that all SOCKS5 protocol messages implement.
|
Socks5PasswordAuthRequest |
|
Socks5PasswordAuthRequestDecoder |
|
Socks5PasswordAuthResponse |
|
Socks5PasswordAuthResponseDecoder |
|
Socks5PasswordAuthStatus |
|
Socks5ProxyHandler |
|
Socks5ServerEncoder |
|
SocksAddressType |
|
SocksAuthRequest |
An socks auth request.
|
SocksAuthRequestDecoder |
|
SocksAuthResponse |
An socks auth response.
|
SocksAuthResponseDecoder |
|
SocksAuthScheme |
|
SocksAuthStatus |
|
SocksCmdRequest |
An socks cmd request.
|
SocksCmdRequestDecoder |
|
SocksCmdResponse |
A socks cmd response.
|
SocksCmdResponseDecoder |
|
SocksCmdStatus |
|
SocksCmdType |
|
SocksInitRequest |
An socks init request.
|
SocksInitRequestDecoder |
|
SocksInitResponse |
An socks init response.
|
SocksInitResponseDecoder |
|
SocksMessage |
|
SocksMessage |
An interface that all SOCKS protocol messages implement.
|
SocksMessageEncoder |
|
SocksMessageType |
|
SocksPortUnificationServerHandler |
|
SocksProtocolVersion |
|
SocksRequest |
|
SocksRequestType |
Type of socks request
|
SocksResponse |
|
SocksResponseType |
Type of socks response
|
SocksSubnegotiationVersion |
|
SocksVersion |
The version of SOCKS protocol.
|
SpdyDataFrame |
A SPDY Protocol DATA Frame
|
SpdyFrame |
A SPDY Protocol Frame
|
SpdyFrameCodec |
|
SpdyFrameDecoder |
|
SpdyFrameDecoderDelegate |
|
SpdyFrameEncoder |
Encodes a SPDY Frame into a ByteBuf .
|
SpdyGoAwayFrame |
A SPDY Protocol GOAWAY Frame
|
SpdyHeaderBlockRawDecoder |
|
SpdyHeaderBlockRawEncoder |
|
SpdyHeaders |
Provides the constants for the standard SPDY HTTP header names and commonly
used utility methods that access a SpdyHeadersFrame .
|
SpdyHeaders.HttpNames |
SPDY HTTP header names
|
SpdyHeadersFrame |
A SPDY Protocol HEADERS Frame
|
SpdyHttpCodec |
|
SpdyHttpDecoder |
|
SpdyHttpEncoder |
|
SpdyHttpHeaders |
|
SpdyHttpHeaders.Names |
SPDY HTTP header names
|
SpdyHttpResponseStreamIdHandler |
|
SpdyPingFrame |
A SPDY Protocol PING Frame
|
SpdyProtocolException |
|
SpdyRstStreamFrame |
A SPDY Protocol RST_STREAM Frame
|
SpdySessionHandler |
Manages streams within a SPDY session.
|
SpdySessionStatus |
The SPDY session status code and its description.
|
SpdySettingsFrame |
A SPDY Protocol SETTINGS Frame
|
SpdyStreamFrame |
A SPDY Protocol Frame that is associated with an individual SPDY Stream
|
SpdyStreamStatus |
The SPDY stream status code and its description.
|
SpdySynReplyFrame |
A SPDY Protocol SYN_REPLY Frame
|
SpdySynStreamFrame |
A SPDY Protocol SYN_STREAM Frame
|
SpdyVersion |
|
SpdyWindowUpdateFrame |
A SPDY Protocol WINDOW_UPDATE Frame
|
SslClientHelloHandler<T> |
|
SslCloseCompletionEvent |
Event that is fired once the close_notify was received or if an failure happens before it was received.
|
SslClosedEngineException |
|
SslCompletionEvent |
|
SslContext |
|
SslContextBuilder |
Builder for configuring a new SslContext for creation.
|
SslContextOption<T> |
|
SslHandler |
|
SslHandshakeCompletionEvent |
Event that is fired once the SSL handshake is complete, which may be because it was successful or there
was an error.
|
SslHandshakeTimeoutException |
|
SslMasterKeyHandler |
The SslMasterKeyHandler is a channel-handler you can include in your pipeline to consume the master key
& session identifier for a TLS session.
|
SslProvider |
An enumeration of SSL/TLS protocol providers.
|
StompCommand |
STOMP command
|
StompContentSubframe |
An STOMP chunk which is used for STOMP chunked transfer-encoding.
|
StompFrame |
|
StompHeaders |
The multimap data structure for the STOMP header names and values.
|
StompHeadersSubframe |
An interface that defines a StompFrame 's command and headers.
|
StompSubframe |
Defines a common interface for all StompSubframe implementations.
|
StompSubframeAggregator |
|
StompSubframeDecoder |
|
StompSubframeEncoder |
|
StreamBufferingEncoder |
|
StreamBufferingEncoder.Http2ChannelClosedException |
Thrown if buffered streams are terminated due to this encoder being closed.
|
StreamBufferingEncoder.Http2GoAwayException |
|
StreamByteDistributor |
An object (used by remote flow control) that is responsible for distributing the bytes to be
written across the streams in the connection.
|
StreamByteDistributor.StreamState |
State information for the stream, indicating the number of bytes that are currently
streamable.
|
StreamByteDistributor.Writer |
Object that performs the writing of the bytes that have been allocated for a stream.
|
StringDecoder |
|
StringEncoder |
|
StringUtil |
String utility class.
|
SucceededFuture<V> |
|
SupportedCipherSuiteFilter |
This class will filter all requested ciphers out that are not supported by the current SSLEngine .
|
SuppressForbidden |
Annotation to suppress forbidden-apis errors inside a whole class, a method, or a field.
|
SuppressJava6Requirement |
Annotation to suppress the Java 6 source code requirement checks for a method.
|
SwappedByteBuf |
Deprecated.
|
SystemPropertyUtil |
A collection of utility methods to retrieve and parse the values of the Java system properties.
|
TcpDnsQueryEncoder |
|
TcpDnsResponseDecoder |
|
TextWebSocketFrame |
Web Socket text frame.
|
ThreadDeathWatcher |
Deprecated.
|
ThreadExecutorMap |
|
ThreadLocalRandom |
A random number generator isolated to the current thread.
|
ThreadPerChannelEventLoop |
Deprecated.
|
ThreadPerChannelEventLoopGroup |
Deprecated.
|
ThreadPerTaskExecutor |
|
ThreadProperties |
|
ThrowableUtil |
|
Timeout |
|
TimeoutException |
A TimeoutException when no data was either read or written within a
certain period of time.
|
Timer |
Schedules TimerTask s for one-time future execution in a background
thread.
|
TimerTask |
|
TooLongFrameException |
An DecoderException which is thrown when the length of the frame
decoded is greater than the allowed maximum.
|
TrafficCounter |
Counts the number of read and written bytes for rate-limiting traffic.
|
TrustManagerFactoryWrapper |
|
TypeParameterMatcher |
|
UnaryPromiseNotifier<T> |
|
UncheckedBooleanSupplier |
Represents a supplier of boolean -valued results which doesn't throw any checked exceptions.
|
UniformStreamByteDistributor |
|
UniqueIpFilter |
This class allows one to ensure that at all times for every IP address there is at most one
Channel connected to the server.
|
Unix |
|
UnixChannel |
Channel that expose operations that are only present on UNIX like systems.
|
UnixChannelOption<T> |
|
UnixChannelUtil |
|
UnixResolverDnsServerAddressStreamProvider |
|
UnknownSocksRequest |
An unknown socks request.
|
UnknownSocksResponse |
An unknown socks response.
|
UnorderedThreadPoolEventExecutor |
EventExecutor implementation which makes no guarantees about the ordering of task execution that
are submitted because there may be multiple threads executing these tasks.
|
Unpooled |
Creates a new ByteBuf by allocating new space or by wrapping
or copying existing byte arrays, byte buffers and a string.
|
UnpooledByteBufAllocator |
|
UnpooledDirectByteBuf |
|
UnpooledHeapByteBuf |
Big endian Java heap buffer implementation.
|
UnpooledUnsafeDirectByteBuf |
|
UnpooledUnsafeHeapByteBuf |
Big endian Java heap buffer implementation.
|
UnstableApi |
Indicates a public API that can change at any time (even in minor/bugfix releases).
|
UnsupportedMessageTypeException |
Thrown if an unsupported message is received by an codec.
|
UnsupportedValueConverter<V> |
|
Utf8FrameValidator |
|
ValueConverter<T> |
Converts to/from a generic object to the type.
|
Version |
Retrieves the version information of available Netty artifacts.
|
VoidChannelPromise |
|
WebSocket00FrameDecoder |
|
WebSocket00FrameEncoder |
|
WebSocket07FrameDecoder |
Decodes a web socket frame from wire protocol version 7 format.
|
WebSocket07FrameEncoder |
Encodes a web socket frame into wire protocol version 7 format.
|
WebSocket08FrameDecoder |
Decodes a web socket frame from wire protocol version 8 format.
|
WebSocket08FrameEncoder |
Encodes a web socket frame into wire protocol version 8 format.
|
WebSocket13FrameDecoder |
Decodes a web socket frame from wire protocol version 13 format.
|
WebSocket13FrameEncoder |
Encodes a web socket frame into wire protocol version 13 format.
|
WebSocketChunkedInput |
A ChunkedInput that fetches data chunk by chunk for use with WebSocket chunked transfers.
|
WebSocketClientCompressionHandler |
Extends io.netty.handler.codec.http.websocketx.extensions.compression.WebSocketClientExtensionHandler
to handle the most common WebSocket Compression Extensions.
|
WebSocketClientExtension |
Created once the handshake phase is done.
|
WebSocketClientExtensionHandler |
This handler negotiates and initializes the WebSocket Extensions.
|
WebSocketClientExtensionHandshaker |
Handshakes a client extension with the server.
|
WebSocketClientHandshakeException |
Client exception during handshaking process.
|
WebSocketClientHandshaker |
Base class for web socket client handshake implementations
|
WebSocketClientHandshaker00 |
|
WebSocketClientHandshaker07 |
|
WebSocketClientHandshaker08 |
|
WebSocketClientHandshaker13 |
|
WebSocketClientHandshakerFactory |
|
WebSocketClientProtocolConfig |
WebSocket server configuration.
|
WebSocketClientProtocolConfig.Builder |
|
WebSocketClientProtocolHandler |
This handler does all the heavy lifting for you to run a websocket client.
|
WebSocketClientProtocolHandler.ClientHandshakeStateEvent |
Events that are fired to notify about handshake status
|
WebSocketCloseStatus |
WebSocket status codes specified in RFC-6455.
|
WebSocketDecoderConfig |
Frames decoder configuration.
|
WebSocketDecoderConfig.Builder |
|
WebSocketExtension |
Created once the handshake phase is done.
|
WebSocketExtensionData |
A WebSocket Extension data from the Sec-WebSocket-Extensions header.
|
WebSocketExtensionDecoder |
Convenient class for io.netty.handler.codec.http.websocketx.extensions.WebSocketExtension decoder.
|
WebSocketExtensionEncoder |
Convenient class for io.netty.handler.codec.http.websocketx.extensions.WebSocketExtension encoder.
|
WebSocketExtensionFilter |
Filter that is responsible to skip the evaluation of a certain extension
according to standard.
|
WebSocketExtensionFilterProvider |
Extension filter provider that is responsible to provide filters for a certain WebSocketExtension extension.
|
WebSocketExtensionUtil |
|
WebSocketFrame |
Base class for web socket frames.
|
WebSocketFrameAggregator |
Handler that aggregate fragmented WebSocketFrame's.
|
WebSocketFrameDecoder |
Marker interface which all WebSocketFrame decoders need to implement.
|
WebSocketFrameEncoder |
Marker interface which all WebSocketFrame encoders need to implement.
|
WebSocketHandshakeException |
Exception during handshaking process
|
WebSocketScheme |
Defines the common schemes used for the WebSocket protocol as defined by
rfc6455.
|
WebSocketServerCompressionHandler |
Extends io.netty.handler.codec.http.websocketx.extensions.compression.WebSocketServerExtensionHandler
to handle the most common WebSocket Compression Extensions.
|
WebSocketServerExtension |
Created once the handshake phase is done.
|
WebSocketServerExtensionHandler |
This handler negotiates and initializes the WebSocket Extensions.
|
WebSocketServerExtensionHandshaker |
Handshakes a client extension based on this server capabilities.
|
WebSocketServerHandshakeException |
Server exception during handshaking process.
|
WebSocketServerHandshaker |
Base class for server side web socket opening and closing handshakes
|
WebSocketServerHandshaker00 |
|
WebSocketServerHandshaker07 |
|
WebSocketServerHandshaker08 |
|
WebSocketServerHandshaker13 |
|
WebSocketServerHandshakerFactory |
|
WebSocketServerProtocolConfig |
WebSocket server configuration.
|
WebSocketServerProtocolConfig.Builder |
|
WebSocketServerProtocolHandler |
This handler does all the heavy lifting for you to run a websocket server.
|
WebSocketServerProtocolHandler.HandshakeComplete |
The Handshake was completed successfully and the channel was upgraded to websockets.
|
WebSocketServerProtocolHandler.ServerHandshakeStateEvent |
Events that are fired to notify about handshake status
|
WebSocketVersion |
Versions of the web socket specification.
|
WeightedFairQueueByteDistributor |
|
WriteBufferWaterMark |
WriteBufferWaterMark is used to set low water mark and high water mark for the write buffer.
|
WriteTimeoutException |
|
WriteTimeoutHandler |
|
XmlFrameDecoder |
A frame decoder for single separate XML based message streams.
|
ZlibCodecFactory |
|
ZlibDecoder |
Decompresses a ByteBuf using the deflate algorithm.
|
ZlibEncoder |
Compresses a ByteBuf using the deflate algorithm.
|
ZlibWrapper |
The container file formats that wrap the stream compressed by the DEFLATE
algorithm.
|