Uses of Class
io.netty.channel.ChannelHandlerAdapter
Packages that use ChannelHandlerAdapter
Package
Description
The core channel API which is asynchronous and event-driven abstraction of
various transports such as a
NIO Channel.
Package to dynamically replace local / remote
SocketAddress.Extensible decoder and its common implementations which deal with the
packet fragmentation and reassembly issue found in a stream-based transport
such as TCP/IP.
Encoder and decoder which transform an array of bytes into a
ByteBuf and vice versa.DNS codec.
Decodes an HAProxy proxy protocol header
Encoder, decoder and their related message types for HTTP.
This package contains Cross Origin Resource Sharing (CORS) related classes.
Encoder, decoder, handshakers and their related message types for
Web Socket data frames.
Encoder, decoder, handshakers to handle
WebSocket Extensions.
Encoder, decoder, handshakers to handle most common WebSocket Compression Extensions.
Handlers for sending and receiving HTTP/2 frames.
HTTP/3 implementation.
JSON specific codecs.
Decoder and Encoder which uses JBoss Marshalling.
Common superset of ascii and binary classes.
Implementations and Interfaces for the Memcache Binary protocol.
Encoder, decoder and different Message Types for MQTT.
Encoder and decoder which transform a
Google Protocol Buffers
Message and MessageNano into a
ByteBuf and vice versa.QUIC implementation
Encoder, decoder for Redis.
An RTSP
extension based on the HTTP codec.
Decoder and encoders to manage message completion and multi-streaming codec in SCTP/IP.
Encoder, decoder and their compatibility stream implementations which
transform a
Serializable object into a byte buffer and
vice versa.SMTP codec.
Encoder, decoder and their related message types for Socks.
Encoder, decoder and their related message types for SOCKS protocol.
Encoder, decoder and their related message types for SOCKSv4 protocol.
Encoder, decoder and their related message types for SOCKSv5 protocol.
Encoder, decoder, session handler and their related message types for the SPDY protocol.
STOMP codec
XML codec provides asynchronous and non-blocking XML parser based on the
Aalto XML parser.
Package to control the flow of messages.
Package to control flush behavior.
Package to filter IP addresses (allow/deny).
Logs the I/O events for debugging purpose.
Capture data and write into Pcap format which helps in troubleshooting.
Adds support for client connections via proxy protocols such as
SOCKS and
HTTP CONNECT tunneling
Certificate validation using OCSP
Writes very large data stream asynchronously neither spending a lot of
memory nor getting
OutOfMemoryError.Adds support for read and write timeout and idle connection notification
using a
Timer.Implementation of a Traffic Shaping Handler and Dynamic Statistics.
-
Uses of ChannelHandlerAdapter in io.netty.channel
Subclasses of ChannelHandlerAdapter in io.netty.channelModifier and TypeClassDescriptionclassChannelHandlerimplementation which represents a combination out of aChannelInboundHandlerand theChannelOutboundHandler.classAbstract base class forChannelInboundHandlerimplementations which provide implementations of all of their methods.classChannelInitializer<C extends Channel>A specialChannelInboundHandlerwhich offers an easy way to initialize aChannelonce it was registered to itsEventLoop.classSkeleton implementation of aChannelOutboundHandler.classCombinedChannelDuplexHandler<I extends ChannelInboundHandler, O extends ChannelOutboundHandler>classChannelInboundHandlerAdapterwhich allows to explicit only handle a specific type of messages.classChannelInboundHandlerAdapterwhich allows to conveniently only handle a specific type of user events. -
Uses of ChannelHandlerAdapter in io.netty.handler.address
Subclasses of ChannelHandlerAdapter in io.netty.handler.addressModifier and TypeClassDescriptionclassChannelOutboundHandlerimplementation which allows to dynamically replace the usedremoteAddressand / orlocalAddresswhen making a connection attempt.classChannelOutboundHandlerAdapterwhich will resolve theSocketAddressthat is passed toResolveAddressHandler.connect(ChannelHandlerContext, SocketAddress, SocketAddress, ChannelPromise)if it is not already resolved and theAddressResolversupports the type ofSocketAddress. -
Uses of ChannelHandlerAdapter in io.netty.handler.codec
Subclasses of ChannelHandlerAdapter in io.netty.handler.codecModifier and TypeClassDescriptionclassA Codec for on-the-fly encoding/decoding of bytes to messages and vise-versa.classChannelInboundHandlerAdapterwhich decodes bytes in a stream-like fashion from oneByteBufto another Message type.classA decoder that decodes the content of the receivedDatagramPacketusing the specifiedByteBufdecoder.classAn encoder that encodes the content inAddressedEnvelopetoDatagramPacketusing the specified message encoder.classA decoder that splits the receivedByteBufs by one or more delimiters.classA decoder that splits the receivedByteBufs by the fixed number of bytes.classA decoder that splits the receivedByteBufs dynamically by the value of the length field in the message.classAn encoder that prepends the length of the message.classA decoder that splits the receivedByteBufs on line endings.classMessageAggregator<I, S, C extends ByteBufHolder, O extends ByteBufHolder>An abstractChannelHandlerthat aggregates a series of message objects into a single aggregated message.classChannelOutboundHandlerAdapterwhich encodes message in a stream-like fashion from one message to anByteBuf.classMessageToMessageCodec<INBOUND_IN, OUTBOUND_IN>A Codec for on-the-fly encoding/decoding of message.classChannelInboundHandlerAdapterwhich decodes from one message to an other message.classChannelOutboundHandlerAdapterwhich encodes from one message to an other message For example here is an implementation which decodes anIntegerto anString.classA specialized variation ofByteToMessageDecoderwhich enables implementation of a non-blocking decoder in the blocking I/O paradigm. -
Uses of ChannelHandlerAdapter in io.netty.handler.codec.base64
Subclasses of ChannelHandlerAdapter in io.netty.handler.codec.base64Modifier and TypeClassDescriptionclassclass -
Uses of ChannelHandlerAdapter in io.netty.handler.codec.bytes
Subclasses of ChannelHandlerAdapter in io.netty.handler.codec.bytes -
Uses of ChannelHandlerAdapter in io.netty.handler.codec.compression
Subclasses of ChannelHandlerAdapter in io.netty.handler.codec.compressionModifier and TypeClassDescriptionfinal classDecompresses aByteBufencoded with the brotli format.final classCompress aByteBufwith the Brotli compression.classUncompresses aByteBufencoded with the Bzip2 format.classCompresses aByteBufusing the Bzip2 algorithm.classUncompresses aByteBufencoded byFastLzFrameEncoderusing the FastLZ algorithm.classCompresses aByteBufusing the FastLZ algorithm.classDecompress aByteBufusing the inflate algorithm.classCompresses aByteBufusing the deflate algorithm.classclassCompresses aByteBufusing the deflate algorithm.classUncompresses aByteBufencoded with the LZ4 format.classCompresses aByteBufusing the LZ4 format.classUncompresses aByteBufencoded with the LZF format.classCompresses aByteBufusing the LZF format.classCompresses aByteBufusing the LZMA algorithm.classDeprecated.classUncompresses aByteBufencoded with the Snappy framing format.classDeprecated.UseSnappyFrameEncoderinstead.classCompresses aByteBufusing the Snappy framing format.classDecompresses aByteBufusing the deflate algorithm.classCompresses aByteBufusing the deflate algorithm.final classDecompresses a compressed blockByteBufusing the Zstandard algorithm.final classCompresses aByteBufusing the Zstandard algorithm. -
Uses of ChannelHandlerAdapter in io.netty.handler.codec.dns
Subclasses of ChannelHandlerAdapter in io.netty.handler.codec.dnsModifier and TypeClassDescriptionclassDecodes aDatagramPacketinto aDatagramDnsQuery.classclassDecodes aDatagramPacketinto aDatagramDnsResponse.classfinal classfinal classfinal classfinal class -
Uses of ChannelHandlerAdapter in io.netty.handler.codec.haproxy
Subclasses of ChannelHandlerAdapter in io.netty.handler.codec.haproxyModifier and TypeClassDescriptionclassDecodes an HAProxy proxy protocol headerfinal classEncodes an HAProxy proxy protocol message -
Uses of ChannelHandlerAdapter in io.netty.handler.codec.http
Subclasses of ChannelHandlerAdapter in io.netty.handler.codec.httpModifier and TypeClassDescriptionfinal classA combination ofHttpRequestEncoderandHttpResponseDecoderwhich enables easier client side HTTP implementation.classClient-side handler for handling an HTTP upgrade handshake to another protocol.classCompresses anHttpMessageand anHttpContentingzipordeflateencoding while respecting the"Accept-Encoding"header.classDecodes the content of the receivedHttpRequestandHttpContent.classclassEncodes the content of the outboundHttpResponseandHttpContent.classAChannelHandlerthat aggregates anHttpMessageand its followingHttpContents into a singleFullHttpRequestorFullHttpResponse(depending on if it used to handle requests or responses) with no followingHttpContents.classclassHttpObjectEncoder<H extends HttpMessage>classclassclassclassfinal classA combination ofHttpRequestDecoderandHttpResponseEncoderwhich enables easier server side HTTP implementation.classclassHttpServerKeepAliveHandler helps close persistent connections when appropriate.classA server-side handler that receives HTTP requests and optionally performs a protocol switch if the requested protocol is supported. -
Uses of ChannelHandlerAdapter in io.netty.handler.codec.http.cors
Subclasses of ChannelHandlerAdapter in io.netty.handler.codec.http.cors -
Uses of ChannelHandlerAdapter in io.netty.handler.codec.http.websocketx
Subclasses of ChannelHandlerAdapter in io.netty.handler.codec.http.websocketxModifier and TypeClassDescriptionclassclassDecodesByteBufs intoWebSocketFrames.classEncodes aWebSocketFrameinto aByteBuf.classDecodes a web socket frame from wire protocol version 7 format.classEncodes a web socket frame into wire protocol version 7 format.classDecodes a web socket frame from wire protocol version 8 format.classEncodes a web socket frame into wire protocol version 8 format.classDecodes a web socket frame from wire protocol version 13 format.classEncodes a web socket frame into wire protocol version 13 format.classThis handler does all the heavy lifting for you to run a websocket client.classHandler that aggregate fragmented WebSocketFrame's.classThis handler does all the heavy lifting for you to run a websocket server. -
Uses of ChannelHandlerAdapter in io.netty.handler.codec.http.websocketx.extensions
Subclasses of ChannelHandlerAdapter in io.netty.handler.codec.http.websocketx.extensionsModifier and TypeClassDescriptionclassThis handler negotiates and initializes the WebSocket Extensions.classConvenient class for io.netty.handler.codec.http.websocketx.extensions.WebSocketExtension decoder.classConvenient class for io.netty.handler.codec.http.websocketx.extensions.WebSocketExtension encoder.classThis handler negotiates and initializes the WebSocket Extensions. -
Uses of ChannelHandlerAdapter in io.netty.handler.codec.http.websocketx.extensions.compression
Subclasses of ChannelHandlerAdapter in io.netty.handler.codec.http.websocketx.extensions.compressionModifier and TypeClassDescriptionfinal classExtends io.netty.handler.codec.http.websocketx.extensions.compression.WebSocketClientExtensionHandler to handle the most common WebSocket Compression Extensions.classExtends io.netty.handler.codec.http.websocketx.extensions.compression.WebSocketServerExtensionHandler to handle the most common WebSocket Compression Extensions. -
Uses of ChannelHandlerAdapter in io.netty.handler.codec.http2
Subclasses of ChannelHandlerAdapter in io.netty.handler.codec.http2Modifier and TypeClassDescriptionfinal classPerforming cleartext upgrade, by h2c HTTP upgrade or Prior Knowledge.classAChannelDuplexHandlerproviding additional functionality for HTTP/2.classProvides the default implementation for processing inbound frame events and delegates to aHttp2FrameListenerclassAn HTTP/2 handler that maps HTTP/2 frames toHttp2Frameobjects and vice versa.classLogs HTTP2 frames for debugging purposes.classDeprecated.useHttp2FrameCodecBuildertogether withHttp2MultiplexHandler.final classAn HTTP/2 handler that creates child channels for each stream.classThis handler converts fromHttp2StreamFrametoHttpObject, and back.classTranslates HTTP/1.x object writes into HTTP/2 frames.classTranslates HTTP/1.x object reads into HTTP/2 frames. -
Uses of ChannelHandlerAdapter in io.netty.handler.codec.http3
Subclasses of ChannelHandlerAdapter in io.netty.handler.codec.http3Modifier and TypeClassDescriptionfinal classclassHandler that handles HTTP3 connections.final classThis handler converts fromHttp3RequestStreamFrametoHttpObject, and back.classAbstract base class that users can extend to init HTTP/3 push-streams for clients.classAbstract base class that users can extend to init HTTP/3 push-streams for servers.classChannelInboundHandlerAdapterwhich makes it easy to handle HTTP3 request streams.classAbstract base class that users can extend to init HTTP/3 request-streams.final classHandler that handles HTTP3 for the server-side. -
Uses of ChannelHandlerAdapter in io.netty.handler.codec.json
Subclasses of ChannelHandlerAdapter in io.netty.handler.codec.jsonModifier and TypeClassDescriptionclassSplits a byte stream of JSON objects and arrays into individual objects/arrays and passes them up theChannelPipeline. -
Uses of ChannelHandlerAdapter in io.netty.handler.codec.marshalling
Subclasses of ChannelHandlerAdapter in io.netty.handler.codec.marshallingModifier and TypeClassDescriptionclassclassMessageToByteEncoderimplementation which uses JBoss Marshalling to marshal an Object.classDecoder which MUST be used withMarshallingEncoder.classMessageToByteEncoderimplementation which uses JBoss Marshalling to marshal an Object. -
Uses of ChannelHandlerAdapter in io.netty.handler.codec.memcache
Subclasses of ChannelHandlerAdapter in io.netty.handler.codec.memcacheModifier and TypeClassDescriptionclassAbstractMemcacheObjectAggregator<H extends MemcacheMessage>AChannelHandlerthat aggregates anMemcacheMessageand its followingMemcacheContents into a singleMemcacheMessagewith no followingMemcacheContents.classAbstract super class for both ascii and binary decoders.classAbstractMemcacheObjectEncoder<M extends MemcacheMessage>A general purposeAbstractMemcacheObjectEncoderthat encodesMemcacheMessages. -
Uses of ChannelHandlerAdapter in io.netty.handler.codec.memcache.binary
Subclasses of ChannelHandlerAdapter in io.netty.handler.codec.memcache.binaryModifier and TypeClassDescriptionclassDecoder for bothBinaryMemcacheRequestandBinaryMemcacheResponse.classAMessageToByteEncoderthat encodes binary memcache messages into bytes.final classThe client codec that combines the proper encoder and decoder.classAn object aggregator for the memcache binary protocol.classThe decoder part which takes care of decoding the request-specific headers.classThe encoder part which takes care of encoding the request headers.classThe decoder which takes care of decoding the response headers.classThe encoder which takes care of encoding the response headers.classThe full server codec that combines the correct encoder and decoder. -
Uses of ChannelHandlerAdapter in io.netty.handler.codec.mqtt
Subclasses of ChannelHandlerAdapter in io.netty.handler.codec.mqttModifier and TypeClassDescriptionfinal classfinal class -
Uses of ChannelHandlerAdapter in io.netty.handler.codec.protobuf
Subclasses of ChannelHandlerAdapter in io.netty.handler.codec.protobufModifier and TypeClassDescriptionclassclassclassclassclassA decoder that splits the receivedByteBufs dynamically by the value of the Google Protocol Buffers Base 128 Varints integer length field in the message.classAn encoder that prepends the Google Protocol Buffers Base 128 Varints integer length field. -
Uses of ChannelHandlerAdapter in io.netty.handler.codec.quic
Subclasses of ChannelHandlerAdapter in io.netty.handler.codec.quicModifier and TypeClassDescriptionclassSpecialChannelHandlerthat should be used to initChannels that will be used for QUIC while SO_REUSEPORT is used to bind to sameInetSocketAddressmultiple times. -
Uses of ChannelHandlerAdapter in io.netty.handler.codec.redis
Subclasses of ChannelHandlerAdapter in io.netty.handler.codec.redisModifier and TypeClassDescriptionfinal classAggregatesRedisMessageparts intoArrayRedisMessage.final classAChannelHandlerthat aggregates anBulkStringHeaderRedisMessageand its followingBulkStringRedisContents into a singleFullBulkStringRedisMessagewith no followingBulkStringRedisContents.final classDecodes the Redis protocol intoRedisMessageobjects following RESP (REdis Serialization Protocol).classEncodesRedisMessageinto bytes following RESP (REdis Serialization Protocol). -
Uses of ChannelHandlerAdapter in io.netty.handler.codec.rtsp
Subclasses of ChannelHandlerAdapter in io.netty.handler.codec.rtspModifier and TypeClassDescriptionclassDecodesByteBufs into RTSP messages represented inHttpMessages.classclassDeprecated.UseRtspDecoderinstead.classRtspObjectEncoder<H extends HttpMessage>Deprecated.UseRtspEncoderinstead.classDeprecated.UseRtspDecoderdirectly insteadclassDeprecated.UseRtspEncoderdirectly insteadclassDeprecated.UseRtspDecoderdirectly insteadclassDeprecated.UseRtspEncoderdirectly instead -
Uses of ChannelHandlerAdapter in io.netty.handler.codec.sctp
Subclasses of ChannelHandlerAdapter in io.netty.handler.codec.sctpModifier and TypeClassDescriptionclassA ChannelHandler which receivesSctpMessages which belong to a application protocol form a specific SCTP Stream and decode it asByteBuf.classMessageToMessageDecoderwhich will take care of handle fragmentedSctpMessages, so only completeSctpMessages will be forwarded to the nextChannelInboundHandler.classclassA ChannelHandler which transformByteBuftoSctpMessageand send it through a specific stream with given protocol identifier. -
Uses of ChannelHandlerAdapter in io.netty.handler.codec.serialization
Subclasses of ChannelHandlerAdapter in io.netty.handler.codec.serializationModifier and TypeClassDescriptionclassDeprecated.This class has been deprecated with no replacement, because serialization can be a security liabilityclassDeprecated.This class has been deprecated with no replacement, because serialization can be a security liabilityclassDeprecated.This class has been deprecated with no replacement, because serialization can be a security liability -
Uses of ChannelHandlerAdapter in io.netty.handler.codec.smtp
Subclasses of ChannelHandlerAdapter in io.netty.handler.codec.smtpModifier and TypeClassDescriptionfinal classEncoder for SMTP requests.final classDecoder for SMTP responses. -
Uses of ChannelHandlerAdapter in io.netty.handler.codec.socks
Subclasses of ChannelHandlerAdapter in io.netty.handler.codec.socksModifier and TypeClassDescriptionclassDecodesByteBufs intoSocksAuthRequest.classDecodesByteBufs intoSocksAuthResponse.classDecodesByteBufs intoSocksCmdRequest.classDecodesByteBufs intoSocksCmdResponse.classDecodesByteBufs intoSocksInitRequest.classDecodesByteBufs intoSocksInitResponse.classEncodes anSocksMessageinto aByteBuf. -
Uses of ChannelHandlerAdapter in io.netty.handler.codec.socksx
Subclasses of ChannelHandlerAdapter in io.netty.handler.codec.socksxModifier and TypeClassDescriptionclassDetects the version of the current SOCKS connection and initializes the pipeline withSocks4ServerDecoderorSocks5InitialRequestDecoder. -
Uses of ChannelHandlerAdapter in io.netty.handler.codec.socksx.v4
Subclasses of ChannelHandlerAdapter in io.netty.handler.codec.socksx.v4Modifier and TypeClassDescriptionclassDecodes a singleSocks4CommandResponsefrom the inboundByteBufs.final classEncodes aSocks4CommandRequestinto aByteBuf.classDecodes a singleSocks4CommandRequestfrom the inboundByteBufs.final classEncodes aSocks4CommandResponseinto aByteBuf. -
Uses of ChannelHandlerAdapter in io.netty.handler.codec.socksx.v5
Subclasses of ChannelHandlerAdapter in io.netty.handler.codec.socksx.v5Modifier and TypeClassDescriptionclassEncodes a client-sideSocks5Messageinto aByteBuf.classDecodes a singleSocks5CommandRequestfrom the inboundByteBufs.classDecodes a singleSocks5CommandResponsefrom the inboundByteBufs.classDecodes a singleSocks5InitialRequestfrom the inboundByteBufs.classDecodes a singleSocks5InitialResponsefrom the inboundByteBufs.classDecodes a singleSocks5PasswordAuthRequestfrom the inboundByteBufs.classDecodes a singleSocks5PasswordAuthResponsefrom the inboundByteBufs.final classDecodes a singleSocks5PrivateAuthRequestfrom the inboundByteBufs.final classDecodes a singleSocks5PrivateAuthResponsefrom the inboundByteBufs.classEncodes a server-sideSocks5Messageinto aByteBuf. -
Uses of ChannelHandlerAdapter in io.netty.handler.codec.spdy
Subclasses of ChannelHandlerAdapter in io.netty.handler.codec.spdyModifier and TypeClassDescriptionclassAChannelHandlerthat encodes and decodes SPDY Frames.final classA combination ofSpdyHttpDecoderandSpdyHttpEncoderclassDecodesSpdySynStreamFrames,SpdySynReplyFrames, andSpdyDataFrames intoFullHttpRequests andFullHttpResponses.classEncodesHttpRequests,HttpResponses, andHttpContents intoSpdySynStreamFrames andSpdySynReplyFrames.classMessageToMessageCodecthat takes care of adding the rightSpdyHttpHeaders.Names.STREAM_IDto theHttpMessageif one is not present.classManages streams within a SPDY session. -
Uses of ChannelHandlerAdapter in io.netty.handler.codec.stomp
Subclasses of ChannelHandlerAdapter in io.netty.handler.codec.stompModifier and TypeClassDescriptionclassAChannelHandlerthat aggregates anStompHeadersSubframeand its followingStompContentSubframes into a singleStompFrame.classclass -
Uses of ChannelHandlerAdapter in io.netty.handler.codec.string
Subclasses of ChannelHandlerAdapter in io.netty.handler.codec.stringModifier and TypeClassDescriptionclassclassclass -
Uses of ChannelHandlerAdapter in io.netty.handler.codec.xml
Subclasses of ChannelHandlerAdapter in io.netty.handler.codec.xmlModifier and TypeClassDescriptionclassAsync XML decoder based on Aalto XML parser.classA frame decoder for single separate XML based message streams. -
Uses of ChannelHandlerAdapter in io.netty.handler.flow
Subclasses of ChannelHandlerAdapter in io.netty.handler.flowModifier and TypeClassDescriptionclassTheFlowControlHandlerensures that only one message perread()is sent downstream. -
Uses of ChannelHandlerAdapter in io.netty.handler.flush
Subclasses of ChannelHandlerAdapter in io.netty.handler.flushModifier and TypeClassDescriptionclassChannelDuplexHandlerwhich consolidatesChannel.flush()/ChannelHandlerContext.flush()operations (which also includesChannel.writeAndFlush(Object)/Channel.writeAndFlush(Object, ChannelPromise)andChannelOutboundInvoker.writeAndFlush(Object)/ChannelOutboundInvoker.writeAndFlush(Object, ChannelPromise)). -
Uses of ChannelHandlerAdapter in io.netty.handler.ipfilter
Subclasses of ChannelHandlerAdapter in io.netty.handler.ipfilterModifier and TypeClassDescriptionclassAbstractRemoteAddressFilter<T extends SocketAddress>This class provides the functionality to either accept or reject newChannels based on their IP address.classThis class allows one to filter newChannels based on theIpSubnetFilters passed to its constructor.classThis class allows one to filter newChannels based on theIpFilterRules passed to its constructor.classThis class allows one to ensure that at all times for every IP address there is at most oneChannelconnected to the server. -
Uses of ChannelHandlerAdapter in io.netty.handler.logging
Subclasses of ChannelHandlerAdapter in io.netty.handler.loggingModifier and TypeClassDescriptionclassAChannelHandlerthat logs all events using a logging framework. -
Uses of ChannelHandlerAdapter in io.netty.handler.pcap
Subclasses of ChannelHandlerAdapter in io.netty.handler.pcapModifier and TypeClassDescriptionfinal classPcapWriteHandlercapturesByteBuffromSocketChannel/ServerChannelorDatagramPacketand writes it into PcapOutputStream. -
Uses of ChannelHandlerAdapter in io.netty.handler.proxy
Subclasses of ChannelHandlerAdapter in io.netty.handler.proxyModifier and TypeClassDescriptionfinal classHandler that establishes a blind forwarding proxy tunnel using HTTP/1.1 CONNECT request.classA common abstraction for protocols that establish blind forwarding proxy tunnels.final classHandler that establishes a blind forwarding proxy tunnel using SOCKS4 protocol.final classHandler that establishes a blind forwarding proxy tunnel using SOCKS Protocol Version 5. -
Uses of ChannelHandlerAdapter in io.netty.handler.ssl
Subclasses of ChannelHandlerAdapter in io.netty.handler.sslModifier and TypeClassDescriptionclassEnables SNI (Server Name Indication) extension for server side SSL.classConfigures aChannelPipelinedepending on the application-level protocol negotiation result ofSslHandler.classOptionalSslHandleris a utility decoder to support both SSL and non-SSL handlers based on the first message received.classEnables SNI (Server Name Indication) extension for server side SSL.classByteToMessageDecoderwhich allows to be notified once a fullClientHellowas received.classclassTheSslMasterKeyHandleris a channel-handler you can include in your pipeline to consume the master key invalid input: '&' session identifier for a TLS session. -
Uses of ChannelHandlerAdapter in io.netty.handler.ssl.ocsp
Subclasses of ChannelHandlerAdapter in io.netty.handler.ssl.ocspModifier and TypeClassDescriptionclassA handler for SSL clients to handle and act upon stapled OCSP responses.classOcspServerCertificateValidatorvalidates incoming server's certificate using OCSP. -
Uses of ChannelHandlerAdapter in io.netty.handler.stream
Subclasses of ChannelHandlerAdapter in io.netty.handler.streamModifier and TypeClassDescriptionclassAChannelHandlerthat adds support for writing a large data stream asynchronously neither spending a lot of memory nor gettingOutOfMemoryError. -
Uses of ChannelHandlerAdapter in io.netty.handler.timeout
Subclasses of ChannelHandlerAdapter in io.netty.handler.timeoutModifier and TypeClassDescriptionclassTriggers anIdleStateEventwhen aChannelhas not performed read, write, or both operation for a while.classRaises aReadTimeoutExceptionwhen no data was read within a certain period of time.classRaises aWriteTimeoutExceptionwhen a write operation cannot finish in a certain period of time. -
Uses of ChannelHandlerAdapter in io.netty.handler.traffic
Subclasses of ChannelHandlerAdapter in io.netty.handler.trafficModifier and TypeClassDescriptionclassAbstractTrafficShapingHandler allows to limit the global bandwidth (seeGlobalTrafficShapingHandler) or per session bandwidth (seeChannelTrafficShapingHandler), as traffic shaping.classThis implementation of theAbstractTrafficShapingHandleris for channel traffic shaping, that is to say a per channel limitation of the bandwidth.classThis implementation of theAbstractTrafficShapingHandleris 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.classThis implementation of theAbstractTrafficShapingHandleris for global traffic shaping, that is to say a global limitation of the bandwidth, whatever the number of opened channels.
SnappyFrameDecoderinstead.