Uses of Annotation Type
io.netty.util.internal.UnstableApi
Packages that use UnstableApi
Package
Description
The core channel API which is asynchronous and event-driven abstraction of
various transports such as a
NIO Channel.
Optimized transport for linux which uses EPOLL Edge-Triggered Mode
for maximal performance.
BSD specific transport.
Abstract TCP and UDP socket interfaces which extend the core channel API.
NIO-based socket channel
API implementation - recommended for a large number of connections (>= 1000).
Old blocking I/O based socket channel API implementation - recommended for
a small number of connections (< 1000).
Unix specific transport.
DNS codec.
Encoder, decoder and their related message types for HTTP.
Encoder, decoder, handshakers to handle
WebSocket Extensions.
Handlers for sending and receiving HTTP/2 frames.
Common superset of ascii and binary classes.
Implementations and Interfaces for the Memcache Binary protocol.
Encoder, decoder for Redis.
SMTP codec.
Encoder, decoder and their related message types for Socks.
Encoder, decoder and their related message types for SOCKSv4 protocol.
Encoder, decoder and their related message types for SOCKSv5 protocol.
STOMP codec
OCSP stapling,
formally known as the TLS Certificate Status Request extension, is an
alternative approach to the Online Certificate Status Protocol (OCSP)
for checking the revocation status of X.509 digital certificates.
Utility classes used across multiple packages.
Utility classes for concurrent / async tasks.
Packages with annotations of type UnstableApi
Package
Description
Implementations and Interfaces for the Memcache Binary protocol.
DNS codec.
Handlers for sending and receiving HTTP/2 frames.
BSD specific transport.
Common superset of ascii and binary classes.
Encoder, decoder for Redis.
SMTP codec.
-
Uses of UnstableApi in io.netty.channel
Classes in io.netty.channel with annotations of type UnstableApiModifier and TypeClassDescriptionclass
final class
final class
Wraps anotherByteBufAllocator
and use heapbuffers everywhere except when a direct buffer is explicit requested.static interface
final class
Methods in io.netty.channel with annotations of type UnstableApiModifier and TypeMethodDescriptionprotected void
DefaultChannelPipeline.decrementPendingOutboundBytes
(long size) protected void
AbstractChannel.doShutdownOutput()
Called when conditions justify shutting down the output portion of the channel.final void
SingleThreadEventLoop.executeAfterEventLoopIteration
(Runnable task) Adds a task to be run once at the end of next (or current)eventloop
iteration.protected void
DefaultChannelPipeline.incrementPendingOutboundBytes
(long size) int
SingleThreadEventLoop.registeredChannels()
SingleThreadEventLoop.registeredChannelsIterator()
(package private) final boolean
SingleThreadEventLoop.removeAfterEventLoopIterationTask
(Runnable task) Removes a task that was added previously viaSingleThreadEventLoop.executeAfterEventLoopIteration(Runnable)
.final void
AbstractChannel.AbstractUnsafe.shutdownOutput
(ChannelPromise promise) Shutdown the output portion of the correspondingChannel
.Constructors in io.netty.channel with annotations of type UnstableApiModifierConstructorDescriptionprotected
ChannelException
(String message, Throwable cause, boolean shared) -
Uses of UnstableApi in io.netty.channel.epoll
Classes in io.netty.channel.epoll with annotations of type UnstableApiModifier and TypeClassDescriptionfinal class
final class
final class
This is an internal datastructure which can be directly passed to epoll_wait to reduce the overhead.final class
A socket which provides access Linux native methods.final class
Used to pass needed data to JNI.Methods in io.netty.channel.epoll with annotations of type UnstableApiModifier and TypeMethodDescriptionvoid
EpollEventLoop.closeFileDescriptors()
This method is intended for use by process checkpoint/restore integration, such as OpenJDK CRaC.protected final void
AbstractEpollStreamChannel.doShutdownOutput()
void
EpollEventLoop.openFileDescriptors()
This method is intended for use by a process checkpoint/restore integration, such as OpenJDK CRaC.EpollDomainSocketChannel.peerCredentials()
Returns the unix credentials (uid, gid, pid) of the peer SO_PEERCRED -
Uses of UnstableApi in io.netty.channel.kqueue
Classes in io.netty.channel.kqueue with annotations of type UnstableApiModifier and TypeClassDescriptionclass
class
class
final class
final class
If KQueue is available the JNI resources will be loaded when this class loads.class
final class
final class
final class
final class
final class
final class
final class
final class
class
final class
final class
class
final class
final class
Methods in io.netty.channel.kqueue with annotations of type UnstableApiModifier and TypeMethodDescriptionprotected final void
AbstractKQueueStreamChannel.doShutdownOutput()
KQueueDomainSocketChannel.peerCredentials()
Returns the unix credentials (uid, gid, pid) of the peer SO_PEERCRED -
Uses of UnstableApi in io.netty.channel.socket
Classes in io.netty.channel.socket with annotations of type UnstableApiModifier and TypeClassDescriptionfinal class
Special event which will be fired and passed to theChannelInboundHandler.userEventTriggered(ChannelHandlerContext, Object)
methods once the output of aSocketChannel
was shutdown.final class
Used to fail pending writes when a channel's output has been shutdown. -
Uses of UnstableApi in io.netty.channel.socket.nio
Methods in io.netty.channel.socket.nio with annotations of type UnstableApi -
Uses of UnstableApi in io.netty.channel.socket.oio
Methods in io.netty.channel.socket.oio with annotations of type UnstableApiModifier and TypeMethodDescriptionprotected final void
OioSocketChannel.doShutdownOutput()
Deprecated. -
Uses of UnstableApi in io.netty.channel.unix
Classes in io.netty.channel.unix with annotations of type UnstableApiModifier and TypeClassDescriptionfinal class
final class
User credentials discovered for the peer unix domain socket.final class
Methods in io.netty.channel.unix with annotations of type UnstableApiModifier and TypeMethodDescriptionstatic void
Unix.registerInternal
(Runnable registerTask) Internal method... -
Uses of UnstableApi in io.netty.handler.codec.dns
Classes in io.netty.handler.codec.dns with annotations of type UnstableApiModifier and TypeClassDescriptionclass
A skeletal implementation ofDnsMessage
.class
An OPT RR record.class
A skeletal implementation ofDnsRecord
.class
ADnsQuery
implementation for UDP/IP.class
Decodes aDatagramPacket
into aDatagramDnsQuery
.class
class
ADnsResponse
implementation for UDP/IP.class
Decodes aDatagramPacket
into aDatagramDnsResponse
.class
final class
DefaultDnsOptEcsRecord
implementation.class
class
The defaultDnsQuery
implementation.class
The defaultDnsQuestion
implementation.class
The defaultDnsRawRecord
implementation.class
The defaultDnsRecordDecoder
implementation.class
The defaultDnsRecordEncoder
implementation.class
The defaultDnsResponse
implementation.interface
The superclass which contains core information concerning aDnsQuery
and aDnsResponse
.class
The DNSOpCode
as defined in RFC2929.interface
An ECS record as defined in Client Subnet in DNS Queries.interface
An OPT RR record.interface
interface
A DNS query message.interface
A DNS question.interface
A genericDnsRecord
that contains an undecodedRDATA
.interface
A DNS resource record.interface
Decodes a DNS record into its object representation.interface
Encodes aDnsRecord
into binary representation.class
Represents a DNS record type.interface
A DNS response message.class
The DNSRCODE
, as defined in RFC2929.enum
Represents a section of aDnsMessage
.final class
final class
final class
final class
-
Uses of UnstableApi in io.netty.handler.codec.http
Classes in io.netty.handler.codec.http with annotations of type UnstableApiModifier and TypeClassDescriptionfinal class
Functions used to perform various validations of HTTP header names and values.final class
A variant ofHttpHeaders
which only supports read-only methods.Methods in io.netty.handler.codec.http with annotations of type UnstableApiModifier and TypeMethodDescriptionstatic long
HttpUtil.normalizeAndGetContentLength
(List<? extends CharSequence> contentLengthFields, boolean isHttp10OrEarlier, boolean allowDuplicateContentLengths) Validates, and optionally extracts the content length from headers. -
Uses of UnstableApi in io.netty.handler.codec.http.websocketx.extensions
Methods in io.netty.handler.codec.http.websocketx.extensions with annotations of type UnstableApiModifier and TypeMethodDescriptionprotected void
WebSocketServerExtensionHandler.onHttpRequestChannelRead
(ChannelHandlerContext ctx, HttpRequest request) This is a method exposed to perform fail-fast checks of user-defined http types.protected void
WebSocketServerExtensionHandler.onHttpResponseWrite
(ChannelHandlerContext ctx, HttpResponse response, ChannelPromise promise) This is a method exposed to perform fail-fast checks of user-defined http types. -
Uses of UnstableApi in io.netty.handler.codec.http2
Classes in io.netty.handler.codec.http2 with annotations of type UnstableApiModifier and TypeClassDescriptionclass
AbstractHttp2ConnectionHandlerBuilder<T extends Http2ConnectionHandler,
B extends AbstractHttp2ConnectionHandlerBuilder<T, B>> Abstract base class which defines commonly used features required to buildHttp2ConnectionHandler
instances.class
Abstract implementation ofHttp2StreamFrame
.class
AbstractInboundHttp2ToHttpAdapterBuilder<T extends InboundHttp2ToHttpAdapter,
B extends AbstractInboundHttp2ToHttpAdapterBuilder<T, B>> A skeletal builder implementation ofInboundHttp2ToHttpAdapter
and its subtypes.final class
Internal use only!final class
Performing cleartext upgrade, by h2c HTTP upgrade or Prior Knowledge.class
A decorating HTTP2 encoder that will compress data frames according to thecontent-encoding
header for each stream.class
Decorator around anotherHttp2ConnectionDecoder
instance.class
A decorator around anotherHttp2ConnectionEncoder
instance.class
Decorator around anotherHttp2FrameWriter
instance.class
Simple implementation ofHttp2Connection
.class
Provides the default implementation for processing inbound frame events and delegates to aHttp2FrameListener
class
Default implementation ofHttp2ConnectionEncoder
.final class
The defaultHttp2DataFrame
implementation.class
AHttp2FrameReader
that supports all frame types defined by the HTTP/2 specification.class
AHttp2FrameWriter
that supports all frame types defined by the HTTP/2 specification.final class
The defaultHttp2GoAwayFrame
implementation.class
class
class
final class
The defaultHttp2HeadersFrame
implementation.class
Basic implementation ofHttp2LocalFlowController
.class
The defaultHttp2PingFrame
implementation.final class
Default implementation of Http2PriorityFramefinal class
Default implementation ofHttp2PushPromiseFrame
class
Basic implementation ofHttp2RemoteFlowController
.final class
The defaultHttp2ResetFrame
implementation.class
The defaultHttp2SettingsFrame
implementation.final class
class
The defaultHttp2WindowUpdateFrame
implementation.class
An HTTP2 frame listener that will decompress data frames according to thecontent-encoding
header for each stream.final class
class
AChannelDuplexHandler
providing additional functionality for HTTP/2.class
Client-side cleartext upgrade codec from HTTP to HTTP/2.final class
Constants and utility method used for encoding/decoding HTTP2 frames.interface
Manager for the state of an HTTP/2 connection with the remote end-point.class
Provides empty implementations of allHttp2Connection.Listener
methods.interface
Handler for inbound traffic on behalf ofHttp2ConnectionHandler
.interface
Handler for outbound HTTP/2 traffic.class
Provides the default implementation for processing inbound frame events and delegates to aHttp2FrameListener
final class
Builder which buildsHttp2ConnectionHandler
objects.final class
Signifies that the connection preface and the initial SETTINGS frame have been sent.interface
HTTP/2 DATA frame.interface
Interface that defines an object capable of producing HTTP/2 data frames.enum
All error codes identified by the HTTP/2 spec.class
This class bringsHttp2Connection.Listener
andHttp2FrameListener
together to provide NOOP implementation so inheriting classes can selectively choose which methods to override.class
Exception thrown when an HTTP/2 error was encountered.final class
Provides utility methods for accessing specific flags as defined by the HTTP/2 spec.interface
Base interface for all HTTP/2 flow controllers.interface
An HTTP/2 frame.class
Convenience class that provides no-op implementations for all methods ofHttp2FrameListener
.class
This API is very immature. The Http2Connection-based API is currently preferred over this API.class
Builder for theHttp2FrameCodec
.interface
An listener of HTTP/2 frames.class
Provides a decorator around aHttp2FrameListener
and delegates all method callsclass
Logs HTTP2 frames for debugging purposes.interface
Reads HTTP/2 frames from an inputByteBuf
and notifies the specifiedHttp2FrameListener
when frames are complete.interface
interface
A single stream within an HTTP/2 connection.final class
static enum
final class
An HTTP/2 exception for a specificHttp2FrameStream
.interface
A visitor that allows to iterate over a collection ofHttp2FrameStream
s.final class
Registry of all standard frame types defined by the HTTP/2 specification.interface
A writer responsible for marshaling HTTP/2 frames to the channel.interface
HTTP/2 GOAWAY frame.interface
A collection of headers sent or received via HTTP/2.interface
Decodes HPACK-encoded headers blocks intoHttp2Headers
.interface
EncodesHttp2Headers
into HPACK-encoded headers blocks.interface
HTTP/2 HEADERS frame.class
Decorator around aHttp2FrameReader
that logs all inbound frames before calling back the listener.interface
Manager for the life cycle of the HTTP/2 connection.interface
AHttp2FlowController
for controlling the inbound flow ofDATA
frames from the remote endpoint.class
Deprecated.class
Deprecated.useHttp2FrameCodecBuilder
together withHttp2MultiplexHandler
.final class
An HTTP/2 handler that creates child channels for each stream.class
This exception is thrown when there are no more stream IDs available for the current connectionclass
Decorator around aHttp2FrameWriter
that logs all outbound frames before calling the writer.interface
HTTP/2 PING Frame.interface
HTTP/2 Priority Frameinterface
Provides an extensibility point for users to define the validity of push requests.interface
HTTP/2 Push Promise Frameinterface
AHttp2FlowController
for controlling the flow of outboundDATA
frames to the remote endpoint.interface
HTTP/2 RST_STREAM frame.final class
Provides utilities related to security requirements specific to HTTP/2.class
Server-side codec for performing a cleartext upgrade from HTTP/1.x to HTTP/2.final class
Settings for one endpoint in an HTTP/2 connection.interface
A single stream within an HTTP2 connection.interface
final class
interface
A frame whose meaning may apply to a particular stream, instead of the entire connection.class
This handler converts fromHttp2StreamFrame
toHttpObject
, and back.interface
A visitor that allows iteration over a collection of streams.interface
interface
HTTP/2 WINDOW_UPDATE frame.final class
Provides utility methods and constants for the HTTP/2 to HTTP conversionclass
Translates HTTP/1.x object writes into HTTP/2 frames.final class
Builder which buildsHttpToHttp2ConnectionHandler
objects.class
This adapter provides just header/data events from the HTTP message flow defined in [RFC 7540], Section 8.1.final class
Builds anInboundHttp2ToHttpAdapter
.class
Translates HTTP/1.x object reads into HTTP/2 frames.class
Implementation of aHttp2ConnectionEncoder
that dispatches all method call to anotherHttp2ConnectionEncoder
, untilSETTINGS_MAX_CONCURRENT_STREAMS
is reached.interface
An object (used by remote flow control) that is responsible for distributing the bytes to be written across the streams in the connection.final class
AStreamByteDistributor
that ignores stream priority and uniformly allocates bytes to all streams.final class
AStreamByteDistributor
that is sensitive to stream priority and uses Weighted Fair Queueing approach for distributing bytes. -
Uses of UnstableApi in io.netty.handler.codec.memcache
Classes in io.netty.handler.codec.memcache with annotations of type UnstableApiModifier and TypeClassDescriptionclass
The defaultMemcacheObject
implementation.class
AbstractMemcacheObjectAggregator<H extends MemcacheMessage>
AChannelHandler
that aggregates anMemcacheMessage
and its followingMemcacheContent
s into a singleMemcacheMessage
with no followingMemcacheContent
s.class
Abstract super class for both ascii and binary decoders.class
AbstractMemcacheObjectEncoder<M extends MemcacheMessage>
A general purposeAbstractMemcacheObjectEncoder
that encodesMemcacheMessage
s.class
The default implementation for theLastMemcacheContent
.class
The defaultMemcacheContent
implementation.interface
CombinesMemcacheMessage
andLastMemcacheContent
into one message.interface
TheMemcacheContent
which signals the end of the content batch.interface
An Memcache content chunk.interface
Marker interface for both ascii and binary messages.interface
Defines a common interface for allMemcacheObject
implementations. -
Uses of UnstableApi in io.netty.handler.codec.memcache.binary
Classes in io.netty.handler.codec.memcache.binary with annotations of type UnstableApiModifier and TypeClassDescriptionclass
Decoder for bothBinaryMemcacheRequest
andBinaryMemcacheResponse
.class
AMessageToByteEncoder
that encodes binary memcache messages into bytes.class
Default implementation of aBinaryMemcacheMessage
.final class
The client codec that combines the proper encoder and decoder.interface
An interface that defines a binary Memcache message, providing common properties forBinaryMemcacheRequest
andBinaryMemcacheResponse
.class
An object aggregator for the memcache binary protocol.final class
Represents all Opcodes that can occur in aBinaryMemcacheMessage
.interface
Represents a fullBinaryMemcacheRequest
, which contains the header and optional key and extras.class
The decoder part which takes care of decoding the request-specific headers.class
The encoder part which takes care of encoding the request headers.interface
Represents a fullBinaryMemcacheResponse
, which contains the header and optional key and extras.class
The decoder which takes care of decoding the response headers.class
The encoder which takes care of encoding the response headers.final class
Contains all possible status values aBinaryMemcacheResponse
can return.class
The full server codec that combines the correct encoder and decoder.class
The default implementation of theBinaryMemcacheRequest
.class
The default implementation of theBinaryMemcacheResponse
.class
The default implementation of aFullBinaryMemcacheRequest
.class
The default implementation of aFullBinaryMemcacheResponse
.interface
ABinaryMemcacheRequest
that also includes the content.interface
ABinaryMemcacheResponse
that also includes the content. -
Uses of UnstableApi in io.netty.handler.codec.redis
Classes in io.netty.handler.codec.redis with annotations of type UnstableApiModifier and TypeClassDescriptionclass
Abstract class for Simple Strings or Errors.class
Header of Redis Array Message.class
Arrays of RESP.class
The header of Bulk Strings in RESP.interface
A chunk of bulk strings which is used for Redis chunked transfer-encoding.class
A default implementation ofBulkStringRedisContent
.final class
A default implementation forLastBulkStringRedisContent
.final class
Errors of RESP.final class
A default fixed redis message pool.class
An aggregated bulk string of RESP.final class
Inline commands of RESP.final class
Integers of RESP.interface
A last chunk of Bulk Strings.final class
AggregatesRedisMessage
parts intoArrayRedisMessage
.final class
AChannelHandler
that aggregates anBulkStringHeaderRedisMessage
and its followingBulkStringRedisContent
s into a singleFullBulkStringRedisMessage
with no followingBulkStringRedisContent
s.final class
final class
Decodes the Redis protocol intoRedisMessage
objects following RESP (REdis Serialization Protocol).class
EncodesRedisMessage
into bytes following RESP (REdis Serialization Protocol).interface
RedisMessage is base interface for codec-redis.interface
A strategy interface for cachingRedisMessage
s.enum
Type of RESP (REdis Serialization Protocol).final class
Simple Strings of RESP. -
Uses of UnstableApi in io.netty.handler.codec.smtp
Classes in io.netty.handler.codec.smtp with annotations of type UnstableApiModifier and TypeClassDescriptionfinal class
Default implementation ofLastSmtpContent
that does no validation of the raw data passed in.class
Default implementation ofSmtpContent
that does no validation of the raw data passed in.final class
DefaultSmtpRequest
implementation.final class
DefaultSmtpResponse
implementation.interface
The last part of a sequence ofSmtpContent
s that are sent after aDATA
request.final class
The command part of aSmtpRequest
.interface
Content that is sent after theDATA
request.interface
An SMTP request.final class
Encoder for SMTP requests.final class
Provides utility methods to createSmtpRequest
s.interface
A SMTP responsefinal class
Decoder for SMTP responses. -
Uses of UnstableApi in io.netty.handler.codec.socks
Classes in io.netty.handler.codec.socks with annotations of type UnstableApiModifier and TypeClassDescriptionstatic enum
static enum
static enum
static enum
static enum
static enum
-
Uses of UnstableApi in io.netty.handler.codec.socksx.v4
Classes in io.netty.handler.codec.socksx.v4 with annotations of type UnstableApiModifier and TypeClassDescriptionstatic enum
static enum
-
Uses of UnstableApi in io.netty.handler.codec.socksx.v5
Classes in io.netty.handler.codec.socksx.v5 with annotations of type UnstableApiModifier and TypeClassDescriptionstatic enum
static enum
static enum
static enum
static enum
static enum
-
Uses of UnstableApi in io.netty.handler.codec.stomp
Classes in io.netty.handler.codec.stomp with annotations of type UnstableApi -
Uses of UnstableApi in io.netty.handler.ssl
Classes in io.netty.handler.ssl with annotations of type UnstableApiModifier and TypeClassDescriptionfinal class
Converts a Java cipher suite string to an OpenSSL cipher suite string and vice versa.interface
Allow to customize private key signing / decrypting (when using RSA).final class
Event that is fired once we did a selection of aSslContext
based on theSNI hostname
, which may be because it was successful or there was an error.Methods in io.netty.handler.ssl with annotations of type UnstableApiModifier and TypeMethodDescriptionSslContextBuilder.enableOcsp
(boolean enableOcsp) Enables OCSP stapling.byte[]
ReferenceCountedOpenSslEngine.getOcspResponse()
Returns the OCSP response ornull
if the server didn't provide a stapled OCSP response.void
ReferenceCountedOpenSslEngine.setOcspResponse
(byte[] response) Sets the OCSP response.final void
ReferenceCountedOpenSslContext.setPrivateKeyMethod
(OpenSslPrivateKeyMethod method) Deprecated.final void
ReferenceCountedOpenSslEngine.setVerify
(int verifyMode, int depth) See SSL_set_verify andSSL.setVerify(long, int, int)
.final void
SslHandler.setWrapDataSize
(int wrapDataSize) Sets the number of bytes to pass to eachSSLEngine.wrap(ByteBuffer[], int, int, ByteBuffer)
call. -
Uses of UnstableApi in io.netty.handler.ssl.ocsp
Classes in io.netty.handler.ssl.ocsp with annotations of type UnstableApiModifier and TypeClassDescriptionclass
A handler for SSL clients to handle and act upon stapled OCSP responses. -
Uses of UnstableApi in io.netty.util
Classes in io.netty.util with annotations of type UnstableApi -
Uses of UnstableApi in io.netty.util.concurrent
Classes in io.netty.util.concurrent with annotations of type UnstableApiModifier and TypeClassDescriptionfinal class
Default implementation which uses simple round-robin to choose nextEventExecutor
.interface
Factory that creates newEventExecutorChooserFactory.EventExecutorChooser
s.static interface
Chooses the nextEventExecutor
to use.final class
EventExecutorGroup
which will preserveRunnable
execution order but makes no guarantees about whatEventExecutor
(and thereforeThread
) will be used to execute theRunnable
s.Methods in io.netty.util.concurrent with annotations of type UnstableApiModifier and TypeMethodDescriptionprotected void
SingleThreadEventExecutor.afterRunningAllTasks()
Invoked before returning fromSingleThreadEventExecutor.runAllTasks()
andSingleThreadEventExecutor.runAllTasks(long)
.protected long
SingleThreadEventExecutor.deadlineNanos()
Returns the absolute point in time (relative toAbstractScheduledEventExecutor.getCurrentTimeNanos()
) at which the next closest scheduled task should run.void
AbstractEventExecutor.lazyExecute
(Runnable task) LikeExecutor.execute(Runnable)
but does not guarantee the task will be run until either a non-lazy task is executed or the executor is shut down.boolean
FastThreadLocalThread.willCleanupFastThreadLocals()
static boolean
FastThreadLocalThread.willCleanupFastThreadLocals
(Thread thread)
Http2FrameCodecBuilder
together withHttp2MultiplexHandler
.