Top Deprecated
Netty 4.1.107.Final

Deprecated API


No API in this release is deprecated for removal.

Deprecated Item Summary

SinceDeprecated Item and Description
io.netty.bootstrap.AbstractBootstrap.channelFactory

Deprecated as a consequence of ChannelFactory being deprecated. See corresponding docs for further information.

io.netty.bootstrap.AbstractBootstrap.channelFactory(ChannelFactory<? extends C> channelFactory)

Deprecated as a consequence of ChannelFactory being deprecated. See corresponding docs for further information.

io.netty.bootstrap.AbstractBootstrap.channelFactory()

Deprecated as a consequence of ChannelFactory being deprecated. See corresponding docs for further information.

io.netty.bootstrap.AbstractBootstrapConfig.channelFactory()

Deprecated as a consequence of ChannelFactory being deprecated. See corresponding docs for further information.

io.netty.buffer.AbstractByteBuf.newSwappedByteBuf()

Deprecated as a consequence of SwappedByteBuf being deprecated. See corresponding docs for further information.

io.netty.buffer.AbstractPooledDerivedByteBuf.PooledNonRetainedDuplicateByteBuf

Deprecated as a consequence of UnpooledDuplicatedByteBuf being deprecated. See corresponding docs for further information.

io.netty.buffer.AbstractPooledDerivedByteBuf.PooledNonRetainedSlicedByteBuf

Deprecated as a consequence of UnpooledSlicedByteBuf being deprecated. See corresponding docs for further information.

io.netty.buffer.AbstractUnpooledSlicedByteBuf

Deprecated as a consequence of AbstractDerivedByteBuf being deprecated.

io.netty.buffer.AbstractUnsafeSwappedByteBuf

Deprecated as a consequence of SwappedByteBuf being deprecated.

io.netty.buffer.ByteBuf.order()

use the Little Endian accessors, e.g. getShortLE, getIntLE instead of creating a buffer with swapped endianness.

io.netty.buffer.ByteBuf.order(ByteOrder endianness)

use the Little Endian accessors, e.g. getShortLE, getIntLE instead of creating a buffer with swapped endianness.

io.netty.buffer.PoolArenaMetric.numActiveTinyAllocations()

Tiny allocations have been merged into small allocations.

io.netty.buffer.PoolArenaMetric.numTinyAllocations()

Tiny allocations have been merged into small allocations.

io.netty.buffer.PoolArenaMetric.numTinyDeallocations()

Tiny deallocations have been merged into small deallocations.

io.netty.buffer.PoolArenaMetric.numTinySubpages()

Tiny sub-pages have been merged into small sub-pages.

io.netty.buffer.PoolArenaMetric.tinySubpages()

Tiny sub-pages have been merged into small sub-pages.

io.netty.buffer.PooledByteBufAllocator(boolean preferDirect, int nHeapArena, int nDirectArena, int pageSize, int maxOrder)

use PooledByteBufAllocator#PooledByteBufAllocator(boolean, int, int, int, int, int, int, boolean)

io.netty.buffer.PooledByteBufAllocator(boolean preferDirect, int nHeapArena, int nDirectArena, int pageSize, int maxOrder, int tinyCacheSize, int smallCacheSize, int normalCacheSize)

use PooledByteBufAllocator#PooledByteBufAllocator(boolean, int, int, int, int, int, int, boolean)

io.netty.buffer.PooledByteBufAllocator(boolean preferDirect, int nHeapArena, int nDirectArena, int pageSize, int maxOrder, int tinyCacheSize, int smallCacheSize, int normalCacheSize, boolean useCacheForAllThreads)

use PooledByteBufAllocator#PooledByteBufAllocator(boolean, int, int, int, int, int, int, boolean)

io.netty.buffer.PooledByteBufAllocator(boolean preferDirect, int nHeapArena, int nDirectArena, int pageSize, int maxOrder, int tinyCacheSize, int smallCacheSize, int normalCacheSize, boolean useCacheForAllThreads, int directMemoryCacheAlignment)

use PooledByteBufAllocator#PooledByteBufAllocator(boolean, int, int, int, int, int, int, boolean, int)

io.netty.buffer.PooledByteBufAllocator.defaultTinyCacheSize()

Tiny caches have been merged into small caches.

io.netty.buffer.PooledByteBufAllocator.freeThreadLocalCache()

will be removed Free all cached buffers for the calling Thread.

io.netty.buffer.PooledByteBufAllocator.hasThreadLocalCache()

will be removed Returns true if the calling Thread has a ThreadLocal cache for the allocated buffers.

io.netty.buffer.PooledByteBufAllocatorMetric.tinyCacheSize()

Tiny caches have been merged into small caches.

io.netty.buffer.PooledUnsafeDirectByteBuf.newSwappedByteBuf()

Deprecated as a consequence of SwappedByteBuf being deprecated. See corresponding docs for further information.

io.netty.buffer.SwappedByteBuf

use the Little Endian accessors, e.g. getShortLE, getIntLE instead.

io.netty.buffer.UnpooledDuplicatedByteBuf

Deprecated as a consequence of DuplicatedByteBuf being deprecated.

io.netty.buffer.UnpooledSlicedByteBuf

Deprecated as a consequence of AbstractUnpooledSlicedByteBuf being deprecated.

io.netty.buffer.UnpooledUnsafeDirectByteBuf.newSwappedByteBuf()

Deprecated as a consequence of SwappedByteBuf being deprecated. See corresponding docs for further information.

io.netty.buffer.UnreleasableByteBuf.swappedBuf

Deprecated as a consequence of SwappedByteBuf being deprecated. See corresponding docs for further information.

io.netty.buffer.UnsafeDirectSwappedByteBuf

Deprecated as a consequence of AbstractUnsafeSwappedByteBuf being deprecated.

io.netty.buffer.UnsafeHeapSwappedByteBuf

Deprecated as a consequence of AbstractUnsafeSwappedByteBuf being deprecated.

io.netty.buffer.WrappedCompositeByteBuf.newSwappedByteBuf()

Deprecated as a consequence of SwappedByteBuf being deprecated. See corresponding docs for further information.

io.netty.channel.AbstractChannel.AbstractUnsafe.recvBufAllocHandle()

Deprecated as a consequence of RecvByteBufAllocator.Handle being deprecated. See corresponding docs for further information.

io.netty.channel.AbstractChannel.AbstractUnsafe.recvHandle

Deprecated as a consequence of RecvByteBufAllocator.Handle being deprecated. See corresponding docs for further information.

io.netty.channel.AdaptiveRecvByteBufAllocator.DEFAULT

There is state for maxMessagesPerRead() which is typically based upon channel type.

io.netty.channel.AdaptiveRecvByteBufAllocator.HandleImpl

Deprecated as a consequence of DefaultMaxMessagesRecvByteBufAllocator.MaxMessageHandle being deprecated. See corresponding docs for further information.

io.netty.channel.AdaptiveRecvByteBufAllocator.newHandle()

Deprecated as a consequence of RecvByteBufAllocator.Handle being deprecated. See corresponding docs for further information.

io.netty.channel.Channel.Unsafe.recvBufAllocHandle()

Deprecated as a consequence of RecvByteBufAllocator.Handle being deprecated. See corresponding docs for further information.

io.netty.channel.ChannelConfig.getMaxMessagesPerRead()

Use MaxMessagesRecvByteBufAllocator and MaxMessagesRecvByteBufAllocator#maxMessagesPerRead().

Returns the maximum number of messages to read per read loop. a channelRead() event. If this value is greater than 1, an event loop might attempt to read multiple times to procure multiple messages.

io.netty.channel.ChannelConfig.setMaxMessagesPerRead(int maxMessagesPerRead)

Use MaxMessagesRecvByteBufAllocator and MaxMessagesRecvByteBufAllocator#maxMessagesPerRead(int).

Sets the maximum number of messages to read per read loop. If this value is greater than 1, an event loop might attempt to read multiple times to procure multiple messages.

io.netty.channel.ChannelFactory<T extends Channel>

Deprecated as a consequence of ChannelFactory being deprecated.

io.netty.channel.ChannelHandler.exceptionCaught(ChannelHandlerContext ctx, Throwable cause)

if you want to handle this event you should implement ChannelInboundHandler and implement the method there.

io.netty.channel.ChannelPromiseAggregator

Use PromiseCombiner Class which is used to consolidate multiple channel futures into one, by listening to the individual futures and producing an aggregated result (success/failure) when all futures have completed.

io.netty.channel.DefaultMaxBytesRecvByteBufAllocator.HandleImpl

Deprecated as a consequence of RecvByteBufAllocator.ExtendedHandle being deprecated. See corresponding docs for further information.

io.netty.channel.DefaultMaxBytesRecvByteBufAllocator.newHandle()

Deprecated as a consequence of RecvByteBufAllocator.Handle being deprecated. See corresponding docs for further information.

io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator.MaxMessageHandle

Deprecated as a consequence of RecvByteBufAllocator.ExtendedHandle being deprecated. See corresponding docs for further information.

io.netty.channel.FixedRecvByteBufAllocator.HandleImpl

Deprecated as a consequence of DefaultMaxMessagesRecvByteBufAllocator.MaxMessageHandle being deprecated. See corresponding docs for further information.

io.netty.channel.FixedRecvByteBufAllocator.newHandle()

Deprecated as a consequence of RecvByteBufAllocator.Handle being deprecated. See corresponding docs for further information.

io.netty.channel.RecvByteBufAllocator.DelegatingHandle

Deprecated as a consequence of RecvByteBufAllocator.Handle being deprecated. See corresponding docs for further information.

io.netty.channel.RecvByteBufAllocator.DelegatingHandle(RecvByteBufAllocator.Handle delegate)

Deprecated as a consequence of RecvByteBufAllocator.Handle being deprecated. See corresponding docs for further information.

io.netty.channel.RecvByteBufAllocator.DelegatingHandle.delegate

Deprecated as a consequence of RecvByteBufAllocator.Handle being deprecated. See corresponding docs for further information.

Returns:

the Handle which all methods will be delegated to.
io.netty.channel.RecvByteBufAllocator.DelegatingHandle.delegate
()

Deprecated as a consequence of RecvByteBufAllocator.Handle being deprecated. See corresponding docs for further information.

io.netty.channel.RecvByteBufAllocator.ExtendedHandle

Deprecated as a consequence of RecvByteBufAllocator.Handle being deprecated. See corresponding docs for further information.

io.netty.channel.RecvByteBufAllocator.newHandle()

Deprecated as a consequence of RecvByteBufAllocator.Handle being deprecated. See corresponding docs for further information.

io.netty.channel.ReflectiveChannelFactory<T extends Channel>

Deprecated as a consequence of ChannelFactory being deprecated.

io.netty.channel.ServerChannelRecvByteBufAllocator.newHandle()

Deprecated as a consequence of RecvByteBufAllocator.Handle being deprecated. See corresponding docs for further information.

io.netty.channel.ThreadPerChannelEventLoop

this will be remove in the next-major release.

io.netty.channel.ThreadPerChannelEventLoop(ThreadPerChannelEventLoopGroup parent)

Deprecated as a consequence of ThreadPerChannelEventLoopGroup being deprecated. See corresponding docs for further information.

io.netty.channel.ThreadPerChannelEventLoop.parent

Deprecated as a consequence of ThreadPerChannelEventLoopGroup being deprecated. See corresponding docs for further information.

io.netty.channel.ThreadPerChannelEventLoopGroup

this will be remove in the next-major release.

io.netty.channel.epoll.AbstractEpollChannel.AbstractEpollUnsafe.allocHandle

Deprecated as a consequence of EpollRecvByteAllocatorHandle being deprecated. See corresponding docs for further information.

io.netty.channel.epoll.AbstractEpollChannel.AbstractEpollUnsafe.newEpollHandle(RecvByteBufAllocator.ExtendedHandle
The handle to wrap with EPOLL specific logic.
handle
)

Deprecated as a consequence of RecvByteBufAllocator.ExtendedHandle and EpollRecvByteAllocatorHandle being deprecated. See corresponding docs for further information.

io.netty.channel.epoll.AbstractEpollChannel.AbstractEpollUnsafe.recvBufAllocHandle()

Deprecated as a consequence of EpollRecvByteAllocatorHandle being deprecated. See corresponding docs for further information.

io.netty.channel.epoll.AbstractEpollStreamChannel.EpollStreamUnsafe.handleReadException(ChannelPipeline pipeline, ByteBuf byteBuf, Throwable cause, boolean close, EpollRecvByteAllocatorHandle allocHandle)

Deprecated as a consequence of EpollRecvByteAllocatorHandle being deprecated. See corresponding docs for further information.

io.netty.channel.epoll.AbstractEpollStreamChannel.EpollStreamUnsafe.newEpollHandle(RecvByteBufAllocator.ExtendedHandle
The handle to wrap with EPOLL specific logic.
handle
)

Deprecated as a consequence of RecvByteBufAllocator.ExtendedHandle and EpollRecvByteAllocatorHandle being deprecated. See corresponding docs for further information.

io.netty.channel.epoll.AbstractEpollStreamChannel.SpliceFdTask.spliceIn(RecvByteBufAllocator.Handle handle)

Deprecated as a consequence of RecvByteBufAllocator.Handle being deprecated. See corresponding docs for further information.

io.netty.channel.epoll.AbstractEpollStreamChannel.SpliceInChannelTask.spliceIn(RecvByteBufAllocator.Handle handle)

Deprecated as a consequence of RecvByteBufAllocator.Handle being deprecated. See corresponding docs for further information.

io.netty.channel.epoll.AbstractEpollStreamChannel.SpliceInTask.spliceIn(RecvByteBufAllocator.Handle handle)

Deprecated as a consequence of RecvByteBufAllocator.Handle being deprecated. See corresponding docs for further information.

io.netty.channel.epoll.AbstractEpollStreamChannel.SpliceInTask.spliceIn(FileDescriptor pipeOut, RecvByteBufAllocator.Handle handle)

Deprecated as a consequence of RecvByteBufAllocator.Handle being deprecated. See corresponding docs for further information.

io.netty.channel.epoll.EpollDatagramChannel.connectedRead(EpollRecvByteAllocatorHandle allocHandle, ByteBuf byteBuf, int maxDatagramPacketSize)

Deprecated as a consequence of EpollRecvByteAllocatorHandle being deprecated. See corresponding docs for further information.

io.netty.channel.epoll.EpollDatagramChannel.processPacket(ChannelPipeline pipeline, EpollRecvByteAllocatorHandle handle, int bytesRead, DatagramPacket packet)

Deprecated as a consequence of EpollRecvByteAllocatorHandle being deprecated. See corresponding docs for further information.

io.netty.channel.epoll.EpollDatagramChannel.processPacketList(ChannelPipeline pipeline, EpollRecvByteAllocatorHandle handle, int bytesRead, RecyclableArrayList packetList)

Deprecated as a consequence of EpollRecvByteAllocatorHandle being deprecated. See corresponding docs for further information.

io.netty.channel.epoll.EpollDatagramChannel.recvmsg(EpollRecvByteAllocatorHandle allocHandle, NativeDatagramPacketArray array, ByteBuf byteBuf)

Deprecated as a consequence of EpollRecvByteAllocatorHandle being deprecated. See corresponding docs for further information.

io.netty.channel.epoll.EpollDatagramChannel.scatteringRead(EpollRecvByteAllocatorHandle allocHandle, NativeDatagramPacketArray array, ByteBuf byteBuf, int datagramSize, int numDatagram)

Deprecated as a consequence of EpollRecvByteAllocatorHandle being deprecated. See corresponding docs for further information.

io.netty.channel.epoll.EpollRecvByteAllocatorHandle(RecvByteBufAllocator.ExtendedHandle handle)

Deprecated as a consequence of RecvByteBufAllocator.ExtendedHandle being deprecated. See corresponding docs for further information.

io.netty.channel.epoll.EpollRecvByteAllocatorStreamingHandle(RecvByteBufAllocator.ExtendedHandle handle)

Deprecated as a consequence of RecvByteBufAllocator.ExtendedHandle being deprecated. See corresponding docs for further information.

io.netty.channel.epoll.Native.epollWait(FileDescriptor epollFd, EpollEventArray events, FileDescriptor timerFd, int timeoutSec, int timeoutNs)

this method is no longer supported. This functionality is internal to this package.

io.netty.channel.epoll.SegmentedDatagramPacket.copy()

Deprecated as a consequence of SegmentedDatagramPacket being deprecated. See corresponding docs for further information.

io.netty.channel.epoll.SegmentedDatagramPacket.duplicate()

Deprecated as a consequence of SegmentedDatagramPacket being deprecated. See corresponding docs for further information.

io.netty.channel.epoll.SegmentedDatagramPacket.replace(ByteBuf content)

Deprecated as a consequence of SegmentedDatagramPacket being deprecated. See corresponding docs for further information.

io.netty.channel.epoll.SegmentedDatagramPacket.retain()

Deprecated as a consequence of SegmentedDatagramPacket being deprecated. See corresponding docs for further information.

io.netty.channel.epoll.SegmentedDatagramPacket.retain(int increment)

Deprecated as a consequence of SegmentedDatagramPacket being deprecated. See corresponding docs for further information.

io.netty.channel.epoll.SegmentedDatagramPacket.retainedDuplicate()

Deprecated as a consequence of SegmentedDatagramPacket being deprecated. See corresponding docs for further information.

io.netty.channel.epoll.SegmentedDatagramPacket.touch()

Deprecated as a consequence of SegmentedDatagramPacket being deprecated. See corresponding docs for further information.

io.netty.channel.epoll.SegmentedDatagramPacket.touch(Object hint)

Deprecated as a consequence of SegmentedDatagramPacket being deprecated. See corresponding docs for further information.

Returns:

the ChannelGroupFuture instance that notifies when the operation is done for all channels
io.netty.channel.group.ChannelGroup.deregister
()

This method will be removed in the next major feature release. Deregister all Channels in this group from their EventLoop. Please note that this operation is asynchronous as Channel#deregister() is.

Returns:

the ChannelGroupFuture instance that notifies when the operation is done for all channels
io.netty.channel.group.ChannelGroup.deregister
(ChannelMatcher matcher)

This method will be removed in the next major feature release. Deregister all Channels in this group from their EventLoop that are matched by the given ChannelMatcher. Please note that this operation is asynchronous as Channel#deregister() is.

io.netty.channel.kqueue.AbstractKQueueChannel.AbstractKQueueUnsafe.allocHandle

Deprecated as a consequence of KQueueRecvByteAllocatorHandle being deprecated. See corresponding docs for further information.

io.netty.channel.kqueue.AbstractKQueueChannel.AbstractKQueueUnsafe.readReady(KQueueRecvByteAllocatorHandle allocHandle)

Deprecated as a consequence of KQueueRecvByteAllocatorHandle being deprecated. See corresponding docs for further information.

io.netty.channel.kqueue.AbstractKQueueChannel.AbstractKQueueUnsafe.recvBufAllocHandle()

Deprecated as a consequence of KQueueRecvByteAllocatorHandle being deprecated. See corresponding docs for further information.

io.netty.channel.kqueue.AbstractKQueueServerChannel.KQueueServerSocketUnsafe.readReady(KQueueRecvByteAllocatorHandle allocHandle)

Deprecated as a consequence of KQueueRecvByteAllocatorHandle being deprecated. See corresponding docs for further information.

io.netty.channel.kqueue.AbstractKQueueStreamChannel.KQueueStreamUnsafe.handleReadException(ChannelPipeline pipeline, ByteBuf byteBuf, Throwable cause, boolean close, KQueueRecvByteAllocatorHandle allocHandle)

Deprecated as a consequence of KQueueRecvByteAllocatorHandle being deprecated. See corresponding docs for further information.

io.netty.channel.kqueue.AbstractKQueueStreamChannel.KQueueStreamUnsafe.readReady(final KQueueRecvByteAllocatorHandle allocHandle)

Deprecated as a consequence of KQueueRecvByteAllocatorHandle being deprecated. See corresponding docs for further information.

io.netty.channel.kqueue.KQueueDatagramChannel.KQueueDatagramChannelUnsafe.readReady(KQueueRecvByteAllocatorHandle allocHandle)

Deprecated as a consequence of KQueueRecvByteAllocatorHandle being deprecated. See corresponding docs for further information.

io.netty.channel.kqueue.KQueueDomainDatagramChannel.KQueueDomainDatagramChannelUnsafe.readReady(KQueueRecvByteAllocatorHandle allocHandle)

Deprecated as a consequence of KQueueRecvByteAllocatorHandle being deprecated. See corresponding docs for further information.

io.netty.channel.kqueue.KQueueDomainSocketChannel.KQueueDomainUnsafe.readReady(KQueueRecvByteAllocatorHandle allocHandle)

Deprecated as a consequence of KQueueRecvByteAllocatorHandle being deprecated. See corresponding docs for further information.

io.netty.channel.kqueue.KQueueRecvByteAllocatorHandle(RecvByteBufAllocator.ExtendedHandle handle)

Deprecated as a consequence of RecvByteBufAllocator.ExtendedHandle being deprecated. See corresponding docs for further information.

io.netty.channel.nio.AbstractNioByteChannel.NioByteUnsafe.handleReadException(ChannelPipeline pipeline, ByteBuf byteBuf, Throwable cause, boolean close, RecvByteBufAllocator.Handle allocHandle)

Deprecated as a consequence of RecvByteBufAllocator.Handle being deprecated. See corresponding docs for further information.

io.netty.channel.nio.AbstractNioChannel.isReadPending()

No longer supported. No longer supported.

io.netty.channel.nio.AbstractNioChannel.setReadPending(final boolean readPending)

Use clearReadPending() if appropriate instead. No longer supported.

io.netty.channel.nio.AbstractNioMessageChannel.continueReading(RecvByteBufAllocator.Handle allocHandle)

Deprecated as a consequence of RecvByteBufAllocator.Handle being deprecated. See corresponding docs for further information.

io.netty.channel.oio

use NIO / EPOLL / KQUEUE transport.

io.netty.channel.oio.AbstractOioByteChannel

use NIO / EPOLL / KQUEUE transport.

io.netty.channel.oio.AbstractOioByteChannel.handleReadException(ChannelPipeline pipeline, ByteBuf byteBuf, Throwable cause, boolean close, RecvByteBufAllocator.Handle allocHandle)

Deprecated as a consequence of RecvByteBufAllocator.Handle being deprecated. See corresponding docs for further information.

io.netty.channel.oio.AbstractOioChannel

use NIO / EPOLL / KQUEUE transport.

io.netty.channel.oio.AbstractOioChannel.isReadPending()

No longer supported. No longer supported.

io.netty.channel.oio.AbstractOioChannel.setReadPending(final boolean readPending)

Use clearReadPending() if appropriate instead. No longer supported.

io.netty.channel.oio.AbstractOioMessageChannel

use NIO / EPOLL / KQUEUE transport.

io.netty.channel.oio.OioByteStreamChannel

use NIO / EPOLL / KQUEUE transport.

io.netty.channel.oio.OioEventLoopGroup

use NIO / EPOLL / KQUEUE transport.

io.netty.channel.socket.nio.NioDatagramChannel.continueReading(RecvByteBufAllocator.Handle allocHandle)

Deprecated as a consequence of RecvByteBufAllocator.Handle being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio

use NIO / EPOLL / KQUEUE transport.

io.netty.channel.socket.oio.DefaultOioDatagramChannelConfig.setAllocator(ByteBufAllocator allocator)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioDatagramChannelConfig.setAutoClose(boolean autoClose)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioDatagramChannelConfig.setAutoRead(boolean autoRead)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioDatagramChannelConfig.setBroadcast(boolean broadcast)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioDatagramChannelConfig.setConnectTimeoutMillis(int
the connect timeout in milliseconds. 0 to disable.
connectTimeoutMillis
)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioDatagramChannelConfig.setInterface(InetAddress interfaceAddress)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioDatagramChannelConfig.setLoopbackModeDisabled(boolean
true if and only if the loopback mode has been disabled
loopbackModeDisabled
)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioDatagramChannelConfig.setMaxMessagesPerRead(int maxMessagesPerRead)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioDatagramChannelConfig.setMessageSizeEstimator(MessageSizeEstimator estimator)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioDatagramChannelConfig.setNetworkInterface(NetworkInterface networkInterface)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioDatagramChannelConfig.setReceiveBufferSize(int receiveBufferSize)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioDatagramChannelConfig.setRecvByteBufAllocator(RecvByteBufAllocator allocator)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioDatagramChannelConfig.setReuseAddress(boolean reuseAddress)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioDatagramChannelConfig.setSendBufferSize(int sendBufferSize)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioDatagramChannelConfig.setSoTimeout(int timeout)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioDatagramChannelConfig.setTimeToLive(int ttl)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioDatagramChannelConfig.setTrafficClass(int trafficClass)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioDatagramChannelConfig.setWriteBufferHighWaterMark(int writeBufferHighWaterMark)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioDatagramChannelConfig.setWriteBufferLowWaterMark(int writeBufferLowWaterMark)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioDatagramChannelConfig.setWriteBufferWaterMark(WriteBufferWaterMark writeBufferWaterMark)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioDatagramChannelConfig.setWriteSpinCount(int writeSpinCount)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig(OioServerSocketChannel channel, ServerSocket javaSocket)

Deprecated as a consequence of OioServerSocketChannel being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig.setAllocator(ByteBufAllocator allocator)

Deprecated as a consequence of OioServerSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig.setAutoClose(boolean autoClose)

Deprecated as a consequence of OioServerSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig.setAutoRead(boolean autoRead)

Deprecated as a consequence of OioServerSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig.setBacklog(int backlog)

Deprecated as a consequence of OioServerSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig.setConnectTimeoutMillis(int
the connect timeout in milliseconds. 0 to disable.
connectTimeoutMillis
)

Deprecated as a consequence of OioServerSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig.setMessageSizeEstimator(MessageSizeEstimator estimator)

Deprecated as a consequence of OioServerSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig.setPerformancePreferences(int connectionTime, int latency, int bandwidth)

Deprecated as a consequence of OioServerSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig.setReceiveBufferSize(int receiveBufferSize)

Deprecated as a consequence of OioServerSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig.setRecvByteBufAllocator(RecvByteBufAllocator allocator)

Deprecated as a consequence of OioServerSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig.setReuseAddress(boolean reuseAddress)

Deprecated as a consequence of OioServerSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig.setSoTimeout(int timeout)

Deprecated as a consequence of OioServerSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig.setWriteBufferHighWaterMark(int writeBufferHighWaterMark)

Deprecated as a consequence of OioServerSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig.setWriteBufferLowWaterMark(int writeBufferLowWaterMark)

Deprecated as a consequence of OioServerSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig.setWriteBufferWaterMark(WriteBufferWaterMark writeBufferWaterMark)

Deprecated as a consequence of OioServerSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig.setWriteSpinCount(int writeSpinCount)

Deprecated as a consequence of OioServerSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioSocketChannelConfig(OioSocketChannel channel, Socket javaSocket)

Deprecated as a consequence of OioSocketChannel being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioSocketChannelConfig.setAllocator(ByteBufAllocator allocator)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioSocketChannelConfig.setAllowHalfClosure(boolean allowHalfClosure)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioSocketChannelConfig.setAutoClose(boolean autoClose)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioSocketChannelConfig.setAutoRead(boolean autoRead)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioSocketChannelConfig.setConnectTimeoutMillis(int
the connect timeout in milliseconds. 0 to disable.
connectTimeoutMillis
)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioSocketChannelConfig.setKeepAlive(boolean keepAlive)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioSocketChannelConfig.setMessageSizeEstimator(MessageSizeEstimator estimator)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioSocketChannelConfig.setPerformancePreferences(int connectionTime, int latency, int bandwidth)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioSocketChannelConfig.setReceiveBufferSize(int receiveBufferSize)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioSocketChannelConfig.setRecvByteBufAllocator(RecvByteBufAllocator allocator)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioSocketChannelConfig.setReuseAddress(boolean reuseAddress)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioSocketChannelConfig.setSendBufferSize(int sendBufferSize)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioSocketChannelConfig.setSoLinger(int soLinger)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioSocketChannelConfig.setSoTimeout(int timeout)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioSocketChannelConfig.setTcpNoDelay(boolean tcpNoDelay)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioSocketChannelConfig.setTrafficClass(int trafficClass)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioSocketChannelConfig.setWriteBufferHighWaterMark(int writeBufferHighWaterMark)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioSocketChannelConfig.setWriteBufferLowWaterMark(int writeBufferLowWaterMark)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioSocketChannelConfig.setWriteBufferWaterMark(WriteBufferWaterMark writeBufferWaterMark)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.DefaultOioSocketChannelConfig.setWriteSpinCount(int writeSpinCount)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioDatagramChannel

use NIO / EPOLL / KQUEUE transport.

io.netty.channel.socket.oio.OioDatagramChannel.config

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioDatagramChannelConfig

use NIO / EPOLL / KQUEUE transport.

io.netty.channel.socket.oio.OioDatagramChannelConfig.setAllocator(ByteBufAllocator allocator)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioDatagramChannelConfig.setAutoClose(boolean autoClose)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioDatagramChannelConfig.setAutoRead(boolean autoRead)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioDatagramChannelConfig.setBroadcast(boolean broadcast)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioDatagramChannelConfig.setConnectTimeoutMillis(int
the connect timeout in milliseconds. 0 to disable.
connectTimeoutMillis
)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioDatagramChannelConfig.setInterface(InetAddress interfaceAddress)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioDatagramChannelConfig.setLoopbackModeDisabled(boolean
true if and only if the loopback mode has been disabled
loopbackModeDisabled
)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioDatagramChannelConfig.setMaxMessagesPerRead(int maxMessagesPerRead)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioDatagramChannelConfig.setMessageSizeEstimator(MessageSizeEstimator estimator)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioDatagramChannelConfig.setNetworkInterface(NetworkInterface networkInterface)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioDatagramChannelConfig.setReceiveBufferSize(int receiveBufferSize)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioDatagramChannelConfig.setRecvByteBufAllocator(RecvByteBufAllocator allocator)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioDatagramChannelConfig.setReuseAddress(boolean reuseAddress)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioDatagramChannelConfig.setSendBufferSize(int sendBufferSize)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioDatagramChannelConfig.setSoTimeout(int timeout)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioDatagramChannelConfig.setTimeToLive(int ttl)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioDatagramChannelConfig.setTrafficClass(int trafficClass)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioDatagramChannelConfig.setWriteBufferHighWaterMark(int writeBufferHighWaterMark)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioDatagramChannelConfig.setWriteBufferLowWaterMark(int writeBufferLowWaterMark)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioDatagramChannelConfig.setWriteBufferWaterMark(WriteBufferWaterMark writeBufferWaterMark)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioDatagramChannelConfig.setWriteSpinCount(int writeSpinCount)

Deprecated as a consequence of OioDatagramChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioServerSocketChannel

use NIO / EPOLL / KQUEUE transport.

io.netty.channel.socket.oio.OioServerSocketChannel.config

Deprecated as a consequence of OioServerSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioServerSocketChannel.config()

Deprecated as a consequence of OioServerSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioServerSocketChannelConfig.setAllocator(ByteBufAllocator allocator)

Deprecated as a consequence of OioServerSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioServerSocketChannelConfig.setAutoClose(boolean autoClose)

Deprecated as a consequence of OioServerSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioServerSocketChannelConfig.setAutoRead(boolean autoRead)

Deprecated as a consequence of OioServerSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioServerSocketChannelConfig.setBacklog(int backlog)

Deprecated as a consequence of OioServerSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioServerSocketChannelConfig.setConnectTimeoutMillis(int
the connect timeout in milliseconds. 0 to disable.
connectTimeoutMillis
)

Deprecated as a consequence of OioServerSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioServerSocketChannelConfig.setMessageSizeEstimator(MessageSizeEstimator estimator)

Deprecated as a consequence of OioServerSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioServerSocketChannelConfig.setPerformancePreferences(int connectionTime, int latency, int bandwidth)

Deprecated as a consequence of OioServerSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioServerSocketChannelConfig.setReceiveBufferSize(int receiveBufferSize)

Deprecated as a consequence of OioServerSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioServerSocketChannelConfig.setRecvByteBufAllocator(RecvByteBufAllocator allocator)

Deprecated as a consequence of OioServerSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioServerSocketChannelConfig.setReuseAddress(boolean reuseAddress)

Deprecated as a consequence of OioServerSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioServerSocketChannelConfig.setSoTimeout(int timeout)

Deprecated as a consequence of OioServerSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioServerSocketChannelConfig.setWriteBufferHighWaterMark(int writeBufferHighWaterMark)

Deprecated as a consequence of OioServerSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioServerSocketChannelConfig.setWriteBufferLowWaterMark(int writeBufferLowWaterMark)

Deprecated as a consequence of OioServerSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioServerSocketChannelConfig.setWriteBufferWaterMark(WriteBufferWaterMark writeBufferWaterMark)

Deprecated as a consequence of OioServerSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioServerSocketChannelConfig.setWriteSpinCount(int writeSpinCount)

Deprecated as a consequence of OioServerSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioSocketChannel

use NIO / EPOLL / KQUEUE transport.

io.netty.channel.socket.oio.OioSocketChannel.config

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioSocketChannel.config()

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioSocketChannelConfig

use NIO / EPOLL / KQUEUE transport.

io.netty.channel.socket.oio.OioSocketChannelConfig.setAllocator(ByteBufAllocator allocator)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioSocketChannelConfig.setAllowHalfClosure(boolean allowHalfClosure)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioSocketChannelConfig.setAutoClose(boolean autoClose)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioSocketChannelConfig.setAutoRead(boolean autoRead)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioSocketChannelConfig.setConnectTimeoutMillis(int
the connect timeout in milliseconds. 0 to disable.
connectTimeoutMillis
)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioSocketChannelConfig.setKeepAlive(boolean keepAlive)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioSocketChannelConfig.setMessageSizeEstimator(MessageSizeEstimator estimator)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioSocketChannelConfig.setPerformancePreferences(int connectionTime, int latency, int bandwidth)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioSocketChannelConfig.setReceiveBufferSize(int receiveBufferSize)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioSocketChannelConfig.setRecvByteBufAllocator(RecvByteBufAllocator allocator)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioSocketChannelConfig.setReuseAddress(boolean reuseAddress)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioSocketChannelConfig.setSendBufferSize(int sendBufferSize)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioSocketChannelConfig.setSoLinger(int soLinger)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioSocketChannelConfig.setSoTimeout(int timeout)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioSocketChannelConfig.setTcpNoDelay(boolean tcpNoDelay)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioSocketChannelConfig.setTrafficClass(int trafficClass)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioSocketChannelConfig.setWriteBufferHighWaterMark(int writeBufferHighWaterMark)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioSocketChannelConfig.setWriteBufferLowWaterMark(int writeBufferLowWaterMark)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioSocketChannelConfig.setWriteBufferWaterMark(WriteBufferWaterMark writeBufferWaterMark)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.socket.oio.OioSocketChannelConfig.setWriteSpinCount(int writeSpinCount)

Deprecated as a consequence of OioSocketChannelConfig being deprecated. See corresponding docs for further information.

io.netty.channel.unix.Errors.throwConnectException(String
The native method name which caused the errno.
method
,
int
the negative value of the errno.
err
)

Use handleConnectErrno(String, int).

Returns:

the cause if unavailable. null if available.
io.netty.channel.unix.Unix.unavailabilityCause
()

io.netty.handler.codec.MessageAggregator.isHandlingOversizedMessage()

This method will be removed in future releases.

io.netty.handler.codec.ReplayingDecoderByteBuf.swapped

Deprecated as a consequence of SwappedByteBuf being deprecated. See corresponding docs for further information.

io.netty.handler.codec.compression.JZlibDecoder.z

Deprecated as a consequence of Inflater being deprecated. See corresponding docs for further information.

io.netty.handler.codec.compression.JZlibEncoder.z

Deprecated as a consequence of Deflater being deprecated. See corresponding docs for further information.

io.netty.handler.codec.compression.Lz4FrameDecoder.decompressor

Deprecated as a consequence of LZ4FastDecompressor being deprecated. See corresponding docs for further information.

io.netty.handler.codec.compression.ZlibUtil.deflaterException(Deflater z, String message, int resultCode)

Deprecated as a consequence of Deflater being deprecated. See corresponding docs for further information.

io.netty.handler.codec.compression.ZlibUtil.fail(Inflater z, String message, int resultCode)

Deprecated as a consequence of Inflater being deprecated. See corresponding docs for further information.

io.netty.handler.codec.compression.ZlibUtil.fail(Deflater z, String message, int resultCode)

Deprecated as a consequence of Deflater being deprecated. See corresponding docs for further information.

io.netty.handler.codec.compression.ZlibUtil.inflaterException(Inflater z, String message, int resultCode)

Deprecated as a consequence of Inflater being deprecated. See corresponding docs for further information.

Returns:

a Rfc6265 style Cookie header value
io.netty.handler.codec.http.ClientCookieEncoder.encode
(String
the cookie name
name
,
String
the cookie value
value
)

Returns:

a Rfc6265 style Cookie header value
io.netty.handler.codec.http.ClientCookieEncoder.encode
(Cookie
the specified cookie
cookie
)

Returns:

a Rfc6265 style Cookie header value, null if no cookies are passed.
io.netty.handler.codec.http.ClientCookieEncoder.encode
(Cookie...
some cookies
cookies
)

Returns:

a Rfc6265 style Cookie header value, null if no cookies are passed.
io.netty.handler.codec.http.ClientCookieEncoder.encode
(Iterable<Cookie>
some cookies
cookies
)

io.netty.handler.codec.http.CombinedHttpHeaders(boolean
Should Netty validate header values to ensure they aren't malicious.
validate
)

Prefer instead to configuring a HttpHeadersFactory by calling withCombiningHeaders(true) on DefaultHttpHeadersFactory#headersFactory().

Returns:

The comment of this Cookie
io.netty.handler.codec.http.Cookie.comment
()

Not part of RFC6265

Returns:

The comment URL of this Cookie
io.netty.handler.codec.http.Cookie.commentUrl
()

Not part of RFC6265

Returns:

True if this Cookie is to be discarded, otherwise false
io.netty.handler.codec.http.Cookie.isDiscard
()

Not part of RFC6265

Returns:

The maximum age of this Cookie
io.netty.handler.codec.http.Cookie.maxAge
()

Not part of RFC6265

Returns:

The Set of ports that this Cookie can use
io.netty.handler.codec.http.Cookie.ports
()

Not part of RFC6265

io.netty.handler.codec.http.Cookie.setComment(String
The comment to use
comment
)

Not part of RFC6265

io.netty.handler.codec.http.Cookie.setCommentUrl(String
The comment URL to use
commentUrl
)

Not part of RFC6265

io.netty.handler.codec.http.Cookie.setDiscard(boolean
True if the Cookie is to be discarded
discard
)

Not part of RFC6265

io.netty.handler.codec.http.Cookie.setMaxAge(long
The maximum age of this Cookie in seconds
maxAge
)

Not part of RFC6265

io.netty.handler.codec.http.Cookie.setPorts(int...
The ports that this Cookie can be accessed on
ports
)

Not part of RFC6265

io.netty.handler.codec.http.Cookie.setPorts(Iterable<Integer>
The Iterable collection of ports that this Cookie can be accessed on.
ports
)

Not part of RFC6265

io.netty.handler.codec.http.Cookie.setVersion(int
The new version to use
version
)

Not part of RFC6265

Returns:

The version of this Cookie
io.netty.handler.codec.http.Cookie.version
()

Not part of RFC6265

io.netty.handler.codec.http.CookieDecoder

Use io.netty.handler.codec.http.cookie.ClientCookieDecoder or io.netty.handler.codec.http.cookie.ServerCookieDecoder instead. Decodes an HTTP header value into Cookies. This decoder can decode the HTTP cookie version 0, 1, and 2.

HttpRequest req = ...;
String value = req.getHeader("Cookie");
Set<Cookie> cookies = CookieDecoder.decode(value);
io.netty.handler.codec.http.CookieDecoder.LAX

Deprecated as a consequence of CookieDecoder being deprecated. See corresponding docs for further information.

io.netty.handler.codec.http.CookieDecoder.STRICT

Deprecated as a consequence of CookieDecoder being deprecated. See corresponding docs for further information.

io.netty.handler.codec.http.CookieDecoder.initCookie(String name, String value)

Deprecated as a consequence of DefaultCookie being deprecated. See corresponding docs for further information.

io.netty.handler.codec.http.DefaultCookie.setDiscard(boolean
True if the Cookie is to be discarded
discard
)

io.netty.handler.codec.http.DefaultCookie.setPorts(int...
The ports that this Cookie can be accessed on
ports
)

io.netty.handler.codec.http.DefaultCookie.setPorts(Iterable<Integer>
The Iterable collection of ports that this Cookie can be accessed on.
ports
)

io.netty.handler.codec.http.DefaultCookie.setVersion(int
The new version to use
version
)

io.netty.handler.codec.http.DefaultHttpHeaders(boolean
Should Netty validate header values to ensure they aren't malicious.
validate
)

Prefer using the DefaultHttpHeaders() constructor instead, to always have validation enabled.

io.netty.handler.codec.http.DefaultHttpMessage(final HttpVersion version, boolean validateHeaders, boolean singleFieldHeaders)

Use the DefaultHttpMessage(HttpVersion, HttpHeadersFactory) constructor instead, ideally using the DefaultHttpHeadersFactory#headersFactory(), or a factory that otherwise has validation enabled.

io.netty.handler.codec.http.DefaultHttpRequest(HttpVersion
the HTTP version of the request
httpVersion
,
HttpMethod
the HTTP method of the request
method
,
String
the URI or path of the request
uri
,
boolean
validate the header names and values when adding them to the HttpHeaders
validateHeaders
)

Prefer the DefaultHttpRequest(HttpVersion, HttpMethod, String) constructor instead, to always have header validation enabled.

io.netty.handler.codec.http.DefaultHttpResponse(HttpVersion
the HTTP version of this response
version
,
HttpResponseStatus
the status of this response
status
,
boolean
validate the header names and values when adding them to the HttpHeaders
validateHeaders
)

Use the DefaultHttpResponse(HttpVersion, HttpResponseStatus, HttpHeadersFactory) constructor instead.

io.netty.handler.codec.http.DefaultHttpResponse(HttpVersion
the HTTP version of this response
version
,
HttpResponseStatus
the status of this response
status
,
boolean
validate the header names and values when adding them to the HttpHeaders
validateHeaders
,
boolean
true to check and enforce that headers with the same name are appended to the same entry and comma separated. See RFC 7230, 3.2.2. false to allow multiple header entries with the same name to coexist.
singleFieldHeaders
)

Use the DefaultHttpResponse(HttpVersion, HttpResponseStatus, HttpHeadersFactory) constructor instead.

io.netty.handler.codec.http.DefaultLastHttpContent(ByteBuf content, boolean validateHeaders)

Prefer the DefaultLastHttpContent(ByteBuf) constructor instead, to always have header validation enabled.

io.netty.handler.codec.http.EmptyHttpHeaders.instance()

Use EmptyHttpHeaders#INSTANCE

This is needed to break a cyclic static initialization loop between HttpHeaders and EmptyHttpHeaders.

io.netty.handler.codec.http.HttpChunkedInput.readChunk(ChannelHandlerContext
The context which provides a ByteBufAllocator if buffer allocation is necessary.
ctx
)

io.netty.handler.codec.http.HttpClientCodec(int maxInitialLineLength, int maxHeaderSize, int maxChunkSize, boolean failOnMissingResponse, boolean validateHeaders)

Prefer the HttpClientCodec(int, int, int, boolean) constructor, to always enable header validation.

io.netty.handler.codec.http.HttpClientCodec(int maxInitialLineLength, int maxHeaderSize, int maxChunkSize, boolean failOnMissingResponse, boolean validateHeaders, boolean parseHttpAfterConnectRequest)

Prefer the HttpClientCodec(HttpDecoderConfig, boolean, boolean) constructor, to always enable header validation.

io.netty.handler.codec.http.HttpClientCodec(int maxInitialLineLength, int maxHeaderSize, int maxChunkSize, boolean failOnMissingResponse, boolean validateHeaders, int initialBufferSize)

Prefer the HttpClientCodec(HttpDecoderConfig, boolean, boolean) constructor, to always enable header validation.

io.netty.handler.codec.http.HttpClientCodec(int maxInitialLineLength, int maxHeaderSize, int maxChunkSize, boolean failOnMissingResponse, boolean validateHeaders, int initialBufferSize, boolean parseHttpAfterConnectRequest)

Prefer the HttpClientCodec(HttpDecoderConfig, boolean, boolean) constructor, to always enable header validation.

io.netty.handler.codec.http.HttpClientCodec(int maxInitialLineLength, int maxHeaderSize, int maxChunkSize, boolean failOnMissingResponse, boolean validateHeaders, int initialBufferSize, boolean parseHttpAfterConnectRequest, boolean allowDuplicateContentLengths)

Prefer the HttpClientCodec(HttpDecoderConfig, boolean, boolean) constructor, to always enable header validation.

io.netty.handler.codec.http.HttpClientCodec(int maxInitialLineLength, int maxHeaderSize, int maxChunkSize, boolean failOnMissingResponse, boolean validateHeaders, int initialBufferSize, boolean parseHttpAfterConnectRequest, boolean allowDuplicateContentLengths, boolean allowPartialChunks)

Prefer the HttpClientCodec(HttpDecoderConfig, boolean, boolean) constructor, to always enable header validation.

io.netty.handler.codec.http.HttpContentCompressor(int
1 yields the fastest compression and 9 yields the best compression. 0 means no compression. The default compression level is 6.
compressionLevel
)

io.netty.handler.codec.http.HttpContentCompressor(int
1 yields the fastest compression and 9 yields the best compression. 0 means no compression. The default compression level is 6.
compressionLevel
,
int
The base two logarithm of the size of the history buffer. The value should be in the range 9 to 15 inclusive. Larger values result in better compression at the expense of memory usage. The default value is 15.
windowBits
,
int
How much memory should be allocated for the internal compression state. 1 uses minimum memory and 9 uses maximum memory. Larger values result in better and faster compression at the expense of memory usage. The default value is 8
memLevel
)

io.netty.handler.codec.http.HttpContentCompressor(int
1 yields the fastest compression and 9 yields the best compression. 0 means no compression. The default compression level is 6.
compressionLevel
,
int
The base two logarithm of the size of the history buffer. The value should be in the range 9 to 15 inclusive. Larger values result in better compression at the expense of memory usage. The default value is 15.
windowBits
,
int
How much memory should be allocated for the internal compression state. 1 uses minimum memory and 9 uses maximum memory. Larger values result in better and faster compression at the expense of memory usage. The default value is 8
memLevel
,
int
The response body is compressed when the size of the response body exceeds the threshold. The value should be a non negative number. 0 will enable compression for all responses.
contentSizeThreshold
)

io.netty.handler.codec.http.HttpHeaderDateFormat.get()

Deprecated as a consequence of HttpHeaderDateFormat being deprecated. See corresponding docs for further information.

io.netty.handler.codec.http.HttpHeaders.EMPTY_HEADERS

Use EmptyHttpHeaders#INSTANCE.

The instance is instantiated here to break the cyclic static initialization between EmptyHttpHeaders and HttpHeaders. The issue is that if someone accesses EmptyHttpHeaders#INSTANCE before HttpHeaders#EMPTY_HEADERS then HttpHeaders#EMPTY_HEADERS will be null.

io.netty.handler.codec.http.HttpHeaders.Names

Use HttpHeaderNames instead. Standard HTTP header names.

io.netty.handler.codec.http.HttpHeaders.Values

Use HttpHeaderValues instead. Standard HTTP header values.

io.netty.handler.codec.http.HttpHeaders.addDateHeader(HttpMessage message, CharSequence name, Date value)

Use add(CharSequence, Object) instead. Adds a new date header with the specified name and value. The specified value is formatted as defined in RFC2616

io.netty.handler.codec.http.HttpHeaders.addHeader(HttpMessage message, CharSequence name, Object value)

Use add(CharSequence, Object) instead. Adds a new header with the specified name and value. If the specified value is not a String, it is converted into a String by Object#toString(), except for Date and Calendar which are formatted to the date format defined in RFC2616.

io.netty.handler.codec.http.HttpHeaders.addIntHeader(HttpMessage message, CharSequence name, int value)

Use addInt(CharSequence, int) instead. Adds a new integer header with the specified name and value.

io.netty.handler.codec.http.HttpHeaders.clearHeaders(HttpMessage message)

Use clear() instead. Removes all headers from the specified message.

Returns:

the content length
io.netty.handler.codec.http.HttpHeaders.getContentLength
(HttpMessage message)

Use HttpUtil#getContentLength(HttpMessage) instead. Returns the length of the content. Please note that this value is not retrieved from HttpContent#content() but from the "Content-Length" header, and thus they are independent from each other.

Returns:

the content length or defaultValue if this message does not have the "Content-Length" header or its value is not a number
io.netty.handler.codec.http.HttpHeaders.getContentLength
(HttpMessage message, long defaultValue)

Use HttpUtil#getContentLength(HttpMessage, long) instead. Returns the length of the content. Please note that this value is not retrieved from HttpContent#content() but from the "Content-Length" header, and thus they are independent from each other.

io.netty.handler.codec.http.HttpHeaders.getDate(HttpMessage message)

Use getTimeMillis(CharSequence) instead. Returns the value of the "Date" header.

io.netty.handler.codec.http.HttpHeaders.getDate(HttpMessage message, Date defaultValue)

Use getTimeMillis(CharSequence, long) instead. Returns the value of the "Date" header. If there is no such header or the header is not a formatted date, the defaultValue is returned.

Returns:

the header value
io.netty.handler.codec.http.HttpHeaders.getDateHeader
(HttpMessage message, CharSequence name)

Use getTimeMillis(CharSequence) instead. Returns the date header value with the specified header name. If there are more than one header value for the specified header name, the first value is returned.

Returns:

the header value or the defaultValue if there is no such header or the header value is not a formatted date
io.netty.handler.codec.http.HttpHeaders.getDateHeader
(HttpMessage message, CharSequence name, Date defaultValue)

Use getTimeMillis(CharSequence, long) instead. Returns the date header value with the specified header name. If there are more than one header value for the specified header name, the first value is returned.

Returns:

the header value or null if there is no such header
io.netty.handler.codec.http.HttpHeaders.getHeader
(HttpMessage message, CharSequence name)

Use get(CharSequence) instead. Returns the header value with the specified header name. If there are more than one header value for the specified header name, the first value is returned.

Returns:

the header value or the defaultValue if there is no such header
io.netty.handler.codec.http.HttpHeaders.getHeader
(HttpMessage message, CharSequence name, String defaultValue)

Use get(CharSequence, String) instead. Returns the header value with the specified header name. If there are more than one header value for the specified header name, the first value is returned.

io.netty.handler.codec.http.HttpHeaders.getHost(HttpMessage message)

Use get(CharSequence) instead. Returns the value of the "Host" header.

io.netty.handler.codec.http.HttpHeaders.getHost(HttpMessage message, String defaultValue)

Use get(CharSequence, String) instead. Returns the value of the "Host" header. If there is no such header, the defaultValue is returned.

Returns:

the header value
io.netty.handler.codec.http.HttpHeaders.getIntHeader
(HttpMessage message, CharSequence name)

Use getInt(CharSequence) instead. Returns the integer header value with the specified header name. If there are more than one header value for the specified header name, the first value is returned.

Returns:

the header value or the defaultValue if there is no such header or the header value is not a number
io.netty.handler.codec.http.HttpHeaders.getIntHeader
(HttpMessage message, CharSequence name, int defaultValue)

Use getInt(CharSequence, int) instead. Returns the integer header value with the specified header name. If there are more than one header value for the specified header name, the first value is returned.

io.netty.handler.codec.http.HttpHeaders.is100ContinueExpected(HttpMessage message)

Use HttpUtil#is100ContinueExpected(HttpMessage) instead. Returns true if and only if the specified message contains the "Expect: 100-continue" header.

io.netty.handler.codec.http.HttpHeaders.isKeepAlive(HttpMessage message)

Use HttpUtil#isKeepAlive(HttpMessage) instead. Returns true if and only if the connection can remain open and thus 'kept alive'. This methods respects the value of the "Connection" header first and then the return value of HttpVersion#isKeepAliveDefault().

Returns:

True if transfer encoding is chunked, otherwise false
io.netty.handler.codec.http.HttpHeaders.isTransferEncodingChunked
(HttpMessage
The message to check
message
)

Use HttpUtil#isTransferEncodingChunked(HttpMessage) instead. Checks to see if the transfer encoding in a specified HttpMessage is chunked

io.netty.handler.codec.http.HttpHeaders.iterator()

It is preferred to use iteratorCharSequence() unless you need String. If String is required then use iteratorAsString().

io.netty.handler.codec.http.HttpHeaders.newEntity(String name)

Use AsciiString instead.

Create a new CharSequence which is optimized for reuse as HttpHeaders name or value. So if you have a Header name or value that you want to reuse you should make use of this.

io.netty.handler.codec.http.HttpHeaders.removeHeader(HttpMessage message, CharSequence name)

Use remove(CharSequence) instead. Removes the header with the specified name.

io.netty.handler.codec.http.HttpHeaders.set100ContinueExpected(HttpMessage message)

Use HttpUtil#set100ContinueExpected(HttpMessage, boolean) instead. Sets the "Expect: 100-continue" header to the specified message. If there is any existing "Expect" header, they are replaced with the new one.

io.netty.handler.codec.http.HttpHeaders.set100ContinueExpected(HttpMessage message, boolean set)

Use HttpUtil#set100ContinueExpected(HttpMessage, boolean) instead. Sets or removes the "Expect: 100-continue" header to / from the specified message. If set is true, the "Expect: 100-continue" header is set and all other previous "Expect" headers are removed. Otherwise, all "Expect" headers are removed completely.

io.netty.handler.codec.http.HttpHeaders.setDateHeader(HttpMessage message, CharSequence name, Date value)

Use set(CharSequence, Object) instead. Sets a new date header with the specified name and value. If there is an existing header with the same name, the existing header is removed. The specified value is formatted as defined in RFC2616

io.netty.handler.codec.http.HttpHeaders.setDateHeader(HttpMessage message, CharSequence name, Iterable<Date> values)

Use set(CharSequence, Iterable) instead. Sets a new date header with the specified name and values. If there is an existing header with the same name, the existing header is removed. The specified values are formatted as defined in RFC2616

io.netty.handler.codec.http.HttpHeaders.setHeader(HttpMessage message, CharSequence name, Object value)

Use set(CharSequence, Object) instead. Sets a new header with the specified name and value. If there is an existing header with the same name, the existing header is removed. If the specified value is not a String, it is converted into a String by Object#toString(), except for Date and Calendar which are formatted to the date format defined in RFC2616.

io.netty.handler.codec.http.HttpHeaders.setHeader(HttpMessage message, CharSequence name, Iterable<?> values)

Use set(CharSequence, Iterable) instead. Sets a new header with the specified name and values. If there is an existing header with the same name, the existing header is removed. This getMethod can be represented approximately as the following code:

removeHeader(message, name);
for (Object v: values) {
    if (v == null) {
        break;
    }
    addHeader(message, name, v);
}
io.netty.handler.codec.http.HttpHeaders.setIntHeader(HttpMessage message, CharSequence name, int value)

Use setInt(CharSequence, int) instead. Sets a new integer header with the specified name and value. If there is an existing header with the same name, the existing header is removed.

io.netty.handler.codec.http.HttpHeaders.setIntHeader(HttpMessage message, CharSequence name, Iterable<Integer> values)

Use set(CharSequence, Iterable) instead. Sets a new integer header with the specified name and values. If there is an existing header with the same name, the existing header is removed.

io.netty.handler.codec.http.HttpHeaders.setKeepAlive(HttpMessage message, boolean keepAlive)

Use HttpUtil#setKeepAlive(HttpMessage, boolean) instead. Sets the value of the "Connection" header depending on the protocol version of the specified message. This getMethod sets or removes the "Connection" header depending on what the default keep alive mode of the message's protocol version is, as specified by HttpVersion#isKeepAliveDefault().

  • If the connection is kept alive by default:
    • set to "close" if keepAlive is false.
    • remove otherwise.
  • If the connection is closed by default:
    • set to "keep-alive" if keepAlive is true.
    • remove otherwise.
io.netty.handler.codec.http.HttpObjectDecoder(int maxInitialLineLength, int maxHeaderSize, int maxChunkSize, boolean chunkedSupported)

Use HttpObjectDecoder(HttpDecoderConfig) instead.

io.netty.handler.codec.http.HttpObjectDecoder(int maxInitialLineLength, int maxHeaderSize, int maxChunkSize, boolean chunkedSupported, boolean validateHeaders)

Use HttpObjectDecoder(HttpDecoderConfig) instead.

io.netty.handler.codec.http.HttpObjectDecoder(int maxInitialLineLength, int maxHeaderSize, int maxChunkSize, boolean chunkedSupported, boolean validateHeaders, int initialBufferSize)

Use HttpObjectDecoder(HttpDecoderConfig) instead.

io.netty.handler.codec.http.HttpObjectDecoder(int maxInitialLineLength, int maxHeaderSize, int maxChunkSize, boolean chunkedSupported, boolean validateHeaders, int initialBufferSize, boolean allowDuplicateContentLengths)

Use HttpObjectDecoder(HttpDecoderConfig) instead.

io.netty.handler.codec.http.HttpObjectDecoder(int maxInitialLineLength, int maxHeaderSize, int maxChunkSize, boolean chunkedSupported, boolean validateHeaders, int initialBufferSize, boolean allowDuplicateContentLengths, boolean allowPartialChunks)

Use HttpObjectDecoder(HttpDecoderConfig) instead.

io.netty.handler.codec.http.HttpRequestDecoder(int maxInitialLineLength, int maxHeaderSize, int maxChunkSize, boolean validateHeaders)

Prefer the HttpRequestDecoder(HttpDecoderConfig) constructor, to always have header validation enabled.

io.netty.handler.codec.http.HttpRequestDecoder(int maxInitialLineLength, int maxHeaderSize, int maxChunkSize, boolean validateHeaders, int initialBufferSize)

Prefer the HttpRequestDecoder(HttpDecoderConfig) constructor, to always have header validation enabled.

io.netty.handler.codec.http.HttpRequestDecoder(int maxInitialLineLength, int maxHeaderSize, int maxChunkSize, boolean validateHeaders, int initialBufferSize, boolean allowDuplicateContentLengths)

Prefer the HttpRequestDecoder(HttpDecoderConfig) constructor, to always have header validation enabled.

io.netty.handler.codec.http.HttpRequestDecoder(int maxInitialLineLength, int maxHeaderSize, int maxChunkSize, boolean validateHeaders, int initialBufferSize, boolean allowDuplicateContentLengths, boolean allowPartialChunks)

Prefer the HttpRequestDecoder(HttpDecoderConfig) constructor, to always have header validation enabled.

io.netty.handler.codec.http.HttpResponseDecoder(int maxInitialLineLength, int maxHeaderSize, int maxChunkSize, boolean validateHeaders)

Prefer the HttpResponseDecoder(HttpDecoderConfig) constructor.

io.netty.handler.codec.http.HttpResponseDecoder(int maxInitialLineLength, int maxHeaderSize, int maxChunkSize, boolean validateHeaders, int initialBufferSize)

Prefer the HttpResponseDecoder(HttpDecoderConfig) constructor.

io.netty.handler.codec.http.HttpResponseDecoder(int maxInitialLineLength, int maxHeaderSize, int maxChunkSize, boolean validateHeaders, int initialBufferSize, boolean allowDuplicateContentLengths)

Prefer the HttpResponseDecoder(HttpDecoderConfig) constructor.

io.netty.handler.codec.http.HttpResponseDecoder(int maxInitialLineLength, int maxHeaderSize, int maxChunkSize, boolean validateHeaders, int initialBufferSize, boolean allowDuplicateContentLengths, boolean allowPartialChunks)

Prefer the HttpResponseDecoder(HttpDecoderConfig) constructor.

io.netty.handler.codec.http.HttpServerCodec(int maxInitialLineLength, int maxHeaderSize, int maxChunkSize, boolean validateHeaders)

Prefer the HttpServerCodec(HttpDecoderConfig) constructor, to always enable header validation.

io.netty.handler.codec.http.HttpServerCodec(int maxInitialLineLength, int maxHeaderSize, int maxChunkSize, boolean validateHeaders, int initialBufferSize)

Prefer the HttpServerCodec(HttpDecoderConfig) constructor, to always enable header validation.

io.netty.handler.codec.http.HttpServerCodec(int maxInitialLineLength, int maxHeaderSize, int maxChunkSize, boolean validateHeaders, int initialBufferSize, boolean allowDuplicateContentLengths)

Prefer the HttpServerCodec(HttpDecoderConfig) constructor, to always enable header validation.

io.netty.handler.codec.http.HttpServerCodec(int maxInitialLineLength, int maxHeaderSize, int maxChunkSize, boolean validateHeaders, int initialBufferSize, boolean allowDuplicateContentLengths, boolean allowPartialChunks)

Prefer the HttpServerCodec(HttpDecoderConfig) constructor, to always enable header validation.

Returns:

the CharSequence with charset from message's Content-Type header or null if charset is not presented
io.netty.handler.codec.http.HttpUtil.getCharsetAsString
(HttpMessage
entity to fetch Content-Type header from
message
)

use getCharsetAsSequence(HttpMessage)

Returns:

a single Set-Cookie header value
io.netty.handler.codec.http.ServerCookieEncoder.encode
(String
the cookie name
name
,
String
the cookie value
value
)

Returns:

a single Set-Cookie header value
io.netty.handler.codec.http.ServerCookieEncoder.encode
(Cookie
the cookie
cookie
)

Returns:

the corresponding bunch of Set-Cookie headers
io.netty.handler.codec.http.ServerCookieEncoder.encode
(Cookie...
a bunch of cookies
cookies
)

Returns:

the corresponding bunch of Set-Cookie headers
io.netty.handler.codec.http.ServerCookieEncoder.encode
(Collection<Cookie>
a bunch of cookies
cookies
)

Returns:

the corresponding bunch of Set-Cookie headers
io.netty.handler.codec.http.ServerCookieEncoder.encode
(Iterable<Cookie>
a bunch of cookies
cookies
)

Returns:

the trimmed, validated attribute value
io.netty.handler.codec.http.cookie.DefaultCookie.validateValue
(String
attribute name
name
,
String
attribute value
value
)

CookieUtil is package private, will be removed once old Cookie API is dropped

Returns:

WebSocketFrame contain chunk of data
io.netty.handler.codec.http.websocketx.WebSocketChunkedInput.readChunk
(ChannelHandlerContext
ChannelHandlerContext context of channelHandler
ctx
)

Use readChunk(ByteBufAllocator). Fetches a chunked data from the stream. Once this method returns the last chunk and thus the stream has reached at its end, any subsequent isEndOfInput() call must return true.

io.netty.handler.codec.http2.AbstractHttp2ConnectionHandlerBuilder.initialHuffmanDecodeCapacity(int initialHuffmanDecodeCapacity)

Huffman decoding no longer depends on having a decode capacity.

io.netty.handler.codec.http2.AbstractHttp2StreamChannel.Http2ChannelUnsafe.doRead0(Http2Frame frame, RecvByteBufAllocator.Handle allocHandle)

Deprecated as a consequence of RecvByteBufAllocator.Handle being deprecated. See corresponding docs for further information.

io.netty.handler.codec.http2.AbstractHttp2StreamChannel.Http2ChannelUnsafe.notifyReadComplete(RecvByteBufAllocator.Handle allocHandle, boolean forceReadComplete, boolean inReadLoop)

Deprecated as a consequence of RecvByteBufAllocator.Handle being deprecated. See corresponding docs for further information.

io.netty.handler.codec.http2.AbstractHttp2StreamChannel.Http2ChannelUnsafe.recvBufAllocHandle()

Deprecated as a consequence of RecvByteBufAllocator.Handle being deprecated. See corresponding docs for further information.

io.netty.handler.codec.http2.AbstractHttp2StreamChannel.Http2ChannelUnsafe.recvHandle

Deprecated as a consequence of RecvByteBufAllocator.Handle being deprecated. See corresponding docs for further information.

io.netty.handler.codec.http2.CompressorHttp2ConnectionEncoder(Http2ConnectionEncoder delegate, int compressionLevel, int windowBits, int memLevel)

io.netty.handler.codec.http2.DefaultHttp2ConnectionDecoder(Http2Connection connection, Http2ConnectionEncoder encoder, Http2FrameReader frameReader, Http2PromisedRequestVerifier requestVerifier, boolean autoAckSettings, boolean autoAckPing)

io.netty.handler.codec.http2.Http2DataChunkedInput.readChunk(ChannelHandlerContext
The context which provides a ByteBufAllocator if buffer allocation is necessary.
ctx
)

io.netty.handler.codec.http2.Http2MultiplexCodecBuilder.autoAckPingFrame(boolean autoAckPingFrame)

Deprecated as a consequence of Http2MultiplexCodecBuilder being deprecated. See corresponding docs for further information.

io.netty.handler.codec.http2.Http2MultiplexCodecBuilder.autoAckSettingsFrame(boolean autoAckSettings)

Deprecated as a consequence of Http2MultiplexCodecBuilder being deprecated. See corresponding docs for further information.

io.netty.handler.codec.http2.Http2MultiplexCodecBuilder.build()

Deprecated as a consequence of Http2MultiplexCodec being deprecated. See corresponding docs for further information.

io.netty.handler.codec.http2.Http2MultiplexCodecBuilder.build(Http2ConnectionDecoder decoder, Http2ConnectionEncoder encoder, Http2Settings initialSettings)

Deprecated as a consequence of Http2MultiplexCodec being deprecated. See corresponding docs for further information.

io.netty.handler.codec.http2.Http2MultiplexCodecBuilder.decoderEnforceMaxConsecutiveEmptyDataFrames(int maxConsecutiveEmptyFrames)

Deprecated as a consequence of Http2MultiplexCodecBuilder being deprecated. See corresponding docs for further information.

io.netty.handler.codec.http2.Http2MultiplexCodecBuilder.decoderEnforceMaxRstFramesPerWindow(int maxRstFramesPerWindow, int secondsPerWindow)

Deprecated as a consequence of Http2MultiplexCodecBuilder being deprecated. See corresponding docs for further information.

io.netty.handler.codec.http2.Http2MultiplexCodecBuilder.decoupleCloseAndGoAway(boolean
true to make Channel#close() directly close the underlying transport, and not attempt graceful closure via GOAWAY.
decoupleCloseAndGoAway
)

Deprecated as a consequence of Http2MultiplexCodecBuilder being deprecated. See corresponding docs for further information.

io.netty.handler.codec.http2.Http2MultiplexCodecBuilder.encoderEnforceMaxConcurrentStreams(boolean encoderEnforceMaxConcurrentStreams)

Deprecated as a consequence of Http2MultiplexCodecBuilder being deprecated. See corresponding docs for further information.

io.netty.handler.codec.http2.Http2MultiplexCodecBuilder.encoderEnforceMaxQueuedControlFrames(int maxQueuedControlFrames)

Deprecated as a consequence of Http2MultiplexCodecBuilder being deprecated. See corresponding docs for further information.

io.netty.handler.codec.http2.Http2MultiplexCodecBuilder.encoderIgnoreMaxHeaderListSize(boolean ignoreMaxHeaderListSize)

Deprecated as a consequence of Http2MultiplexCodecBuilder being deprecated. See corresponding docs for further information.

io.netty.handler.codec.http2.Http2MultiplexCodecBuilder.flushPreface(boolean
true to automatically flush, false otherwise.
flushPreface
)

Deprecated as a consequence of Http2MultiplexCodecBuilder being deprecated. See corresponding docs for further information.

io.netty.handler.codec.http2.Http2MultiplexCodecBuilder.forClient(ChannelHandler
the handler added to channels for remotely-created streams. It must be ChannelHandler.Sharable.
childHandler
)

Deprecated as a consequence of Http2MultiplexCodecBuilder being deprecated. See corresponding docs for further information.

io.netty.handler.codec.http2.Http2MultiplexCodecBuilder.forServer(ChannelHandler
the handler added to channels for remotely-created streams. It must be ChannelHandler.Sharable.
childHandler
)

Deprecated as a consequence of Http2MultiplexCodecBuilder being deprecated. See corresponding docs for further information.

io.netty.handler.codec.http2.Http2MultiplexCodecBuilder.frameLogger(Http2FrameLogger frameLogger)

Deprecated as a consequence of Http2MultiplexCodecBuilder being deprecated. See corresponding docs for further information.

io.netty.handler.codec.http2.Http2MultiplexCodecBuilder.frameWriter(Http2FrameWriter frameWriter)

Deprecated as a consequence of Http2MultiplexCodecBuilder being deprecated. See corresponding docs for further information.

io.netty.handler.codec.http2.Http2MultiplexCodecBuilder.gracefulShutdownTimeoutMillis(long gracefulShutdownTimeoutMillis)

Deprecated as a consequence of Http2MultiplexCodecBuilder being deprecated. See corresponding docs for further information.

io.netty.handler.codec.http2.Http2MultiplexCodecBuilder.headerSensitivityDetector(Http2HeadersEncoder.SensitivityDetector headerSensitivityDetector)

Deprecated as a consequence of Http2MultiplexCodecBuilder being deprecated. See corresponding docs for further information.

io.netty.handler.codec.http2.Http2MultiplexCodecBuilder.initialSettings(Http2Settings settings)

Deprecated as a consequence of Http2MultiplexCodecBuilder being deprecated. See corresponding docs for further information.

io.netty.handler.codec.http2.Http2MultiplexCodecBuilder.maxReservedStreams(int maxReservedStreams)

Deprecated as a consequence of Http2MultiplexCodecBuilder being deprecated. See corresponding docs for further information.

io.netty.handler.codec.http2.Http2MultiplexCodecBuilder.validateHeaders(boolean validateHeaders)

Deprecated as a consequence of Http2MultiplexCodecBuilder being deprecated. See corresponding docs for further information.

io.netty.handler.codec.http2.Http2MultiplexCodecBuilder.withUpgradeStreamHandler(ChannelHandler upgradeStreamHandler)

Deprecated as a consequence of Http2MultiplexCodecBuilder being deprecated. See corresponding docs for further information.

io.netty.handler.codec.http2.Http2ServerUpgradeCodec(Http2MultiplexCodec
the HTTP/2 multiplexing handler.
http2Codec
)

Deprecated as a consequence of Http2MultiplexCodec being deprecated. See corresponding docs for further information.

io.netty.handler.codec.http2.Http2ServerUpgradeCodec(String
the name of the HTTP/2 connection handler to be used in the pipeline.
handlerName
,
Http2MultiplexCodec
the HTTP/2 multiplexing handler.
http2Codec
)

Deprecated as a consequence of Http2MultiplexCodec being deprecated. See corresponding docs for further information.

io.netty.handler.codec.rtsp.RtspDecoder(final int
The max allowed length of initial line
maxInitialLineLength
,
final int
The max allowed size of header
maxHeaderSize
,
final int
The max allowed content length
maxContentLength
,
final boolean
Set to true if headers should be validated
validateHeaders
)

Use the RtspDecoder(HttpDecoderConfig) constructor instead, or the RtspDecoder(int, int, int) to always enable header validation.

io.netty.handler.codec.rtsp.RtspHeaders

Use RtspHeaderNames or RtspHeaderValues instead. Standard RTSP header names and values.

io.netty.handler.codec.rtsp.RtspHeaders.Names

Use RtspHeaderNames instead. Standard RTSP header names.

io.netty.handler.codec.rtsp.RtspHeaders.Values

Use RtspHeaderValues instead. Standard RTSP header values.

io.netty.handler.codec.serialization

This package has been deprecated with no replacement, because serialization can be a security liability

io.netty.handler.codec.serialization.CachingClassResolver

Deprecated as a consequence of ClassResolver being deprecated.

io.netty.handler.codec.serialization.CachingClassResolver(ClassResolver delegate, Map<String, Class<?>> classCache)

Deprecated as a consequence of ClassResolver being deprecated. See corresponding docs for further information.

io.netty.handler.codec.serialization.CachingClassResolver.delegate

Deprecated as a consequence of ClassResolver being deprecated. See corresponding docs for further information.

io.netty.handler.codec.serialization.ClassLoaderClassResolver

Deprecated as a consequence of ClassResolver being deprecated.

io.netty.handler.codec.serialization.ClassResolver

This class has been deprecated with no replacement, because serialization can be a security liability

io.netty.handler.codec.serialization.ClassResolvers

This class has been deprecated with no replacement, because serialization can be a security liability

Returns:

new instance of class resolver
io.netty.handler.codec.serialization.ClassResolvers.cacheDisabled
(ClassLoader
- specific classLoader to use, or null if you want to revert to default
classLoader
)

Deprecated as a consequence of ClassResolver being deprecated. See corresponding docs for further information.

Returns:

new instance of class resolver
io.netty.handler.codec.serialization.ClassResolvers.softCachingConcurrentResolver
(ClassLoader
- specific classLoader to use, or null if you want to revert to default
classLoader
)

Deprecated as a consequence of ClassResolver being deprecated. See corresponding docs for further information.

Returns:

new instance of class resolver
io.netty.handler.codec.serialization.ClassResolvers.softCachingResolver
(ClassLoader
- specific classLoader to use, or null if you want to revert to default
classLoader
)

Deprecated as a consequence of ClassResolver being deprecated. See corresponding docs for further information.

Returns:

new instance of class resolver
io.netty.handler.codec.serialization.ClassResolvers.weakCachingConcurrentResolver
(ClassLoader
- specific classLoader to use, or null if you want to revert to default
classLoader
)

Deprecated as a consequence of ClassResolver being deprecated. See corresponding docs for further information.

Returns:

new instance of class resolver
io.netty.handler.codec.serialization.ClassResolvers.weakCachingResolver
(ClassLoader
- specific classLoader to use, or null if you want to revert to default
classLoader
)

Deprecated as a consequence of ClassResolver being deprecated. See corresponding docs for further information.

io.netty.handler.codec.serialization.CompactObjectInputStream(InputStream in, ClassResolver classResolver)

Deprecated as a consequence of ClassResolver being deprecated. See corresponding docs for further information.

io.netty.handler.codec.serialization.CompactObjectInputStream.classResolver

Deprecated as a consequence of ClassResolver being deprecated. See corresponding docs for further information.

io.netty.handler.codec.serialization.CompatibleObjectEncoder

This class has been deprecated with no replacement, because serialization can be a security liability

io.netty.handler.codec.serialization.ObjectDecoder

This class has been deprecated with no replacement, because serialization can be a security liability

io.netty.handler.codec.serialization.ObjectDecoder(ClassResolver
the ClassResolver to use for this decoder
classResolver
)

Deprecated as a consequence of ClassResolver being deprecated. See corresponding docs for further information.

io.netty.handler.codec.serialization.ObjectDecoder(int
the maximum byte length of the serialized object. if the length of the received object is greater than this value, StreamCorruptedException will be raised.
maxObjectSize
,
ClassResolver
the ClassResolver which will load the class of the serialized object
classResolver
)

Deprecated as a consequence of ClassResolver being deprecated. See corresponding docs for further information.

io.netty.handler.codec.serialization.ObjectDecoder.classResolver

Deprecated as a consequence of ClassResolver being deprecated. See corresponding docs for further information.

io.netty.handler.codec.serialization.ObjectDecoderInputStream

This class has been deprecated with no replacement, because serialization can be a security liability

io.netty.handler.codec.serialization.ObjectDecoderInputStream.classResolver

Deprecated as a consequence of ClassResolver being deprecated. See corresponding docs for further information.

io.netty.handler.codec.serialization.ObjectEncoder

This class has been deprecated with no replacement, because serialization can be a security liability

io.netty.handler.codec.serialization.ObjectEncoderOutputStream

This class has been deprecated with no replacement, because serialization can be a security liability

io.netty.handler.codec.socks.SocksMessage.encodeAsByteBuf(ByteBuf byteBuf)

Do not use; this method was intended for an internal use only.

io.netty.handler.codec.spdy.SpdyHeaderBlockJZlibEncoder.z

Deprecated as a consequence of Deflater being deprecated. See corresponding docs for further information.

io.netty.handler.codec.spdy.SpdyHttpCodec(SpdyVersion version, int maxContentLength, boolean validateHttpHeaders)

io.netty.handler.codec.spdy.SpdyHttpDecoder(SpdyVersion
the protocol version
version
,
int
the maximum length of the message content. If the length of the message content exceeds this value, a TooLongFrameException will be raised.
maxContentLength
,
boolean
true if http headers should be validated
validateHeaders
)

Use the SpdyHttpDecoder(SpdyVersion, int, Map, HttpHeadersFactory, HttpHeadersFactory) constructor instead.

io.netty.handler.codec.spdy.SpdyHttpDecoder(SpdyVersion
the protocol version
version
,
int
the maximum length of the message content. If the length of the message content exceeds this value, a TooLongFrameException will be raised.
maxContentLength
,
Map<Integer, FullHttpMessage>
the Map used to hold partially received messages.
messageMap
,
boolean
true if http headers should be validated
validateHeaders
)

Use the SpdyHttpDecoder(SpdyVersion, int, Map, HttpHeadersFactory, HttpHeadersFactory) constructor instead.

io.netty.handler.pcap.PcapWriteHandler(OutputStream
OutputStream where Pcap data will be written. Call close() to close this OutputStream.
outputStream
)

Use Builder instead.

io.netty.handler.pcap.PcapWriteHandler(OutputStream
OutputStream where Pcap data will be written. Call close() to close this OutputStream.
outputStream
,
boolean
Set to true to enable capturing packets with empty (0 bytes) payload. Otherwise, if set to false, empty packets will be filtered out.
captureZeroByte
,
boolean
Set to true to write Pcap Global Header on initialization. Otherwise, if set to false, Pcap Global Header will not be written on initialization. This could when writing Pcap data on a existing file where Pcap Global Header is already present.
writePcapGlobalHeader
)

Use Builder instead.

io.netty.handler.ssl.BouncyCastleAlpnSslEngine(SSLEngine engine, JdkApplicationProtocolNegotiator applicationNegotiator, boolean isServer)

Deprecated as a consequence of JdkApplicationProtocolNegotiator being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.ConscryptAlpnSslEngine.ClientEngine(SSLEngine engine, ByteBufAllocator alloc, JdkApplicationProtocolNegotiator applicationNegotiator)

Deprecated as a consequence of JdkApplicationProtocolNegotiator being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.ConscryptAlpnSslEngine.ServerEngine(SSLEngine engine, ByteBufAllocator alloc, JdkApplicationProtocolNegotiator applicationNegotiator)

Deprecated as a consequence of JdkApplicationProtocolNegotiator being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.ConscryptAlpnSslEngine.newClientEngine(SSLEngine engine, ByteBufAllocator alloc, JdkApplicationProtocolNegotiator applicationNegotiator)

Deprecated as a consequence of JdkApplicationProtocolNegotiator being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.ConscryptAlpnSslEngine.newServerEngine(SSLEngine engine, ByteBufAllocator alloc, JdkApplicationProtocolNegotiator applicationNegotiator)

Deprecated as a consequence of JdkApplicationProtocolNegotiator being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.DelegatingSslContext.applicationProtocolNegotiator()

Deprecated as a consequence of ApplicationProtocolNegotiator being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.ExtendedOpenSslSession.getPeerCertificateChain()

Deprecated as a consequence of X509Certificate being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.JdkAlpnApplicationProtocolNegotiator.AlpnWrapper.wrapSslEngine(SSLEngine
The engine to wrap.
engine
,
ByteBufAllocator
the buffer allocator.
alloc
,
JdkApplicationProtocolNegotiator
The application level protocol negotiator
applicationNegotiator
,
boolean
  • true if the engine is for server side of connections
  • false if the engine is for client side of connections
isServer
)

Deprecated as a consequence of JdkApplicationProtocolNegotiator being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.JdkAlpnApplicationProtocolNegotiator.FailureWrapper.wrapSslEngine(SSLEngine
The engine to wrap.
engine
,
ByteBufAllocator
the buffer allocator.
alloc
,
JdkApplicationProtocolNegotiator
The application level protocol negotiator
applicationNegotiator
,
boolean
  • true if the engine is for server side of connections
  • false if the engine is for client side of connections
isServer
)

Deprecated as a consequence of JdkApplicationProtocolNegotiator being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.JdkAlpnSslEngine(SSLEngine engine, JdkApplicationProtocolNegotiator applicationNegotiator, boolean isServer, BiConsumer<SSLEngine, JdkAlpnSslEngine.AlpnSelector> setHandshakeApplicationProtocolSelector, BiConsumer<SSLEngine, List<String>> setApplicationProtocols)

Deprecated as a consequence of JdkApplicationProtocolNegotiator being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.JdkAlpnSslEngine(SSLEngine engine, JdkApplicationProtocolNegotiator applicationNegotiator, boolean isServer)

Deprecated as a consequence of JdkApplicationProtocolNegotiator being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.JdkApplicationProtocolNegotiator.AllocatorAwareSslEngineWrapperFactory.wrapSslEngine(SSLEngine
The engine to wrap.
engine
,
JdkApplicationProtocolNegotiator
The application level protocol negotiator
applicationNegotiator
,
boolean
  • true if the engine is for server side of connections
  • false if the engine is for client side of connections
isServer
)

Deprecated as a consequence of JdkApplicationProtocolNegotiator being deprecated. See corresponding docs for further information.

Returns:

The resulting wrapped engine. This may just be engine.
io.netty.handler.ssl.JdkApplicationProtocolNegotiator.AllocatorAwareSslEngineWrapperFactory.wrapSslEngine
(SSLEngine
The engine to wrap.
engine
,
ByteBufAllocator
the buffer allocator.
alloc
,
JdkApplicationProtocolNegotiator
The application level protocol negotiator
applicationNegotiator
,
boolean
  • true if the engine is for server side of connections
  • false if the engine is for client side of connections
isServer
)

Deprecated as a consequence of JdkApplicationProtocolNegotiator being deprecated. See corresponding docs for further information.

Returns:

The resulting wrapped engine. This may just be engine.
io.netty.handler.ssl.JdkApplicationProtocolNegotiator.SslEngineWrapperFactory.wrapSslEngine
(SSLEngine
The engine to wrap.
engine
,
JdkApplicationProtocolNegotiator
The application level protocol negotiator
applicationNegotiator
,
boolean
  • true if the engine is for server side of connections
  • false if the engine is for client side of connections
isServer
)

Deprecated as a consequence of JdkApplicationProtocolNegotiator being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.JdkDefaultApplicationProtocolNegotiator.INSTANCE

Deprecated as a consequence of JdkDefaultApplicationProtocolNegotiator being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.JdkSslClientContext(File
an X.509 certificate chain file in PEM format. null to use the system default
certChainFile
)

use SslContextBuilder

io.netty.handler.ssl.JdkSslClientContext(TrustManagerFactory
the TrustManagerFactory that provides the TrustManagers that verifies the certificates sent from servers. null to use the default.
trustManagerFactory
)

use SslContextBuilder

io.netty.handler.ssl.JdkSslClientContext(File
an X.509 certificate chain file in PEM format. null to use the system default
certChainFile
,
TrustManagerFactory
the TrustManagerFactory that provides the TrustManagers that verifies the certificates sent from servers. null to use the default.
trustManagerFactory
)

use SslContextBuilder

io.netty.handler.ssl.JdkSslClientContext(File
an X.509 certificate chain file in PEM format. null to use the system default
certChainFile
,
TrustManagerFactory
the TrustManagerFactory that provides the TrustManagers that verifies the certificates sent from servers. null to use the default.
trustManagerFactory
,
Iterable<String>
the cipher suites to enable, in the order of preference. null to use the default cipher suites.
ciphers
,
Iterable<String>
the application layer protocols to accept, in the order of preference. null to disable TLS NPN/ALPN extension.
nextProtocols
,
long
the size of the cache used for storing SSL session objects. 0 to use the default value.
sessionCacheSize
,
long
the timeout for the cached SSL session objects, in seconds. 0 to use the default value.
sessionTimeout
)

use SslContextBuilder

io.netty.handler.ssl.JdkSslClientContext(File
an X.509 certificate chain file in PEM format. null to use the system default
certChainFile
,
TrustManagerFactory
the TrustManagerFactory that provides the TrustManagers that verifies the certificates sent from servers. null to use the default.
trustManagerFactory
,
Iterable<String>
the cipher suites to enable, in the order of preference. null to use the default cipher suites.
ciphers
,
CipherSuiteFilter
a filter to apply over the supplied list of ciphers
cipherFilter
,
ApplicationProtocolConfig
Provides a means to configure parameters related to application protocol negotiation.
apn
,
long
the size of the cache used for storing SSL session objects. 0 to use the default value.
sessionCacheSize
,
long
the timeout for the cached SSL session objects, in seconds. 0 to use the default value.
sessionTimeout
)

use SslContextBuilder

io.netty.handler.ssl.JdkSslClientContext(File
an X.509 certificate chain file in PEM format. null to use the system default
certChainFile
,
TrustManagerFactory
the TrustManagerFactory that provides the TrustManagers that verifies the certificates sent from servers. null to use the default.
trustManagerFactory
,
Iterable<String>
the cipher suites to enable, in the order of preference. null to use the default cipher suites.
ciphers
,
CipherSuiteFilter
a filter to apply over the supplied list of ciphers
cipherFilter
,
JdkApplicationProtocolNegotiator
Application Protocol Negotiator object.
apn
,
long
the size of the cache used for storing SSL session objects. 0 to use the default value.
sessionCacheSize
,
long
the timeout for the cached SSL session objects, in seconds. 0 to use the default value.
sessionTimeout
)

use SslContextBuilder

io.netty.handler.ssl.JdkSslClientContext(Provider provider, File trustCertCollectionFile, TrustManagerFactory trustManagerFactory, Iterable<String> ciphers, CipherSuiteFilter cipherFilter, JdkApplicationProtocolNegotiator apn, long sessionCacheSize, long sessionTimeout)

Deprecated as a consequence of JdkApplicationProtocolNegotiator being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.JdkSslClientContext(File
an X.509 certificate collection file in PEM format. null to use the system default
trustCertCollectionFile
,
TrustManagerFactory
the TrustManagerFactory that provides the TrustManagers that verifies the certificates sent from servers. null to use the default or the results of parsing trustCertCollectionFile
trustManagerFactory
,
File
an X.509 certificate chain file in PEM format. This provides the public key for mutual authentication. null to use the system default
keyCertChainFile
,
File
a PKCS#8 private key file in PEM format. This provides the private key for mutual authentication. null for no mutual authentication.
keyFile
,
String
the password of the keyFile. null if it's not password-protected. Ignored if keyFile is null.
keyPassword
,
KeyManagerFactory
the KeyManagerFactory that provides the KeyManagers that is used to encrypt data being sent to servers. null to use the default or the results of parsing keyCertChainFile and keyFile.
keyManagerFactory
,
Iterable<String>
the cipher suites to enable, in the order of preference. null to use the default cipher suites.
ciphers
,
CipherSuiteFilter
a filter to apply over the supplied list of ciphers
cipherFilter
,
ApplicationProtocolConfig
Provides a means to configure parameters related to application protocol negotiation.
apn
,
long
the size of the cache used for storing SSL session objects. 0 to use the default value.
sessionCacheSize
,
long
the timeout for the cached SSL session objects, in seconds. 0 to use the default value.
sessionTimeout
)

use SslContextBuilder

io.netty.handler.ssl.JdkSslClientContext(File
an X.509 certificate collection file in PEM format. null to use the system default
trustCertCollectionFile
,
TrustManagerFactory
the TrustManagerFactory that provides the TrustManagers that verifies the certificates sent from servers. null to use the default or the results of parsing trustCertCollectionFile
trustManagerFactory
,
File
an X.509 certificate chain file in PEM format. This provides the public key for mutual authentication. null to use the system default
keyCertChainFile
,
File
a PKCS#8 private key file in PEM format. This provides the private key for mutual authentication. null for no mutual authentication.
keyFile
,
String
the password of the keyFile. null if it's not password-protected. Ignored if keyFile is null.
keyPassword
,
KeyManagerFactory
the KeyManagerFactory that provides the KeyManagers that is used to encrypt data being sent to servers. null to use the default or the results of parsing keyCertChainFile and keyFile.
keyManagerFactory
,
Iterable<String>
the cipher suites to enable, in the order of preference. null to use the default cipher suites.
ciphers
,
CipherSuiteFilter
a filter to apply over the supplied list of ciphers
cipherFilter
,
JdkApplicationProtocolNegotiator
Application Protocol Negotiator object.
apn
,
long
the size of the cache used for storing SSL session objects. 0 to use the default value.
sessionCacheSize
,
long
the timeout for the cached SSL session objects, in seconds. 0 to use the default value.
sessionTimeout
)

use SslContextBuilder

io.netty.handler.ssl.JdkSslContext(SSLContext
the SSLContext to use.
sslContext
,
boolean
true if this context should create SSLEngines for client-side usage.
isClient
,
ClientAuth
the ClientAuth to use. This will only be used when {@param isClient} is false.
clientAuth
)

Use JdkSslContext(SSLContext, boolean, Iterable, CipherSuiteFilter, ApplicationProtocolConfig, ClientAuth, String[], boolean)

io.netty.handler.ssl.JdkSslContext(SSLContext
the SSLContext to use.
sslContext
,
boolean
true if this context should create SSLEngines for client-side usage.
isClient
,
Iterable<String>
the ciphers to use or null if the standard should be used.
ciphers
,
CipherSuiteFilter
the filter to use.
cipherFilter
,
ApplicationProtocolConfig apn, ClientAuth
the ClientAuth to use. This will only be used when {@param isClient} is false.
clientAuth
)

Use JdkSslContext(SSLContext, boolean, Iterable, CipherSuiteFilter, ApplicationProtocolConfig, ClientAuth, String[], boolean)

io.netty.handler.ssl.JdkSslContext(SSLContext sslContext, boolean isClient, Iterable<String> ciphers, CipherSuiteFilter cipherFilter, JdkApplicationProtocolNegotiator apn, ClientAuth clientAuth, String[] protocols, boolean startTls)

Deprecated as a consequence of JdkApplicationProtocolNegotiator being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.JdkSslContext.apn

Deprecated as a consequence of JdkApplicationProtocolNegotiator being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.JdkSslContext.applicationProtocolNegotiator()

Deprecated as a consequence of JdkApplicationProtocolNegotiator being deprecated. See corresponding docs for further information.

Returns:

A KeyManagerFactory based upon a key file, key file password, and a certificate chain.
io.netty.handler.ssl.JdkSslContext.buildKeyManagerFactory
(File
an X.509 certificate chain file in PEM format
certChainFile
,
File
a PKCS#8 private key file in PEM format
keyFile
,
String
the password of the keyFile. null if it's not password-protected.
keyPassword
,
KeyManagerFactory
The existing KeyManagerFactory that will be used if not null
kmf
)

will be removed.

Returns:

A KeyManagerFactory based upon a key algorithm, key file, key file password, and a certificate chain.
io.netty.handler.ssl.JdkSslContext.buildKeyManagerFactory
(File
an buildKeyManagerFactory X.509 certificate chain file in PEM format
certChainFile
,
String
the standard name of the requested algorithm. See the Java Secure Socket Extension Reference Guide for information about standard algorithm names.
keyAlgorithm
,
File
a PKCS#8 private key file in PEM format
keyFile
,
String
the password of the keyFile. null if it's not password-protected.
keyPassword
,
KeyManagerFactory
The existing KeyManagerFactory that will be used if not null
kmf
)

will be removed.

Returns:

The results of the translation
io.netty.handler.ssl.JdkSslContext.toNegotiator
(ApplicationProtocolConfig
The configuration which defines the translation
config
,
boolean
true if a server false otherwise.
isServer
)

Deprecated as a consequence of JdkApplicationProtocolNegotiator being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.JdkSslServerContext(File
an X.509 certificate chain file in PEM format
certChainFile
,
File
a PKCS#8 private key file in PEM format
keyFile
)

use SslContextBuilder

io.netty.handler.ssl.JdkSslServerContext(File
an X.509 certificate chain file in PEM format
certChainFile
,
File
a PKCS#8 private key file in PEM format
keyFile
,
String
the password of the keyFile. null if it's not password-protected.
keyPassword
)

use SslContextBuilder

io.netty.handler.ssl.JdkSslServerContext(File
an X.509 certificate chain file in PEM format
certChainFile
,
File
a PKCS#8 private key file in PEM format
keyFile
,
String
the password of the keyFile. null if it's not password-protected.
keyPassword
,
Iterable<String>
the cipher suites to enable, in the order of preference. null to use the default cipher suites.
ciphers
,
Iterable<String>
the application layer protocols to accept, in the order of preference. null to disable TLS NPN/ALPN extension.
nextProtocols
,
long
the size of the cache used for storing SSL session objects. 0 to use the default value.
sessionCacheSize
,
long
the timeout for the cached SSL session objects, in seconds. 0 to use the default value.
sessionTimeout
)

use SslContextBuilder

io.netty.handler.ssl.JdkSslServerContext(File
an X.509 certificate chain file in PEM format
certChainFile
,
File
a PKCS#8 private key file in PEM format
keyFile
,
String
the password of the keyFile. null if it's not password-protected.
keyPassword
,
Iterable<String>
the cipher suites to enable, in the order of preference. null to use the default cipher suites.
ciphers
,
CipherSuiteFilter
a filter to apply over the supplied list of ciphers
cipherFilter
,
ApplicationProtocolConfig
Provides a means to configure parameters related to application protocol negotiation.
apn
,
long
the size of the cache used for storing SSL session objects. 0 to use the default value.
sessionCacheSize
,
long
the timeout for the cached SSL session objects, in seconds. 0 to use the default value.
sessionTimeout
)

use SslContextBuilder

io.netty.handler.ssl.JdkSslServerContext(File
an X.509 certificate chain file in PEM format
certChainFile
,
File
a PKCS#8 private key file in PEM format
keyFile
,
String
the password of the keyFile. null if it's not password-protected.
keyPassword
,
Iterable<String>
the cipher suites to enable, in the order of preference. null to use the default cipher suites.
ciphers
,
CipherSuiteFilter
a filter to apply over the supplied list of ciphers
cipherFilter
,
JdkApplicationProtocolNegotiator
Application Protocol Negotiator object.
apn
,
long
the size of the cache used for storing SSL session objects. 0 to use the default value.
sessionCacheSize
,
long
the timeout for the cached SSL session objects, in seconds. 0 to use the default value.
sessionTimeout
)

use SslContextBuilder

io.netty.handler.ssl.JdkSslServerContext(Provider provider, File certChainFile, File keyFile, String keyPassword, Iterable<String> ciphers, CipherSuiteFilter cipherFilter, JdkApplicationProtocolNegotiator apn, long sessionCacheSize, long sessionTimeout, String keyStore)

Deprecated as a consequence of JdkApplicationProtocolNegotiator being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.JdkSslServerContext(File
an X.509 certificate collection file in PEM format. This provides the certificate collection used for mutual authentication. null to use the system default
trustCertCollectionFile
,
TrustManagerFactory
the TrustManagerFactory that provides the TrustManagers that verifies the certificates sent from clients. null to use the default or the results of parsing trustCertCollectionFile.
trustManagerFactory
,
File
an X.509 certificate chain file in PEM format
keyCertChainFile
,
File
a PKCS#8 private key file in PEM format
keyFile
,
String
the password of the keyFile. null if it's not password-protected.
keyPassword
,
KeyManagerFactory
the KeyManagerFactory that provides the KeyManagers that is used to encrypt data being sent to clients. null to use the default or the results of parsing keyCertChainFile and keyFile.
keyManagerFactory
,
Iterable<String>
the cipher suites to enable, in the order of preference. null to use the default cipher suites.
ciphers
,
CipherSuiteFilter
a filter to apply over the supplied list of ciphers Only required if provider is SslProvider#JDK
cipherFilter
,
ApplicationProtocolConfig
Provides a means to configure parameters related to application protocol negotiation.
apn
,
long
the size of the cache used for storing SSL session objects. 0 to use the default value.
sessionCacheSize
,
long
the timeout for the cached SSL session objects, in seconds. 0 to use the default value.
sessionTimeout
)

use SslContextBuilder

io.netty.handler.ssl.JdkSslServerContext(File
an X.509 certificate collection file in PEM format. This provides the certificate collection used for mutual authentication. null to use the system default
trustCertCollectionFile
,
TrustManagerFactory
the TrustManagerFactory that provides the TrustManagers that verifies the certificates sent from clients. null to use the default or the results of parsing trustCertCollectionFile
trustManagerFactory
,
File
an X.509 certificate chain file in PEM format
keyCertChainFile
,
File
a PKCS#8 private key file in PEM format
keyFile
,
String
the password of the keyFile. null if it's not password-protected.
keyPassword
,
KeyManagerFactory
the KeyManagerFactory that provides the KeyManagers that is used to encrypt data being sent to clients. null to use the default or the results of parsing keyCertChainFile and keyFile.
keyManagerFactory
,
Iterable<String>
the cipher suites to enable, in the order of preference. null to use the default cipher suites.
ciphers
,
CipherSuiteFilter
a filter to apply over the supplied list of ciphers Only required if provider is SslProvider#JDK
cipherFilter
,
JdkApplicationProtocolNegotiator
Application Protocol Negotiator object.
apn
,
long
the size of the cache used for storing SSL session objects. 0 to use the default value.
sessionCacheSize
,
long
the timeout for the cached SSL session objects, in seconds. 0 to use the default value
sessionTimeout
)

use SslContextBuilder

io.netty.handler.ssl.JettyAlpnSslEngine.ClientEngine(SSLEngine engine, final JdkApplicationProtocolNegotiator applicationNegotiator)

Deprecated as a consequence of JdkApplicationProtocolNegotiator being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.JettyAlpnSslEngine.ServerEngine(SSLEngine engine, final JdkApplicationProtocolNegotiator applicationNegotiator)

Deprecated as a consequence of JdkApplicationProtocolNegotiator being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.JettyAlpnSslEngine.newClientEngine(SSLEngine engine, JdkApplicationProtocolNegotiator applicationNegotiator)

Deprecated as a consequence of JdkApplicationProtocolNegotiator being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.JettyAlpnSslEngine.newServerEngine(SSLEngine engine, JdkApplicationProtocolNegotiator applicationNegotiator)

Deprecated as a consequence of JdkApplicationProtocolNegotiator being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.JettyNpnSslEngine(SSLEngine engine, final JdkApplicationProtocolNegotiator applicationNegotiator, boolean server)

Deprecated as a consequence of JdkApplicationProtocolNegotiator being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.OpenSsl.supportsHostnameValidation()

Will be removed because hostname validation is always done by a javax.net.ssl.TrustManager implementation.

io.netty.handler.ssl.OpenSslClientContext(File
an X.509 certificate chain file in PEM format. null to use the system default
certChainFile
)

use SslContextBuilder

io.netty.handler.ssl.OpenSslClientContext(TrustManagerFactory
the TrustManagerFactory that provides the TrustManagers that verifies the certificates sent from servers. null to use the default.
trustManagerFactory
)

use SslContextBuilder

io.netty.handler.ssl.OpenSslClientContext(File
an X.509 certificate chain file in PEM format. null to use the system default
certChainFile
,
TrustManagerFactory
the TrustManagerFactory that provides the TrustManagers that verifies the certificates sent from servers. null to use the default.
trustManagerFactory
)

use SslContextBuilder

io.netty.handler.ssl.OpenSslClientContext(File
an X.509 certificate chain file in PEM format
certChainFile
,
TrustManagerFactory
the TrustManagerFactory that provides the TrustManagers that verifies the certificates sent from servers. null to use the default..
trustManagerFactory
,
Iterable<String>
the cipher suites to enable, in the order of preference. null to use the default cipher suites.
ciphers
,
ApplicationProtocolConfig
Provides a means to configure parameters related to application protocol negotiation.
apn
,
long
the size of the cache used for storing SSL session objects. 0 to use the default value.
sessionCacheSize
,
long
the timeout for the cached SSL session objects, in seconds. 0 to use the default value.
sessionTimeout
)

use SslContextBuilder

io.netty.handler.ssl.OpenSslClientContext(File
an X.509 certificate chain file in PEM format
certChainFile
,
TrustManagerFactory
the TrustManagerFactory that provides the TrustManagers that verifies the certificates sent from servers. null to use the default..
trustManagerFactory
,
Iterable<String>
the cipher suites to enable, in the order of preference. null to use the default cipher suites.
ciphers
,
CipherSuiteFilter
a filter to apply over the supplied list of ciphers
cipherFilter
,
ApplicationProtocolConfig
Provides a means to configure parameters related to application protocol negotiation.
apn
,
long
the size of the cache used for storing SSL session objects. 0 to use the default value.
sessionCacheSize
,
long
the timeout for the cached SSL session objects, in seconds. 0 to use the default value.
sessionTimeout
)

use SslContextBuilder

io.netty.handler.ssl.OpenSslClientContext(File
an X.509 certificate collection file in PEM format. null to use the system default
trustCertCollectionFile
,
TrustManagerFactory
the TrustManagerFactory that provides the TrustManagers that verifies the certificates sent from servers. null to use the default or the results of parsing trustCertCollectionFile
trustManagerFactory
,
File
an X.509 certificate chain file in PEM format. This provides the public key for mutual authentication. null to use the system default
keyCertChainFile
,
File
a PKCS#8 private key file in PEM format. This provides the private key for mutual authentication. null for no mutual authentication.
keyFile
,
String
the password of the keyFile. null if it's not password-protected. Ignored if keyFile is null.
keyPassword
,
KeyManagerFactory
the KeyManagerFactory that provides the javax.net.ssl.KeyManagers that is used to encrypt data being sent to servers. null to use the default or the results of parsing keyCertChainFile and keyFile.
keyManagerFactory
,
Iterable<String>
the cipher suites to enable, in the order of preference. null to use the default cipher suites.
ciphers
,
CipherSuiteFilter
a filter to apply over the supplied list of ciphers
cipherFilter
,
ApplicationProtocolConfig
Application Protocol Negotiator object.
apn
,
long
the size of the cache used for storing SSL session objects. 0 to use the default value.
sessionCacheSize
,
long
the timeout for the cached SSL session objects, in seconds. 0 to use the default value.
sessionTimeout
)

use SslContextBuilder

io.netty.handler.ssl.OpenSslContext(Iterable<String> ciphers, CipherSuiteFilter cipherFilter, OpenSslApplicationProtocolNegotiator apn, int mode, Certificate[] keyCertChain, ClientAuth clientAuth, String[] protocols, boolean startTls, boolean enableOcsp, Map.Entry<SslContextOption<?>, Object>... options)

Deprecated as a consequence of OpenSslApplicationProtocolNegotiator being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.OpenSslServerContext(File
an X.509 certificate chain file in PEM format
certChainFile
,
File
a PKCS#8 private key file in PEM format
keyFile
)

use SslContextBuilder

io.netty.handler.ssl.OpenSslServerContext(File
an X.509 certificate chain file in PEM format
certChainFile
,
File
a PKCS#8 private key file in PEM format
keyFile
,
String
the password of the keyFile. null if it's not password-protected.
keyPassword
)

use SslContextBuilder

io.netty.handler.ssl.OpenSslServerContext(File
an X.509 certificate chain file in PEM format
certChainFile
,
File
a PKCS#8 private key file in PEM format
keyFile
,
String
the password of the keyFile. null if it's not password-protected.
keyPassword
,
Iterable<String>
the cipher suites to enable, in the order of preference. null to use the default cipher suites.
ciphers
,
ApplicationProtocolConfig
Provides a means to configure parameters related to application protocol negotiation.
apn
,
long
the size of the cache used for storing SSL session objects. 0 to use the default value.
sessionCacheSize
,
long
the timeout for the cached SSL session objects, in seconds. 0 to use the default value.
sessionTimeout
)

use SslContextBuilder

io.netty.handler.ssl.OpenSslServerContext(File
an X.509 certificate chain file in PEM format
certChainFile
,
File
a PKCS#8 private key file in PEM format
keyFile
,
String
the password of the keyFile. null if it's not password-protected.
keyPassword
,
Iterable<String>
the cipher suites to enable, in the order of preference. null to use the default cipher suites.
ciphers
,
Iterable<String>
the application layer protocols to accept, in the order of preference. null to disable TLS NPN/ALPN extension.
nextProtocols
,
long
the size of the cache used for storing SSL session objects. 0 to use the default value.
sessionCacheSize
,
long
the timeout for the cached SSL session objects, in seconds. 0 to use the default value.
sessionTimeout
)

use SslContextBuilder

io.netty.handler.ssl.OpenSslServerContext(File
an X.509 certificate chain file in PEM format
certChainFile
,
File
a PKCS#8 private key file in PEM format
keyFile
,
String
the password of the keyFile. null if it's not password-protected.
keyPassword
,
TrustManagerFactory trustManagerFactory, Iterable<String>
the cipher suites to enable, in the order of preference. null to use the default cipher suites.
ciphers
,
ApplicationProtocolConfig
Application protocol config.
config
,
long
the size of the cache used for storing SSL session objects. 0 to use the default value.
sessionCacheSize
,
long
the timeout for the cached SSL session objects, in seconds. 0 to use the default value.
sessionTimeout
)

use SslContextBuilder

io.netty.handler.ssl.OpenSslServerContext(File
an X.509 certificate chain file in PEM format
certChainFile
,
File
a PKCS#8 private key file in PEM format
keyFile
,
String
the password of the keyFile. null if it's not password-protected.
keyPassword
,
TrustManagerFactory trustManagerFactory, Iterable<String>
the cipher suites to enable, in the order of preference. null to use the default cipher suites.
ciphers
,
OpenSslApplicationProtocolNegotiator
Application protocol negotiator.
apn
,
long
the size of the cache used for storing SSL session objects. 0 to use the default value.
sessionCacheSize
,
long
the timeout for the cached SSL session objects, in seconds. 0 to use the default value.
sessionTimeout
)

use SslContextBuilder

io.netty.handler.ssl.OpenSslServerContext(File
an X.509 certificate chain file in PEM format
certChainFile
,
File
a PKCS#8 private key file in PEM format
keyFile
,
String
the password of the keyFile. null if it's not password-protected.
keyPassword
,
Iterable<String>
the cipher suites to enable, in the order of preference. null to use the default cipher suites.
ciphers
,
CipherSuiteFilter
a filter to apply over the supplied list of ciphers
cipherFilter
,
ApplicationProtocolConfig
Provides a means to configure parameters related to application protocol negotiation.
apn
,
long
the size of the cache used for storing SSL session objects. 0 to use the default value.
sessionCacheSize
,
long
the timeout for the cached SSL session objects, in seconds. 0 to use the default value.
sessionTimeout
)

use SslContextBuilder

io.netty.handler.ssl.OpenSslServerContext(File
an X.509 certificate collection file in PEM format. This provides the certificate collection used for mutual authentication. null to use the system default
trustCertCollectionFile
,
TrustManagerFactory
the TrustManagerFactory that provides the TrustManagers that verifies the certificates sent from clients. null to use the default or the results of parsing trustCertCollectionFile.
trustManagerFactory
,
File
an X.509 certificate chain file in PEM format
keyCertChainFile
,
File
a PKCS#8 private key file in PEM format
keyFile
,
String
the password of the keyFile. null if it's not password-protected.
keyPassword
,
KeyManagerFactory
the KeyManagerFactory that provides the KeyManagers that is used to encrypt data being sent to clients. null to use the default or the results of parsing keyCertChainFile and keyFile.
keyManagerFactory
,
Iterable<String>
the cipher suites to enable, in the order of preference. null to use the default cipher suites.
ciphers
,
CipherSuiteFilter
a filter to apply over the supplied list of ciphers Only required if provider is SslProvider#JDK
cipherFilter
,
ApplicationProtocolConfig
Provides a means to configure parameters related to application protocol negotiation.
config
,
long
the size of the cache used for storing SSL session objects. 0 to use the default value.
sessionCacheSize
,
long
the timeout for the cached SSL session objects, in seconds. 0 to use the default value.
sessionTimeout
)

use SslContextBuilder

io.netty.handler.ssl.OpenSslServerContext(File
an X.509 certificate chain file in PEM format
certChainFile
,
File
a PKCS#8 private key file in PEM format
keyFile
,
String
the password of the keyFile. null if it's not password-protected.
keyPassword
,
TrustManagerFactory trustManagerFactory, Iterable<String>
the cipher suites to enable, in the order of preference. null to use the default cipher suites.
ciphers
,
CipherSuiteFilter
a filter to apply over the supplied list of ciphers
cipherFilter
,
ApplicationProtocolConfig
Application protocol config.
config
,
long
the size of the cache used for storing SSL session objects. 0 to use the default value.
sessionCacheSize
,
long
the timeout for the cached SSL session objects, in seconds. 0 to use the default value.
sessionTimeout
)

use SslContextBuilder

io.netty.handler.ssl.OpenSslServerContext(File
an X.509 certificate chain file in PEM format
certChainFile
,
File
a PKCS#8 private key file in PEM format
keyFile
,
String
the password of the keyFile. null if it's not password-protected.
keyPassword
,
TrustManagerFactory trustManagerFactory, Iterable<String>
the cipher suites to enable, in the order of preference. null to use the default cipher suites.
ciphers
,
CipherSuiteFilter
a filter to apply over the supplied list of ciphers
cipherFilter
,
OpenSslApplicationProtocolNegotiator
Application protocol negotiator.
apn
,
long
the size of the cache used for storing SSL session objects. 0 to use the default value.
sessionCacheSize
,
long
the timeout for the cached SSL session objects, in seconds. 0 to use the default value.
sessionTimeout
)

use SslContextBuilder}

io.netty.handler.ssl.OpenSslServerContext(File
an X.509 certificate collection file in PEM format. This provides the certificate collection used for mutual authentication. null to use the system default
trustCertCollectionFile
,
TrustManagerFactory
the TrustManagerFactory that provides the TrustManagers that verifies the certificates sent from clients. null to use the default or the results of parsing trustCertCollectionFile.
trustManagerFactory
,
File
an X.509 certificate chain file in PEM format
keyCertChainFile
,
File
a PKCS#8 private key file in PEM format
keyFile
,
String
the password of the keyFile. null if it's not password-protected.
keyPassword
,
KeyManagerFactory
the KeyManagerFactory that provides the KeyManagers that is used to encrypt data being sent to clients. null to use the default or the results of parsing keyCertChainFile and keyFile.
keyManagerFactory
,
Iterable<String>
the cipher suites to enable, in the order of preference. null to use the default cipher suites.
ciphers
,
CipherSuiteFilter
a filter to apply over the supplied list of ciphers Only required if provider is SslProvider#JDK
cipherFilter
,
OpenSslApplicationProtocolNegotiator
Application Protocol Negotiator object
apn
,
long
the size of the cache used for storing SSL session objects. 0 to use the default value.
sessionCacheSize
,
long
the timeout for the cached SSL session objects, in seconds. 0 to use the default value.
sessionTimeout
)

use SslContextBuilder

io.netty.handler.ssl.OpenSslServerContext(X509Certificate[] trustCertCollection, TrustManagerFactory trustManagerFactory, X509Certificate[] keyCertChain, PrivateKey key, String keyPassword, KeyManagerFactory keyManagerFactory, Iterable<String> ciphers, CipherSuiteFilter cipherFilter, OpenSslApplicationProtocolNegotiator apn, long sessionCacheSize, long sessionTimeout, ClientAuth clientAuth, String[] protocols, boolean startTls, boolean enableOcsp, String keyStore, Map.Entry<SslContextOption<?>, Object>... options)

Deprecated as a consequence of OpenSslApplicationProtocolNegotiator being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.OpenSslSessionCache.NativeSslSession.getPeerCertificateChain()

Deprecated as a consequence of X509Certificate being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.ReferenceCountedOpenSslContext.NONE_PROTOCOL_NEGOTIATOR

Deprecated as a consequence of OpenSslApplicationProtocolNegotiator being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.ReferenceCountedOpenSslContext(Iterable<String> ciphers, CipherSuiteFilter cipherFilter, OpenSslApplicationProtocolNegotiator apn, int mode, Certificate[] keyCertChain, ClientAuth clientAuth, String[] protocols, boolean startTls, boolean enableOcsp, boolean leakDetection, Map.Entry<SslContextOption<?>, Object>... ctxOptions)

Deprecated as a consequence of OpenSslApplicationProtocolNegotiator being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.ReferenceCountedOpenSslContext.apn

Deprecated as a consequence of OpenSslApplicationProtocolNegotiator being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.ReferenceCountedOpenSslContext.applicationProtocolNegotiator()

Deprecated as a consequence of ApplicationProtocolNegotiator being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.ReferenceCountedOpenSslContext.context()

this method is considered unsafe as the returned pointer may be released later. Dont use it!

io.netty.handler.ssl.ReferenceCountedOpenSslContext.sslCtxPointer()

this method is considered unsafe as the returned pointer may be released later. Dont use it!

Returns:

The results of the translation
io.netty.handler.ssl.ReferenceCountedOpenSslContext.toNegotiator
(ApplicationProtocolConfig
The configuration which defines the translation
config
)

Deprecated as a consequence of OpenSslApplicationProtocolNegotiator being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.ReferenceCountedOpenSslEngine.DefaultOpenSslSession.getPeerCertificateChain()

Deprecated as a consequence of X509Certificate being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.ReferenceCountedOpenSslEngine.DefaultOpenSslSession.x509PeerCerts

Deprecated as a consequence of X509Certificate being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.ReferenceCountedOpenSslEngine.JAVAX_CERTS_NOT_SUPPORTED

Deprecated as a consequence of X509Certificate being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.ReferenceCountedOpenSslEngine.apn

Deprecated as a consequence of OpenSslApplicationProtocolNegotiator being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.ReferenceCountedOpenSslServerContext(X509Certificate[] trustCertCollection, TrustManagerFactory trustManagerFactory, X509Certificate[] keyCertChain, PrivateKey key, String keyPassword, KeyManagerFactory keyManagerFactory, Iterable<String> ciphers, CipherSuiteFilter cipherFilter, OpenSslApplicationProtocolNegotiator apn, long sessionCacheSize, long sessionTimeout, ClientAuth clientAuth, String[] protocols, boolean startTls, boolean enableOcsp, String keyStore, Map.Entry<SslContextOption<?>, Object>... options)

Deprecated as a consequence of OpenSslApplicationProtocolNegotiator being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.SniHandler(DomainNameMapping<? extends SslContext>
the mapping of domain name to SslContext
mapping
)

Deprecated as a consequence of DomainNameMapping being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.SslContext.applicationProtocolNegotiator()

Deprecated as a consequence of ApplicationProtocolNegotiator being deprecated. See corresponding docs for further information.

Returns:

A TrustManagerFactory which contains the certificates in certChainFile
io.netty.handler.ssl.SslContext.buildTrustManagerFactory
(File
The certificate file to build from.
certChainFile
,
TrustManagerFactory
The existing TrustManagerFactory that will be used if not null.
trustManagerFactory
)

Returns:

a key specification
io.netty.handler.ssl.SslContext.generateKeySpec
(char[]
characters, if null an unencrypted key is assumed
password
,
byte[]
bytes of the DER encoded private key
key
)

Returns:

a new client-side SslContext
io.netty.handler.ssl.SslContext.newClientContext
(File
an X.509 certificate chain file in PEM format
certChainFile
)

Replaced by SslContextBuilder

Returns:

a new client-side SslContext
io.netty.handler.ssl.SslContext.newClientContext
(TrustManagerFactory
the TrustManagerFactory that provides the TrustManagers that verifies the certificates sent from servers. null to use the default.
trustManagerFactory
)

Replaced by SslContextBuilder

Returns:

a new client-side SslContext
io.netty.handler.ssl.SslContext.newClientContext
(File
an X.509 certificate chain file in PEM format. null to use the system default
certChainFile
,
TrustManagerFactory
the TrustManagerFactory that provides the TrustManagers that verifies the certificates sent from servers. null to use the default.
trustManagerFactory
)

Replaced by SslContextBuilder

Returns:

a new client-side SslContext
io.netty.handler.ssl.SslContext.newClientContext
(File
an X.509 certificate chain file in PEM format. null to use the system default
certChainFile
,
TrustManagerFactory
the TrustManagerFactory that provides the TrustManagers that verifies the certificates sent from servers. null to use the default.
trustManagerFactory
,
Iterable<String>
the cipher suites to enable, in the order of preference. null to use the default cipher suites.
ciphers
,
Iterable<String>
the application layer protocols to accept, in the order of preference. null to disable TLS NPN/ALPN extension.
nextProtocols
,
long
the size of the cache used for storing SSL session objects. 0 to use the default value.
sessionCacheSize
,
long
the timeout for the cached SSL session objects, in seconds. 0 to use the default value.
sessionTimeout
)

Replaced by SslContextBuilder

Returns:

a new client-side SslContext
io.netty.handler.ssl.SslContext.newClientContext
(File
an X.509 certificate chain file in PEM format. null to use the system default
certChainFile
,
TrustManagerFactory
the TrustManagerFactory that provides the TrustManagers that verifies the certificates sent from servers. null to use the default.
trustManagerFactory
,
Iterable<String>
the cipher suites to enable, in the order of preference. null to use the default cipher suites.
ciphers
,
CipherSuiteFilter
a filter to apply over the supplied list of ciphers
cipherFilter
,
ApplicationProtocolConfig
Provides a means to configure parameters related to application protocol negotiation.
apn
,
long
the size of the cache used for storing SSL session objects. 0 to use the default value.
sessionCacheSize
,
long
the timeout for the cached SSL session objects, in seconds. 0 to use the default value.
sessionTimeout
)

Replaced by SslContextBuilder

Returns:

a new client-side SslContext
io.netty.handler.ssl.SslContext.newClientContext
(SslProvider
the SslContext implementation to use. null to use the current default one.
provider
)

Replaced by SslContextBuilder

Returns:

a new client-side SslContext
io.netty.handler.ssl.SslContext.newClientContext
(SslProvider
the SslContext implementation to use. null to use the current default one.
provider
,
File
an X.509 certificate chain file in PEM format. null to use the system default
certChainFile
)

Replaced by SslContextBuilder

Returns:

a new client-side SslContext
io.netty.handler.ssl.SslContext.newClientContext
(SslProvider
the SslContext implementation to use. null to use the current default one.
provider
,
TrustManagerFactory
the TrustManagerFactory that provides the TrustManagers that verifies the certificates sent from servers. null to use the default.
trustManagerFactory
)

Replaced by SslContextBuilder

Returns:

a new client-side SslContext
io.netty.handler.ssl.SslContext.newClientContext
(SslProvider
the SslContext implementation to use. null to use the current default one.
provider
,
File
an X.509 certificate chain file in PEM format. null to use the system default
certChainFile
,
TrustManagerFactory
the TrustManagerFactory that provides the TrustManagers that verifies the certificates sent from servers. null to use the default.
trustManagerFactory
)

Replaced by SslContextBuilder

Returns:

a new client-side SslContext
io.netty.handler.ssl.SslContext.newClientContext
(SslProvider
the SslContext implementation to use. null to use the current default one.
provider
,
File
an X.509 certificate chain file in PEM format. null to use the system default
certChainFile
,
TrustManagerFactory
the TrustManagerFactory that provides the TrustManagers that verifies the certificates sent from servers. null to use the default.
trustManagerFactory
,
Iterable<String>
the cipher suites to enable, in the order of preference. null to use the default cipher suites.
ciphers
,
Iterable<String>
the application layer protocols to accept, in the order of preference. null to disable TLS NPN/ALPN extension.
nextProtocols
,
long
the size of the cache used for storing SSL session objects. 0 to use the default value.
sessionCacheSize
,
long
the timeout for the cached SSL session objects, in seconds. 0 to use the default value.
sessionTimeout
)

Replaced by SslContextBuilder

Returns:

a new client-side SslContext
io.netty.handler.ssl.SslContext.newClientContext
(SslProvider
the SslContext implementation to use. null to use the current default one.
provider
,
File
an X.509 certificate chain file in PEM format. null to use the system default
certChainFile
,
TrustManagerFactory
the TrustManagerFactory that provides the TrustManagers that verifies the certificates sent from servers. null to use the default.
trustManagerFactory
,
Iterable<String>
the cipher suites to enable, in the order of preference. null to use the default cipher suites.
ciphers
,
CipherSuiteFilter
a filter to apply over the supplied list of ciphers
cipherFilter
,
ApplicationProtocolConfig
Provides a means to configure parameters related to application protocol negotiation.
apn
,
long
the size of the cache used for storing SSL session objects. 0 to use the default value.
sessionCacheSize
,
long
the timeout for the cached SSL session objects, in seconds. 0 to use the default value.
sessionTimeout
)

Replaced by SslContextBuilder

Returns:

a new client-side SslContext
io.netty.handler.ssl.SslContext.newClientContext
(SslProvider
the SslContext implementation to use. null to use the current default one.
provider
,
File
an X.509 certificate collection file in PEM format. null to use the system default
trustCertCollectionFile
,
TrustManagerFactory
the TrustManagerFactory that provides the TrustManagers that verifies the certificates sent from servers. null to use the default or the results of parsing trustCertCollectionFile. This parameter is ignored if provider is not SslProvider#JDK.
trustManagerFactory
,
File
an X.509 certificate chain file in PEM format. This provides the public key for mutual authentication. null to use the system default
keyCertChainFile
,
File
a PKCS#8 private key file in PEM format. This provides the private key for mutual authentication. null for no mutual authentication.
keyFile
,
String
the password of the keyFile. null if it's not password-protected. Ignored if keyFile is null.
keyPassword
,
KeyManagerFactory
the KeyManagerFactory that provides the KeyManagers that is used to encrypt data being sent to servers. null to use the default or the results of parsing keyCertChainFile and keyFile. This parameter is ignored if provider is not SslProvider#JDK.
keyManagerFactory
,
Iterable<String>
the cipher suites to enable, in the order of preference. null to use the default cipher suites.
ciphers
,
CipherSuiteFilter
a filter to apply over the supplied list of ciphers
cipherFilter
,
ApplicationProtocolConfig
Provides a means to configure parameters related to application protocol negotiation.
apn
,
long
the size of the cache used for storing SSL session objects. 0 to use the default value.
sessionCacheSize
,
long
the timeout for the cached SSL session objects, in seconds. 0 to use the default value.
sessionTimeout
)

Replaced by SslContextBuilder

Returns:

a new server-side SslContext
io.netty.handler.ssl.SslContext.newServerContext
(File
an X.509 certificate chain file in PEM format
certChainFile
,
File
a PKCS#8 private key file in PEM format
keyFile
)

Replaced by SslContextBuilder

Returns:

a new server-side SslContext
io.netty.handler.ssl.SslContext.newServerContext
(File
an X.509 certificate chain file in PEM format
certChainFile
,
File
a PKCS#8 private key file in PEM format
keyFile
,
String
the password of the keyFile. null if it's not password-protected.
keyPassword
)

Replaced by SslContextBuilder

Returns:

a new server-side SslContext
io.netty.handler.ssl.SslContext.newServerContext
(File
an X.509 certificate chain file in PEM format
certChainFile
,
File
a PKCS#8 private key file in PEM format
keyFile
,
String
the password of the keyFile. null if it's not password-protected.
keyPassword
,
Iterable<String>
the cipher suites to enable, in the order of preference. null to use the default cipher suites.
ciphers
,
Iterable<String>
the application layer protocols to accept, in the order of preference. null to disable TLS NPN/ALPN extension.
nextProtocols
,
long
the size of the cache used for storing SSL session objects. 0 to use the default value.
sessionCacheSize
,
long
the timeout for the cached SSL session objects, in seconds. 0 to use the default value.
sessionTimeout
)

Replaced by SslContextBuilder

Returns:

a new server-side SslContext
io.netty.handler.ssl.SslContext.newServerContext
(File
an X.509 certificate chain file in PEM format
certChainFile
,
File
a PKCS#8 private key file in PEM format
keyFile
,
String
the password of the keyFile. null if it's not password-protected.
keyPassword
,
Iterable<String>
the cipher suites to enable, in the order of preference. null to use the default cipher suites.
ciphers
,
CipherSuiteFilter
a filter to apply over the supplied list of ciphers
cipherFilter
,
ApplicationProtocolConfig
Provides a means to configure parameters related to application protocol negotiation.
apn
,
long
the size of the cache used for storing SSL session objects. 0 to use the default value.
sessionCacheSize
,
long
the timeout for the cached SSL session objects, in seconds. 0 to use the default value.
sessionTimeout
)

Replaced by SslContextBuilder

Returns:

a new server-side SslContext
io.netty.handler.ssl.SslContext.newServerContext
(SslProvider
the SslContext implementation to use. null to use the current default one.
provider
,
File
an X.509 certificate chain file in PEM format
certChainFile
,
File
a PKCS#8 private key file in PEM format
keyFile
)

Replaced by SslContextBuilder

Returns:

a new server-side SslContext
io.netty.handler.ssl.SslContext.newServerContext
(SslProvider
the SslContext implementation to use. null to use the current default one.
provider
,
File
an X.509 certificate chain file in PEM format
certChainFile
,
File
a PKCS#8 private key file in PEM format
keyFile
,
String
the password of the keyFile. null if it's not password-protected.
keyPassword
)

Replaced by SslContextBuilder

Returns:

a new server-side SslContext
io.netty.handler.ssl.SslContext.newServerContext
(SslProvider
the SslContext implementation to use. null to use the current default one.
provider
,
File
an X.509 certificate chain file in PEM format
certChainFile
,
File
a PKCS#8 private key file in PEM format
keyFile
,
String
the password of the keyFile. null if it's not password-protected.
keyPassword
,
Iterable<String>
the cipher suites to enable, in the order of preference. null to use the default cipher suites.
ciphers
,
Iterable<String>
the application layer protocols to accept, in the order of preference. null to disable TLS NPN/ALPN extension.
nextProtocols
,
long
the size of the cache used for storing SSL session objects. 0 to use the default value.
sessionCacheSize
,
long
the timeout for the cached SSL session objects, in seconds. 0 to use the default value.
sessionTimeout
)

Replaced by SslContextBuilder

Returns:

a new server-side SslContext
io.netty.handler.ssl.SslContext.newServerContext
(SslProvider
the SslContext implementation to use. null to use the current default one.
provider
,
File
an X.509 certificate chain file in PEM format
certChainFile
,
File
a PKCS#8 private key file in PEM format
keyFile
,
String
the password of the keyFile. null if it's not password-protected.
keyPassword
,
TrustManagerFactory
the TrustManagerFactory that provides the TrustManagers that verifies the certificates sent from servers. null to use the default.
trustManagerFactory
,
Iterable<String>
the cipher suites to enable, in the order of preference. null to use the default cipher suites.
ciphers
,
Iterable<String>
the application layer protocols to accept, in the order of preference. null to disable TLS NPN/ALPN extension.
nextProtocols
,
long
the size of the cache used for storing SSL session objects. 0 to use the default value.
sessionCacheSize
,
long
the timeout for the cached SSL session objects, in seconds. 0 to use the default value.
sessionTimeout
)

Replaced by SslContextBuilder

Returns:

a new server-side SslContext
io.netty.handler.ssl.SslContext.newServerContext
(SslProvider
the SslContext implementation to use. null to use the current default one.
provider
,
File
an X.509 certificate chain file in PEM format
certChainFile
,
File
a PKCS#8 private key file in PEM format
keyFile
,
String
the password of the keyFile. null if it's not password-protected.
keyPassword
,
Iterable<String>
the cipher suites to enable, in the order of preference. null to use the default cipher suites.
ciphers
,
CipherSuiteFilter
a filter to apply over the supplied list of ciphers Only required if provider is SslProvider#JDK
cipherFilter
,
ApplicationProtocolConfig
Provides a means to configure parameters related to application protocol negotiation.
apn
,
long
the size of the cache used for storing SSL session objects. 0 to use the default value.
sessionCacheSize
,
long
the timeout for the cached SSL session objects, in seconds. 0 to use the default value.
sessionTimeout
)

Replaced by SslContextBuilder

Returns:

a new server-side SslContext
io.netty.handler.ssl.SslContext.newServerContext
(SslProvider
the SslContext implementation to use. null to use the current default one.
provider
,
File
an X.509 certificate collection file in PEM format. This provides the certificate collection used for mutual authentication. null to use the system default
trustCertCollectionFile
,
TrustManagerFactory
the TrustManagerFactory that provides the TrustManagers that verifies the certificates sent from clients. null to use the default or the results of parsing trustCertCollectionFile. This parameter is ignored if provider is not SslProvider#JDK.
trustManagerFactory
,
File
an X.509 certificate chain file in PEM format
keyCertChainFile
,
File
a PKCS#8 private key file in PEM format
keyFile
,
String
the password of the keyFile. null if it's not password-protected.
keyPassword
,
KeyManagerFactory
the KeyManagerFactory that provides the KeyManagers that is used to encrypt data being sent to clients. null to use the default or the results of parsing keyCertChainFile and keyFile. This parameter is ignored if provider is not SslProvider#JDK.
keyManagerFactory
,
Iterable<String>
the cipher suites to enable, in the order of preference. null to use the default cipher suites.
ciphers
,
CipherSuiteFilter
a filter to apply over the supplied list of ciphers Only required if provider is SslProvider#JDK
cipherFilter
,
ApplicationProtocolConfig
Provides a means to configure parameters related to application protocol negotiation.
apn
,
long
the size of the cache used for storing SSL session objects. 0 to use the default value.
sessionCacheSize
,
long
the timeout for the cached SSL session objects, in seconds. 0 to use the default value.
sessionTimeout
)

Replaced by SslContextBuilder

io.netty.handler.ssl.SslProtocols.SSL_v2

SSLv2 is no longer secure. Consider using TLS_v1_2 or TLS_v1_3

io.netty.handler.ssl.SslProtocols.SSL_v2_HELLO

SSLv2Hello is no longer secure. Consider using TLS_v1_2 or TLS_v1_3

io.netty.handler.ssl.SslProtocols.SSL_v3

SSLv3 is no longer secure. Consider using TLS_v1_2 or TLS_v1_3

io.netty.handler.ssl.SslProtocols.TLS_v1

TLSv1 is no longer secure. Consider using TLS_v1_2 or TLS_v1_3

io.netty.handler.ssl.SslProtocols.TLS_v1_1

TLSv1.1 is no longer secure. Consider using TLS_v1_2 or TLS_v1_3

io.netty.handler.ssl.util.FingerprintTrustManagerFactory(Iterable<String>
a list of SHA1 fingerprints in hexadecimal form
fingerprints
)

This deprecated constructor uses SHA-1 that is considered insecure. It is recommended to specify a stronger hash algorithm, such as SHA-256, by calling FingerprintTrustManagerFactory#builder(String) method.

io.netty.handler.ssl.util.FingerprintTrustManagerFactory(String...
a list of SHA1 fingerprints in hexadecimal form
fingerprints
)

This deprecated constructor uses SHA-1 that is considered insecure. It is recommended to specify a stronger hash algorithm, such as SHA-256, by calling FingerprintTrustManagerFactory#builder(String) method.

io.netty.handler.ssl.util.FingerprintTrustManagerFactory(byte[]...
a list of SHA1 fingerprints
fingerprints
)

This deprecated constructor uses SHA-1 that is considered insecure. It is recommended to specify a stronger hash algorithm, such as SHA-256, by calling FingerprintTrustManagerFactory#builder(String) method.

io.netty.handler.ssl.util.LazyJavaxX509Certificate

Deprecated as a consequence of X509Certificate being deprecated.

io.netty.handler.ssl.util.LazyJavaxX509Certificate.unwrap()

Deprecated as a consequence of X509Certificate being deprecated. See corresponding docs for further information.

io.netty.handler.ssl.util.LazyJavaxX509Certificate.wrapped

Deprecated as a consequence of X509Certificate being deprecated. See corresponding docs for further information.

io.netty.handler.stream.ChunkedFile.readChunk(ChannelHandlerContext
The context which provides a ByteBufAllocator if buffer allocation is necessary.
ctx
)

Returns:

the fetched chunk. null if there is no data left in the stream. Please note that null does not necessarily mean that the stream has reached at its end. In a slow stream, the next chunk might be unavailable just momentarily.
io.netty.handler.stream.ChunkedInput.readChunk
(ChannelHandlerContext
The context which provides a ByteBufAllocator if buffer allocation is necessary.
ctx
)

Use readChunk(ByteBufAllocator).

Fetches a chunked data from the stream. Once this method returns the last chunk and thus the stream has reached at its end, any subsequent isEndOfInput() call must return true.

io.netty.handler.stream.ChunkedNioFile.readChunk(ChannelHandlerContext
The context which provides a ByteBufAllocator if buffer allocation is necessary.
ctx
)

io.netty.handler.stream.ChunkedNioStream.readChunk(ChannelHandlerContext
The context which provides a ByteBufAllocator if buffer allocation is necessary.
ctx
)

io.netty.handler.stream.ChunkedStream.readChunk(ChannelHandlerContext
The context which provides a ByteBufAllocator if buffer allocation is necessary.
ctx
)

Returns:

the current time to wait (in ms) if needed for Read operation.
io.netty.handler.traffic.TrafficCounter.readTimeToWait
(final long
the recv size
size
,
final long
the traffic limit in bytes per second.
limitTraffic
,
final long
the max time in ms to wait in case of excess of traffic.
maxTime
)

Returns:

the current time to wait (in ms) if needed for Write operation.
io.netty.handler.traffic.TrafficCounter.writeTimeToWait
(final long
the write size
size
,
final long
the traffic limit in bytes per second.
limitTraffic
,
final long
the max time in ms to wait in case of excess of traffic.
maxTime
)

io.netty.resolver.dns.DnsAddressResolverGroup(ChannelFactory<? extends DatagramChannel> channelFactory, DnsServerAddressStreamProvider nameServerProvider)

Deprecated as a consequence of ChannelFactory being deprecated. See corresponding docs for further information.

io.netty.resolver.dns.DnsAddressResolverGroup.newNameResolver(EventLoop eventLoop, ChannelFactory<? extends DatagramChannel> channelFactory, DnsServerAddressStreamProvider nameServerProvider)

Deprecated as a consequence of ChannelFactory being deprecated. See corresponding docs for further information.

io.netty.resolver.dns.DnsNameResolver(EventLoop
the EventLoop which will perform the communication with the DNS servers
eventLoop
,
ChannelFactory<? extends DatagramChannel>
the ChannelFactory that will create a DatagramChannel
channelFactory
,
final DnsCache
the DNS resolved entries cache
resolveCache
,
final DnsCache
the cache used to find the authoritative DNS server for a domain
authoritativeDnsServerCache
,
DnsQueryLifecycleObserverFactory
used to generate new instances of DnsQueryLifecycleObserver which can be used to track metrics for DNS servers.
dnsQueryLifecycleObserverFactory
,
long
timeout of each DNS query in millis. 0 disables the timeout. If not set or a negative number is set, the default timeout is used.
queryTimeoutMillis
,
ResolvedAddressTypes
the preferred address types
resolvedAddressTypes
,
boolean
if recursion desired flag must be set
recursionDesired
,
int
the maximum allowed number of DNS queries for a given name resolution
maxQueriesPerResolve
,
boolean
if trace is enabled
traceEnabled
,
int
the capacity of the datagram packet buffer
maxPayloadSize
,
boolean
if automatic inclusion of a optional records is enabled
optResourceEnabled
,
HostsFileEntriesResolver
the HostsFileEntriesResolver used to check for local aliases
hostsFileEntriesResolver
,
DnsServerAddressStreamProvider
The DnsServerAddressStreamProvider used to determine the name servers for each hostname lookup.
dnsServerAddressStreamProvider
,
String[]
the list of search domain (can be null, if so, will try to default to the underlying platform ones)
searchDomains
,
int
the ndots value
ndots
,
boolean
true if domain / host names should be decoded to unicode when received. See rfc3492.
decodeIdn
)

Use DnsNameResolverBuilder.

io.netty.resolver.dns.DnsNameResolver(EventLoop
the EventLoop which will perform the communication with the DNS servers
eventLoop
,
ChannelFactory<? extends DatagramChannel>
the ChannelFactory that will create a DatagramChannel
channelFactory
,
final DnsCache
the DNS resolved entries cache
resolveCache
,
final AuthoritativeDnsServerCache
the cache used to find the authoritative DNS server for a domain
authoritativeDnsServerCache
,
DnsQueryLifecycleObserverFactory
used to generate new instances of DnsQueryLifecycleObserver which can be used to track metrics for DNS servers.
dnsQueryLifecycleObserverFactory
,
long
timeout of each DNS query in millis. 0 disables the timeout. If not set or a negative number is set, the default timeout is used.
queryTimeoutMillis
,
ResolvedAddressTypes
the preferred address types
resolvedAddressTypes
,
boolean
if recursion desired flag must be set
recursionDesired
,
int
the maximum allowed number of DNS queries for a given name resolution
maxQueriesPerResolve
,
boolean
if trace is enabled
traceEnabled
,
int
the capacity of the datagram packet buffer
maxPayloadSize
,
boolean
if automatic inclusion of a optional records is enabled
optResourceEnabled
,
HostsFileEntriesResolver
the HostsFileEntriesResolver used to check for local aliases
hostsFileEntriesResolver
,
DnsServerAddressStreamProvider
The DnsServerAddressStreamProvider used to determine the name servers for each hostname lookup.
dnsServerAddressStreamProvider
,
String[]
the list of search domain (can be null, if so, will try to default to the underlying platform ones)
searchDomains
,
int
the ndots value
ndots
,
boolean
true if domain / host names should be decoded to unicode when received. See rfc3492.
decodeIdn
)

Use DnsNameResolverBuilder.

io.netty.resolver.dns.DnsNameResolver(EventLoop eventLoop, ChannelFactory<? extends DatagramChannel> channelFactory, ChannelFactory<? extends SocketChannel> socketChannelFactory, boolean retryWithTcpOnTimeout, final DnsCache resolveCache, final DnsCnameCache cnameCache, final AuthoritativeDnsServerCache authoritativeDnsServerCache, SocketAddress localAddress, DnsQueryLifecycleObserverFactory dnsQueryLifecycleObserverFactory, long queryTimeoutMillis, ResolvedAddressTypes resolvedAddressTypes, boolean recursionDesired, int maxQueriesPerResolve, boolean traceEnabled, int maxPayloadSize, boolean optResourceEnabled, HostsFileEntriesResolver hostsFileEntriesResolver, DnsServerAddressStreamProvider dnsServerAddressStreamProvider, String[] searchDomains, int ndots, boolean decodeIdn, boolean completeOncePreferredResolved, int maxNumConsolidation)

Deprecated as a consequence of ChannelFactory being deprecated. See corresponding docs for further information.

io.netty.resolver.dns.DnsNameResolverBuilder.channelFactory

Deprecated as a consequence of ChannelFactory being deprecated. See corresponding docs for further information.

io.netty.resolver.dns.DnsNameResolverBuilder.channelFactory()

Deprecated as a consequence of ChannelFactory being deprecated. See corresponding docs for further information.

Returns:

this
io.netty.resolver.dns.DnsNameResolverBuilder.channelFactory
(ChannelFactory<? extends DatagramChannel> channelFactory)

Deprecated as a consequence of ChannelFactory being deprecated. See corresponding docs for further information.

io.netty.resolver.dns.DnsNameResolverBuilder.socketChannelFactory

Deprecated as a consequence of ChannelFactory being deprecated. See corresponding docs for further information.

Returns:

this
io.netty.resolver.dns.DnsNameResolverBuilder.socketChannelFactory
(ChannelFactory<? extends SocketChannel>
the ChannelFactory or null if TCP fallback should not be supported. By default, TCP fallback is not enabled.
channelFactory
)

Deprecated as a consequence of ChannelFactory being deprecated. See corresponding docs for further information.

Returns:

this
io.netty.resolver.dns.DnsNameResolverBuilder.socketChannelFactory
(ChannelFactory<? extends SocketChannel>
the ChannelFactory or null if TCP fallback should not be supported. By default, TCP fallback is not enabled.
channelFactory
,
boolean
if true the DnsNameResolver will also fallback to TCP if a timeout was detected, if false it will only try to use TCP if the response was marked as truncated.
retryOnTimeout
)

Deprecated as a consequence of ChannelFactory being deprecated. See corresponding docs for further information.

Returns:

this
io.netty.resolver.dns.DnsNameResolverBuilder.traceEnabled
(boolean
true if trace is enabled
traceEnabled
)

Prefer to configure a LoggingDnsQueryLifeCycleObserverFactory instead.

io.netty.resolver.dns.DnsServerAddresses.defaultAddressList()

Use DefaultDnsServerAddressStreamProvider#defaultAddressList().

Returns the list of the system DNS server addresses. If it failed to retrieve the list of the system DNS server addresses from the environment, it will return "8.8.8.8" and "8.8.4.4", the addresses of the Google public DNS servers.

io.netty.resolver.dns.DnsServerAddresses.defaultAddresses()

Use DefaultDnsServerAddressStreamProvider#defaultAddresses().

Returns the DnsServerAddresses that yields the system DNS server addresses sequentially. If it failed to retrieve the list of the system DNS server addresses from the environment, it will use "8.8.8.8" and "8.8.4.4", the addresses of the Google public DNS servers.

This method has the same effect with the following code:

DnsServerAddresses.sequential(DnsServerAddresses.defaultAddressList());

io.netty.resolver.dns.RoundRobinDnsAddressResolverGroup(ChannelFactory<? extends DatagramChannel> channelFactory, DnsServerAddressStreamProvider nameServerProvider)

Deprecated as a consequence of ChannelFactory being deprecated. See corresponding docs for further information.

io.netty.util.Attribute.getAndRemove()

please consider using getAndSet(Object) (with value of null).

io.netty.util.Attribute.remove()

please consider using set(Object) (with value of null).

io.netty.util.DomainMappingBuilder<
concrete type of value objects
V
>

Use DomainWildcardMappingBuilder instead.

io.netty.util.DomainMappingBuilder.add(String
the host name (optionally wildcard)
hostname
,
V
the output value that will be returned by DomainNameMapping#map(String) when the specified host name matches the specified input host name
output
)

Deprecated as a consequence of DomainMappingBuilder being deprecated. See corresponding docs for further information.

Returns:

new DomainNameMapping instance
io.netty.util.DomainMappingBuilder.build
()

Deprecated as a consequence of DomainNameMapping being deprecated. See corresponding docs for further information.

io.netty.util.DomainMappingBuilder.builder

Deprecated as a consequence of DomainNameMappingBuilder being deprecated. See corresponding docs for further information.

io.netty.util.DomainNameMapping(V
the default value for map(String) to return when nothing matches the input
defaultValue
)

use DomainNameMappingBuilder to create and fill the mapping instead

io.netty.util.DomainNameMapping(int
initial capacity for the internal map
initialCapacity
,
V
the default value for map(String) to return when nothing matches the input
defaultValue
)

use DomainNameMappingBuilder to create and fill the mapping instead

io.netty.util.DomainNameMapping.add(String
the host name (optionally wildcard)
hostname
,
V
the output value that will be returned by map(String) when the specified host name matches the specified input host name
output
)

use DomainNameMappingBuilder to create and fill the mapping instead

io.netty.util.DomainNameMappingBuilder.ImmutableDomainNameMapping<
concrete type of value objects
V
>

Deprecated as a consequence of DomainNameMapping being deprecated. See corresponding docs for further information.

io.netty.util.DomainNameMappingBuilder.ImmutableDomainNameMapping.add(String
the host name (optionally wildcard)
hostname
,
V
the output value that will be returned by map(String) when the specified host name matches the specified input host name
output
)

io.netty.util.DomainNameMappingBuilder.add(String
the host name (optionally wildcard)
hostname
,
V
the output value that will be returned by DomainNameMapping#map(String) when the specified host name matches the specified input host name
output
)

Deprecated as a consequence of DomainNameMappingBuilder being deprecated. See corresponding docs for further information.

Returns:

new DomainNameMapping instance
io.netty.util.DomainNameMappingBuilder.build
()

Deprecated as a consequence of DomainNameMapping being deprecated. See corresponding docs for further information.

io.netty.util.Recycler(int maxCapacityPerThread, int maxSharedCapacityFactor)

Use one of the following instead: Recycler(), Recycler(int), Recycler(int, int, int).

io.netty.util.Recycler(int maxCapacityPerThread, int maxSharedCapacityFactor, int ratio, int maxDelayedQueuesPerThread)

Use one of the following instead: Recycler(), Recycler(int), Recycler(int, int, int).

io.netty.util.Recycler(int maxCapacityPerThread, int maxSharedCapacityFactor, int ratio, int maxDelayedQueuesPerThread, int delayedQueueRatio)

Use one of the following instead: Recycler(), Recycler(int), Recycler(int, int, int).

io.netty.util.ReferenceCountUtil.releaseLater(T msg)

this may introduce a lot of memory usage so it is generally preferable to manually release objects.

io.netty.util.ReferenceCountUtil.releaseLater(T msg, int decrement)

this may introduce a lot of memory usage so it is generally preferable to manually release objects.

io.netty.util.ResourceLeak

please use ResourceLeakTracker as it may lead to false-positives.

io.netty.util.ResourceLeakDetector.DefaultResourceLeak<T>

Deprecated as a consequence of ResourceLeak being deprecated. See corresponding docs for further information.

io.netty.util.ResourceLeakDetector(Class<?> resourceType, int samplingInterval, long
This is deprecated and will be ignored.
maxActive
)

Use ResourceLeakDetector#ResourceLeakDetector(Class, int).

This should not be used directly by users of ResourceLeakDetector. Please use ResourceLeakDetectorFactory#newResourceLeakDetector(Class) or ResourceLeakDetectorFactory#newResourceLeakDetector(Class, int, long)

io.netty.util.ResourceLeakDetector(String resourceType, int samplingInterval, long
This is deprecated and will be ignored.
maxActive
)

use ResourceLeakDetectorFactory#newResourceLeakDetector(Class, int, long).

io.netty.util.ResourceLeakDetector.reportInstancesLeak(String resourceType)

This method will no longer be invoked by ResourceLeakDetector.

io.netty.util.ResourceLeakDetector.track0(T obj, boolean force)

Deprecated as a consequence of ResourceLeakDetector.DefaultResourceLeak being deprecated. See corresponding docs for further information.

Returns:

a new instance of ResourceLeakDetector
io.netty.util.ResourceLeakDetectorFactory.newResourceLeakDetector
(Class<T>
the resource class used to initialize the ResourceLeakDetector
resource
,
int
the interval on which sampling takes place
samplingInterval
,
long
This is deprecated and will be ignored.
maxActive
)

Use newResourceLeakDetector(Class, int) instead.

Returns a new instance of a ResourceLeakDetector with the given resource class.

io.netty.util.ResourceLeakException

This class will be removed in the future version.

io.netty.util.ThreadDeathWatcher

will be removed in the next major release

io.netty.util.concurrent.FastThreadLocal.addToVariablesToRemove(InternalThreadLocalMap threadLocalMap, FastThreadLocal<?> variable)

Deprecated as a consequence of InternalThreadLocalMap being deprecated. See corresponding docs for further information.

io.netty.util.concurrent.FastThreadLocal.get(InternalThreadLocalMap threadLocalMap)

Deprecated as a consequence of InternalThreadLocalMap being deprecated. See corresponding docs for further information.

io.netty.util.concurrent.FastThreadLocal.initialize(InternalThreadLocalMap threadLocalMap)

Deprecated as a consequence of InternalThreadLocalMap being deprecated. See corresponding docs for further information.

io.netty.util.concurrent.FastThreadLocal.isSet(InternalThreadLocalMap threadLocalMap)

Deprecated as a consequence of InternalThreadLocalMap being deprecated. See corresponding docs for further information.

io.netty.util.concurrent.FastThreadLocal.remove(InternalThreadLocalMap threadLocalMap)

Deprecated as a consequence of InternalThreadLocalMap being deprecated. See corresponding docs for further information.

io.netty.util.concurrent.FastThreadLocal.removeFromVariablesToRemove(InternalThreadLocalMap threadLocalMap, FastThreadLocal<?> variable)

Deprecated as a consequence of InternalThreadLocalMap being deprecated. See corresponding docs for further information.

io.netty.util.concurrent.FastThreadLocal.set(InternalThreadLocalMap threadLocalMap, V value)

Deprecated as a consequence of InternalThreadLocalMap being deprecated. See corresponding docs for further information.

io.netty.util.concurrent.FastThreadLocal.setKnownNotUnset(InternalThreadLocalMap threadLocalMap, V value)

Deprecated as a consequence of InternalThreadLocalMap being deprecated. See corresponding docs for further information.

io.netty.util.concurrent.FastThreadLocalThread.setThreadLocalMap(InternalThreadLocalMap threadLocalMap)

Deprecated as a consequence of InternalThreadLocalMap being deprecated. See corresponding docs for further information.

io.netty.util.concurrent.FastThreadLocalThread.threadLocalMap

Deprecated as a consequence of InternalThreadLocalMap being deprecated. See corresponding docs for further information.

io.netty.util.concurrent.FastThreadLocalThread.threadLocalMap()

Deprecated as a consequence of InternalThreadLocalMap being deprecated. See corresponding docs for further information.

io.netty.util.concurrent.PromiseAggregator<
the type of value returned by the Future
V
,
the type of Future
F extends Future<V>
>

Use PromiseCombiner#PromiseCombiner(EventExecutor). GenericFutureListener implementation which consolidates multiple Futures into one, by listening to individual Futures and producing an aggregated result (success/failure) when all Futures have completed.

io.netty.util.concurrent.PromiseAggregator.add(Promise<V>... promises)

Deprecated as a consequence of PromiseAggregator being deprecated. See corresponding docs for further information.

io.netty.util.concurrent.PromiseCombiner.add(Promise<V>
the promise to add to this promise combiner
promise
)

Replaced by PromiseCombiner#add(Future).

io.netty.util.concurrent.PromiseCombiner.addAll(Promise<V>...
the promises to add to this promise combiner
promises
)

Replaced by PromiseCombiner#addAll(Future[])

io.netty.util.internal.ConcurrentSet<E>

For removal in Netty 4.2. Please use ConcurrentHashMap#newKeySet() instead

io.netty.util.internal.EmptyArrays.EMPTY_JAVAX_X509_CERTIFICATES

Deprecated as a consequence of X509Certificate being deprecated. See corresponding docs for further information.

io.netty.util.internal.IntegerHolder

For removal in netty 4.2

io.netty.util.internal.InternalThreadLocalMap

Deprecated as a consequence of UnpaddedInternalThreadLocalMap being deprecated.

io.netty.util.internal.InternalThreadLocalMap.counterHashCode

Deprecated as a consequence of IntegerHolder being deprecated. See corresponding docs for further information.

io.netty.util.internal.InternalThreadLocalMap.fastGet(FastThreadLocalThread thread)

Deprecated as a consequence of InternalThreadLocalMap being deprecated. See corresponding docs for further information.

io.netty.util.internal.InternalThreadLocalMap.get()

Deprecated as a consequence of InternalThreadLocalMap being deprecated. See corresponding docs for further information.

io.netty.util.internal.InternalThreadLocalMap.getIfSet()

Deprecated as a consequence of InternalThreadLocalMap being deprecated. See corresponding docs for further information.

io.netty.util.internal.InternalThreadLocalMap.rp1

These padding fields will be removed in the future.

io.netty.util.internal.InternalThreadLocalMap.rp2

These padding fields will be removed in the future.

io.netty.util.internal.InternalThreadLocalMap.rp3

These padding fields will be removed in the future.

io.netty.util.internal.InternalThreadLocalMap.rp4

These padding fields will be removed in the future.

io.netty.util.internal.InternalThreadLocalMap.rp5

These padding fields will be removed in the future.

io.netty.util.internal.InternalThreadLocalMap.rp6

These padding fields will be removed in the future.

io.netty.util.internal.InternalThreadLocalMap.rp7

These padding fields will be removed in the future.

io.netty.util.internal.InternalThreadLocalMap.rp8

These padding fields will be removed in the future.

io.netty.util.internal.InternalThreadLocalMap.slowGet()

Deprecated as a consequence of InternalThreadLocalMap being deprecated. See corresponding docs for further information.

io.netty.util.internal.UnpaddedInternalThreadLocalMap

This class will be removed in the future.

io.netty.util.internal.shaded.org.jctools.queues.QueueFactory.newQueue(ConcurrentQueueSpec qs)

Deprecated as a consequence of ConcurrentQueueSpec being deprecated. See corresponding docs for further information.

io.netty.util.internal.shaded.org.jctools.queues.atomic.AtomicQueueFactory.newQueue(ConcurrentQueueSpec qs)

Deprecated as a consequence of ConcurrentQueueSpec being deprecated. See corresponding docs for further information.

io.netty.util.internal.shaded.org.jctools.queues.spec.ConcurrentQueueSpec(int producers, int consumers, int capacity, Ordering ordering, Preference preference)

Deprecated as a consequence of Ordering and Preference being deprecated. See corresponding docs for further information.

io.netty.util.internal.shaded.org.jctools.queues.spec.ConcurrentQueueSpec.createBoundedMpmc(int capacity)

Deprecated as a consequence of ConcurrentQueueSpec being deprecated. See corresponding docs for further information.

io.netty.util.internal.shaded.org.jctools.queues.spec.ConcurrentQueueSpec.createBoundedMpsc(int capacity)

Deprecated as a consequence of ConcurrentQueueSpec being deprecated. See corresponding docs for further information.

io.netty.util.internal.shaded.org.jctools.queues.spec.ConcurrentQueueSpec.createBoundedSpmc(int capacity)

Deprecated as a consequence of ConcurrentQueueSpec being deprecated. See corresponding docs for further information.

io.netty.util.internal.shaded.org.jctools.queues.spec.ConcurrentQueueSpec.createBoundedSpsc(int capacity)

Deprecated as a consequence of ConcurrentQueueSpec being deprecated. See corresponding docs for further information.

io.netty.util.internal.shaded.org.jctools.queues.spec.ConcurrentQueueSpec.ordering

Deprecated as a consequence of Ordering being deprecated. See corresponding docs for further information.

io.netty.util.internal.shaded.org.jctools.queues.spec.ConcurrentQueueSpec.preference

Deprecated as a consequence of Preference being deprecated. See corresponding docs for further information.

io.netty.util.internal.shaded.org.jctools.queues.spec.Ordering.FIFO

Deprecated as a consequence of Ordering being deprecated. See corresponding docs for further information.

io.netty.util.internal.shaded.org.jctools.queues.spec.Ordering.KFIFO

Deprecated as a consequence of Ordering being deprecated. See corresponding docs for further information.

io.netty.util.internal.shaded.org.jctools.queues.spec.Ordering.NONE

Deprecated as a consequence of Ordering being deprecated. See corresponding docs for further information.

io.netty.util.internal.shaded.org.jctools.queues.spec.Ordering.PRODUCER_FIFO

Deprecated as a consequence of Ordering being deprecated. See corresponding docs for further information.

io.netty.util.internal.shaded.org.jctools.queues.spec.Ordering.valueOf(String name)

Deprecated as a consequence of Ordering being deprecated. See corresponding docs for further information.

io.netty.util.internal.shaded.org.jctools.queues.spec.Ordering.values()

Deprecated as a consequence of Ordering being deprecated. See corresponding docs for further information.

io.netty.util.internal.shaded.org.jctools.queues.spec.Preference.LATENCY

Deprecated as a consequence of Preference being deprecated. See corresponding docs for further information.

io.netty.util.internal.shaded.org.jctools.queues.spec.Preference.NONE

Deprecated as a consequence of Preference being deprecated. See corresponding docs for further information.

io.netty.util.internal.shaded.org.jctools.queues.spec.Preference.THROUGHPUT

Deprecated as a consequence of Preference being deprecated. See corresponding docs for further information.

io.netty.util.internal.shaded.org.jctools.queues.spec.Preference.valueOf(String name)

Deprecated as a consequence of Preference being deprecated. See corresponding docs for further information.

io.netty.util.internal.shaded.org.jctools.queues.spec.Preference.values()

Deprecated as a consequence of Preference being deprecated. See corresponding docs for further information.