All Classes Interface Summary Class Summary Enum Summary Exception Summary Error Summary Annotation Types Summary
Class |
Description |
AbstractAddressResolver<T extends SocketAddress> |
|
AbstractBootstrap<B extends AbstractBootstrap<B,C,F>,C extends Channel,F> |
|
AbstractBootstrapConfig<B extends AbstractBootstrap<B,C,F>,C extends Channel,F> |
|
AbstractChannel<P extends Channel,L extends SocketAddress,R extends SocketAddress> |
|
AbstractChannel.DefaultAbstractChannelPipeline |
|
AbstractCoalescingBufferQueue |
|
AbstractConstant<T extends AbstractConstant<T>> |
|
AbstractDnsMessage |
|
AbstractDnsOptPseudoRrRecord |
|
AbstractDnsRecord |
|
AbstractEventExecutor |
|
AbstractHttp2ConnectionHandlerBuilder<T extends Http2ConnectionHandler,B extends AbstractHttp2ConnectionHandlerBuilder<T,B>> |
|
AbstractHttp2StreamFrame |
|
AbstractInboundHttp2ToHttpAdapterBuilder<T extends InboundHttp2ToHttpAdapter,B extends AbstractInboundHttp2ToHttpAdapterBuilder<T,B>> |
|
AbstractInternalLogger |
|
AbstractNioByteChannel<P extends Channel,L extends SocketAddress,R extends SocketAddress> |
|
AbstractNioChannel<P extends Channel,L extends SocketAddress,R extends SocketAddress> |
Abstract base class for Channel implementations which use a Selector based approach.
|
AbstractNioMessageChannel<P extends Channel,L extends SocketAddress,R extends SocketAddress> |
|
AbstractReferenceCounted |
|
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.
|
AbstractServerChannel<P extends Channel,L extends SocketAddress,R extends SocketAddress> |
A skeletal server-side Channel implementation.
|
AbstractSniHandler<T> |
|
AbstractTrafficShapingHandler |
|
AcceptFilter |
|
AdaptableBuffer<T extends ResourceSupport<Buffer,T>> |
|
AdaptiveRecvBufferAllocator |
The RecvBufferAllocator 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> |
|
AllocationType |
An object used by buffer allocators to communicate desirable properties of an
allocation to a memory manager, such as whether an allocation should be off-heap.
|
AllocatorControl |
Methods for accessing and controlling the internals of an allocator.
|
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.
|
ArcDrop<T> |
|
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<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 Buffer that encodes and decodes to and from
Base64 notation.
|
Base64Decoder |
|
Base64Dialect |
Enumeration of supported Base64 dialects.
|
Base64Encoder |
|
BiDnsQueryLifecycleObserver |
|
BiDnsQueryLifecycleObserverFactory |
|
BinaryWebSocketFrame |
Web Socket frame containing binary data.
|
BlockingOperationException |
An IllegalStateException which is raised when a user performed a blocking operation
when the user is in an event loop thread.
|
Bootstrap |
|
BootstrapConfig |
|
Brotli |
|
BrotliCompressor |
Compress a Buffer with the brotli format.
|
BrotliDecompressor |
Uncompresses a Buffer encoded with the brotli format.
|
BrotliOptions |
|
Buffer |
A life cycled buffer of memory, with separate reader and writer offsets.
|
Buffer |
|
BufferAccessor |
This interface is just the primitive data accessor methods that Buffer exposes.
|
BufferAddressedEnvelope<A extends SocketAddress,T extends BufferAddressedEnvelope<A,T>> |
Base class for addressed envelopes that have Buffer instances as messages.
|
BufferAllocator |
Interface for allocating Buffer s.
|
BufferAllocatorMetric |
|
BufferAllocatorMetricProvider |
|
BufferClosedException |
An exception thrown when an operation is attempted on a Buffer when it has been closed.
|
BufferFormat |
Used to control the format and verbosity of logging for buffers and buffer-like objects.
|
BufferHolder<T extends Resource<T>> |
The BufferHolder is an abstract class that simplifies the implementation of objects that themselves contain
a Buffer instance.
|
BufferInputStream |
|
BufferOutputStream |
|
BufferReadOnlyException |
|
BufferRef |
A mutable reference to a buffer.
|
BufferStub |
A stub of a Buffer implementation that implements all buffer methods by delegating them to a wrapped buffer
instance.
|
BufferUtil |
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.
|
ByteArrayDecoder |
Decodes a received Buffer into an array of bytes.
|
ByteArrayEncoder |
Encodes the requested array of bytes into a Buffer .
|
ByteBufferMemoryManager |
This memory manager produces and manages Buffer instances that are backed by NIO ByteBuffer
instances.
|
ByteCollections |
Utilities for byte-based primitive collections.
|
ByteCursor |
The ByteCursor scans through a sequence of bytes.
|
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 |
ChannelHandler which decodes bytes in a stream-like fashion from one Buffer to an
other Message type.
|
ByteToMessageDecoder.Cumulator |
|
Bzip2Compressor |
Compresses a Buffer using the Bzip2 algorithm.
|
Bzip2Decompressor |
Uncompresses a Buffer encoded with the Bzip2 format.
|
Channel |
A nexus to a network socket or a component which is capable of I/O
operations such as read, write, connect, and bind.
|
ChannelException |
|
ChannelFactory<T extends Channel> |
|
ChannelFutureListeners |
|
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 .
|
ChannelHandlerAdapter |
|
ChannelHandlerContext |
|
ChannelId |
Represents the globally unique identifier of a Channel .
|
ChannelInboundInvoker |
|
ChannelInitializer<C extends Channel> |
|
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<T extends Exception> |
|
ChannelOutboundInvoker |
|
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 |
|
ChannelShutdownDirection |
The direction of a shutdown.
|
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 |
|
Ciphers |
Cipher suites
|
CipherSuiteConverter |
Converts a Java cipher suite string to an OpenSSL cipher suite string and vice versa.
|
CipherSuiteFilter |
Provides a means to filter the supplied cipher suite based upon the supported and default cipher suites.
|
ClassInitializerUtil |
Utility which ensures that classes are loaded by the ClassLoader .
|
CleanerDrop<T extends Buffer> |
A drop implementation that delegates to another drop instance, either when called directly, or when it becomes
cleanable.
|
CleartextHttp2ServerUpgradeHandler |
Performing clear-text 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 |
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 Buffer and consumers take bytes in
arbitrary lengths.
|
CodecException |
|
CombinedChannelDuplexHandler<I extends ChannelHandler,O extends ChannelHandler> |
|
CombinedHttpHeaders |
Will add multiple values for the same header as single header with a comma separated list of values.
|
CommonsLoggerFactory |
Deprecated.
|
ComponentIterator<T extends ComponentIterator.Next> |
A facade for iterating the readable or writable components of a Buffer .
|
ComponentIterator.Next |
This interface exposes external iteration on components.
|
CompositeBuffer |
The CompositeBuffer is a concrete Buffer implementation that make a number of other buffers appear
as one.
|
CompositeNameResolver<T> |
|
CompressionException |
|
CompressionHandler |
|
CompressionOptions |
CompressionOptions provides compression options for
various types of compressor types, like Brotli.
|
Compressor |
Compressor that takes care of compress some input.
|
CompressorHttp2ConnectionEncoder |
A decorating HTTP2 encoder that will compress data frames according to the content-encoding header for each
stream.
|
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 |
|
CookieDecoder |
Parent of Client and Server side cookie decoders
|
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 |
|
DatagramDnsQuery |
|
DatagramDnsQueryDecoder |
|
DatagramDnsQueryEncoder |
|
DatagramDnsResponse |
|
DatagramDnsResponseDecoder |
|
DatagramDnsResponseEncoder |
|
DatagramPacket |
The message container that is used for DatagramChannel to communicate with the remote peer.
|
DatagramPacketDecoder |
A decoder that decodes the content of the received DatagramPacket using
the specified Buffer decoder.
|
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 |
|
DecompressionHandler |
|
Decompressor |
Decompressor that takes care of decompress some input.
|
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 |
|
DefaultBufferAddressedEnvelope<A extends SocketAddress> |
|
DefaultBufferAllocators |
|
DefaultChannelGroup |
|
DefaultChannelId |
|
DefaultChannelPipeline |
|
DefaultCookie |
The default Cookie implementation.
|
DefaultDnsCache |
|
DefaultDnsCnameCache |
|
DefaultDnsOptEcsRecord |
|
DefaultDnsPtrRecord |
|
DefaultDnsQuery |
|
DefaultDnsQuestion |
|
DefaultDnsRawRecord |
The default DnsRawRecord implementation.
|
DefaultDnsRecordDecoder |
|
DefaultDnsRecordEncoder |
|
DefaultDnsResponse |
|
DefaultDnsServerAddressStreamProvider |
|
DefaultEventExecutorGroup |
|
DefaultFileRegion |
|
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 |
|
DefaultHttpHeaders |
|
DefaultHttpMessage |
|
DefaultHttpObject |
|
DefaultHttpRequest |
|
DefaultHttpResponse |
|
DefaultLastHttpContent |
|
DefaultMaxBytesRecvBufferAllocator |
The RecvBufferAllocator that yields a buffer size prediction based upon decrementing the value from
the max bytes per read.
|
DefaultMaxMessagesRecvBufferAllocator |
|
DefaultMessageSizeEstimator |
|
DefaultNameResolver |
A InetNameResolver that resolves using JDK's built-in domain name lookup mechanism.
|
DefaultPriorityQueue<T extends PriorityQueueNode> |
A priority queue which uses natural ordering of elements.
|
DefaultPromise<V> |
|
DefaultSelectStrategyFactory |
Factory which uses the default select strategy.
|
DefaultThreadFactory |
|
DeflateFrameClientExtensionHandshaker |
|
DeflateFrameServerExtensionHandshaker |
|
DeflateOptions |
|
DelegatingChannelHandlerContext |
|
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 Buffer s by one or more
delimiters.
|
Delimiters |
|
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 |
|
DomainDatagramSocketAddress |
Act as special DomainSocketAddress to be able to easily pass all needed data from JNI without the need
to create more objects then needed.
|
DomainMappingBuilder<V> |
Deprecated.
|
DomainNameMapping<V> |
Deprecated.
|
DomainNameMappingBuilder<V> |
Deprecated.
|
DomainSocketAddress |
|
DomainSocketReadMode |
Different modes of reading from a UnixChannel that uses Unix Domain Sockets.
|
DomainWildcardMappingBuilder<V> |
|
Drop<T> |
An interface used by Resource instances to implement their resource disposal mechanics.
|
DropCaptor<T> |
Utility class to capture or hold on to a drop instance.
|
DynamicAddressConnectHandler |
ChannelHandler 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 |
|
EmptyHeaders<K,V,T extends Headers<K,V,T>> |
|
EmptyHttp2Headers |
|
EmptyHttpHeaders |
|
EmptyLastHttpContent |
|
EmptyPriorityQueue<T> |
|
EncoderException |
|
Epoll |
|
EpollChannelOption<T> |
|
EpollDatagramChannel |
DatagramChannel implementation that uses linux EPOLL Edge-Triggered Mode for
maximal performance.
|
EpollEventArray |
This is an internal datastructure which can be directly passed to epoll_wait to reduce the overhead.
|
EpollHandler |
|
EpollServerSocketChannel |
ServerSocketChannel implementation that uses linux EPOLL Edge-Triggered Mode for
maximal performance.
|
EpollSocketChannel |
SocketChannel implementation that uses linux EPOLL Edge-Triggered Mode for
maximal performance.
|
EpollTcpInfo |
struct tcp_info
{
__u8 tcpi_state;
__u8 tcpi_ca_state;
__u8 tcpi_retransmits;
__u8 tcpi_probes;
__u8 tcpi_backoff;
__u8 tcpi_options;
__u8 tcpi_snd_wscale : 4, tcpi_rcv_wscale : 4;
__u32 tcpi_rto;
__u32 tcpi_ato;
__u32 tcpi_snd_mss;
__u32 tcpi_rcv_mss;
__u32 tcpi_unacked;
__u32 tcpi_sacked;
__u32 tcpi_lost;
__u32 tcpi_retrans;
__u32 tcpi_fackets;
__u32 tcpi_last_data_sent;
__u32 tcpi_last_ack_sent;
__u32 tcpi_last_data_recv;
__u32 tcpi_last_ack_recv;
__u32 tcpi_pmtu;
__u32 tcpi_rcv_ssthresh;
__u32 tcpi_rtt;
__u32 tcpi_rttvar;
__u32 tcpi_snd_ssthresh;
__u32 tcpi_snd_cwnd;
__u32 tcpi_advmss;
__u32 tcpi_reordering;
__u32 tcpi_rcv_rtt;
__u32 tcpi_rcv_space;
__u32 tcpi_total_retrans;
};
|
Errors |
Internal usage only!
|
Errors.NativeIoException |
Internal usage only!
|
EventExecutor |
|
EventExecutorGroup |
|
EventLoop |
Will handle all the I/O operations for a IoHandle once registered.
|
EventLoopException |
|
EventLoopGroup |
|
FastLzCompressor |
Compresses a Buffer using the FastLZ algorithm.
|
FastLzDecompressor |
|
FastThreadLocal<V> |
|
FastThreadLocalThread |
|
FileDescriptor |
|
FileRegion |
|
FingerprintTrustManagerFactory |
|
FingerprintTrustManagerFactoryBuilder |
|
FixedLengthFrameDecoder |
A decoder that splits the received Buffer s by the fixed number
of bytes.
|
FixedRecvBufferAllocator |
|
FlowControlHandler |
|
FlushConsolidationHandler |
|
FormattingTuple |
|
FullHttpMessage<R extends FullHttpMessage<R>> |
|
FullHttpRequest |
|
FullHttpResponse |
|
Future<V> |
The result of an asynchronous operation.
|
FutureCompletionStage<V> |
|
FutureContextListener<C,V> |
Listens to the result of a Future .
|
FutureListener<V> |
Listens to the result of a Future .
|
FuturePromiseFactory |
|
GenericUnixChannelOption<T> |
A generic socket option.
|
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.
|
GzipOptions |
|
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.
|
HostsFileEntriesProvider |
A container of hosts file entries
|
HostsFileEntriesProvider.Parser |
|
HostsFileEntriesResolver |
Resolves a hostname against the hosts file entries.
|
HostsFileParser |
A parser for hosts files.
|
Http2ChannelDuplexHandler |
|
Http2ClientUpgradeCodec |
Client-side clear-text 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 |
|
Http2DataChunkedInput |
A ChunkedInput that fetches data chunk by chunk for use with HTTP/2 Data Frames.
|
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 |
|
Http2FrameStreamEvent.Type |
|
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.
|
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<C extends HttpContent<C>> |
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<R extends HttpContent<R>> |
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
|
HttpExpectationFailedEvent |
A user event designed to communicate that a expectation has failed and there should be no expectation that a
body will follow.
|
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 .
|
HttpHeaderValues |
Standard HTTP header values.
|
HttpMessage |
|
HttpMessageDecoderResult |
|
HttpMethod |
The request method of HTTP or its derived protocols, such as
RTSP and
ICAP.
|
HttpObject |
|
HttpObjectAggregator<C extends HttpContent<C>> |
|
HttpObjectDecoder |
|
HttpObjectEncoder<H extends HttpMessage> |
|
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<C extends HttpContent<C>> |
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 |
|
InsecureTrustManagerFactory |
|
IntCollections |
Utilities for int-based primitive collections.
|
IntegerUnixChannelOption |
|
InternalLogger |
Internal-use-only logger used by Netty.
|
InternalLoggerFactory |
|
InternalLogLevel |
|
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> |
|
IoExecutionContext |
|
IoHandle |
A handle that will process I/O.
|
IoHandler |
|
IoHandlerFactory |
|
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.
|
JdkSslContext |
An SslContext which uses JDK's SSL/TLS implementation.
|
KeyManagerFactoryWrapper |
|
KQueue |
If KQueue is available the JNI resources will be loaded when this class loads.
|
KQueueChannelOption<T> |
|
KQueueDatagramChannel |
|
KQueueGuessRecvBufferAllocator |
|
KQueueHandler |
IoHandler which uses kqueue under the covers.
|
KQueueServerSocketChannel |
|
KQueueSocketChannel |
|
LastHttpContent<R extends LastHttpContent<R>> |
|
LazyJavaxX509Certificate |
|
LazyX509Certificate |
|
LeakDetection |
Utility class for the leak detection parts that are static and shared system-wide.
|
LeakInfo |
Information about a resource leak that happened.
|
LeakInfo.TracePoint |
A moment in the life of the leaked object, for which some information was recorded.
|
LengthFieldBasedFrameDecoder |
A decoder that splits the received Buffer s dynamically by the
value of the length field in the message.
|
LengthFieldPrepender |
An encoder that prepends the length of the message.
|
LifecycleTracer |
Instances of this class record life cycle events of resources, to help debug life-cycle errors.
|
Limits |
|
LineBasedFrameDecoder |
A decoder that splits the received Buffer s on line endings.
|
LineEncoder |
Apply a line separator to the requested String and encode it into a Buffer .
|
LineSeparator |
A class to represent line separators in different environments.
|
LinuxSocket |
A socket which provides access Linux native methods.
|
LocalAddress |
An endpoint in the local transport.
|
LocalChannel |
|
LocalHandler |
|
LocalServerChannel |
A ServerChannel for the local transport which allows in VM communication.
|
Log4J2LoggerFactory |
|
LoggingDnsQueryLifeCycleObserverFactory |
|
LoggingHandler |
|
LoggingLeakCallback |
|
LogLevel |
|
LongCollections |
Utilities for long-based primitive collections.
|
LongLongHashMap |
Internal primitive map implementation that is specifically optimised for the runs availability map use case in
PoolChunk .
|
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> |
|
LongPriorityQueue |
Internal primitive priority queue, used by PoolChunk .
|
Lz4Compressor |
Compresses a Buffer using the LZ4 format.
|
Lz4Decompressor |
Uncompresses a Buffer encoded with the LZ4 format.
|
Lz4XXHash32 |
|
LzfCompressor |
Compresses a Buffer using the LZF format.
|
LzfDecompressor |
Uncompresses a Buffer encoded with the LZF format.
|
LzmaCompressor |
Compresses a Buffer using the LZMA algorithm.
|
MacAddressUtil |
|
MacOSDnsServerAddressStreamProvider |
|
Mapping<IN,OUT> |
Maintains the mapping from the objects of one type to the objects of the other type.
|
MathUtil |
Math utility methods.
|
MaxBytesRecvBufferAllocator |
RecvBufferAllocator 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.
|
MaxMessagesRecvBufferAllocator |
RecvBufferAllocator that limits the number of read operations that will be attempted when a read operation
is attempted by the event loop.
|
MemoryManager |
The choice of MemoryManager implementation also determines the choice of Buffer implementation.
|
MemoryManagerLoader |
|
MemoryManagerOverride |
|
MessageAggregationException |
Raised by MessageAggregator when aggregation fails due to an unexpected message sequence.
|
MessageAggregator<I,S,C extends AutoCloseable,A extends AutoCloseable> |
An abstract ChannelHandler that aggregates a series of message objects into a single aggregated message.
|
MessageFormatter |
Formats messages according to very simple substitution rules.
|
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> |
ChannelHandler which encodes from one message to another message
For example here is an implementation which decodes an Integer to an String .
|
MultiDnsServerAddressStreamProvider |
|
MultithreadEventExecutorGroup |
EventExecutorGroup implementation that handles their tasks with multiple threads at
the same time.
|
MultithreadEventLoopGroup |
EventLoopGroup implementation that will handle its tasks with multiple threads.
|
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.
|
Native |
Native helper methods
|
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 |
|
NioHandler |
IoHandler implementation which register the Channel 's to a
Selector and so does the multi-plexing of these in the event loop.
|
NioSelectableChannelHandle<S extends SelectableChannel> |
|
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 |
|
NotReadOnlyReadableComponent |
|
NotSslRecordException |
Special SSLException which will get thrown if a packet is
received that not looks like a TLS/SSL record.
|
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.
|
OcspClientHandler |
A handler for SSL clients to handle and act upon stapled OCSP responses.
|
OpenSsl |
|
OpenSslApplicationProtocolNegotiator |
Deprecated.
|
OpenSslAsyncPrivateKeyMethod |
|
OpenSslCachingX509KeyManagerFactory |
|
OpenSslCertificateCompressionAlgorithm |
Provides compression and decompression implementations for TLS Certificate Compression
( RFC 8879).
|
OpenSslCertificateCompressionConfig |
Configuration for TLS1.3 certificate compression extension.
|
OpenSslCertificateCompressionConfig.AlgorithmConfig |
The configuration for the algorithm.
|
OpenSslCertificateCompressionConfig.AlgorithmMode |
|
OpenSslCertificateCompressionConfig.Builder |
|
OpenSslCertificateException |
A special CertificateException which allows to specify which error code is included in the
SSL Record.
|
OpenSslContext |
This class will use a finalizer to ensure native resources are automatically cleaned up.
|
OpenSslContextOption<T> |
|
OpenSslDefaultApplicationProtocolNegotiator |
Deprecated.
|
OpenSslEngine |
|
OpenSslNpnApplicationProtocolNegotiator |
Deprecated.
|
OpenSslPrivateKeyMethod |
Allow customization of private key signing / decrypting (when using RSA).
|
OpenSslServerSessionContext |
OpenSslSessionContext implementation which offers extra methods which are only useful for the server-side.
|
OpenSslSessionContext |
|
OpenSslSessionStats |
Stats exposed by an OpenSSL session context.
|
OpenSslSessionTicketKey |
Session Ticket Key
|
OpenSslX509KeyManagerFactory |
|
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 |
|
Owned<T> |
This interface encapsulates the ownership of a Resource , and exposes a method that may be used to transfer
this ownership to the specified recipient thread.
|
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.
|
PooledBufferAllocator |
|
PoolSubpageMetric |
Metrics for a sub-page.
|
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 |
|
Promise<V> |
Special Future which is writable.
|
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.
|
ProtocolDetectionResult<T> |
Result of detecting a protocol.
|
ProtocolDetectionState |
The state of the current detection.
|
ProtocolEvent |
An application-level event propagated via an ChannelPipeline , such as a TLS or WebSocket handshake event.
|
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.
|
RawUnixChannelOption |
|
ReadableComponent |
|
ReadableComponentProcessor<E extends Exception> |
|
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 |
|
RecvBufferAllocator |
Allocates a new receive buffer whose capacity is probably large enough to read all inbound data and small enough
not to waste its space.
|
RecvBufferAllocator.Handle |
|
RecvFromAddressDomainSocket |
This class facilitates datagram reads from domain sockets, into buffers.
|
RecyclableArrayList |
A simple list which is recyclable.
|
Recycler<T> |
Light-weight object pool based on a thread-local stack.
|
Recycler.Handle<T> |
|
ReferenceCounted |
A reference-counted object that requires explicit deallocation.
|
ReferenceCountedOpenSslClientContext |
A client-side SslContext which uses OpenSSL's SSL/TLS implementation.
|
ReferenceCountedOpenSslContext |
An implementation of SslContext which works with libraries that support the
OpenSsl C library API.
|
ReferenceCountedOpenSslEngine |
|
ReferenceCountedOpenSslServerContext |
A server-side SslContext which uses OpenSSL's SSL/TLS implementation.
|
ReferenceCountUpdater<T extends ReferenceCounted> |
|
ReferenceCountUtil |
|
ReflectionUtil |
|
ReflectiveChannelFactory<T extends Channel> |
|
ReflectiveServerChannelFactory<T extends ServerChannel> |
|
RejectedExecutionHandler |
|
RejectedExecutionHandlers |
|
ResolveAddressHandler |
|
ResolvedAddressTypes |
Defined resolved address types.
|
Resource<T extends Resource<T>> |
A resource that has a life-time, and can be closed.
|
ResourceLeakDetector<T> |
|
ResourceLeakDetector.Level |
Represents the level of resource leak detection.
|
ResourceLeakDetectorFactory |
|
ResourceLeakHint |
A hint object that provides human-readable message for easier resource leak tracking.
|
ResourceLeakTracker<T> |
|
ResourceSupport<I extends Resource<I>,T extends ResourceSupport<I,T>> |
Internal support class for resources.
|
ResourcesUtil |
A utility class that provides various common operations and constants
related to loading resources
|
RoundRobinDnsAddressResolverGroup |
|
RoundRobinInetAddressResolver |
|
RtspDecoder |
Decodes io.netty5.buffer.ByteBuf s into RTSP messages represented in
HttpMessage s.
|
RtspEncoder |
|
RtspHeaderNames |
Standard RTSP header names.
|
RtspHeaderValues |
Standard RTSP header names.
|
RtspMethods |
The request getMethod of RTSP.
|
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.
|
RunnableFuture<V> |
|
RunnableScheduledFuture<V> |
A combination of RunnableFuture and Comparable (sorting by their next deadline),
with additional methods for scheduling, periodicity, and delay.
|
SafeCloseable |
A SafeCloseable can be safely closed without risk of an exception being thrown.
|
SegmentedDatagramPacket |
Allows to use GSO
if the underlying OS supports it.
|
SelectStrategy |
Select strategy interface.
|
SelectStrategyFactory |
|
SelfSignedCertificate |
Generates a temporary self-signed certificate for testing purposes.
|
Send<T extends Resource<T>> |
A temporary holder of a Resource , used for transferring the ownership of the
resource from one thread to another.
|
SendFromOwned<I extends Resource<I>,T extends ResourceSupport<I,T>> |
|
SendFromSupplier<T extends Resource<T>> |
|
SensitiveBufferAllocator |
This BufferAllocator is for allocating off-heap
Buffer s that may contain sensitive information, which should be erased from memory (overwritten) when the
buffer is closed.
|
SequentialDnsServerAddressStreamProvider |
|
ServerBootstrap |
|
ServerBootstrapConfig |
|
ServerChannel |
A Channel that accepts an incoming connection attempt and creates
its child Channel s by accepting them.
|
ServerChannelFactory<T extends ServerChannel> |
|
ServerChannelRecvBufferAllocator |
|
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).
|
ServerSocketChannel |
A Socket ServerChannel which accepts incoming Socket connections.
|
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> |
|
SilentDispose |
|
SimpleChannelInboundHandler<I> |
ChannelHandler which allows to explicit only handle a specific type of messages.
|
SimpleKeyManagerFactory |
|
SimpleNameResolver<T> |
|
SimpleTrustManagerFactory |
|
SimpleUserEventChannelHandler<I> |
ChannelHandler which allows to conveniently only handle a specific type of user events.
|
SingleComponentIterator<T extends ComponentIterator.Next> |
|
SingleThreadEventExecutor |
|
SingleThreadEventLoop |
EventLoop that execute all its submitted tasks in a single thread and uses an IoHandler for
IO processing.
|
SingletonDnsServerAddressStreamProvider |
|
SizeClassesMetric |
Expose metrics for an SizeClasses.
|
Slf4JLoggerFactory |
Logger factory which creates a SLF4J
logger.
|
Snappy |
Uncompresses an input Buffer encoded with Snappy compression into an
output Buffer .
|
SnappyCompressor |
Compresses a Buffer using the Snappy framing format.
|
SnappyDecompressor |
Uncompresses a Buffer encoded with 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 |
|
SocketProtocolFamily |
ProtocolFamily implementation that is used by the different transport implementations.
|
SocketUtils |
Provides socket operations with privileges enabled.
|
SocketWritableByteChannel |
|
SslClientHelloHandler<T> |
|
SslCloseCompletionEvent |
Event that is fired once the close_notify was received or if a 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.
|
SslProtocols |
SSL/TLS protocols
|
SslProvider |
An enumeration of SSL/TLS protocol providers.
|
StandardAllocationTypes |
|
StandardCompressionOptions |
|
Statics |
|
Statics.UncheckedLoadByte |
This interface provides the fastest possible offsetted byte-access to a buffer.
|
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.
|
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.
|
SystemPropertyUtil |
A collection of utility methods to retrieve and parse the values of the Java system properties.
|
TcpDnsQueryDecoder |
|
TcpDnsQueryEncoder |
|
TcpDnsResponseDecoder |
|
TcpDnsResponseEncoder |
|
TextWebSocketFrame |
Web Socket text frame.
|
ThreadExecutorMap |
|
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.
|
TooLongHttpContentException |
An TooLongFrameException which is thrown when the length of the
content decoded is greater than the allowed maximum.
|
TooLongHttpHeaderException |
An TooLongFrameException which is thrown when the length of the
header decoded is greater than the allowed maximum.
|
TooLongHttpLineException |
An TooLongFrameException which is thrown when the length of the
line decoded is greater than the allowed maximum.
|
TrafficCounter |
Counts the number of read and written bytes for rate-limiting traffic.
|
TrustManagerFactoryWrapper |
|
TypeParameterMatcher |
|
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 |
|
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.
|
UnsafeAccess |
Marker annotation for internal Netty classes that gives them permission to directly access the
Unsafe instance, if available.
|
UnsafeMemoryManager |
This memory manager produces and manages Buffer instances that are using Unsafe to allocate and
access memory.
|
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 a codec.
|
UnsupportedValueConverter<V> |
|
UntetheredMemory |
Memory that isn't attached to any particular buffer.
|
Utf8FrameValidator |
|
ValueConverter<T> |
Converts to/from a generic object to the type.
|
Version |
Retrieves the version information of available Netty artifacts.
|
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.netty5.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.
|
WebSocketClientHandshakeCompletionEvent |
A websocket handshake was completed on the client-side.
|
WebSocketClientHandshakeException |
Client exception during handshaking process.
|
WebSocketClientHandshaker |
Base class for web socket client handshake implementations
|
WebSocketClientHandshaker13 |
Performs client side opening and closing handshakes for web socket specification version
websocketprotocol-v13
|
WebSocketClientHandshakerFactory |
|
WebSocketClientProtocolConfig |
WebSocket server configuration.
|
WebSocketClientProtocolConfig.Builder |
|
WebSocketClientProtocolHandler |
This handler does all the heavy lifting for you to run a websocket client.
|
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.netty5.handler.codec.http.websocketx.extensions.WebSocketExtension decoder.
|
WebSocketExtensionEncoder |
Convenient class for io.netty5.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.
|
WebSocketHandshakeCompletionEvent |
ProtocolEvent that indicate the completion of a websocket handshake.
|
WebSocketHandshakeException |
Exception during handshaking process
|
WebSocketHandshakeTimeoutException |
|
WebSocketScheme |
Defines the common schemes used for the WebSocket protocol as defined by
rfc6455.
|
WebSocketServerCompressionHandler |
Extends io.netty5.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.
|
WebSocketServerHandshakeCompletionEvent |
A websocket handshake was completed on the server-side.
|
WebSocketServerHandshakeException |
Server exception during handshaking process.
|
WebSocketServerHandshaker |
Base class for server side web socket opening and closing handshakes
|
WebSocketServerHandshaker13 |
|
WebSocketServerHandshakerFactory |
|
WebSocketServerProtocolConfig |
WebSocket server configuration.
|
WebSocketServerProtocolConfig.Builder |
|
WebSocketServerProtocolHandler |
This handler does all the heavy lifting for you to run a websocket server.
|
WebSocketVersion |
Versions of the web socket specification.
|
WeightedFairQueueByteDistributor |
|
WrappingAllocation |
An AllocationType for on-heap buffer allocations that wrap an existing byte array.
|
WritableComponent |
|
WritableComponentProcessor<E extends Exception> |
|
WriteBufferWaterMark |
|
WriteTimeoutException |
|
WriteTimeoutHandler |
|
ZlibCodecFactory |
Creates a new ZLIB encoder / decoder.
|
ZlibCompressor |
Compresses a Buffer using the deflate algorithm.
|
ZlibDecompressor |
Decompress a Buffer using the inflate algorithm.
|
ZlibWrapper |
The container file formats that wrap the stream compressed by the DEFLATE
algorithm.
|
Zstd |
|
ZstdCompressor |
Compresses a Buffer using the Zstandard algorithm.
|
ZstdOptions |
ZstdOptions holds compressionLevel for
Zstd compression.
|