Package | Description |
---|---|
io.netty.channel |
The core channel API which is asynchronous and event-driven abstraction of
various transports such as a
NIO Channel.
|
io.netty.channel.epoll |
Optimized transport for linux which uses EPOLL Edge-Triggered Mode
for maximal performance.
|
io.netty.channel.kqueue |
BSD specific transport.
|
io.netty.channel.socket |
Abstract TCP and UDP socket interfaces which extend the core channel API.
|
io.netty.channel.socket.nio |
NIO-based socket channel
API implementation - recommended for a large number of connections (>= 1000).
|
io.netty.channel.socket.oio |
Old blocking I/O based socket channel API implementation - recommended for
a small number of connections (< 1000).
|
io.netty.channel.unix |
Unix specific transport.
|
io.netty.handler.codec.dns |
DNS codec.
|
io.netty.handler.codec.http2 |
Handlers for sending and receiving HTTP/2 frames.
|
io.netty.handler.codec.memcache |
Common superset of ascii and binary classes.
|
io.netty.handler.codec.memcache.binary |
Implementations and Interfaces for the Memcache Binary protocol.
|
io.netty.handler.codec.redis |
Encoder, decoder for Redis.
|
io.netty.handler.codec.smtp |
SMTP codec.
|
io.netty.handler.ssl | |
io.netty.handler.ssl.ocsp |
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.
|
io.netty.resolver |
Resolves an arbitrary string that represents the name of an endpoint into an address.
|
io.netty.resolver.dns |
An alternative to Java's built-in domain name lookup mechanism that resolves a domain name asynchronously,
which supports the queries of an arbitrary DNS record type as well.
|
io.netty.util.concurrent |
Utility classes for concurrent / async tasks.
|
Package | Description |
---|---|
io.netty.channel.kqueue |
BSD specific transport.
|
io.netty.handler.codec.dns |
DNS codec.
|
io.netty.handler.codec.http2 |
Handlers for sending and receiving HTTP/2 frames.
|
io.netty.handler.codec.memcache |
Common superset of ascii and binary classes.
|
io.netty.handler.codec.memcache.binary |
Implementations and Interfaces for the Memcache Binary protocol.
|
io.netty.handler.codec.redis |
Encoder, decoder for Redis.
|
io.netty.handler.codec.smtp |
SMTP codec.
|
io.netty.resolver |
Resolves an arbitrary string that represents the name of an endpoint into an address.
|
io.netty.resolver.dns |
An alternative to Java's built-in domain name lookup mechanism that resolves a domain name asynchronously,
which supports the queries of an arbitrary DNS record type as well.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractCoalescingBufferQueue |
class |
DelegatingChannelPromiseNotifier |
class |
PreferHeapByteBufAllocator
Wraps another
ByteBufAllocator and use heapbuffers everywhere except when a direct buffer is explicit
requested. |
static interface |
RecvByteBufAllocator.ExtendedHandle |
class |
VoidChannelPromise |
Modifier and Type | Method and Description |
---|---|
protected void |
DefaultChannelPipeline.decrementPendingOutboundBytes(long size) |
protected void |
AbstractChannel.doShutdownOutput()
Called when conditions justify shutting down the output portion of the channel.
|
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) |
void |
AbstractChannel.AbstractUnsafe.shutdownOutput(ChannelPromise promise)
Shutdown the output portion of the corresponding
Channel . |
Modifier and Type | Method and Description |
---|---|
protected void |
AbstractEpollStreamChannel.doShutdownOutput() |
PeerCredentials |
EpollDomainSocketChannel.peerCredentials()
Returns the unix credentials (uid, gid, pid) of the peer
SO_PEERCRED
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractKQueueServerChannel |
class |
AbstractKQueueStreamChannel |
class |
AcceptFilter |
class |
KQueue
If KQueue is available the JNI resources will be loaded when this class loads.
|
class |
KQueueChannelConfig |
class |
KQueueChannelOption<T> |
class |
KQueueDatagramChannel |
class |
KQueueDatagramChannelConfig |
class |
KQueueDomainSocketChannel |
class |
KQueueDomainSocketChannelConfig |
class |
KQueueEventLoopGroup |
class |
KQueueServerChannelConfig |
class |
KQueueServerDomainSocketChannel |
class |
KQueueServerSocketChannel |
class |
KQueueServerSocketChannelConfig |
class |
KQueueSocketChannel |
class |
KQueueSocketChannelConfig |
Modifier and Type | Method and Description |
---|---|
protected void |
AbstractKQueueStreamChannel.doShutdownOutput() |
PeerCredentials |
KQueueDomainSocketChannel.peerCredentials()
Returns the unix credentials (uid, gid, pid) of the peer
SO_PEERCRED
|
Modifier and Type | Class and Description |
---|---|
class |
ChannelOutputShutdownEvent
Special event which will be fired and passed to the
ChannelInboundHandler.userEventTriggered(ChannelHandlerContext, Object) methods once the output of
a SocketChannel was shutdown. |
class |
ChannelOutputShutdownException
Used to fail pending writes when a channel's output has been shutdown.
|
Modifier and Type | Method and Description |
---|---|
protected void |
NioSocketChannel.doShutdownOutput() |
Modifier and Type | Method and Description |
---|---|
protected void |
OioSocketChannel.doShutdownOutput() |
Modifier and Type | Class and Description |
---|---|
class |
PeerCredentials
User credentials discovered for the peer unix domain socket.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractDnsMessage
A skeletal implementation of
DnsMessage . |
class |
AbstractDnsOptPseudoRrRecord
An OPT RR record.
|
class |
AbstractDnsRecord
A skeletal implementation of
DnsRecord . |
class |
DatagramDnsQuery
A
DnsQuery implementation for UDP/IP. |
class |
DatagramDnsQueryDecoder
Decodes a
DatagramPacket into a DatagramDnsQuery . |
class |
DatagramDnsQueryEncoder
|
class |
DatagramDnsResponse
A
DnsResponse implementation for UDP/IP. |
class |
DatagramDnsResponseDecoder
Decodes a
DatagramPacket into a DatagramDnsResponse . |
class |
DatagramDnsResponseEncoder
|
class |
DefaultDnsOptEcsRecord
Default
DnsOptEcsRecord implementation. |
class |
DefaultDnsPtrRecord |
class |
DefaultDnsQuery
The default
DnsQuery implementation. |
class |
DefaultDnsQuestion
The default
DnsQuestion implementation. |
class |
DefaultDnsRawRecord
The default
DnsRawRecord implementation. |
class |
DefaultDnsRecordDecoder
The default
DnsRecordDecoder implementation. |
class |
DefaultDnsRecordEncoder
The default
DnsRecordEncoder implementation. |
class |
DefaultDnsResponse
The default
DnsResponse implementation. |
interface |
DnsMessage
The superclass which contains core information concerning a
DnsQuery and a DnsResponse . |
class |
DnsOpCode
The DNS
OpCode as defined in RFC2929. |
interface |
DnsOptEcsRecord
An ECS record as defined in Client Subnet in DNS Queries.
|
interface |
DnsOptPseudoRecord
An OPT RR record.
|
interface |
DnsPtrRecord |
interface |
DnsQuery
A DNS query message.
|
interface |
DnsQuestion
A DNS question.
|
interface |
DnsRawRecord
A generic
DnsRecord that contains an undecoded RDATA . |
interface |
DnsRecord
A DNS resource record.
|
interface |
DnsRecordDecoder
Decodes a DNS record into its object representation.
|
interface |
DnsRecordEncoder
Encodes a
DnsRecord into binary representation. |
class |
DnsRecordType
Represents a DNS record type.
|
interface |
DnsResponse
A DNS response message.
|
class |
DnsResponseCode
The DNS
RCODE , as defined in RFC2929. |
class |
DnsSection
Represents a section of a
DnsMessage . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractHttp2ConnectionHandlerBuilder<T extends Http2ConnectionHandler,B extends AbstractHttp2ConnectionHandlerBuilder<T,B>>
Abstract base class which defines commonly used features required to build
Http2ConnectionHandler instances. |
class |
AbstractHttp2StreamFrame
Abstract implementation of
Http2StreamFrame . |
class |
AbstractInboundHttp2ToHttpAdapterBuilder<T extends InboundHttp2ToHttpAdapter,B extends AbstractInboundHttp2ToHttpAdapterBuilder<T,B>>
A skeletal builder implementation of
InboundHttp2ToHttpAdapter and its subtypes. |
class |
CharSequenceMap<V>
Internal use only!
|
class |
CleartextHttp2ServerUpgradeHandler
Performing cleartext upgrade, by h2c HTTP upgrade or Prior Knowledge.
|
class |
CompressorHttp2ConnectionEncoder
A decorating HTTP2 encoder that will compress data frames according to the
content-encoding header for each
stream. |
class |
DecoratingHttp2ConnectionDecoder
Decorator around another
Http2ConnectionDecoder instance. |
class |
DecoratingHttp2ConnectionEncoder
A decorator around another
Http2ConnectionEncoder instance. |
class |
DecoratingHttp2FrameWriter
Decorator around another
Http2FrameWriter instance. |
class |
DefaultHttp2Connection
Simple implementation of
Http2Connection . |
class |
DefaultHttp2ConnectionDecoder
Provides the default implementation for processing inbound frame events and delegates to a
Http2FrameListener
This class will read HTTP/2 frames and delegate the events to a Http2FrameListener
This interface enforces inbound flow control functionality through
Http2LocalFlowController |
class |
DefaultHttp2ConnectionEncoder
Default implementation of
Http2ConnectionEncoder . |
class |
DefaultHttp2DataFrame
The default
Http2DataFrame implementation. |
class |
DefaultHttp2FrameReader
A
Http2FrameReader that supports all frame types defined by the HTTP/2 specification. |
class |
DefaultHttp2FrameWriter
A
Http2FrameWriter that supports all frame types defined by the HTTP/2 specification. |
class |
DefaultHttp2GoAwayFrame
The default
Http2GoAwayFrame implementation. |
class |
DefaultHttp2Headers |
class |
DefaultHttp2HeadersDecoder |
class |
DefaultHttp2HeadersEncoder |
class |
DefaultHttp2HeadersFrame
The default
Http2HeadersFrame implementation. |
class |
DefaultHttp2LocalFlowController
Basic implementation of
Http2LocalFlowController . |
class |
DefaultHttp2PingFrame
The default
Http2PingFrame implementation. |
class |
DefaultHttp2RemoteFlowController
Basic implementation of
Http2RemoteFlowController . |
class |
DefaultHttp2ResetFrame
The default
Http2ResetFrame implementation. |
class |
DefaultHttp2SettingsFrame
The default
Http2SettingsFrame implementation. |
class |
DefaultHttp2UnknownFrame |
class |
DefaultHttp2WindowUpdateFrame
The default
Http2WindowUpdateFrame implementation. |
class |
DelegatingDecompressorFrameListener
A HTTP2 frame listener that will decompress data frames according to the
content-encoding header for each
stream. |
class |
EmptyHttp2Headers |
class |
Http2ChannelDuplexHandler
A
ChannelDuplexHandler providing additional functionality for HTTP/2. |
class |
Http2ClientUpgradeCodec
Client-side cleartext upgrade codec from HTTP to HTTP/2.
|
class |
Http2CodecUtil
Constants and utility method used for encoding/decoding HTTP2 frames.
|
interface |
Http2Connection
Manager for the state of an HTTP/2 connection with the remote end-point.
|
class |
Http2ConnectionAdapter
Provides empty implementations of all
Http2Connection.Listener methods. |
interface |
Http2ConnectionDecoder
Handler for inbound traffic on behalf of
Http2ConnectionHandler . |
interface |
Http2ConnectionEncoder
Handler for outbound HTTP/2 traffic.
|
class |
Http2ConnectionHandler
Provides the default implementation for processing inbound frame events and delegates to a
Http2FrameListener
This class will read HTTP/2 frames and delegate the events to a Http2FrameListener
This interface enforces inbound flow control functionality through
Http2LocalFlowController |
class |
Http2ConnectionHandlerBuilder
Builder which builds
Http2ConnectionHandler objects. |
class |
Http2ConnectionPrefaceWrittenEvent
Signifies that the connection preface has been sent.
|
interface |
Http2DataFrame
HTTP/2 DATA frame.
|
interface |
Http2DataWriter
Interface that defines an object capable of producing HTTP/2 data frames.
|
class |
Http2Error
All error codes identified by the HTTP/2 spec.
|
class |
Http2EventAdapter
This class brings
Http2Connection.Listener and Http2FrameListener together to provide
NOOP implementation so inheriting classes can selectively choose which methods to override. |
class |
Http2Exception
Exception thrown when an HTTP/2 error was encountered.
|
class |
Http2Flags
Provides utility methods for accessing specific flags as defined by the HTTP/2 spec.
|
interface |
Http2FlowController
Base interface for all HTTP/2 flow controllers.
|
interface |
Http2Frame
An HTTP/2 frame.
|
class |
Http2FrameAdapter
Convenience class that provides no-op implementations for all methods of
Http2FrameListener . |
class |
Http2FrameCodec
This API is very immature.
|
class |
Http2FrameCodecBuilder
Builder for the
Http2FrameCodec . |
interface |
Http2FrameListener
An listener of HTTP/2 frames.
|
class |
Http2FrameListenerDecorator
Provides a decorator around a
Http2FrameListener and delegates all method calls |
class |
Http2FrameLogger
Logs HTTP2 frames for debugging purposes.
|
interface |
Http2FrameReader
Reads HTTP/2 frames from an input
ByteBuf and notifies the specified
Http2FrameListener when frames are complete. |
interface |
Http2FrameSizePolicy |
interface |
Http2FrameStream
A single stream within a HTTP/2 connection.
|
class |
Http2FrameStreamEvent |
class |
Http2FrameStreamException
A HTTP/2 exception for a specific
Http2FrameStream . |
interface |
Http2FrameStreamVisitor
A visitor that allows to iterate over a collection of
Http2FrameStream s. |
class |
Http2FrameTypes
Registry of all standard frame types defined by the HTTP/2 specification.
|
interface |
Http2FrameWriter
A writer responsible for marshaling HTTP/2 frames to the channel.
|
interface |
Http2GoAwayFrame
HTTP/2 GOAWAY frame.
|
interface |
Http2Headers
A collection of headers sent or received via HTTP/2.
|
interface |
Http2HeadersDecoder
Decodes HPACK-encoded headers blocks into
Http2Headers . |
interface |
Http2HeadersEncoder
Encodes
Http2Headers into HPACK-encoded headers blocks. |
interface |
Http2HeadersFrame
HTTP/2 HEADERS frame.
|
class |
Http2InboundFrameLogger
Decorator around a
Http2FrameReader that logs all inbound frames before calling
back the listener. |
interface |
Http2LifecycleManager
Manager for the life cycle of the HTTP/2 connection.
|
interface |
Http2LocalFlowController
A
Http2FlowController for controlling the inbound flow of DATA frames from the remote endpoint. |
class |
Http2MultiplexCodec
An HTTP/2 handler that creates child channels for each stream.
|
class |
Http2MultiplexCodecBuilder
A builder for
Http2MultiplexCodec . |
class |
Http2NoMoreStreamIdsException
This exception is thrown when there are no more stream IDs available for the current connection
|
class |
Http2OutboundFrameLogger
Decorator around a
Http2FrameWriter that logs all outbound frames before calling the
writer. |
interface |
Http2PingFrame
HTTP/2 PING Frame.
|
interface |
Http2PromisedRequestVerifier
Provides an extensibility point for users to define the validity of push requests.
|
interface |
Http2RemoteFlowController
A
Http2FlowController for controlling the flow of outbound DATA frames to the remote
endpoint. |
interface |
Http2ResetFrame
HTTP/2 RST_STREAM frame.
|
class |
Http2SecurityUtil
Provides utilities related to security requirements specific to HTTP/2.
|
class |
Http2ServerUpgradeCodec
Server-side codec for performing a cleartext upgrade from HTTP/1.x to HTTP/2.
|
class |
Http2Settings
Settings for one endpoint in an HTTP/2 connection.
|
interface |
Http2Stream
A single stream within an HTTP2 connection.
|
interface |
Http2StreamChannel |
class |
Http2StreamChannelBootstrap |
interface |
Http2StreamFrame
A frame whose meaning may apply to a particular stream, instead of the entire connection.
|
class |
Http2StreamFrameToHttpObjectCodec
This handler converts from
Http2StreamFrame to HttpObject ,
and back. |
interface |
Http2StreamVisitor
A visitor that allows iteration over a collection of streams.
|
interface |
Http2UnknownFrame |
interface |
Http2WindowUpdateFrame
HTTP/2 WINDOW_UPDATE frame.
|
class |
HttpConversionUtil
Provides utility methods and constants for the HTTP/2 to HTTP conversion
|
class |
HttpToHttp2ConnectionHandler
Translates HTTP/1.x object writes into HTTP/2 frames.
|
class |
HttpToHttp2ConnectionHandlerBuilder
Builder which builds
HttpToHttp2ConnectionHandler objects. |
class |
InboundHttp2ToHttpAdapter
|
class |
InboundHttp2ToHttpAdapterBuilder
Builds an
InboundHttp2ToHttpAdapter . |
class |
InboundHttpToHttp2Adapter
Translates HTTP/1.x object reads into HTTP/2 frames.
|
class |
StreamBufferingEncoder
Implementation of a
Http2ConnectionEncoder that dispatches all method call to another
Http2ConnectionEncoder , until SETTINGS_MAX_CONCURRENT_STREAMS is reached. |
interface |
StreamByteDistributor
An object (used by remote flow control) that is responsible for distributing the bytes to be
written across the streams in the connection.
|
class |
UniformStreamByteDistributor
A
StreamByteDistributor that ignores stream priority and uniformly allocates bytes to all
streams. |
class |
WeightedFairQueueByteDistributor
A
StreamByteDistributor that is sensitive to stream priority and uses
Weighted Fair Queueing approach for distributing
bytes. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractMemcacheObject
The default
MemcacheObject implementation. |
class |
AbstractMemcacheObjectAggregator<H extends MemcacheMessage>
A
ChannelHandler that aggregates an MemcacheMessage
and its following MemcacheContent s into a single MemcacheMessage with
no following MemcacheContent s. |
class |
AbstractMemcacheObjectDecoder
Abstract super class for both ascii and binary decoders.
|
class |
AbstractMemcacheObjectEncoder<M extends MemcacheMessage>
A general purpose
AbstractMemcacheObjectEncoder that encodes MemcacheMessage s. |
class |
DefaultLastMemcacheContent
The default implementation for the
LastMemcacheContent . |
class |
DefaultMemcacheContent
The default
MemcacheContent implementation. |
interface |
FullMemcacheMessage
Combines
MemcacheMessage and LastMemcacheContent into one
message. |
interface |
LastMemcacheContent
The
MemcacheContent which signals the end of the content batch. |
interface |
MemcacheContent
An Memcache content chunk.
|
interface |
MemcacheMessage
Marker interface for both ascii and binary messages.
|
interface |
MemcacheObject
Defines a common interface for all
MemcacheObject implementations. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractBinaryMemcacheDecoder<M extends BinaryMemcacheMessage>
Decoder for both
BinaryMemcacheRequest and BinaryMemcacheResponse . |
class |
AbstractBinaryMemcacheEncoder<M extends BinaryMemcacheMessage>
A
MessageToByteEncoder that encodes binary memcache messages into bytes. |
class |
AbstractBinaryMemcacheMessage
Default implementation of a
BinaryMemcacheMessage . |
class |
BinaryMemcacheClientCodec
The client codec that combines the proper encoder and decoder.
|
interface |
BinaryMemcacheMessage
An interface that defines a binary Memcache message, providing common properties for
BinaryMemcacheRequest and BinaryMemcacheResponse . |
class |
BinaryMemcacheObjectAggregator
An object aggregator for the memcache binary protocol.
|
class |
BinaryMemcacheOpcodes
Represents all Opcodes that can occur in a
BinaryMemcacheMessage . |
interface |
BinaryMemcacheRequest
Represents a full
BinaryMemcacheRequest , which contains the header and optional key and extras. |
class |
BinaryMemcacheRequestDecoder
The decoder part which takes care of decoding the request-specific headers.
|
class |
BinaryMemcacheRequestEncoder
The encoder part which takes care of encoding the request headers.
|
interface |
BinaryMemcacheResponse
Represents a full
BinaryMemcacheResponse , which contains the header and optional key and extras. |
class |
BinaryMemcacheResponseDecoder
The decoder which takes care of decoding the response headers.
|
class |
BinaryMemcacheResponseEncoder
The encoder which takes care of encoding the response headers.
|
class |
BinaryMemcacheResponseStatus
Contains all possible status values a
BinaryMemcacheResponse can return. |
class |
BinaryMemcacheServerCodec
The full server codec that combines the correct encoder and decoder.
|
class |
DefaultBinaryMemcacheRequest
The default implementation of the
BinaryMemcacheRequest . |
class |
DefaultBinaryMemcacheResponse
The default implementation of the
BinaryMemcacheResponse . |
class |
DefaultFullBinaryMemcacheRequest
The default implementation of a
FullBinaryMemcacheRequest . |
class |
DefaultFullBinaryMemcacheResponse
The default implementation of a
FullBinaryMemcacheResponse . |
interface |
FullBinaryMemcacheRequest
A
BinaryMemcacheRequest that also includes the content. |
interface |
FullBinaryMemcacheResponse
A
BinaryMemcacheResponse that also includes the content. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractStringRedisMessage
Abstract class for Simple Strings or Errors.
|
class |
ArrayHeaderRedisMessage
Header of Redis Array Message.
|
class |
ArrayRedisMessage
Arrays of RESP.
|
class |
BulkStringHeaderRedisMessage
The header of Bulk Strings in RESP.
|
interface |
BulkStringRedisContent
A chunk of bulk strings which is used for Redis chunked transfer-encoding.
|
class |
DefaultBulkStringRedisContent
A default implementation of
BulkStringRedisContent . |
class |
DefaultLastBulkStringRedisContent
A default implementation for
LastBulkStringRedisContent . |
class |
ErrorRedisMessage
Errors of RESP.
|
class |
FixedRedisMessagePool
A default fixed redis message pool.
|
class |
FullBulkStringRedisMessage
An aggregated bulk string of RESP.
|
class |
IntegerRedisMessage
Integers of RESP.
|
interface |
LastBulkStringRedisContent
A last chunk of Bulk Strings.
|
class |
RedisArrayAggregator
Aggregates
RedisMessage parts into ArrayRedisMessage . |
class |
RedisBulkStringAggregator
A
ChannelHandler that aggregates an BulkStringHeaderRedisMessage
and its following BulkStringRedisContent s into a single FullBulkStringRedisMessage
with no following BulkStringRedisContent s. |
class |
RedisCodecException
|
class |
RedisDecoder
Decodes the Redis protocol into
RedisMessage objects following
RESP (REdis Serialization Protocol). |
class |
RedisEncoder
Encodes
RedisMessage into bytes following
RESP (REdis Serialization Protocol). |
interface |
RedisMessage
RedisMessage is base interface for codec-redis.
|
interface |
RedisMessagePool
A strategy interface for caching
RedisMessage s. |
class |
RedisMessageType
Type of RESP (REdis Serialization Protocol).
|
class |
SimpleStringRedisMessage
Simple Strings of RESP.
|
Modifier and Type | Class and Description |
---|---|
class |
DefaultLastSmtpContent
Default implementation of
LastSmtpContent that does no validation of the raw data passed in. |
class |
DefaultSmtpContent
Default implementation of
SmtpContent that does no validation of the raw data passed in. |
class |
DefaultSmtpRequest
Default
SmtpRequest implementation. |
class |
DefaultSmtpResponse
Default
SmtpResponse implementation. |
interface |
LastSmtpContent
The last part of a sequence of
SmtpContent s that are sent after a DATA request. |
class |
SmtpCommand
The command part of a
SmtpRequest . |
interface |
SmtpContent
Content that is sent after the
DATA request. |
interface |
SmtpRequest
An SMTP request.
|
class |
SmtpRequestEncoder
Encoder for SMTP requests.
|
class |
SmtpRequests
Provides utility methods to create
SmtpRequest s. |
interface |
SmtpResponse
A SMTP response
|
class |
SmtpResponseDecoder
Decoder for SMTP responses.
|
Modifier and Type | Method and Description |
---|---|
SslContextBuilder |
SslContextBuilder.enableOcsp(boolean enableOcsp)
Enables OCSP stapling.
|
byte[] |
ReferenceCountedOpenSslEngine.getOcspResponse()
Returns the OCSP response or
null if the server didn't provide a stapled OCSP response. |
void |
ReferenceCountedOpenSslEngine.setOcspResponse(byte[] response)
Sets the OCSP response.
|
void |
ReferenceCountedOpenSslEngine.setVerify(int verifyMode,
int depth)
|
void |
SslHandler.setWrapDataSize(int wrapDataSize)
Sets the number of bytes to pass to each
SSLEngine.wrap(ByteBuffer[], int, int, ByteBuffer) call. |
Modifier and Type | Class and Description |
---|---|
class |
OcspClientHandler
A handler for SSL clients to handle and act upon stapled OCSP responses.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractAddressResolver<T extends SocketAddress>
A skeletal
AddressResolver implementation. |
interface |
AddressResolver<T extends SocketAddress>
Resolves a possibility unresolved
SocketAddress . |
class |
AddressResolverGroup<T extends SocketAddress>
Creates and manages
NameResolver s so that each EventExecutor has its own resolver instance. |
class |
CompositeNameResolver<T>
A composite
SimpleNameResolver that resolves a host name against a sequence of NameResolver s. |
class |
DefaultAddressResolverGroup
|
class |
DefaultHostsFileEntriesResolver
Default
HostsFileEntriesResolver that resolves hosts file entries only once. |
class |
DefaultNameResolver
A
InetNameResolver that resolves using JDK's built-in domain name lookup mechanism. |
class |
HostsFileEntries
A container of hosts file entries
|
interface |
HostsFileEntriesResolver
Resolves a hostname against the hosts file entries.
|
class |
HostsFileParser
A parser for hosts files.
|
class |
InetNameResolver
A skeletal
NameResolver implementation that resolves InetAddress . |
class |
InetSocketAddressResolver
A
AbstractAddressResolver that resolves InetSocketAddress . |
interface |
NameResolver<T>
Resolves an arbitrary string that represents the name of an endpoint into an address.
|
class |
NoopAddressResolver
A
AddressResolver that does not perform any resolution but always reports successful resolution. |
class |
NoopAddressResolverGroup
|
class |
ResolvedAddressTypes
Defined resolved address types.
|
class |
RoundRobinInetAddressResolver
A
NameResolver that resolves InetAddress and force Round Robin by choosing a single address
randomly in SimpleNameResolver.resolve(String) and SimpleNameResolver.resolve(String, Promise)
if multiple are returned by the NameResolver . |
class |
SimpleNameResolver<T>
A skeletal
NameResolver implementation. |
Modifier and Type | Class and Description |
---|---|
class |
BiDnsQueryLifecycleObserver
Combines two
DnsQueryLifecycleObserver into a single DnsQueryLifecycleObserver . |
class |
BiDnsQueryLifecycleObserverFactory
Combines two
DnsQueryLifecycleObserverFactory into a single DnsQueryLifecycleObserverFactory . |
class |
DefaultDnsCache
Default implementation of
DnsCache , backed by a ConcurrentMap . |
class |
DefaultDnsServerAddressStreamProvider
A
DnsServerAddressStreamProvider which will use predefined default DNS servers to use for DNS resolution. |
class |
DnsAddressResolverGroup
|
interface |
DnsCache
A cache for DNS resolution entries.
|
interface |
DnsCacheEntry
Represents the results from a previous DNS query which can be cached.
|
class |
DnsNameResolver
A DNS-based
InetNameResolver . |
class |
DnsNameResolverBuilder
A
DnsNameResolver builder. |
class |
DnsNameResolverException
A
RuntimeException raised when DnsNameResolver failed to perform a successful query. |
interface |
DnsQueryLifecycleObserver
This interface provides visibility into individual DNS queries.
|
interface |
DnsQueryLifecycleObserverFactory
Used to generate new instances of
DnsQueryLifecycleObserver . |
class |
DnsServerAddresses
Provides an infinite sequence of DNS server addresses to
DnsNameResolver . |
interface |
DnsServerAddressStream
An infinite stream of DNS server addresses.
|
interface |
DnsServerAddressStreamProvider
Provides an opportunity to override which
DnsServerAddressStream is used to resolve a specific hostname. |
class |
DnsServerAddressStreamProviders
Utility methods related to
DnsServerAddressStreamProvider . |
class |
MultiDnsServerAddressStreamProvider
A
DnsServerAddressStreamProvider which iterates through a collection of
DnsServerAddressStreamProvider until the first non-null result is found. |
class |
NoopDnsCache
A noop DNS cache that actually never caches anything.
|
class |
NoopDnsQueryLifecycleObserverFactory |
class |
RoundRobinDnsAddressResolverGroup
A
AddressResolverGroup of DnsNameResolver s that supports random selection of destination addresses if
multiple are provided by the nameserver. |
class |
SequentialDnsServerAddressStreamProvider
A
DnsServerAddressStreamProvider which is backed by a sequential list of DNS servers. |
class |
SingletonDnsServerAddressStreamProvider
A
DnsServerAddressStreamProvider which always uses a single DNS server for resolution. |
class |
UnixResolverDnsServerAddressStreamProvider
Able to parse files such as /etc/resolv.conf and
/etc/resolver to respect the system default domain servers.
|
Modifier and Type | Class and Description |
---|---|
class |
DefaultEventExecutorChooserFactory
Default implementation which uses simple round-robin to choose next
EventExecutor . |
interface |
EventExecutorChooserFactory
Factory that creates new
EventExecutorChooserFactory.EventExecutorChooser s. |
static interface |
EventExecutorChooserFactory.EventExecutorChooser
Chooses the next
EventExecutor to use. |
class |
NonStickyEventExecutorGroup
EventExecutorGroup which will preserve Runnable execution order but makes no guarantees about what
EventExecutor (and therefore Thread ) will be used to execute the Runnable s. |
Modifier and Type | Method and Description |
---|---|
protected void |
SingleThreadEventExecutor.afterRunningAllTasks()
Invoked before returning from
SingleThreadEventExecutor.runAllTasks() and SingleThreadEventExecutor.runAllTasks(long) . |
Copyright © 2008–2017 The Netty Project. All rights reserved.