Search Java Classes and Packages

Search Java Frameworks and Libraries

255581 classes and counting ...
Search Tips Index Status



# Classes and Interfaces in #Netty - 798 results found.
NameDescriptionTypePackageFramework
AbstractBinaryMemcacheDecoderDecoder for both BinaryMemcacheRequest and BinaryMemcacheResponse.Classio.netty.handler.codec.memcache.binaryNetty
AbstractBinaryMemcacheEncoderA MessageToByteEncoder that encodes binary memache messages into bytes.Classio.netty.handler.codec.memcache.binaryNetty
AbstractBinaryMemcacheMessageDefault implementation of a BinaryMemcacheMessage.Classio.netty.handler.codec.memcache.binaryNetty
AbstractBootstrapAbstractBootstrap is a helper class that makes it easy to bootstrap a Channel.Classio.netty.bootstrapNetty
AbstractByteBufA skeletal implementation of a buffer.Classio.netty.bufferNetty
AbstractByteBufAllocatorSkeletal ByteBufAllocator implementation to extend.Classio.netty.bufferNetty
AbstractChannelA skeletal Channel implementation.Classio.netty.channelNetty
AbstractConstantBase implementation of Constant.Classio.netty.utilNetty
AbstractDerivedByteBufClassio.netty.bufferNetty
AbstractDiskHttpDataClassio.netty.handler.codec.http.multipartNetty
AbstractEpollServerChannelClassio.netty.channel.epollNetty
AbstractEpollStreamChannelClassio.netty.channel.epollNetty
AbstractEventExecutorAbstract base class for EventExecutor implementations.Classio.netty.util.concurrentNetty
AbstractEventExecutorGroupAbstract base class for EventExecutorGroup implementations.Classio.netty.util.concurrentNetty
AbstractEventLoopSkeletal implementation of EventLoop.Classio.netty.channelNetty
AbstractEventLoopGroupSkeletal implementation of EventLoopGroup.Classio.netty.channelNetty
AbstractFutureAbstract Future implementation which does not allow for cancellation.Classio.netty.util.concurrentNetty
AbstractHttpDataClassio.netty.handler.codec.http.multipartNetty
AbstractMemcacheObjectThe default MemcacheObject implementation.Classio.netty.handler.codec.memcacheNetty
AbstractMemcacheObjectAggregatorA ChannelHandler that aggregates an MemcacheMessageand its following MemcacheContents into a single MemcacheMessage withClassio.netty.handler.codec.memcacheNetty
AbstractMemcacheObjectDecoderAbstract super class for both ascii and binary decoders.Classio.netty.handler.codec.memcacheNetty
AbstractMemcacheObjectEncoderA general purpose AbstractMemcacheObjectEncoder that encodes MemcacheMessages.Classio.netty.handler.codec.memcacheNetty
AbstractMemoryHttpDataClassio.netty.handler.codec.http.multipartNetty
AbstractNioByteChannelAbstractNioChannel base class for Channels that operate on bytes.Classio.netty.channel.nioNetty
AbstractNioChannelAbstract base class for Channel implementations which use a Selector based approach.Classio.netty.channel.nioNetty
AbstractNioMessageChannelAbstractNioChannel base class for Channels that operate on messages.Classio.netty.channel.nioNetty
AbstractOioByteChannelClassio.netty.channel.oioNetty
AbstractOioChannelClassio.netty.channel.oioNetty
AbstractOioMessageChannelClassio.netty.channel.oioNetty
AbstractReferenceCountedAbstract base class for classes wants to implement ReferenceCounted.Classio.netty.utilNetty
AbstractReferenceCountedByteBufAbstract base class for ByteBuf implementations that count references.Classio.netty.bufferNetty
AbstractRemoteAddressFilterThis class provides the functionality to either accept or reject new Channelsbased on their IP address.Classio.netty.handler.ipfilterNetty
AbstractScheduledEventExecutorAbstract base class for EventExecutors that want to support scheduling.Classio.netty.util.concurrentNetty
AbstractServerChannelA skeletal server-side Channel implementation.Classio.netty.channelNetty
AbstractSocks4MessageAn abstract Socks4Message.Classio.netty.handler.codec.socksx.v4Netty
AbstractSocks5MessageAn abstract Socks5Message.Classio.netty.handler.codec.socksx.v5Netty
AbstractSocksMessageAn abstract SocksMessage.Classio.netty.handler.codec.socksxNetty
AbstractTrafficShapingHandlerAbstractTrafficShapingHandler allows to limit the global bandwidth(see GlobalTrafficShapingHandler) or per sessionClassio.netty.handler.trafficNetty
AdaptiveRecvByteBufAllocatorThe RecvByteBufAllocator that automatically increases anddecreases the predicted buffer size on feed back.Classio.netty.channelNetty
AddressedEnvelopeA message that wraps another message with a sender address and a recipient address.Interfaceio.netty.channelNetty
ApplicationProtocolConfigProvides an SSLEngine agnostic way to configure a ApplicationProtocolNegotiator.Classio.netty.handler.sslNetty
ApplicationProtocolNegotiatorInterface to support Application Protocol Negotiation.Interfaceio.netty.handler.sslNetty
AsciiHeadersEncoderClassio.netty.handler.codecNetty
AsciiStringA string which has been encoded into a character encoding whose character always takes a single byte, similarly toASCII.Classio.netty.handler.codecNetty
AttributeInterfaceio.netty.handler.codec.http.multipartNetty
AttributeAn attribute which allows to store a value reference.Interfaceio.netty.utilNetty
AttributeKeyKey which can be used to access Attribute out of the AttributeMap.Classio.netty.utilNetty
AttributeMapHolds Attributes which can be accessed via AttributeKey.Interfaceio.netty.utilNetty
Base64Utility class for ByteBuf that encodes and decodes to and fromThe encoding and decoding algorithm in this class has been derived fromClassio.netty.handler.codec.base64Netty
Base64DecoderDecodes a Base64-encoded ByteBuf or US-ASCII Stringinto a ByteBuf.Classio.netty.handler.codec.base64Netty
Base64DialectEnumeration of supported Base64 dialects.Classio.netty.handler.codec.base64Netty
Base64EncoderEncodes a ByteBuf into a Base64-encoded ByteBuf.Classio.netty.handler.codec.base64Netty
BinaryHeadersA typical AsciiString multimap used by protocols that use binary headers (such as HTTP/2) for therepresentation of arbitrary key-value data.Interfaceio.netty.handler.codecNetty
BinaryMemcacheClientCodecThe client codec that combines the proper encoder and decoder.Classio.netty.handler.codec.memcache.binaryNetty
BinaryMemcacheMessageAn interface that defines a binary Memcache message, providing common properties forBinaryMemcacheRequest and BinaryMemcacheResponse.Interfaceio.netty.handler.codec.memcache.binaryNetty
BinaryMemcacheObjectAggregatorAn object aggregator for the memcache binary protocol.Classio.netty.handler.codec.memcache.binaryNetty
BinaryMemcacheOpcodesRepresents all Opcodes that can occur in a BinaryMemcacheMessage.Classio.netty.handler.codec.memcache.binaryNetty
BinaryMemcacheRequestRepresents a full BinaryMemcacheRequest, which contains the header and optional key and extras.Interfaceio.netty.handler.codec.memcache.binaryNetty
BinaryMemcacheRequestDecoderThe decoder part which takes care of decoding the request-specific headers.Classio.netty.handler.codec.memcache.binaryNetty
BinaryMemcacheRequestEncoderThe encoder part which takes care of encoding the request headers.Classio.netty.handler.codec.memcache.binaryNetty
BinaryMemcacheResponseRepresents a full BinaryMemcacheResponse, which contains the header and optional key and extras.Interfaceio.netty.handler.codec.memcache.binaryNetty
BinaryMemcacheResponseDecoderThe decoder which takes care of decoding the response headers.Classio.netty.handler.codec.memcache.binaryNetty
BinaryMemcacheResponseEncoderThe encoder which takes care of encoding the response headers.Classio.netty.handler.codec.memcache.binaryNetty
BinaryMemcacheResponseStatusContains all possible status values a BinaryMemcacheResponse can return.Classio.netty.handler.codec.memcache.binaryNetty
BinaryMemcacheServerCodecThe full server codec that combines the correct encoder and decoder.Classio.netty.handler.codec.memcache.binaryNetty
BinaryWebSocketFrameClassio.netty.handler.codec.http.websocketxNetty
BlockingOperationExceptionAn IllegalStateException which is raised when a user performed a blocking operationwhen the user is in an event loop thread.Classio.netty.util.concurrentNetty
BootstrapA Bootstrap that makes it easy to bootstrap a Channel to useThe AbstractBootstrap.Classio.netty.bootstrapNetty
ByteArrayDecoderDecodes a received ByteBuf into an array of bytes.Classio.netty.handler.codec.bytesNetty
ByteArrayEncoderEncodes the requested array of bytes into a ByteBuf.Classio.netty.handler.codec.bytesNetty
ByteBufA random and sequential accessible sequence of zero or more bytes (octets).Classio.netty.bufferNetty
ByteBufAllocatorInterfaceio.netty.bufferNetty
ByteBufHolderA packet which is send or receive.Interfaceio.netty.bufferNetty
ByteBufInputStreamAn InputStream which reads data from a ByteBuf.Classio.netty.bufferNetty
ByteBufOutputStreamAn OutputStream which writes data to a ByteBuf.Classio.netty.bufferNetty
ByteBufProcessorInterfaceio.netty.bufferNetty
ByteBufUtilA collection of utility methods that is related with handling ByteBuf.Classio.netty.bufferNetty
ByteToMessageCodecA Codec for on-the-fly encoding/decoding of bytes to messages and vise-versa.Classio.netty.handler.codecNetty
ByteToMessageDecoderA ChannelHandler which decodes bytes in a stream-like fashion from one ByteBuf to anFor example here is an implementation which reads all readable bytes fromClassio.netty.handler.codecNetty
Bzip2DecoderUncompresses a ByteBuf encoded with the Bzip2 format.Classio.netty.handler.codec.compressionNetty
Bzip2EncoderCompresses a ByteBuf using the Bzip2 algorithm.Classio.netty.handler.codec.compressionNetty
ChannelA nexus to a network socket or a component which is capable of I/Ooperations such as read, write, connect, and bind.Interfaceio.netty.channelNetty
ChannelConfigA set of configuration properties of a Channel.Interfaceio.netty.channelNetty
ChannelDuplexHandlerClassio.netty.channelNetty
ChannelExceptionA RuntimeException which is thrown when an I/O operation fails.Classio.netty.channelNetty
ChannelFactoryInterfaceio.netty.bootstrapNetty
ChannelFactoryCreates a new Channel.Interfaceio.netty.channelNetty
ChannelFlushPromiseNotifierThis implementation allows to register ChannelFuture instances which will get notified once some amount ofdata was written and so a checkpoint was reached.Classio.netty.channelNetty
ChannelFutureThe result of an asynchronous Channel I/O operation.Interfaceio.netty.channelNetty
ChannelFutureListenerListens to the result of a ChannelFuture.Interfaceio.netty.channelNetty
ChannelGroupA thread-safe Set that contains open Channels and providesvarious bulk operations on them.Interfaceio.netty.channel.groupNetty
ChannelGroupExceptionChannelException which holds ChannelFutures that failed because of an error.Classio.netty.channel.groupNetty
ChannelGroupFutureThe result of an asynchronous ChannelGroup operation.Interfaceio.netty.channel.groupNetty
ChannelGroupFutureListenerListens to the result of a ChannelGroupFuture.Interfaceio.netty.channel.groupNetty
ChannelHandlerHandles an I/O event or intercepts an I/O operation, and forwards it to its next handler inits ChannelPipeline.Interfaceio.netty.channelNetty
ChannelHandlerAdapterSkelton implementation of a ChannelHandler.Classio.netty.channelNetty
ChannelHandlerAppenderA ChannelHandler that appends the specified ChannelHandlers right next to itself.Classio.netty.channelNetty
ChannelHandlerContextEnables a ChannelHandler to interact with its ChannelPipelineand other handlers.Interfaceio.netty.channelNetty
ChannelHandlerInvokerInvokes the event handler methods of ChannelHandler.Interfaceio.netty.channelNetty
ChannelHandlerInvokerUtilA set of helper methods for easier implementation of custom ChannelHandlerInvoker implementation.Classio.netty.channelNetty
ChannelIdRepresents the globally unique identifier of a Channel.Interfaceio.netty.channelNetty
ChannelInboundHandlerAdapterClassio.netty.channelNetty
ChannelInitializerA special ChannelHandler which offers an easy way to initialize a Channel once it wasregistered to its EventLoop.Classio.netty.channelNetty
ChannelInputShutdownEventSpecial event which will be fired and passed to theChannelHandler.Classio.netty.channel.socketNetty
ChannelMatcherAllows to only match some Channel's for operations in ChannelGroup.Interfaceio.netty.channel.groupNetty
ChannelMatchersHelper class which provides often used ChannelMatcher implementations.Classio.netty.channel.groupNetty
ChannelMetadataRepresents the properties of a Channel implementation.Classio.netty.channelNetty
ChannelOptionClassio.netty.channelNetty
ChannelOutboundBuffer(Transport implementors only) an internal data structure used by AbstractChannel to store its pendingoutbound write requests.Classio.netty.channelNetty
ChannelOutboundHandlerAdapterClassio.netty.channelNetty
ChannelPipelineA list of ChannelHandlers which handles or intercepts inbound events and outbound operations of aChannel.Interfaceio.netty.channelNetty
ChannelPipelineExceptionA ChannelException which is thrown when a ChannelPipelinefailed to execute an operation.Classio.netty.channelNetty
ChannelProgressiveFutureInterfaceio.netty.channelNetty
ChannelProgressiveFutureListenerInterfaceio.netty.channelNetty
ChannelProgressivePromiseSpecial ChannelPromise which will be notified once the associated bytes is transferring.Interfaceio.netty.channelNetty
ChannelPromiseSpecial ChannelFuture which is writable.Interfaceio.netty.channelNetty
ChannelPromiseAggregatorClass which is used to consolidate multiple channel futures into one, bylistening to the individual futures and producing an aggregated resultClassio.netty.channelNetty
ChannelPromiseNotifierChannelFutureListener implementation which takes other ChannelFuture(s) and notifies them on completion.Classio.netty.channelNetty
ChannelTrafficShapingHandlerThis implementation of the AbstractTrafficShapingHandler is for channeltraffic shaping, that is to say a per channel limitation of the bandwidth.Classio.netty.handler.trafficNetty
CharsetUtilA utility class that provides various common operations and constantsrelated with Charset and its relevant classes.Classio.netty.utilNetty
ChunkedFileA ChunkedInput that fetches data from a file chunk by chunk.Classio.netty.handler.streamNetty
ChunkedInputA data stream of indefinite length which is consumed by ChunkedWriteHandler.Interfaceio.netty.handler.streamNetty
ChunkedNioFileA ChunkedInput that fetches data from a file chunk by chunk usingIf your operating system supportsClassio.netty.handler.streamNetty
ChunkedNioStreamA ChunkedInput that fetches data from a ReadableByteChannelchunk by chunk.Classio.netty.handler.streamNetty
ChunkedStreamA ChunkedInput that fetches data from an InputStream chunk byPlease note that the InputStream instance that feeds data intoClassio.netty.handler.streamNetty
ChunkedWriteHandlerA ChannelHandler that adds support for writing a large data streamasynchronously neither spending a lot of memory nor gettingClassio.netty.handler.streamNetty
CipherSuiteFilterProvides a means to filter the supplied cipher suite based upon the supported and default cipher suites.Interfaceio.netty.handler.sslNetty
ClassResolverInterfaceio.netty.handler.codec.serializationNetty
ClassResolversClassio.netty.handler.codec.serializationNetty
ClientCookieDecoderA RFC6265 compliant cookie decoder to be used client side.Classio.netty.handler.codec.httpNetty
ClientCookieEncoderA RFC6265 compliant cookie encoder to be used client side,so only name=value pairs are sent.Classio.netty.handler.codec.httpNetty
CloseWebSocketFrameClassio.netty.handler.codec.http.websocketxNetty
CodecExceptionAn Exception which is thrown by a codec.Classio.netty.handler.codecNetty
CompatibleMarshallingDecoderReplayingDecoder which use an Unmarshaller to read the Object out of the ByteBuf.Classio.netty.handler.codec.marshallingNetty
CompatibleMarshallingEncoderMessageToByteEncoder implementation which uses JBoss Marshalling to marshalSee JBoss Marshalling websiteClassio.netty.handler.codec.marshallingNetty
CompatibleObjectEncoderAn encoder which serializes a Java object into a ByteBuf(interoperability version).Classio.netty.handler.codec.serializationNetty
CompleteFutureA skeletal Future implementation which represents a Future which has been completed already.Classio.netty.util.concurrentNetty
CompositeByteBufA virtual buffer which shows multiple buffers as a single merged buffer.Classio.netty.bufferNetty
CompressionExceptionAn EncoderException that is raised when compression failed.Classio.netty.handler.codec.compressionNetty
CompressorHttp2ConnectionEncoderA HTTP2 encoder that will compress data frames according to the content-encoding header for each stream.Classio.netty.handler.codec.http2Netty
ConnectTimeoutExceptionConnectException which will be thrown if a connection couldnot be established because of a connection timeout.Classio.netty.channelNetty
ConstantA singleton which is safe to compare via the == operator.Interfaceio.netty.utilNetty
ConstantPoolA pool of Constants.Classio.netty.utilNetty
ContextBoundUnmarshallerProviderUnmarshallerProvider which store a reference to the Unmarshaller in theChannelHandlerContext via the AttributeMap.Classio.netty.handler.codec.marshallingNetty
ContinuationWebSocketFrameWeb Socket continuation frame containing continuation text or binary data.Classio.netty.handler.codec.http.websocketxNetty
ConvertibleHeadersExtension to the Headers interface to provide methods which convert thenative UnconvertedType to the not-native ConvertedTypeInterfaceio.netty.handler.codecNetty
CookieInterfaceio.netty.handler.codec.httpNetty
CorruptedFrameExceptionAn DecoderException which is thrown when the received frame data could not be decoded bySee Also:Serialized FormClassio.netty.handler.codecNetty
CorsConfigConfiguration for Cross-Origin Resource Sharing (CORS).Classio.netty.handler.codec.http.corsNetty
CorsHandlerHandles Cross Origin Resource Sharing (CORS) requests.Classio.netty.handler.codec.http.corsNetty
DatagramChannelInterfaceio.netty.channel.socketNetty
DatagramChannelConfigA ChannelConfig for a DatagramChannel.Interfaceio.netty.channel.socketNetty
DatagramPacketThe message container that is used for DatagramChannel to communicate with the remote peer.Classio.netty.channel.socketNetty
DecoderExceptionAn CodecException which is thrown by a dencoder.Classio.netty.handler.codecNetty
DecoderResultClassio.netty.handler.codecNetty
DecoderResultProviderProvides the accessor methods for the DecoderResult property of a decoded message.Interfaceio.netty.handler.codecNetty
DecompressionExceptionA DecoderException that is raised when decompression failed.Classio.netty.handler.codec.compressionNetty
DefaultAddressedEnvelopeThe default AddressedEnvelope implementation.Classio.netty.channelNetty
DefaultAttributeMapClassio.netty.utilNetty
DefaultBinaryHeadersClassio.netty.handler.codecNetty
DefaultBinaryMemcacheRequestThe default implementation of the BinaryMemcacheRequest.Classio.netty.handler.codec.memcache.binaryNetty
DefaultBinaryMemcacheResponseThe default implementation of the BinaryMemcacheResponse.Classio.netty.handler.codec.memcache.binaryNetty
DefaultByteBufHolderDefault implementation of a ByteBufHolder that holds it's data in a ByteBuf.Classio.netty.bufferNetty
DefaultChannelConfigThe default SocketChannelConfig implementation.Classio.netty.channelNetty
DefaultChannelGroupThe default ChannelGroup implementation.Classio.netty.channel.groupNetty
DefaultChannelHandlerInvokerClassio.netty.channelNetty
DefaultChannelProgressivePromiseThe default ChannelProgressivePromise implementation.Classio.netty.channelNetty
DefaultChannelPromiseThe default ChannelPromise implementation.Classio.netty.channelNetty
DefaultConvertibleHeadersClassio.netty.handler.codecNetty
DefaultCookieThe default Cookie implementation.Classio.netty.handler.codec.httpNetty
DefaultDatagramChannelConfigThe default DatagramChannelConfig implementation.Classio.netty.channel.socketNetty
DefaultEventExecutorClassio.netty.util.concurrentNetty
DefaultEventExecutorGroupDefault implementation of MultithreadEventExecutorGroup which will use DefaultEventExecutorinstances to handle the tasks.Classio.netty.util.concurrentNetty
DefaultEventLoopClassio.netty.channelNetty
DefaultEventLoopGroupMultithreadEventLoopGroup which must be used for the local transport.Classio.netty.channelNetty
DefaultExecutorServiceFactoryAn implementation of an ExecutorServiceFactory that creates a new ForkJoinPool on eachcall to newExecutorService(int).Classio.netty.util.concurrentNetty
DefaultFileRegionDefault FileRegion implementation which transfer data from a FileChannel or File.Classio.netty.channelNetty
DefaultFullBinaryMemcacheRequestThe default implementation of a FullBinaryMemcacheRequest.Classio.netty.handler.codec.memcache.binaryNetty
DefaultFullBinaryMemcacheResponseThe default implementation of a FullBinaryMemcacheResponse.Classio.netty.handler.codec.memcache.binaryNetty
DefaultFullHttpRequestDefault implementation of FullHttpRequest.Classio.netty.handler.codec.httpNetty
DefaultFullHttpResponseDefault implementation of a FullHttpResponse.Classio.netty.handler.codec.httpNetty
DefaultHeadersClassio.netty.handler.codecNetty
DefaultHttp2ConnectionSimple implementation of Http2Connection.Classio.netty.handler.codec.http2Netty
DefaultHttp2ConnectionDecoderProvides the default implementation for processing inbound frame events and delegates to aThis class will read HTTP/2 frames and delegate the events to a Http2FrameListenerClassio.netty.handler.codec.http2Netty
DefaultHttp2ConnectionEncoderDefault implementation of Http2ConnectionEncoder.Classio.netty.handler.codec.http2Netty
DefaultHttp2FrameReaderA Http2FrameReader that supports all frame types defined by the HTTP/2 specification.Classio.netty.handler.codec.http2Netty
DefaultHttp2FrameWriterA Http2FrameWriter that supports all frame types defined by the HTTP/2 specification.Classio.netty.handler.codec.http2Netty
DefaultHttp2HeadersClassio.netty.handler.codec.http2Netty
DefaultHttp2HeadersDecoderClassio.netty.handler.codec.http2Netty
DefaultHttp2HeadersEncoderClassio.netty.handler.codec.http2Netty
DefaultHttp2LocalFlowControllerBasic implementation of Http2LocalFlowController.Classio.netty.handler.codec.http2Netty
DefaultHttp2RemoteFlowControllerBasic implementation of Http2RemoteFlowController.Classio.netty.handler.codec.http2Netty
DefaultHttp2StreamRemovalPolicyA Http2StreamRemovalPolicy that periodically runs garbage collection on streams that havebeen marked for removal.Classio.netty.handler.codec.http2Netty
DefaultHttpContentThe default HttpContent implementation.Classio.netty.handler.codec.httpNetty
DefaultHttpDataFactoryDefault factory giving Attribute and FileUpload according to constructorAttribute and FileUpload could be :Classio.netty.handler.codec.http.multipartNetty
DefaultHttpHeadersClassio.netty.handler.codec.httpNetty
DefaultHttpMessageThe default HttpMessage implementation.Classio.netty.handler.codec.httpNetty
DefaultHttpObjectClassio.netty.handler.codec.httpNetty
DefaultHttpRequestThe default HttpRequest implementation.Classio.netty.handler.codec.httpNetty
DefaultHttpResponseThe default HttpResponse implementation.Classio.netty.handler.codec.httpNetty
DefaultLastHttpContentThe default LastHttpContent implementation.Classio.netty.handler.codec.httpNetty
DefaultLastMemcacheContentThe default implementation for the LastMemcacheContent.Classio.netty.handler.codec.memcacheNetty
DefaultLastStompContentSubframeThe default implementation for the LastStompContentSubframe.Classio.netty.handler.codec.stompNetty
DefaultMarshallerProviderDefault implementation of MarshallerProvider which just create a new Marshalleron ever getMarshaller(ChannelHandlerContext) call.Classio.netty.handler.codec.marshallingNetty
DefaultMemcacheContentThe default MemcacheContent implementation.Classio.netty.handler.codec.memcacheNetty
DefaultMessageSizeEstimatorDefault MessageSizeEstimator implementation which supports the estimation of the size ofByteBuf, ByteBufHolder and FileRegion.Classio.netty.channelNetty
DefaultNameResolverA NameResolver that resolves an InetSocketAddress using JDK's built-in domain name lookup mechanism.Classio.netty.resolverNetty
DefaultNameResolverGroupA NameResolverGroup of DefaultNameResolvers.Classio.netty.resolverNetty
DefaultOioServerSocketChannelConfigClassio.netty.channel.socket.oioNetty
DefaultOioSocketChannelConfigClassio.netty.channel.socket.oioNetty
DefaultProgressivePromiseClassio.netty.util.concurrentNetty
DefaultPromiseClassio.netty.util.concurrentNetty
DefaultSctpChannelConfigThe default SctpChannelConfig implementation for SCTP.Classio.netty.channel.sctpNetty
DefaultSctpServerChannelConfigThe default SctpServerChannelConfig implementation for SCTP.Classio.netty.channel.sctpNetty
DefaultServerSocketChannelConfigThe default ServerSocketChannelConfig implementation.Classio.netty.channel.socketNetty
DefaultSocketChannelConfigThe default SocketChannelConfig implementation.Classio.netty.channel.socketNetty
DefaultSocks4CommandRequestThe default Socks4CommandRequest.Classio.netty.handler.codec.socksx.v4Netty
DefaultSocks4CommandResponseThe default Socks4CommandResponse.Classio.netty.handler.codec.socksx.v4Netty
DefaultSocks5CommandRequestThe default Socks5CommandRequest.Classio.netty.handler.codec.socksx.v5Netty
DefaultSocks5CommandResponseThe default Socks5CommandResponse.Classio.netty.handler.codec.socksx.v5Netty
DefaultSocks5InitialRequestThe default Socks5InitialRequest.Classio.netty.handler.codec.socksx.v5Netty
DefaultSocks5InitialResponseThe default Socks5InitialResponse.Classio.netty.handler.codec.socksx.v5Netty
DefaultSocks5PasswordAuthRequestThe default Socks5PasswordAuthRequest.Classio.netty.handler.codec.socksx.v5Netty
DefaultSocks5PasswordAuthResponseThe default Socks5PasswordAuthResponse.Classio.netty.handler.codec.socksx.v5Netty
DefaultSpdyDataFrameThe default SpdyDataFrame implementation.Classio.netty.handler.codec.spdyNetty
DefaultSpdyGoAwayFrameThe default SpdyGoAwayFrame implementation.Classio.netty.handler.codec.spdyNetty
DefaultSpdyHeadersClassio.netty.handler.codec.spdyNetty
DefaultSpdyHeadersFrameThe default SpdyHeadersFrame implementation.Classio.netty.handler.codec.spdyNetty
DefaultSpdyPingFrameThe default SpdyPingFrame implementation.Classio.netty.handler.codec.spdyNetty
DefaultSpdyRstStreamFrameThe default SpdyRstStreamFrame implementation.Classio.netty.handler.codec.spdyNetty
DefaultSpdySettingsFrameThe default SpdySettingsFrame implementation.Classio.netty.handler.codec.spdyNetty
DefaultSpdyStreamFrameThe default SpdyStreamFrame implementation.Classio.netty.handler.codec.spdyNetty
DefaultSpdySynReplyFrameThe default SpdySynReplyFrame implementation.Classio.netty.handler.codec.spdyNetty
DefaultSpdySynStreamFrameThe default SpdySynStreamFrame implementation.Classio.netty.handler.codec.spdyNetty
DefaultSpdyWindowUpdateFrameThe default SpdyWindowUpdateFrame implementation.Classio.netty.handler.codec.spdyNetty
DefaultStompContentSubframeThe default StompContentSubframe implementation.Classio.netty.handler.codec.stompNetty
DefaultStompFrameDefault implementation of StompFrame.Classio.netty.handler.codec.stompNetty
DefaultStompHeadersClassio.netty.handler.codec.stompNetty
DefaultStompHeadersSubframeDefault implementation of StompHeadersSubframe.Classio.netty.handler.codec.stompNetty
DefaultTextHeadersClassio.netty.handler.codecNetty
DefaultThreadFactoryA ThreadFactory implementation with a simple naming rule.Classio.netty.util.concurrentNetty
DefaultUdtChannelConfigThe default UdtChannelConfig implementation.Classio.netty.channel.udtNetty
DefaultUdtServerChannelConfigThe default UdtServerChannelConfig implementation.Classio.netty.channel.udtNetty
DefaultUnmarshallerProviderDefault implementation of UnmarshallerProvider which will just create a new Unmarshalleron every call to getUnmarshaller(ChannelHandlerContext)Classio.netty.handler.codec.marshallingNetty
DeflateFrameClientExtensionHandshakerhandshake implementation.Classio.netty.handler.codec.http.websocketx.extensions.compressionNetty
DeflateFrameServerExtensionHandshakerhandshake implementation.Classio.netty.handler.codec.http.websocketx.extensions.compressionNetty
DelegatingDecompressorFrameListenerA HTTP2 frame listener that will decompress data frames according to the content-encoding header for eachstream.Classio.netty.handler.codec.http2Netty
DelimiterBasedFrameDecoderA decoder that splits the received ByteBufs by one or moredelimiters.Classio.netty.handler.codecNetty
DelimitersA set of commonly used delimiters for DelimiterBasedFrameDecoder.Classio.netty.handler.codecNetty
DiskAttributeClassio.netty.handler.codec.http.multipartNetty
DiskFileUploadClassio.netty.handler.codec.http.multipartNetty
DnsClassClassio.netty.handler.codec.dnsNetty
DnsEntryA class representing entries in a DNS packet (questions, and all resourcerecords).Classio.netty.handler.codec.dnsNetty
DnsHeaderThe header super-class which includes information shared by DNS query andresponse packet headers such as the ID, opcode, and type.Classio.netty.handler.codec.dnsNetty
DnsMessageThe message super-class which contains core information concerning DNSpackets, both outgoing and incoming.Classio.netty.handler.codec.dnsNetty
DnsNameResolverA DNS-based NameResolver.Classio.netty.resolver.dnsNetty
DnsNameResolverGroupA NameResolverGroup of DnsNameResolvers.Classio.netty.resolver.dnsNetty
DnsQueryA DNS query packet which is sent to a server to receive a DNS response packetwith information answering a DnsQuery's questions.Classio.netty.handler.codec.dnsNetty
DnsQueryEncoderDnsQueryEncoder accepts DnsQuery and encodes to ByteBuf.Classio.netty.handler.codec.dnsNetty
DnsQueryHeaderClassio.netty.handler.codec.dnsNetty
DnsQuestionThe DNS question class which represents a question being sent to a server viaa query, or the question being duplicated and sent back in a response.Classio.netty.handler.codec.dnsNetty
DnsResourceClassio.netty.handler.codec.dnsNetty
DnsResponseClassio.netty.handler.codec.dnsNetty
DnsResponseCodeRepresents the possible response codes a server may send after receiving aquery.Classio.netty.handler.codec.dnsNetty
DnsResponseDecoderDnsResponseDecoder accepts DatagramPacket and encodes toDnsResponse.Classio.netty.handler.codec.dnsNetty
DnsResponseHeaderThe DNS response header class which is used when receiving data from a DNSserver.Classio.netty.handler.codec.dnsNetty
DnsServerAddressesProvides a sequence of DNS server addresses to DnsNameResolver.Classio.netty.resolver.dnsNetty
DnsTypeRepresents a DNS record type.Classio.netty.handler.codec.dnsNetty
DomainNameMappingMaps a domain name to its associated value object.Classio.netty.utilNetty
DomainSocketAddressClassio.netty.channel.unixNetty
DomainSocketChannelInterfaceio.netty.channel.unixNetty
DomainSocketChannelConfigSpecial ChannelConfig for DomainSocketChannels.Interfaceio.netty.channel.unixNetty
DomainSocketReadModeenum DomainSocketReadModeDifferent modes of reading from a DomainSocketChannel.Classio.netty.channel.unixNetty
DuplicatedByteBufA derived buffer which simply forwards all data access requests to itsparent.Classio.netty.bufferNetty
EmbeddedChannelBase class for Channel implementations that are used in an embedded fashion.Classio.netty.channel.embeddedNetty
EmptyBinaryHeadersClassio.netty.handler.codecNetty
EmptyByteBufAn empty ByteBuf whose capacity and maximum capacity are all 0.Classio.netty.bufferNetty
EmptyConvertibleHeadersClassio.netty.handler.codecNetty
EmptyHeadersClassio.netty.handler.codecNetty
EmptyHttp2HeadersClassio.netty.handler.codec.http2Netty
EmptyHttpHeadersClassio.netty.handler.codec.httpNetty
EmptyTextHeadersClassio.netty.handler.codecNetty
EncoderExceptionAn CodecException which is thrown by an encoder.Classio.netty.handler.codecNetty
EpollTells if netty-transport-native-epoll is supported.Classio.netty.channel.epollNetty
EpollChannelConfigClassio.netty.channel.epollNetty
EpollChannelOptionClassio.netty.channel.epollNetty
EpollDatagramChannelDatagramChannel implementation that uses linux EPOLL Edge-Triggered Mode formaximal performance.Classio.netty.channel.epollNetty
EpollDatagramChannelConfigClassio.netty.channel.epollNetty
EpollDomainSocketChannelClassio.netty.channel.epollNetty
EpollDomainSocketChannelConfigClassio.netty.channel.epollNetty
EpollEventLoopGroupA MultithreadEventLoopGroup which uses epoll under thecovers.Classio.netty.channel.epollNetty
EpollModeThe epoll mode to use.Classio.netty.channel.epollNetty
EpollServerChannelConfigClassio.netty.channel.epollNetty
EpollServerDomainSocketChannelClassio.netty.channel.epollNetty
EpollServerSocketChannelServerSocketChannel implementation that uses linux EPOLL Edge-Triggered Mode formaximal performance.Classio.netty.channel.epollNetty
EpollServerSocketChannelConfigClassio.netty.channel.epollNetty
EpollSocketChannelSocketChannel implementation that uses linux EPOLL Edge-Triggered Mode formaximal performance.Classio.netty.channel.epollNetty
EpollSocketChannelConfigClassio.netty.channel.epollNetty
EpollTcpInfo__u8 tcpi_retransmits;__u8 tcpi_snd_wscale : 4, tcpi_rcv_wscale : 4;Classio.netty.channel.epollNetty
EventExecutorThe EventExecutor is a special EventExecutorGroup which comeswith some handy methods to see if a Thread is executed in a event loop.Interfaceio.netty.util.concurrentNetty
EventExecutorGroupThe EventExecutorGroup is responsible for providing the EventExecutor's to usevia its next() method.Interfaceio.netty.util.concurrentNetty
EventLoopWill handle all the I/O operations for a Channel once registered.Interfaceio.netty.channelNetty
EventLoopExceptionSpecial ChannelException which will be thrown by EventLoop and EventLoopGroupSee Also:Serialized FormClassio.netty.channelNetty
EventLoopGroupSpecial EventExecutorGroup which allows registering Channels that getprocessed for later selection during the event loop.Interfaceio.netty.channelNetty
ExecutorServiceFactoryAn object that creates new ExecutorService on demand.Interfaceio.netty.util.concurrentNetty
FailedFutureThe CompleteFuture which is failed already.Classio.netty.util.concurrentNetty
FastLzFrameDecoderUncompresses a ByteBuf encoded by FastLzFrameEncoder using the FastLZ algorithm.Classio.netty.handler.codec.compressionNetty
FastLzFrameEncoderCompresses a ByteBuf using the FastLZ algorithm.Classio.netty.handler.codec.compressionNetty
FastThreadLocalA special variant of ThreadLocal that yields higher access performance when accessed from aFastThreadLocalThread.Classio.netty.util.concurrentNetty
FastThreadLocalAccessNetty's Thread implementations implement this interface to provide fast access to FastThreadLocalSee Also:FastThreadLocalThreadInterfaceio.netty.util.concurrentNetty
FastThreadLocalThreadA special Thread that provides fast access to FastThreadLocal variables.Classio.netty.util.concurrentNetty
FileDescriptorNative FileDescriptor implementation which allows to wrap an int and provide aFileDescriptor for it.Classio.netty.channel.unixNetty
FileRegionA region of a file that is sent via a Channel which supportszero-copy file transfer.Interfaceio.netty.channelNetty
FileUploadFileUpload interface that could be in memory, on temporary file or any other implementations.Interfaceio.netty.handler.codec.http.multipartNetty
FingerprintTrustManagerFactoryAn TrustManagerFactory that trusts an X.Classio.netty.handler.ssl.utilNetty
FixedLengthFrameDecoderA decoder that splits the received ByteBufs by the fixed numberof bytes.Classio.netty.handler.codecNetty
FixedRecvByteBufAllocatorThe RecvByteBufAllocator that always yields the same buffersize prediction.Classio.netty.channelNetty
FullBinaryMemcacheRequestA BinaryMemcacheRequest that also includes the content.Interfaceio.netty.handler.codec.memcache.binaryNetty
FullBinaryMemcacheResponseA BinaryMemcacheResponse that also includes the content.Interfaceio.netty.handler.codec.memcache.binaryNetty
FullHttpMessageCombines HttpMessage and LastHttpContent into onemessage.Interfaceio.netty.handler.codec.httpNetty
FullHttpRequestCombinate the HttpRequest and FullHttpMessage, so the request is a complete HTTP request.Interfaceio.netty.handler.codec.httpNetty
FullHttpResponseCombination of a HttpResponse and FullHttpMessage.Interfaceio.netty.handler.codec.httpNetty
FullMemcacheMessageCombines MemcacheMessage and LastMemcacheContent into onemessage.Interfaceio.netty.handler.codec.memcacheNetty
FutureThe result of an asynchronous operation.Interfaceio.netty.util.concurrentNetty
FutureListenerA subtype of GenericFutureListener that hides type parameter for convenience.Interfaceio.netty.util.concurrentNetty
GenericFutureListenerListens to the result of a Future.Interfaceio.netty.util.concurrentNetty
GenericProgressiveFutureListenerInterfaceio.netty.util.concurrentNetty
GlobalChannelTrafficCounterVersion for GlobalChannelTrafficShapingHandler.Classio.netty.handler.trafficNetty
GlobalChannelTrafficShapingHandlerThis implementation of the AbstractTrafficShapingHandler is for globaland per channel traffic shaping, that is to say a global limitation of the bandwidth, whateverClassio.netty.handler.trafficNetty
GlobalEventExecutorSingle-thread singleton EventExecutor.Classio.netty.util.concurrentNetty
GlobalTrafficShapingHandlerThis implementation of the AbstractTrafficShapingHandler is for globaltraffic shaping, that is to say a global limitation of the bandwidth, whateverClassio.netty.handler.trafficNetty
HAProxyCommandThe command of an HAProxy proxy protocol headerEnum Constant SummaryClassio.netty.handler.codec.haproxyNetty
HAProxyMessageClassio.netty.handler.codec.haproxyNetty
HAProxyMessageDecoderDecodes an HAProxy proxy protocol headerSee Also:Proxy Protocol SpecificationClassio.netty.handler.codec.haproxyNetty
HAProxyProtocolExceptionA DecoderException which is thrown when an invalid HAProxy proxy protocol header is encounteredSee Also:Serialized FormClassio.netty.handler.codec.haproxyNetty
HAProxyProtocolVersionenum HAProxyProtocolVersionThe HAProxy proxy protocol specification version.Classio.netty.handler.codec.haproxyNetty
HAProxyProxiedProtocolenum HAProxyProxiedProtocolA protocol proxied by HAProxy which is represented by its transport protocol and address family.Classio.netty.handler.codec.haproxyNetty
HashedWheelTimerA Timer optimized for approximated I/O timeout scheduling.Classio.netty.utilNetty
HeadersInterfaceio.netty.handler.codecNetty
Http2ClientUpgradeCodecClient-side cleartext upgrade codec from HTTP to HTTP/2.Classio.netty.handler.codec.http2Netty
Http2CodecUtilConstants and utility method used for encoding/decoding HTTP2 frames.Classio.netty.handler.codec.http2Netty
Http2ConnectionManager for the state of an HTTP/2 connection with the remote end-point.Interfaceio.netty.handler.codec.http2Netty
Http2ConnectionAdapterProvides empty implementations of all Http2Connection.Classio.netty.handler.codec.http2Netty
Http2ConnectionDecoderHandler for inbound traffic on behalf of Http2ConnectionHandler.Interfaceio.netty.handler.codec.http2Netty
Http2ConnectionEncoderHandler for outbound HTTP/2 traffic.Interfaceio.netty.handler.codec.http2Netty
Http2ConnectionHandlerProvides the default implementation for processing inbound frame events and delegates to aThis class will read HTTP/2 frames and delegate the events to a Http2FrameListenerClassio.netty.handler.codec.http2Netty
Http2DataWriterInterface that defines an object capable of producing HTTP/2 data frames.Interfaceio.netty.handler.codec.http2Netty
Http2ErrorAll error codes identified by the HTTP/2 spec.Classio.netty.handler.codec.http2Netty
Http2EventAdapterThis class brings Http2Connection.Classio.netty.handler.codec.http2Netty
Http2ExceptionException thrown when an HTTP/2 error was encountered.Classio.netty.handler.codec.http2Netty
Http2FlagsProvides utility methods for accessing specific flags as defined by the HTTP/2 spec.Classio.netty.handler.codec.http2Netty
Http2FlowControllerBase interface for all HTTP/2 flow controllers.Interfaceio.netty.handler.codec.http2Netty
Http2FrameAdapterConvenience class that provides no-op implementations for all methods of Http2FrameListener.Classio.netty.handler.codec.http2Netty
Http2FrameListenerAn listener of HTTP/2 frames.Interfaceio.netty.handler.codec.http2Netty
Http2FrameListenerDecoratorClassio.netty.handler.codec.http2Netty
Http2FrameLoggerLogs HTTP2 frames for debugging purposes.Classio.netty.handler.codec.http2Netty
Http2FrameReaderReads HTTP/2 frames from an input ByteBuf and notifies the specifiedHttp2FrameListener when frames are complete.Interfaceio.netty.handler.codec.http2Netty
Http2FrameSizePolicyInterfaceio.netty.handler.codec.http2Netty
Http2FrameTypesRegistry of all standard frame types defined by the HTTP/2 specification.Classio.netty.handler.codec.http2Netty
Http2FrameWriterA writer responsible for marshaling HTTP/2 frames to the channel.Interfaceio.netty.handler.codec.http2Netty
Http2HeadersA collection of headers sent or received via HTTP/2.Interfaceio.netty.handler.codec.http2Netty
Http2HeadersDecoderDecodes HPACK-encoded headers blocks into Http2Headers.Interfaceio.netty.handler.codec.http2Netty
Http2HeadersEncoderEncodes Http2Headers into HPACK-encoded headers blocks.Interfaceio.netty.handler.codec.http2Netty
Http2HeaderTableInterfaceio.netty.handler.codec.http2Netty
Http2InboundFrameLoggerClassio.netty.handler.codec.http2Netty
Http2LifecycleManagerManager for the life cycle of the HTTP/2 connection.Interfaceio.netty.handler.codec.http2Netty
Http2LocalFlowControllerInterfaceio.netty.handler.codec.http2Netty
Http2NoMoreStreamIdsExceptionThis exception is thrown when there are no more stream IDs available for the current connectionSee Also:Serialized FormClassio.netty.handler.codec.http2Netty
Http2OrHttpChooserChannelHandler which is responsible to setup theChannelPipeline either for HTTP or HTTP2.Classio.netty.handler.codec.http2Netty
Http2OutboundFrameLoggerClassio.netty.handler.codec.http2Netty
Http2RemoteFlowControllerInterfaceio.netty.handler.codec.http2Netty
Http2SecurityUtilProvides utilities related to security requirements specific to HTTP/2.Classio.netty.handler.codec.http2Netty
Http2ServerUpgradeCodecServer-side codec for performing a cleartext upgrade from HTTP/1.Classio.netty.handler.codec.http2Netty
Http2SettingsSettings for one endpoint in an HTTP/2 connection.Classio.netty.handler.codec.http2Netty
Http2StreamA single stream within an HTTP2 connection.Interfaceio.netty.handler.codec.http2Netty
Http2StreamRemovalPolicyA policy for determining when it is appropriate to remove streams from an HTTP/2 stream registry.Interfaceio.netty.handler.codec.http2Netty
HttpChunkedInputA ChunkedInput that fetches data chunk by chunk for use with HTTP chunked transfers.Classio.netty.handler.codec.httpNetty
HttpClientCodecA combination of HttpRequestEncoder and HttpResponseDecoderwhich enables easier client side HTTP implementation.Classio.netty.handler.codec.httpNetty
HttpClientUpgradeHandlerClient-side handler for handling an HTTP upgrade handshake to another protocol.Classio.netty.handler.codec.httpNetty
HttpConstantsClassio.netty.handler.codec.httpNetty
HttpContentAn HTTP chunk which is used for HTTP chunked transfer-encoding.Interfaceio.netty.handler.codec.httpNetty
HttpContentCompressorCompresses an HttpMessage and an HttpContent in gzip ordeflate encoding while respecting the Accept-Encoding header.Classio.netty.handler.codec.httpNetty
HttpContentDecoderDecodes the content of the received HttpRequest and HttpContent.Classio.netty.handler.codec.httpNetty
HttpContentDecompressorDecompresses an HttpMessage and an HttpContent compressed ingzip or deflate encoding.Classio.netty.handler.codec.httpNetty
HttpContentEncoderEncodes the content of the outbound HttpResponse and HttpContent.Classio.netty.handler.codec.httpNetty
HttpDataInterfaceio.netty.handler.codec.http.multipartNetty
HttpDataFactoryInterfaceio.netty.handler.codec.http.multipartNetty
HttpHeaderNamesStandard HTTP header names.Classio.netty.handler.codec.httpNetty
HttpHeadersProvides the constants for the standard HTTP header names and values andcommonly used utility methods that accesses an HttpMessage.Interfaceio.netty.handler.codec.httpNetty
HttpHeaderUtilClassio.netty.handler.codec.httpNetty
HttpHeaderValuesStandard HTTP header values.Classio.netty.handler.codec.httpNetty
HttpMessageAn interface that defines a HTTP message, providing common properties forHttpRequest and HttpResponse.Interfaceio.netty.handler.codec.httpNetty
HttpMethodClassio.netty.handler.codec.httpNetty
HttpObjectAggregatorA ChannelHandler that aggregates an HttpMessageand its following HttpContents into a single FullHttpRequestClassio.netty.handler.codec.httpNetty
HttpObjectDecoderDecodes ByteBufs into HttpMessages andParameters that prevents excessive memory consumptionClassio.netty.handler.codec.httpNetty
HttpObjectEncoderEncodes an HttpMessage or an HttpContent intoPlease note that this encoder is designed to be extended to implementClassio.netty.handler.codec.httpNetty
HttpPostMultipartRequestDecoderThis decoder will decode Body and can handle POST BODY.Classio.netty.handler.codec.http.multipartNetty
HttpPostRequestDecoderThis decoder will decode Body and can handle POST BODY.Classio.netty.handler.codec.http.multipartNetty
HttpPostRequestEncoderThis encoder will help to encode Request for a FORM as POST.Classio.netty.handler.codec.http.multipartNetty
HttpPostStandardRequestDecoderThis decoder will decode Body and can handle POST BODY.Classio.netty.handler.codec.http.multipartNetty
HttpProxyHandlerClassio.netty.handler.proxyNetty
HttpRequestAccessing Query Parameters and CookieUnlike the Servlet API, a query string is constructed and decomposed byInterfaceio.netty.handler.codec.httpNetty
HttpRequestDecoderDecodes ByteBufs into HttpRequests and HttpContents.Classio.netty.handler.codec.httpNetty
HttpRequestEncoderClassio.netty.handler.codec.httpNetty
HttpResponseUnlike the Servlet API, Cookie support is provided separately via ClientCookieDecoder,ServerCookieDecoder, ClientCookieEncoder, and @ServerCookieEncoder.Interfaceio.netty.handler.codec.httpNetty
HttpResponseDecoderDecodes ByteBufs into HttpResponses andParameters that prevents excessive memory consumptionClassio.netty.handler.codec.httpNetty
HttpResponseEncoderClassio.netty.handler.codec.httpNetty
HttpResponseStatusClassio.netty.handler.codec.httpNetty
HttpServerCodecA combination of HttpRequestDecoder and HttpResponseEncoderwhich enables easier server side HTTP implementation.Classio.netty.handler.codec.httpNetty
HttpServerUpgradeHandlerA server-side handler that receives HTTP requests and optionally performs a protocol switch ifthe requested protocol is supported.Classio.netty.handler.codec.httpNetty
HttpStatusClassenum HttpStatusClassThe class of HTTP status.Classio.netty.handler.codec.httpNetty
HttpToHttp2ConnectionHandlerTranslates HTTP/1.Classio.netty.handler.codec.http2Netty
HttpUtilClassio.netty.handler.codec.http2Netty
HttpVersionClassio.netty.handler.codec.httpNetty
IdentityCipherSuiteFilterThis class will not do any filtering of ciphers suites.Classio.netty.handler.sslNetty
IdleStateAn Enum that represents the idle state of a Channel.Classio.netty.handler.timeoutNetty
IdleStateEventA user event triggered by IdleStateHandler when a Channel is idle.Classio.netty.handler.timeoutNetty
IdleStateHandlerTriggers an IdleStateEvent when a Channel has not performedread, write, or both operation for a while.Classio.netty.handler.timeoutNetty
IllegalReferenceCountExceptionAn IllegalStateException which is raised when a user attempts to access a ReferenceCounted whosereference count has been decreased to 0 (and consequently freed).Classio.netty.utilNetty
ImmediateEventExecutorAbstractEventExecutor which execute tasks in the callers thread.Classio.netty.util.concurrentNetty
ImmediateExecutorExecutor which execute tasks in the callers thread.Classio.netty.util.concurrentNetty
InboundHttp2ToHttpAdapterThis adapter provides just header/data events from the HTTP message flow definedhere HTTP/2 Spec Message Flow.Classio.netty.handler.codec.http2Netty
InboundHttp2ToHttpPriorityAdapterTranslate header/data/priority HTTP/2 frame events into HTTP events.Classio.netty.handler.codec.http2Netty
InsecureTrustManagerFactoryAn insecure TrustManagerFactory that trusts all X.Classio.netty.handler.ssl.utilNetty
InterfaceHttpDataInterfaceio.netty.handler.codec.http.multipartNetty
InterfaceHttpPostRequestDecoderThis decoder will decode Body and can handle POST BODY (or for PUT, PATCH or OPTIONS).Interfaceio.netty.handler.codec.http.multipartNetty
InternetProtocolFamilyenum InternetProtocolFamilyInternet Protocol (IP) families used byte the DatagramChannelClassio.netty.channel.socketNetty
IntObjectHashMapA hash map implementation of IntObjectMap that uses open addressing for keys.Classio.netty.util.collectionNetty
IntObjectMapInterface for a primitive map that uses ints as keys.Interfaceio.netty.util.collectionNetty
IpFilterRuleInterfaceio.netty.handler.ipfilterNetty
IpFilterRuleTypeenum IpFilterRuleTypeUsed in IpFilterRule to decide if a matching IP Address should be allowed or denied to connect.Classio.netty.handler.ipfilterNetty
IpSubnetFilterRuleUse this class to create rules for RuleBasedIpFilter that group IP addresses into subnets.Classio.netty.handler.ipfilterNetty
JdkAlpnApplicationProtocolNegotiatorThe JdkApplicationProtocolNegotiator to use if you need ALPN and are using SslProvider.Classio.netty.handler.sslNetty
JdkApplicationProtocolNegotiatorInterfaceio.netty.handler.sslNetty
JdkNpnApplicationProtocolNegotiatorThe JdkApplicationProtocolNegotiator to use if you need NPN and are using SslProvider.Classio.netty.handler.sslNetty
JdkSslClientContextA client-side SslContext which uses JDK's SSL/TLS implementation.Classio.netty.handler.sslNetty
JdkSslContextAn SslContext which uses JDK's SSL/TLS implementation.Classio.netty.handler.sslNetty
JdkSslServerContextA server-side SslContext which uses JDK's SSL/TLS implementation.Classio.netty.handler.sslNetty
JdkZlibDecoderDecompress a ByteBuf using the inflate algorithm.Classio.netty.handler.codec.compressionNetty
JdkZlibEncoderCompresses a ByteBuf using the deflate algorithm.Classio.netty.handler.codec.compressionNetty
JsonObjectDecoderSplits a byte stream of JSON objects and arrays into individual objects/arrays and passes them up theThis class does not do any real parsing or validation.Classio.netty.handler.codec.jsonNetty
JZlibDecoderClassio.netty.handler.codec.compressionNetty
JZlibEncoderCompresses a ByteBuf using the deflate algorithm.Classio.netty.handler.codec.compressionNetty
LastHttpContentThe last HttpContent which has trailing headers.Interfaceio.netty.handler.codec.httpNetty
LastMemcacheContentThe MemcacheContent which signals the end of the content batch.Interfaceio.netty.handler.codec.memcacheNetty
LastStompContentSubframeThe last StompContentSubframe which signals the end of the content batchNote, even when no content is emitted by the protocol, anInterfaceio.netty.handler.codec.stompNetty
LengthFieldBasedFrameDecoderA decoder that splits the received ByteBufs dynamically by thevalue of the length field in the message.Classio.netty.handler.codecNetty
LengthFieldPrependerAn encoder that prepends the length of the message.Classio.netty.handler.codecNetty
LineBasedFrameDecoderA decoder that splits the received ByteBufs on line endings.Classio.netty.handler.codecNetty
LocalAddressAn endpoint in the local transport.Classio.netty.channel.localNetty
LocalChannelA Channel for the local transport.Classio.netty.channel.localNetty
LocalServerChannelA ServerChannel for the local transport which allows in VM communication.Classio.netty.channel.localNetty
LoggingHandlerA ChannelHandler that logs all events using a logging framework.Classio.netty.handler.loggingNetty
LogLevelMaps the regular LogLevels with the InternalLogLevel ones.Classio.netty.handler.loggingNetty
Lz4FrameDecoderUncompresses a ByteBuf encoded with the LZ4 format.Classio.netty.handler.codec.compressionNetty
Lz4FrameEncoderCompresses a ByteBuf using the LZ4 format.Classio.netty.handler.codec.compressionNetty
LzfDecoderUncompresses a ByteBuf encoded with the LZF format.Classio.netty.handler.codec.compressionNetty
LzfEncoderCompresses a ByteBuf using the LZF format.Classio.netty.handler.codec.compressionNetty
LzmaFrameEncoderCompresses a ByteBuf using the LZMA algorithm.Classio.netty.handler.codec.compressionNetty
MappingMaintains the mapping from the objects of one type to the objects of the other type.Interfaceio.netty.utilNetty
MarshallerProviderThis provider is responsible to get a Marshaller for the given ChannelHandlerContext.Interfaceio.netty.handler.codec.marshallingNetty
MarshallingDecoderDecoder which MUST be used with MarshallingEncoder.Classio.netty.handler.codec.marshallingNetty
MarshallingEncoderMessageToByteEncoder implementation which uses JBoss Marshalling to marshalan Object.Classio.netty.handler.codec.marshallingNetty
MemcacheContentAn Memcache content chunk.Interfaceio.netty.handler.codec.memcacheNetty
MemcacheMessageMarker interface for both ascii and binary messages.Interfaceio.netty.handler.codec.memcacheNetty
MemcacheObjectDefines a common interface for all MemcacheObject implementations.Interfaceio.netty.handler.codec.memcacheNetty
MemoryAttributeClassio.netty.handler.codec.http.multipartNetty
MemoryFileUploadDefault FileUpload implementation that stores file into memory.Classio.netty.handler.codec.http.multipartNetty
MessageAggregationExceptionRaised by MessageAggregator when aggregation fails due to an unexpected message sequence.Classio.netty.handler.codecNetty
MessageAggregatorAn abstract ChannelHandler that aggregates a series of message objects into a single aggregated message.Classio.netty.handler.codecNetty
MessageSizeEstimatorResponsible to estimate size of a message.Interfaceio.netty.channelNetty
MessageToByteEncoderChannelHandlerAdapter which encodes message in a stream-like fashion from one message to anExample implementation which encodes Integers to a ByteBuf.Classio.netty.handler.codecNetty
MessageToMessageCodecA Codec for on-the-fly encoding/decoding of message.Classio.netty.handler.codecNetty
MessageToMessageDecoderA ChannelHandler which decodes from one message to an other message.Classio.netty.handler.codecNetty
MessageToMessageEncoderA ChannelHandler which encodes from one message to an other messageFor example here is an implementation which decodes an Integer to an String.Classio.netty.handler.codecNetty
MixedAttributeClassio.netty.handler.codec.http.multipartNetty
MixedFileUploadClassio.netty.handler.codec.http.multipartNetty
MqttConnAckMessageSee MQTTV3.Classio.netty.handler.codec.mqttNetty
MqttConnAckVariableHeaderClassio.netty.handler.codec.mqttNetty
MqttConnectMessageSee MQTTV3.Classio.netty.handler.codec.mqttNetty
MqttConnectPayloadClassio.netty.handler.codec.mqttNetty
MqttConnectReturnCodeenum MqttConnectReturnCodeReturn Code of MqttConnAckMessageClassio.netty.handler.codec.mqttNetty
MqttConnectVariableHeaderClassio.netty.handler.codec.mqttNetty
MqttDecoderDecodes Mqtt messages from bytes, followingthe MQTT protocl specification v3.Classio.netty.handler.codec.mqttNetty
MqttEncoderEncodes Mqtt messages into bytes following the protocl specification v3.Classio.netty.handler.codec.mqttNetty
MqttFixedHeaderMQTTV3.Classio.netty.handler.codec.mqttNetty
MqttIdentifierRejectedExceptionA MqttIdentifierRejectedException which is thrown when a CONNECT request contains invalid client identifier.Classio.netty.handler.codec.mqttNetty
MqttMessageBase class for all MQTT message types.Classio.netty.handler.codec.mqttNetty
MqttMessageFactoryUtility class with factory methods to create different types of MQTT messages.Classio.netty.handler.codec.mqttNetty
MqttMessageIdVariableHeaderClassio.netty.handler.codec.mqttNetty
MqttMessageTypeenum MqttMessageTypeEnum Constant SummaryClassio.netty.handler.codec.mqttNetty
MqttPubAckMessageClassio.netty.handler.codec.mqttNetty
MqttPublishMessageSee MQTTV3.Classio.netty.handler.codec.mqttNetty
MqttPublishVariableHeaderClassio.netty.handler.codec.mqttNetty
MqttQoSClassio.netty.handler.codec.mqttNetty
MqttSubAckMessageClassio.netty.handler.codec.mqttNetty
MqttSubAckPayloadClassio.netty.handler.codec.mqttNetty
MqttSubscribeMessageClassio.netty.handler.codec.mqttNetty
MqttSubscribePayloadClassio.netty.handler.codec.mqttNetty
MqttTopicSubscriptionContains a topic name and Qos Level.Classio.netty.handler.codec.mqttNetty
MqttUnacceptableProtocolVersionExceptionA MqttUnacceptableProtocolVersionException which is thrown whena CONNECT request contains unacceptable protocol version.Classio.netty.handler.codec.mqttNetty
MqttUnsubAckMessageSee MQTTV3.Classio.netty.handler.codec.mqttNetty
MqttUnsubscribeMessageMQTTV3.Classio.netty.handler.codec.mqttNetty
MqttUnsubscribePayloadClassio.netty.handler.codec.mqttNetty
MqttVersionMqtt version specific constant values used by multiple classes in mqtt-codec.Classio.netty.handler.codec.mqttNetty
MultithreadEventExecutorGroupClassio.netty.util.concurrentNetty
MultithreadEventLoopGroupClassio.netty.channelNetty
NameResolverResolves an arbitrary string that represents the name of an endpoint into a SocketAddress.Interfaceio.netty.resolverNetty
NameResolverGroupCreates and manages NameResolvers so that each EventExecutor has its own resolver instance.Classio.netty.resolverNetty
NetUtilA class that holds a number of network-related constants.Classio.netty.utilNetty
NioDatagramChannelAn NIO datagram Channel that sends and receives anSee Also:AddressedEnvelope, Classio.netty.channel.socket.nioNetty
NioEventLoopA SingleThreadEventLoop implementation which registers each Channel with aNIO Selector and performs the multiplexing of these in the event loop.Classio.netty.channel.nioNetty
NioEventLoopGroupA MultithreadEventLoopGroup implementation which is used for NIO Selector based Channels.Classio.netty.channel.nioNetty
NioSctpChannelSctpChannel implementation which use non-blocking mode and allows to read /write SctpMessages to the underlying SctpChannel.Classio.netty.channel.sctp.nioNetty
NioSctpServerChannelSctpServerChannel implementation which use non-blocking mode to accept newconnections and create the NioSctpChannel for them.Classio.netty.channel.sctp.nioNetty
NioServerSocketChannelA ServerSocketChannel implementation which usesNIO selector based implementation to accept new connections.Classio.netty.channel.socket.nioNetty
NioSocketChannelSocketChannel which uses NIO selector based implementation.Classio.netty.channel.socket.nioNetty
NioTaskAn arbitrary task that can be executed by NioEventLoop when a SelectableChannel becomes ready.Interfaceio.netty.channel.nioNetty
NioUdtAcceptorChannelCommon base for Netty Byte/Message UDT Stream/Datagram acceptors.Classio.netty.channel.udt.nioNetty
NioUdtByteAcceptorChannelByte Channel Acceptor for UDT Streams.Classio.netty.channel.udt.nioNetty
NioUdtByteConnectorChannelByte Channel Connector for UDT Streams.Classio.netty.channel.udt.nioNetty
NioUdtByteRendezvousChannelByte Channel Rendezvous for UDT Streams.Classio.netty.channel.udt.nioNetty
NioUdtMessageAcceptorChannelMessage Channel Acceptor for UDT Datagrams.Classio.netty.channel.udt.nioNetty
NioUdtMessageConnectorChannelMessage Connector for UDT Datagrams.Classio.netty.channel.udt.nioNetty
NioUdtMessageRendezvousChannelMessage Rendezvous for UDT Datagrams.Classio.netty.channel.udt.nioNetty
NioUdtProviderUDT NIO components provider:Provides ChannelFactory for UDT channels.Classio.netty.channel.udt.nioNetty
NoopNameResolverA NameResolver that does not perform any resolution but always reports successful resolution.Classio.netty.resolverNetty
NoopNameResolverGroupA NameResolverGroup of NoopNameResolvers.Classio.netty.resolverNetty
NotSslRecordExceptionSpecial SSLException which will get thrown if a packet isreceived that not looks like a TLS/SSL record.Classio.netty.handler.sslNetty
ObjectDecoderA decoder which deserializes the received ByteBufs into JavaPlease note that the serialized form this decoder expects is notClassio.netty.handler.codec.serializationNetty
ObjectDecoderInputStreamAn ObjectInput which is interoperable with ObjectEncoderand ObjectEncoderOutputStream.Classio.netty.handler.codec.serializationNetty
ObjectEncoderAn encoder which serializes a Java object into a ByteBuf.Classio.netty.handler.codec.serializationNetty
ObjectEncoderOutputStreamAn ObjectOutput which is interoperable with ObjectDecoderand ObjectDecoderInputStream.Classio.netty.handler.codec.serializationNetty
OioByteStreamChannelAbstract base class for OIO Channels that are based on streams.Classio.netty.channel.oioNetty
OioDatagramChannelAn OIO datagram Channel that sends and receives anSee Also:AddressedEnvelope, Classio.netty.channel.socket.oioNetty
OioEventLoopGroupEventLoopGroup which is used to handle OIO Channel's.Classio.netty.channel.oioNetty
OioSctpChannelSctpChannel implementation which use blocking mode and allows to read / writeSctpMessages to the underlying SctpChannel.Classio.netty.channel.sctp.oioNetty
OioSctpServerChannelSctpServerChannel implementation which use blocking mode to accept newconnections and create the OioSctpChannel for them.Classio.netty.channel.sctp.oioNetty
OioServerSocketChannelServerSocketChannel which accepts new connections and create the OioSocketChannel's for them.Classio.netty.channel.socket.oioNetty
OioServerSocketChannelConfigA ServerSocketChannelConfig for a OioServerSocketChannel.Interfaceio.netty.channel.socket.oioNetty
OioSocketChannelClassio.netty.channel.socket.oioNetty
OioSocketChannelConfigA ChannelConfig for a OioSocketChannel.Interfaceio.netty.channel.socket.oioNetty
OpenSslClassio.netty.handler.sslNetty
OpenSslApplicationProtocolNegotiatorOpenSSL version of ApplicationProtocolNegotiator.Interfaceio.netty.handler.sslNetty
OpenSslClientContextA client-side SslContext which uses OpenSSL's SSL/TLS implementation.Classio.netty.handler.sslNetty
OpenSslContextClassio.netty.handler.sslNetty
OpenSslEngineOpenSSL BIO abstractions.Classio.netty.handler.sslNetty
OpenSslNpnApplicationProtocolNegotiatorOpenSSL ApplicationProtocolNegotiator for NPN.Classio.netty.handler.sslNetty
OpenSslServerContextA server-side SslContext which uses OpenSSL's SSL/TLS implementation.Classio.netty.handler.sslNetty
OpenSslServerSessionContextOpenSslSessionContext implementation which offers extra methods which are only useful for the server-side.Classio.netty.handler.sslNetty
OpenSslSessionContextOpenSSL specific SSLSessionContext implementation.Classio.netty.handler.sslNetty
OpenSslSessionStatsStats exposed by an OpenSSL session context.Classio.netty.handler.sslNetty
PausableEventExecutorInterfaceio.netty.util.concurrentNetty
PendingWriteQueueA queue of write operations which are pending for later execution.Classio.netty.channelNetty
PerMessageDeflateClientExtensionHandshakerhandshake implementation.Classio.netty.handler.codec.http.websocketx.extensions.compressionNetty
PerMessageDeflateServerExtensionHandshakerhandshake implementation.Classio.netty.handler.codec.http.websocketx.extensions.compressionNetty
PingWebSocketFrameClassio.netty.handler.codec.http.websocketxNetty
PongWebSocketFrameClassio.netty.handler.codec.http.websocketxNetty
PooledByteBufAllocatorClassio.netty.bufferNetty
PrematureChannelClosureExceptionA CodecException which is thrown when a Channel is closed unexpectedly beforethe codec finishes handling the current message, such as missing response while waiting for aClassio.netty.handler.codecNetty
PrimitiveCollectionsUtility methods for primitive collections.Classio.netty.util.collectionNetty
ProgressiveFutureA Future which is used to indicate the progress of an operation.Interfaceio.netty.util.concurrentNetty
ProgressivePromiseSpecial ProgressiveFuture which is writable.Interfaceio.netty.util.concurrentNetty
PromiseSpecial Future which is writable.Interfaceio.netty.util.concurrentNetty
PromiseAggregatorGenericFutureListener implementation which consolidates multiple Futuresinto one, by listening to individual Futures and producing an aggregated resultClassio.netty.util.concurrentNetty
PromiseNotifierGenericFutureListener implementation which takes other Futuresand notifies them on completion.Classio.netty.util.concurrentNetty
ProtobufDecoderDecodes a received ByteBuf into aGoogle Protocol BuffersClassio.netty.handler.codec.protobufNetty
ProtobufEncoderEncodes the requested GoogleProtocol Buffers Message and MessageLite into aClassio.netty.handler.codec.protobufNetty
ProtobufVarint32FrameDecoderA decoder that splits the received ByteBufs dynamically by thevalue of the Google Protocol BuffersClassio.netty.handler.codec.protobufNetty
ProtobufVarint32LengthFieldPrependerAn encoder that prepends the the Google Protocol Buffers128 Varints integer length field.Classio.netty.handler.codec.protobufNetty
ProxyConnectExceptionClassio.netty.handler.proxyNetty
ProxyConnectionEventClassio.netty.handler.proxyNetty
ProxyHandlerClassio.netty.handler.proxyNetty
QueryStringDecoderSplits an HTTP query string into a path string and key-value parameter pairs.Classio.netty.handler.codec.httpNetty
QueryStringEncoderCreates an URL-encoded URI from a path string and key-value parameter pairs.Classio.netty.handler.codec.httpNetty
ReadOnlyByteBufA derived buffer which forbids any write requests to its parent.Classio.netty.bufferNetty
ReadTimeoutExceptionA TimeoutException raised by ReadTimeoutHandler when no datawas read within a certain period of time.Classio.netty.handler.timeoutNetty
ReadTimeoutHandlerRaises a ReadTimeoutException when no data was read within a certain // The connection is closed when there is no inbound trafficClassio.netty.handler.timeoutNetty
RecvByteBufAllocatorAllocates a new receive buffer whose capacity is probably large enough to read all inbound data and small enoughnot to waste its space.Interfaceio.netty.channelNetty
RecyclerLight-weight object pool based on a thread-local stack.Classio.netty.utilNetty
ReferenceCountedA reference-counted object that requires explicit deallocation.Interfaceio.netty.utilNetty
ReferenceCountUtilCollection of method to handle objects that may implement ReferenceCounted.Classio.netty.utilNetty
ReflectiveChannelFactoryA ChannelFactory that instantiates a new Channel by invoking its default constructor reflectively.Classio.netty.channelNetty
ReplayingDecoderA specialized variation of ByteToMessageDecoder which enables implementationof a non-blocking decoder in the blocking I/O paradigm.Classio.netty.handler.codecNetty
ResourceLeakInterfaceio.netty.utilNetty
ResourceLeakDetectorClassio.netty.utilNetty
ResourceLeakHintA hint object that provides human-readable message for easier resource leak tracking.Interfaceio.netty.utilNetty
RtspHeaderNamesStandard RTSP header names.Classio.netty.handler.codec.rtspNetty
RtspHeaderValuesStandard RTSP header names.Classio.netty.handler.codec.rtspNetty
RtspMethodsThe request getMethod of RTSP.Classio.netty.handler.codec.rtspNetty
RtspObjectDecoderDecodes ByteBufs into RTSP messages represented inParameters that prevents excessive memory consumptionClassio.netty.handler.codec.rtspNetty
RtspObjectEncoderClassio.netty.handler.codec.rtspNetty
RtspRequestDecoderDecodes ByteBufs into RTSP requests represented inParameters that prevents excessive memory consumptionClassio.netty.handler.codec.rtspNetty
RtspRequestEncoderClassio.netty.handler.codec.rtspNetty
RtspResponseDecoderDecodes ByteBufs into RTSP responses represented inParameters that prevents excessive memory consumptionClassio.netty.handler.codec.rtspNetty
RtspResponseEncoderClassio.netty.handler.codec.rtspNetty
RtspResponseStatusesThe getStatus code and its description of a RTSP response.Classio.netty.handler.codec.rtspNetty
RtspVersionsThe version of RTSP.Classio.netty.handler.codec.rtspNetty
RuleBasedIpFilterThis class allows one to filter new Channels based on theIpFilterRules passed to its constructor.Classio.netty.handler.ipfilterNetty
RxtxChannelA channel to a serial device using the RXTX library.Classio.netty.channel.rxtxNetty
RxtxChannelConfigA configuration class for RXTX device connections.Interfaceio.netty.channel.rxtxNetty
RxtxChannelOptionClassio.netty.channel.rxtxNetty
RxtxDeviceAddressA SocketAddress subclass to wrap the serial port address of a RXTXdevice (e.Classio.netty.channel.rxtxNetty
ScheduledFutureThe result of an scheduled asynchronous operation.Interfaceio.netty.util.concurrentNetty
SctpChannelA SCTP/IP Channel interface for single SCTP association.Interfaceio.netty.channel.sctpNetty
SctpChannelConfigA ChannelConfig for a SctpChannel.Interfaceio.netty.channel.sctpNetty
SctpChannelOptionClassio.netty.channel.sctpNetty
SctpInboundByteStreamHandlerA ChannelHandler which receives SctpMessages which belong to a application protocol form a specificSCTP Stream and decode it as ByteBuf.Classio.netty.handler.codec.sctpNetty
SctpMessageClassio.netty.channel.sctpNetty
SctpMessageCompletionHandlerMessageToMessageDecoder which will take care of handle fragmented SctpMessages, soonly complete SctpMessages will be forwarded to the nextClassio.netty.handler.codec.sctpNetty
SctpMessageToMessageDecoderClassio.netty.handler.codec.sctpNetty
SctpNotificationHandlerAbstractNotificationHandler implementation which will handle all Notifications by trigger aNotification user event in the ChannelPipeline of a SctpChannel.Classio.netty.channel.sctpNetty
SctpOutboundByteStreamHandlerA ChannelHandler which transform ByteBuf to SctpMessage and send it through a specific streamwith given protocol identifier.Classio.netty.handler.codec.sctpNetty
SctpServerChannelA SCTP/IP ServerChannel which accepts incoming SCTP/IP associations.Interfaceio.netty.channel.sctpNetty
SctpServerChannelConfigA ChannelConfig for a SctpServerChannelConfig.Interfaceio.netty.channel.sctpNetty
SelfSignedCertificateGenerates a temporary self-signed certificate for testing purposes.Classio.netty.handler.ssl.utilNetty
ServerBootstrapClassio.netty.bootstrapNetty
ServerChannelA Channel that accepts an incoming connection attempt and createsits child Channels by accepting them.Interfaceio.netty.channelNetty
ServerCookieDecoderA RFC6265 compliant cookie decoder to be used server side.Classio.netty.handler.codec.httpNetty
ServerCookieEncoderA RFC6265 compliant cookie encoder to be used server side,so some fields are sent (Version is typically ignored).Classio.netty.handler.codec.httpNetty
ServerDomainSocketChannelInterfaceio.netty.channel.unixNetty
ServerSocketChannelA TCP/IP ServerChannel which accepts incoming TCP/IP connections.Interfaceio.netty.channel.socketNetty
ServerSocketChannelConfigA ChannelConfig for a ServerSocketChannel.Interfaceio.netty.channel.socketNetty
SignalA special Error which is used to signal some state or request by throwing it.Classio.netty.utilNetty
SimpleChannelInboundHandlerChannelHandler which allows to explicit only handle a specific type of messages.Classio.netty.channelNetty
SimpleNameResolverA skeletal NameResolver implementation.Classio.netty.resolverNetty
SimpleTrustManagerFactoryHelps to implement a custom TrustManagerFactory.Classio.netty.handler.ssl.utilNetty
SingleThreadEventExecutorAbstract base class for EventExecutor's that execute all its submitted tasks in a single thread.Classio.netty.util.concurrentNetty
SingleThreadEventLoopAbstract base class for EventLoops that execute all its submitted tasks in a single thread.Classio.netty.channelNetty
SlicedByteBufA derived buffer which exposes its parent's sub-region only.Classio.netty.bufferNetty
SnappyFrameDecoderUncompresses a ByteBuf encoded with the Snappy framing format.Classio.netty.handler.codec.compressionNetty
SnappyFrameEncoderCompresses a ByteBuf using the Snappy framing format.Classio.netty.handler.codec.compressionNetty
SniHandler(Server Name Indication) extension for server side SSL.Classio.netty.handler.sslNetty
SocketChannelA TCP/IP socket Channel.Interfaceio.netty.channel.socketNetty
SocketChannelConfigA ChannelConfig for a SocketChannel.Interfaceio.netty.channel.socketNetty
Socks4ClientDecoderDecodes a single Socks4CommandResponse from the inbound ByteBufs.Classio.netty.handler.codec.socksx.v4Netty
Socks4ClientEncoderEncodes a Socks4CommandRequest into a ByteBuf.Classio.netty.handler.codec.socksx.v4Netty
Socks4CommandRequestA SOCKS4a CONNECT or BIND request.Interfaceio.netty.handler.codec.socksx.v4Netty
Socks4CommandResponseInterfaceio.netty.handler.codec.socksx.v4Netty
Socks4CommandStatusThe status of Socks4CommandResponse.Classio.netty.handler.codec.socksx.v4Netty
Socks4CommandTypeThe type of Socks4CommandRequest.Classio.netty.handler.codec.socksx.v4Netty
Socks4MessageA tag interface that all SOCKS4a protocol messages implement.Interfaceio.netty.handler.codec.socksx.v4Netty
Socks4ProxyHandlerClassio.netty.handler.proxyNetty
Socks4ServerDecoderDecodes a single Socks4CommandRequest from the inbound ByteBufs.Classio.netty.handler.codec.socksx.v4Netty
Socks4ServerEncoderEncodes a Socks4CommandResponse into a ByteBuf.Classio.netty.handler.codec.socksx.v4Netty
Socks5AddressDecoderDecodes a SOCKS5 address field into its string representation.Interfaceio.netty.handler.codec.socksx.v5Netty
Socks5AddressEncoderEncodes a SOCKS5 address into binary representation.Interfaceio.netty.handler.codec.socksx.v5Netty
Socks5AddressTypeThe type of address in Socks5CommandRequest and Socks5CommandResponse.Classio.netty.handler.codec.socksx.v5Netty
Socks5AuthMethodThe authentication method of SOCKS5.Classio.netty.handler.codec.socksx.v5Netty
Socks5ClientEncoderEncodes a client-side Socks5Message into a ByteBuf.Classio.netty.handler.codec.socksx.v5Netty
Socks5CommandRequestA SOCKS5 request detail message, as defined inthe section 4, RFC1928.Interfaceio.netty.handler.codec.socksx.v5Netty
Socks5CommandRequestDecoderDecodes a single Socks5CommandRequest from the inbound ByteBufs.Classio.netty.handler.codec.socksx.v5Netty
Socks5CommandResponseA response to a SOCKS5 request detail message, as defined inthe section 6, RFC1928.Interfaceio.netty.handler.codec.socksx.v5Netty
Socks5CommandResponseDecoderDecodes a single Socks5CommandResponse from the inbound ByteBufs.Classio.netty.handler.codec.socksx.v5Netty
Socks5CommandStatusThe status of Socks5CommandResponse.Classio.netty.handler.codec.socksx.v5Netty
Socks5CommandTypeThe type of Socks5CommandRequest.Classio.netty.handler.codec.socksx.v5Netty
Socks5InitialRequestAn initial SOCKS5 authentication method selection request, as defined inthe section 3, RFC1928.Interfaceio.netty.handler.codec.socksx.v5Netty
Socks5InitialRequestDecoderDecodes a single Socks5InitialRequest from the inbound ByteBufs.Classio.netty.handler.codec.socksx.v5Netty
Socks5InitialResponseAn initial SOCKS5 authentication method selection request, as defined inthe section 3, RFC1928.Interfaceio.netty.handler.codec.socksx.v5Netty
Socks5InitialResponseDecoderDecodes a single Socks5InitialResponse from the inbound ByteBufs.Classio.netty.handler.codec.socksx.v5Netty
Socks5MessageA tag interface that all SOCKS5 protocol messages implement.Interfaceio.netty.handler.codec.socksx.v5Netty
Socks5PasswordAuthRequestA SOCKS5 subnegotiation request for username-password authentication, as defined inthe section 2, RFC1929.Interfaceio.netty.handler.codec.socksx.v5Netty
Socks5PasswordAuthRequestDecoderDecodes a single Socks5PasswordAuthRequest from the inbound ByteBufs.Classio.netty.handler.codec.socksx.v5Netty
Socks5PasswordAuthResponseA SOCKS5 subnegotiation response for username-password authentication, as defined inthe section 2, RFC1929.Interfaceio.netty.handler.codec.socksx.v5Netty
Socks5PasswordAuthResponseDecoderDecodes a single Socks5PasswordAuthResponse from the inbound ByteBufs.Classio.netty.handler.codec.socksx.v5Netty
Socks5PasswordAuthStatusThe status of Socks5PasswordAuthResponse.Classio.netty.handler.codec.socksx.v5Netty
Socks5ProxyHandlerClassio.netty.handler.proxyNetty
Socks5ServerEncoderEncodes a server-side Socks5Message into a ByteBuf.Classio.netty.handler.codec.socksx.v5Netty
SocksMessageAn interface that all SOCKS protocol messages implement.Interfaceio.netty.handler.codec.socksxNetty
SocksPortUnificationServerHandlerDetects the version of the current SOCKS connection and initializes the pipeline withSocks4ServerDecoder or Socks5InitialRequestDecoder.Classio.netty.handler.codec.socksxNetty
SocksVersionThe version of SOCKS protocol.Classio.netty.handler.codec.socksxNetty
SpdyDataFrameInterfaceio.netty.handler.codec.spdyNetty
SpdyFrameCodecA ChannelHandler that encodes and decodes SPDY Frames.Classio.netty.handler.codec.spdyNetty
SpdyFrameDecoderDecodes ByteBufs into SPDY Frames.Classio.netty.handler.codec.spdyNetty
SpdyFrameDecoderDelegateCallback interface for SpdyFrameDecoder.Interfaceio.netty.handler.codec.spdyNetty
SpdyFrameEncoderEncodes a SPDY Frame into a ByteBuf.Classio.netty.handler.codec.spdyNetty
SpdyGoAwayFrameInterfaceio.netty.handler.codec.spdyNetty
SpdyHeaderBlockRawDecoderClassio.netty.handler.codec.spdyNetty
SpdyHeaderBlockRawEncoderClassio.netty.handler.codec.spdyNetty
SpdyHeadersProvides the constants for the standard SPDY HTTP header names and commonlyused utility methods that access a SpdyHeadersFrame.Interfaceio.netty.handler.codec.spdyNetty
SpdyHeadersFrameInterfaceio.netty.handler.codec.spdyNetty
SpdyHttpCodecClassio.netty.handler.codec.spdyNetty
SpdyHttpDecoderDecodes SpdySynStreamFrames, SpdySynReplyFrames,and SpdyDataFrames into FullHttpRequests and FullHttpResponses.Classio.netty.handler.codec.spdyNetty
SpdyHttpEncoderEncodes HttpRequests, HttpResponses, and HttpContentsinto SpdySynStreamFrames and SpdySynReplyFrames.Classio.netty.handler.codec.spdyNetty
SpdyHttpHeadersProvides the constants for the header names used by the SpdyHttpDecoder and SpdyHttpEncoder.Classio.netty.handler.codec.spdyNetty
SpdyHttpResponseStreamIdHandlerMessageToMessageCodec that takes care of adding the right SpdyHttpHeaders.Classio.netty.handler.codec.spdyNetty
SpdyOrHttpChooserChannelHandler which is responsible to setup the ChannelPipeline either for HTTP or SPDY.Classio.netty.handler.codec.spdyNetty
SpdyPingFrameInterfaceio.netty.handler.codec.spdyNetty
SpdyProtocolExceptionClassio.netty.handler.codec.spdyNetty
SpdyRstStreamFrameInterfaceio.netty.handler.codec.spdyNetty
SpdySessionHandlerManages streams within a SPDY session.Classio.netty.handler.codec.spdyNetty
SpdySessionStatusThe SPDY session status code and its description.Classio.netty.handler.codec.spdyNetty
SpdySettingsFrameInterfaceio.netty.handler.codec.spdyNetty
SpdyStreamFrameInterfaceio.netty.handler.codec.spdyNetty
SpdyStreamStatusThe SPDY stream status code and its description.Classio.netty.handler.codec.spdyNetty
SpdySynReplyFrameInterfaceio.netty.handler.codec.spdyNetty
SpdySynStreamFrameInterfaceio.netty.handler.codec.spdyNetty
SpdyVersionClassio.netty.handler.codec.spdyNetty
SpdyWindowUpdateFrameInterfaceio.netty.handler.codec.spdyNetty
SslContextA secure socket protocol implementation which acts as a factory for SSLEngine and SslHandler.Classio.netty.handler.sslNetty
SslHandlerClassio.netty.handler.sslNetty
SslHandshakeCompletionEventClassio.netty.handler.sslNetty
SslProviderAn enumeration of SSL/TLS protocol providers.Classio.netty.handler.sslNetty
StompCommandClassio.netty.handler.codec.stompNetty
StompContentSubframeAn STOMP chunk which is used for STOMP chunked transfer-encoding.Interfaceio.netty.handler.codec.stompNetty
StompFrameCombines StompHeadersSubframe and LastStompContentSubframe into oneframe.Interfaceio.netty.handler.codec.stompNetty
StompHeadersThe multimap data structure for the STOMP header names and values.Interfaceio.netty.handler.codec.stompNetty
StompHeadersSubframeAn interface that defines a StompFrame's command and headers.Interfaceio.netty.handler.codec.stompNetty
StompSubframeDefines a common interface for all StompSubframe implementations.Interfaceio.netty.handler.codec.stompNetty
StompSubframeAggregatorA ChannelHandler that aggregates an StompHeadersSubframeand its following StompContentSubframes into a single StompFrame.Classio.netty.handler.codec.stompNetty
StompSubframeDecoderDecodes ByteBufs into StompHeadersSubframes andStompContentSubframes.Classio.netty.handler.codec.stompNetty
StompSubframeEncoderEncodes a StompFrame or a StompSubframe into a ByteBuf.Classio.netty.handler.codec.stompNetty
StringDecoderDecodes a received ByteBuf into a String.Classio.netty.handler.codec.stringNetty
StringEncoderEncodes the requested String into a ByteBuf.Classio.netty.handler.codec.stringNetty
SucceededFutureThe CompleteFuture which is succeeded already.Classio.netty.util.concurrentNetty
SupportedCipherSuiteFilterThis class will filter all requested ciphers out that are not supported by the current SSLEngine.Classio.netty.handler.sslNetty
SwappedByteBufWrapper which swap the ByteOrder of a ByteBuf.Classio.netty.bufferNetty
TextHeadersA typical string multimap used by text protocols such as HTTP for the representation of arbitrary key-value data.Interfaceio.netty.handler.codecNetty
TextWebSocketFrameClassio.netty.handler.codec.http.websocketxNetty
ThreadDeathWatcherChecks if a thread is alive periodically and runs a task when a thread dies.Classio.netty.utilNetty
ThreadLocalMarshallerProviderUnmarshallerProvider implementation which use a ThreadLocal to store referencesto Marshaller instances.Classio.netty.handler.codec.marshallingNetty
ThreadLocalUnmarshallerProviderUnmarshallerProvider implementation which use a ThreadLocal to store referencesto Unmarshaller instances.Classio.netty.handler.codec.marshallingNetty
ThreadPerChannelEventLoopSingleThreadEventLoop which is used to handle OIO Channel's.Classio.netty.channelNetty
ThreadPerChannelEventLoopGroupAn EventLoopGroup that creates one EventLoop per Channel.Classio.netty.channelNetty
ThreadPerTaskExecutorClassio.netty.util.concurrentNetty
TimeoutInterfaceio.netty.utilNetty
TimeoutExceptionA TimeoutException when no data was either read or written within acertain period of time.Classio.netty.handler.timeoutNetty
TimerInterfaceio.netty.utilNetty
TimerTaskA task which is executed after the delay specified withTimer.Interfaceio.netty.utilNetty
TooLongFrameExceptionAn DecoderException which is thrown when the length of the framedecoded is greater than the allowed maximum.Classio.netty.handler.codecNetty
TrafficCounterTrafficCounter is associated with AbstractTrafficShapingHandler.Classio.netty.handler.trafficNetty
UdtChannelSupported UDT UdtChannel are available via NioUdtProvider.Interfaceio.netty.channel.udtNetty
UdtChannelConfigA ChannelConfig for a UdtChannel.Interfaceio.netty.channel.udtNetty
UdtChannelOptionClassio.netty.channel.udtNetty
UdtMessageThe message container that is used for TypeUDT.Classio.netty.channel.udtNetty
UdtServerChannelSupported UDT UdtServerChannel are available via NioUdtProvider.Interfaceio.netty.channel.udtNetty
UdtServerChannelConfigA ChannelConfig for a UdtServerChannel.Interfaceio.netty.channel.udtNetty
UniqueIpFilterThis class allows one to ensure that at all times for every IP address there is at most oneChannel connected to the server.Classio.netty.handler.ipfilterNetty
UnixChannelChannel that expose operations that are only present on UNIX like systems.Interfaceio.netty.channel.unixNetty
UnmarshallerProviderInterfaceio.netty.handler.codec.marshallingNetty
UnpooledCreates a new ByteBuf by allocating new space or by wrappingor copying existing byte arrays, byte buffers and a string.Classio.netty.bufferNetty
UnpooledByteBufAllocatorSimplistic ByteBufAllocator implementation that does not pool anything.Classio.netty.bufferNetty
UnpooledDirectByteBufA NIO ByteBuffer based buffer.Classio.netty.bufferNetty
UnpooledHeapByteBufBig endian Java heap buffer implementation.Classio.netty.bufferNetty
UnpooledUnsafeDirectByteBufA NIO ByteBuffer based buffer.Classio.netty.bufferNetty
UnsupportedMessageTypeExceptionThrown if an unsupported message is received by an codec.Classio.netty.handler.codecNetty
Utf8FrameValidatorClassio.netty.handler.codec.http.websocketxNetty
VersionRetrieves the version information of available Netty artifacts.Classio.netty.utilNetty
WebSocket00FrameDecoderDecodes ByteBufs into WebSocketFrames.Classio.netty.handler.codec.http.websocketxNetty
WebSocket00FrameEncoderEncodes a WebSocketFrame into a ByteBuf.Classio.netty.handler.codec.http.websocketxNetty
WebSocket07FrameDecoderDecodes a web socket frame from wire protocol version 7 format.Classio.netty.handler.codec.http.websocketxNetty
WebSocket07FrameEncoderEncodes a web socket frame into wire protocol version 7 format.Classio.netty.handler.codec.http.websocketxNetty
WebSocket08FrameDecoderDecodes a web socket frame from wire protocol version 8 format.Classio.netty.handler.codec.http.websocketxNetty
WebSocket08FrameEncoderEncodes a web socket frame into wire protocol version 8 format.Classio.netty.handler.codec.http.websocketxNetty
WebSocket13FrameDecoderDecodes a web socket frame from wire protocol version 13 format.Classio.netty.handler.codec.http.websocketxNetty
WebSocket13FrameEncoderEncodes a web socket frame into wire protocol version 13 format.Classio.netty.handler.codec.http.websocketxNetty
WebSocketClientCompressionHandlerto handle the most common WebSocket Compression Extensions.Classio.netty.handler.codec.http.websocketx.extensions.compressionNetty
WebSocketClientExtensionCreated once the handshake phase is done.Interfaceio.netty.handler.codec.http.websocketx.extensionsNetty
WebSocketClientExtensionHandlerThis handler negotiates and initializes the WebSocket Extensions.Classio.netty.handler.codec.http.websocketx.extensionsNetty
WebSocketClientExtensionHandshakerHandshakes a client extension with the server.Interfaceio.netty.handler.codec.http.websocketx.extensionsNetty
WebSocketClientHandshakerClassio.netty.handler.codec.http.websocketxNetty
WebSocketClientHandshaker00Performs client side opening and closing handshakes for web socket specification version draft-ietf-hybi-thewebsocketprotocol-A very large portion of this code was taken from the Netty 3.Classio.netty.handler.codec.http.websocketxNetty
WebSocketClientHandshaker07Classio.netty.handler.codec.http.websocketxNetty
WebSocketClientHandshaker08Classio.netty.handler.codec.http.websocketxNetty
WebSocketClientHandshaker13Classio.netty.handler.codec.http.websocketxNetty
WebSocketClientHandshakerFactoryCreates a new WebSocketClientHandshaker of desired protocol version.Classio.netty.handler.codec.http.websocketxNetty
WebSocketClientProtocolHandlerThis handler does all the heavy lifting for you to run a websocket client.Classio.netty.handler.codec.http.websocketxNetty
WebSocketExtensionCreated once the handshake phase is done.Interfaceio.netty.handler.codec.http.websocketx.extensionsNetty
WebSocketExtensionDataA WebSocket Extension data from the Sec-WebSocket-Extensions header.Classio.netty.handler.codec.http.websocketx.extensionsNetty
WebSocketExtensionDecoderConvenient class for io.Classio.netty.handler.codec.http.websocketx.extensionsNetty
WebSocketExtensionEncoderConvenient class for io.Classio.netty.handler.codec.http.websocketx.extensionsNetty
WebSocketExtensionUtilClassio.netty.handler.codec.http.websocketx.extensionsNetty
WebSocketFrameClassio.netty.handler.codec.http.websocketxNetty
WebSocketFrameAggregatorHandler that aggregate fragmented WebSocketFrame's.Classio.netty.handler.codec.http.websocketxNetty
WebSocketFrameDecoderMarker interface which all WebSocketFrame decoders need to implement.Interfaceio.netty.handler.codec.http.websocketxNetty
WebSocketFrameEncoderMarker interface which all WebSocketFrame encoders need to implement.Interfaceio.netty.handler.codec.http.websocketxNetty
WebSocketHandshakeExceptionException during handshaking processSee Also:Serialized FormClassio.netty.handler.codec.http.websocketxNetty
WebSocketServerCompressionHandlerto handle the most common WebSocket Compression Extensions.Classio.netty.handler.codec.http.websocketx.extensions.compressionNetty
WebSocketServerExtensionCreated once the handshake phase is done.Interfaceio.netty.handler.codec.http.websocketx.extensionsNetty
WebSocketServerExtensionHandlerThis handler negotiates and initializes the WebSocket Extensions.Classio.netty.handler.codec.http.websocketx.extensionsNetty
WebSocketServerExtensionHandshakerHandshakes a client extension based on this server capabilities.Interfaceio.netty.handler.codec.http.websocketx.extensionsNetty
WebSocketServerHandshakerClassio.netty.handler.codec.http.websocketxNetty
WebSocketServerHandshaker00Performs server side opening and closing handshakes for web socket specification version draft-ietf-hybi-thewebsocketprotocol-A very large portion of this code was taken from the Netty 3.Classio.netty.handler.codec.http.websocketxNetty
WebSocketServerHandshaker07Classio.netty.handler.codec.http.websocketxNetty
WebSocketServerHandshaker08Classio.netty.handler.codec.http.websocketxNetty
WebSocketServerHandshaker13Performs server side opening and closing handshakes for RFC 6455(originally web socket specification draft-ietf-hybi-thewebsocketprotocol-17).Classio.netty.handler.codec.http.websocketxNetty
WebSocketServerHandshakerFactoryAuto-detects the version of the Web Socket protocol in use and creates a new properWebSocketServerHandshaker.Classio.netty.handler.codec.http.websocketxNetty
WebSocketServerProtocolHandlerThis handler does all the heavy lifting for you to run a websocket server.Classio.netty.handler.codec.http.websocketxNetty
WebSocketVersionenum WebSocketVersionVersions of the web socket specification.Classio.netty.handler.codec.http.websocketxNetty
WrappedByteBufClassio.netty.bufferNetty
WrappedEventExecutorA marker interface indicating that the EventExecutor is a wrapper aroundanother EventExecutor implementation.Interfaceio.netty.util.concurrentNetty
WriteTimeoutExceptionA TimeoutException raised by WriteTimeoutHandler when no datawas written within a certain period of time.Classio.netty.handler.timeoutNetty
WriteTimeoutHandlerRaises a WriteTimeoutException when no data was written within acertain period of time.Classio.netty.handler.timeoutNetty
XmlFrameDecoderA frame decoder for single separate XML based message streams.Classio.netty.handler.codec.xmlNetty
ZlibCodecFactoryCreates a new ZlibEncoder and a new ZlibDecoder.Classio.netty.handler.codec.compressionNetty
ZlibDecoderDecompresses a ByteBuf using the deflate algorithm.Classio.netty.handler.codec.compressionNetty
ZlibEncoderCompresses a ByteBuf using the deflate algorithm.Classio.netty.handler.codec.compressionNetty
ZlibWrapperThe container file formats that wrap the stream compressed by the DEFLATEEnum Constant SummaryClassio.netty.handler.codec.compressionNetty