Uses of Class
io.netty.util.internal.UnstableApi
-
Packages that use UnstableApi 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.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.handler.codec.dns DNS codec.io.netty.handler.codec.http Encoder, decoder and their related message types for HTTP.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 SSL · TLS implementation based onSSLEngineio.netty.util.concurrent Utility classes for concurrent / async tasks. -
Packages with annotations of type UnstableApi Package Description io.netty.handler.codec.memcache.binary Implementations and Interfaces for the Memcache Binary protocol.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.redis Encoder, decoder for Redis.io.netty.handler.codec.smtp SMTP codec. -
-
Uses of UnstableApi in io.netty.channel
Classes in io.netty.channel with annotations of type UnstableApi Modifier and Type Class Description classAbstractCoalescingBufferQueueclassDelegatingChannelPromiseNotifierclassPreferHeapByteBufAllocatorWraps anotherByteBufAllocatorand use heapbuffers everywhere except when a direct buffer is explicit requested.static interfaceRecvByteBufAllocator.ExtendedHandleclassVoidChannelPromiseMethods in io.netty.channel with annotations of type UnstableApi Modifier and Type Method Description protected voidDefaultChannelPipeline. decrementPendingOutboundBytes(long size)protected voidAbstractChannel. doShutdownOutput()Called when conditions justify shutting down the output portion of the channel.voidSingleThreadEventLoop. executeAfterEventLoopIteration(java.lang.Runnable task)Adds a task to be run once at the end of next (or current)eventloopiteration.protected voidDefaultChannelPipeline. incrementPendingOutboundBytes(long size)intSingleThreadEventLoop. registeredChannels()(package private) booleanSingleThreadEventLoop. removeAfterEventLoopIterationTask(java.lang.Runnable task)Removes a task that was added previously viaSingleThreadEventLoop.executeAfterEventLoopIteration(Runnable).voidAbstractChannel.AbstractUnsafe. shutdownOutput(ChannelPromise promise)Shutdown the output portion of the correspondingChannel.Constructors in io.netty.channel with annotations of type UnstableApi Constructor Description ChannelException(java.lang.String message, java.lang.Throwable cause, boolean shared) -
Uses of UnstableApi in io.netty.channel.socket
Classes in io.netty.channel.socket with annotations of type UnstableApi Modifier and Type Class Description classChannelOutputShutdownEventSpecial event which will be fired and passed to theChannelInboundHandler.userEventTriggered(ChannelHandlerContext, Object)methods once the output of aSocketChannelwas shutdown.classChannelOutputShutdownExceptionUsed 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 Modifier and Type Method Description protected voidNioSocketChannel. doShutdownOutput() -
Uses of UnstableApi in io.netty.channel.socket.oio
Methods in io.netty.channel.socket.oio with annotations of type UnstableApi Modifier and Type Method Description protected voidOioSocketChannel. doShutdownOutput()Deprecated. -
Uses of UnstableApi in io.netty.handler.codec.dns
Classes in io.netty.handler.codec.dns with annotations of type UnstableApi Modifier and Type Class Description classAbstractDnsMessageA skeletal implementation ofDnsMessage.classAbstractDnsOptPseudoRrRecordAn OPT RR record.classAbstractDnsRecordA skeletal implementation ofDnsRecord.classDatagramDnsQueryADnsQueryimplementation for UDP/IP.classDatagramDnsQueryDecoderDecodes aDatagramPacketinto aDatagramDnsQuery.classDatagramDnsQueryEncoderclassDatagramDnsResponseADnsResponseimplementation for UDP/IP.classDatagramDnsResponseDecoderDecodes aDatagramPacketinto aDatagramDnsResponse.classDatagramDnsResponseEncoderclassDefaultDnsOptEcsRecordDefaultDnsOptEcsRecordimplementation.classDefaultDnsPtrRecordclassDefaultDnsQueryThe defaultDnsQueryimplementation.classDefaultDnsQuestionThe defaultDnsQuestionimplementation.classDefaultDnsRawRecordThe defaultDnsRawRecordimplementation.classDefaultDnsRecordDecoderThe defaultDnsRecordDecoderimplementation.classDefaultDnsRecordEncoderThe defaultDnsRecordEncoderimplementation.classDefaultDnsResponseThe defaultDnsResponseimplementation.interfaceDnsMessageThe superclass which contains core information concerning aDnsQueryand aDnsResponse.classDnsOpCodeThe DNSOpCodeas defined in RFC2929.interfaceDnsOptEcsRecordAn ECS record as defined in Client Subnet in DNS Queries.interfaceDnsOptPseudoRecordAn OPT RR record.interfaceDnsPtrRecordinterfaceDnsQueryA DNS query message.interfaceDnsQuestionA DNS question.interfaceDnsRawRecordA genericDnsRecordthat contains an undecodedRDATA.interfaceDnsRecordA DNS resource record.interfaceDnsRecordDecoderDecodes a DNS record into its object representation.interfaceDnsRecordEncoderEncodes aDnsRecordinto binary representation.classDnsRecordTypeRepresents a DNS record type.interfaceDnsResponseA DNS response message.classDnsResponseCodeThe DNSRCODE, as defined in RFC2929.classDnsSectionRepresents a section of aDnsMessage.classTcpDnsQueryEncoderclassTcpDnsResponseDecoder -
Uses of UnstableApi in io.netty.handler.codec.http
Classes in io.netty.handler.codec.http with annotations of type UnstableApi Modifier and Type Class Description classReadOnlyHttpHeadersA variant ofHttpHeaderswhich only supports read-only methods. -
Uses of UnstableApi in io.netty.handler.codec.http2
Classes in io.netty.handler.codec.http2 with annotations of type UnstableApi Modifier and Type Class Description classAbstractHttp2ConnectionHandlerBuilder<T extends Http2ConnectionHandler,B extends AbstractHttp2ConnectionHandlerBuilder<T,B>>Abstract base class which defines commonly used features required to buildHttp2ConnectionHandlerinstances.classAbstractHttp2StreamFrameAbstract implementation ofHttp2StreamFrame.classAbstractInboundHttp2ToHttpAdapterBuilder<T extends InboundHttp2ToHttpAdapter,B extends AbstractInboundHttp2ToHttpAdapterBuilder<T,B>>A skeletal builder implementation ofInboundHttp2ToHttpAdapterand its subtypes.classCharSequenceMap<V>Internal use only!classCleartextHttp2ServerUpgradeHandlerPerforming cleartext upgrade, by h2c HTTP upgrade or Prior Knowledge.classCompressorHttp2ConnectionEncoderA decorating HTTP2 encoder that will compress data frames according to thecontent-encodingheader for each stream.classDecoratingHttp2ConnectionDecoderDecorator around anotherHttp2ConnectionDecoderinstance.classDecoratingHttp2ConnectionEncoderA decorator around anotherHttp2ConnectionEncoderinstance.classDecoratingHttp2FrameWriterDecorator around anotherHttp2FrameWriterinstance.classDefaultHttp2ConnectionSimple implementation ofHttp2Connection.classDefaultHttp2ConnectionDecoderProvides the default implementation for processing inbound frame events and delegates to aHttp2FrameListenerclassDefaultHttp2ConnectionEncoderDefault implementation ofHttp2ConnectionEncoder.classDefaultHttp2DataFrameThe defaultHttp2DataFrameimplementation.classDefaultHttp2FrameReaderAHttp2FrameReaderthat supports all frame types defined by the HTTP/2 specification.classDefaultHttp2FrameWriterAHttp2FrameWriterthat supports all frame types defined by the HTTP/2 specification.classDefaultHttp2GoAwayFrameThe defaultHttp2GoAwayFrameimplementation.classDefaultHttp2HeadersclassDefaultHttp2HeadersDecoderclassDefaultHttp2HeadersEncoderclassDefaultHttp2HeadersFrameThe defaultHttp2HeadersFrameimplementation.classDefaultHttp2LocalFlowControllerBasic implementation ofHttp2LocalFlowController.classDefaultHttp2PingFrameThe defaultHttp2PingFrameimplementation.classDefaultHttp2RemoteFlowControllerBasic implementation ofHttp2RemoteFlowController.classDefaultHttp2ResetFrameThe defaultHttp2ResetFrameimplementation.classDefaultHttp2SettingsFrameThe defaultHttp2SettingsFrameimplementation.classDefaultHttp2UnknownFrameclassDefaultHttp2WindowUpdateFrameThe defaultHttp2WindowUpdateFrameimplementation.classDelegatingDecompressorFrameListenerAn HTTP2 frame listener that will decompress data frames according to thecontent-encodingheader for each stream.classEmptyHttp2HeadersclassHttp2ChannelDuplexHandlerAChannelDuplexHandlerproviding additional functionality for HTTP/2.classHttp2ClientUpgradeCodecClient-side cleartext upgrade codec from HTTP to HTTP/2.classHttp2CodecUtilConstants and utility method used for encoding/decoding HTTP2 frames.interfaceHttp2ConnectionManager for the state of an HTTP/2 connection with the remote end-point.classHttp2ConnectionAdapterProvides empty implementations of allHttp2Connection.Listenermethods.interfaceHttp2ConnectionDecoderHandler for inbound traffic on behalf ofHttp2ConnectionHandler.interfaceHttp2ConnectionEncoderHandler for outbound HTTP/2 traffic.classHttp2ConnectionHandlerProvides the default implementation for processing inbound frame events and delegates to aHttp2FrameListenerclassHttp2ConnectionHandlerBuilderBuilder which buildsHttp2ConnectionHandlerobjects.classHttp2ConnectionPrefaceAndSettingsFrameWrittenEventSignifies that the connection preface and the initial SETTINGS frame have been sent.interfaceHttp2DataFrameHTTP/2 DATA frame.interfaceHttp2DataWriterInterface that defines an object capable of producing HTTP/2 data frames.classHttp2ErrorAll error codes identified by the HTTP/2 spec.classHttp2EventAdapterThis class bringsHttp2Connection.ListenerandHttp2FrameListenertogether to provide NOOP implementation so inheriting classes can selectively choose which methods to override.classHttp2ExceptionException thrown when an HTTP/2 error was encountered.classHttp2FlagsProvides utility methods for accessing specific flags as defined by the HTTP/2 spec.interfaceHttp2FlowControllerBase interface for all HTTP/2 flow controllers.interfaceHttp2FrameAn HTTP/2 frame.classHttp2FrameAdapterConvenience class that provides no-op implementations for all methods ofHttp2FrameListener.classHttp2FrameCodecThis API is very immature. The Http2Connection-based API is currently preferred over this API.classHttp2FrameCodecBuilderBuilder for theHttp2FrameCodec.interfaceHttp2FrameListenerAn listener of HTTP/2 frames.classHttp2FrameListenerDecoratorProvides a decorator around aHttp2FrameListenerand delegates all method callsclassHttp2FrameLoggerLogs HTTP2 frames for debugging purposes.interfaceHttp2FrameReaderReads HTTP/2 frames from an inputByteBufand notifies the specifiedHttp2FrameListenerwhen frames are complete.interfaceHttp2FrameSizePolicyinterfaceHttp2FrameStreamA single stream within an HTTP/2 connection.classHttp2FrameStreamEventclassHttp2FrameStreamExceptionAn HTTP/2 exception for a specificHttp2FrameStream.interfaceHttp2FrameStreamVisitorA visitor that allows to iterate over a collection ofHttp2FrameStreams.classHttp2FrameTypesRegistry of all standard frame types defined by the HTTP/2 specification.interfaceHttp2FrameWriterA writer responsible for marshaling HTTP/2 frames to the channel.interfaceHttp2GoAwayFrameHTTP/2 GOAWAY frame.interfaceHttp2HeadersA collection of headers sent or received via HTTP/2.interfaceHttp2HeadersDecoderDecodes HPACK-encoded headers blocks intoHttp2Headers.interfaceHttp2HeadersEncoderEncodesHttp2Headersinto HPACK-encoded headers blocks.interfaceHttp2HeadersFrameHTTP/2 HEADERS frame.classHttp2InboundFrameLoggerDecorator around aHttp2FrameReaderthat logs all inbound frames before calling back the listener.interfaceHttp2LifecycleManagerManager for the life cycle of the HTTP/2 connection.interfaceHttp2LocalFlowControllerAHttp2FlowControllerfor controlling the inbound flow ofDATAframes from the remote endpoint.classHttp2MultiplexCodecDeprecated.useHttp2FrameCodecBuildertogether withHttp2MultiplexHandler.classHttp2MultiplexCodecBuilderDeprecated.useHttp2FrameCodecBuildertogether withHttp2MultiplexHandler.classHttp2MultiplexHandlerAn HTTP/2 handler that creates child channels for each stream.classHttp2NoMoreStreamIdsExceptionThis exception is thrown when there are no more stream IDs available for the current connectionclassHttp2OutboundFrameLoggerDecorator around aHttp2FrameWriterthat logs all outbound frames before calling the writer.interfaceHttp2PingFrameHTTP/2 PING Frame.interfaceHttp2PromisedRequestVerifierProvides an extensibility point for users to define the validity of push requests.interfaceHttp2RemoteFlowControllerAHttp2FlowControllerfor controlling the flow of outboundDATAframes to the remote endpoint.interfaceHttp2ResetFrameHTTP/2 RST_STREAM frame.classHttp2SecurityUtilProvides utilities related to security requirements specific to HTTP/2.classHttp2ServerUpgradeCodecServer-side codec for performing a cleartext upgrade from HTTP/1.x to HTTP/2.classHttp2SettingsSettings for one endpoint in an HTTP/2 connection.interfaceHttp2StreamA single stream within an HTTP2 connection.interfaceHttp2StreamChannelclassHttp2StreamChannelBootstrapinterfaceHttp2StreamFrameA frame whose meaning may apply to a particular stream, instead of the entire connection.classHttp2StreamFrameToHttpObjectCodecThis handler converts fromHttp2StreamFrametoHttpObject, and back.interfaceHttp2StreamVisitorA visitor that allows iteration over a collection of streams.interfaceHttp2UnknownFrameinterfaceHttp2WindowUpdateFrameHTTP/2 WINDOW_UPDATE frame.classHttpConversionUtilProvides utility methods and constants for the HTTP/2 to HTTP conversionclassHttpToHttp2ConnectionHandlerTranslates HTTP/1.x object writes into HTTP/2 frames.classHttpToHttp2ConnectionHandlerBuilderBuilder which buildsHttpToHttp2ConnectionHandlerobjects.classInboundHttp2ToHttpAdapterThis adapter provides just header/data events from the HTTP message flow defined in [RFC 7540], Section 8.1.classInboundHttp2ToHttpAdapterBuilderBuilds anInboundHttp2ToHttpAdapter.classInboundHttpToHttp2AdapterTranslates HTTP/1.x object reads into HTTP/2 frames.classStreamBufferingEncoderImplementation of aHttp2ConnectionEncoderthat dispatches all method call to anotherHttp2ConnectionEncoder, untilSETTINGS_MAX_CONCURRENT_STREAMSis reached.interfaceStreamByteDistributorAn object (used by remote flow control) that is responsible for distributing the bytes to be written across the streams in the connection.classUniformStreamByteDistributorAStreamByteDistributorthat ignores stream priority and uniformly allocates bytes to all streams.classWeightedFairQueueByteDistributorAStreamByteDistributorthat 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 UnstableApi Modifier and Type Class Description classAbstractMemcacheObjectThe defaultMemcacheObjectimplementation.classAbstractMemcacheObjectAggregator<H extends MemcacheMessage>AChannelHandlerthat aggregates anMemcacheMessageand its followingMemcacheContents into a singleMemcacheMessagewith no followingMemcacheContents.classAbstractMemcacheObjectDecoderAbstract super class for both ascii and binary decoders.classAbstractMemcacheObjectEncoder<M extends MemcacheMessage>A general purposeAbstractMemcacheObjectEncoderthat encodesMemcacheMessages.classDefaultLastMemcacheContentThe default implementation for theLastMemcacheContent.classDefaultMemcacheContentThe defaultMemcacheContentimplementation.interfaceFullMemcacheMessageCombinesMemcacheMessageandLastMemcacheContentinto one message.interfaceLastMemcacheContentTheMemcacheContentwhich signals the end of the content batch.interfaceMemcacheContentAn Memcache content chunk.interfaceMemcacheMessageMarker interface for both ascii and binary messages.interfaceMemcacheObjectDefines a common interface for allMemcacheObjectimplementations. -
Uses of UnstableApi in io.netty.handler.codec.memcache.binary
Classes in io.netty.handler.codec.memcache.binary with annotations of type UnstableApi Modifier and Type Class Description classAbstractBinaryMemcacheDecoder<M extends BinaryMemcacheMessage>Decoder for bothBinaryMemcacheRequestandBinaryMemcacheResponse.classAbstractBinaryMemcacheEncoder<M extends BinaryMemcacheMessage>AMessageToByteEncoderthat encodes binary memcache messages into bytes.classAbstractBinaryMemcacheMessageDefault implementation of aBinaryMemcacheMessage.classBinaryMemcacheClientCodecThe client codec that combines the proper encoder and decoder.interfaceBinaryMemcacheMessageAn interface that defines a binary Memcache message, providing common properties forBinaryMemcacheRequestandBinaryMemcacheResponse.classBinaryMemcacheObjectAggregatorAn object aggregator for the memcache binary protocol.classBinaryMemcacheOpcodesRepresents all Opcodes that can occur in aBinaryMemcacheMessage.interfaceBinaryMemcacheRequestRepresents a fullBinaryMemcacheRequest, which contains the header and optional key and extras.classBinaryMemcacheRequestDecoderThe decoder part which takes care of decoding the request-specific headers.classBinaryMemcacheRequestEncoderThe encoder part which takes care of encoding the request headers.interfaceBinaryMemcacheResponseRepresents a fullBinaryMemcacheResponse, which contains the header and optional key and extras.classBinaryMemcacheResponseDecoderThe decoder which takes care of decoding the response headers.classBinaryMemcacheResponseEncoderThe encoder which takes care of encoding the response headers.classBinaryMemcacheResponseStatusContains all possible status values aBinaryMemcacheResponsecan return.classBinaryMemcacheServerCodecThe full server codec that combines the correct encoder and decoder.classDefaultBinaryMemcacheRequestThe default implementation of theBinaryMemcacheRequest.classDefaultBinaryMemcacheResponseThe default implementation of theBinaryMemcacheResponse.classDefaultFullBinaryMemcacheRequestThe default implementation of aFullBinaryMemcacheRequest.classDefaultFullBinaryMemcacheResponseThe default implementation of aFullBinaryMemcacheResponse.interfaceFullBinaryMemcacheRequestABinaryMemcacheRequestthat also includes the content.interfaceFullBinaryMemcacheResponseABinaryMemcacheResponsethat also includes the content. -
Uses of UnstableApi in io.netty.handler.codec.redis
Classes in io.netty.handler.codec.redis with annotations of type UnstableApi Modifier and Type Class Description classAbstractStringRedisMessageAbstract class for Simple Strings or Errors.classArrayHeaderRedisMessageHeader of Redis Array Message.classArrayRedisMessageArrays of RESP.classBulkStringHeaderRedisMessageThe header of Bulk Strings in RESP.interfaceBulkStringRedisContentA chunk of bulk strings which is used for Redis chunked transfer-encoding.classDefaultBulkStringRedisContentA default implementation ofBulkStringRedisContent.classDefaultLastBulkStringRedisContentA default implementation forLastBulkStringRedisContent.classErrorRedisMessageErrors of RESP.classFixedRedisMessagePoolA default fixed redis message pool.classFullBulkStringRedisMessageAn aggregated bulk string of RESP.classInlineCommandRedisMessageInline commands of RESP.classIntegerRedisMessageIntegers of RESP.interfaceLastBulkStringRedisContentA last chunk of Bulk Strings.classRedisArrayAggregatorAggregatesRedisMessageparts intoArrayRedisMessage.classRedisBulkStringAggregatorAChannelHandlerthat aggregates anBulkStringHeaderRedisMessageand its followingBulkStringRedisContents into a singleFullBulkStringRedisMessagewith no followingBulkStringRedisContents.classRedisCodecExceptionclassRedisDecoderDecodes the Redis protocol intoRedisMessageobjects following RESP (REdis Serialization Protocol).classRedisEncoderEncodesRedisMessageinto bytes following RESP (REdis Serialization Protocol).interfaceRedisMessageRedisMessage is base interface for codec-redis.interfaceRedisMessagePoolA strategy interface for cachingRedisMessages.classRedisMessageTypeType of RESP (REdis Serialization Protocol).classSimpleStringRedisMessageSimple Strings of RESP. -
Uses of UnstableApi in io.netty.handler.codec.smtp
Classes in io.netty.handler.codec.smtp with annotations of type UnstableApi Modifier and Type Class Description classDefaultLastSmtpContentDefault implementation ofLastSmtpContentthat does no validation of the raw data passed in.classDefaultSmtpContentDefault implementation ofSmtpContentthat does no validation of the raw data passed in.classDefaultSmtpRequestDefaultSmtpRequestimplementation.classDefaultSmtpResponseDefaultSmtpResponseimplementation.interfaceLastSmtpContentThe last part of a sequence ofSmtpContents that are sent after aDATArequest.classSmtpCommandThe command part of aSmtpRequest.interfaceSmtpContentContent that is sent after theDATArequest.interfaceSmtpRequestAn SMTP request.classSmtpRequestEncoderEncoder for SMTP requests.classSmtpRequestsProvides utility methods to createSmtpRequests.interfaceSmtpResponseA SMTP responseclassSmtpResponseDecoderDecoder for SMTP responses. -
Uses of UnstableApi in io.netty.handler.ssl
Classes in io.netty.handler.ssl with annotations of type UnstableApi Modifier and Type Class Description classSniCompletionEventEvent that is fired once we did a selection of aSslContextbased 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 UnstableApi Modifier and Type Method Description SslContextBuilderSslContextBuilder. enableOcsp(boolean enableOcsp)Enables OCSP stapling.voidSslHandler. setWrapDataSize(int wrapDataSize)Sets the number of bytes to pass to eachSSLEngine.wrap(ByteBuffer[], int, int, ByteBuffer)call. -
Uses of UnstableApi in io.netty.util.concurrent
Classes in io.netty.util.concurrent with annotations of type UnstableApi Modifier and Type Interface Description static interfaceAbstractEventExecutor.LazyRunnableMarker interface forRunnableto indicate that it should be queued for execution but does not need to run immediately.classDefaultEventExecutorChooserFactoryDefault implementation which uses simple round-robin to choose nextEventExecutor.interfaceEventExecutorChooserFactoryFactory that creates newEventExecutorChooserFactory.EventExecutorChoosers.static interfaceEventExecutorChooserFactory.EventExecutorChooserChooses the nextEventExecutorto use.classNonStickyEventExecutorGroupEventExecutorGroupwhich will preserveRunnableexecution order but makes no guarantees about whatEventExecutor(and thereforeThread) will be used to execute theRunnables.Methods in io.netty.util.concurrent with annotations of type UnstableApi Modifier and Type Method Description protected voidSingleThreadEventExecutor. afterRunningAllTasks()Invoked before returning fromSingleThreadEventExecutor.runAllTasks()andSingleThreadEventExecutor.runAllTasks(long).protected longSingleThreadEventExecutor. deadlineNanos()Returns the absolute point in time (relative toAbstractScheduledEventExecutor.nanoTime()) at which the the next closest scheduled task should run.voidAbstractEventExecutor. lazyExecute(java.lang.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.booleanFastThreadLocalThread. willCleanupFastThreadLocals()static booleanFastThreadLocalThread. willCleanupFastThreadLocals(java.lang.Thread thread)
-