META-INF/
META-INF/MANIFEST.MF
io/
io/netty/
io/netty/channel/
io/netty/channel/oio/
io/netty/channel/group/
io/netty/channel/embedded/
io/netty/channel/local/
io/netty/channel/socket/
io/netty/channel/socket/oio/
io/netty/channel/socket/nio/
io/netty/channel/nio/
io/netty/channel/pool/
io/netty/bootstrap/
io/netty/channel/ChannelPipelineException.classChannelPipelineException.java
package io.netty.channel
public io.netty.channel.ChannelPipelineException extends io.netty.channel.ChannelException {
private static final long serialVersionUID
public void ()
public void (java.lang.String, java.lang.Throwable)
String message
Throwable cause
public void (java.lang.String)
String message
public void (java.lang.Throwable)
Throwable cause
}
io/netty/channel/AbstractChannel$AbstractUnsafe.classAbstractChannel.java
package io.netty.channel
public abstract io.netty.channel.AbstractChannel$AbstractUnsafe extends java.lang.Object implements io.netty.channel.Channel$Unsafe {
private io.netty.channel.ChannelOutboundBuffer outboundBuffer
private io.netty.channel.RecvByteBufAllocator$Handle recvHandle
private boolean inFlush0
private boolean neverRegistered
final io.netty.channel.AbstractChannel this$0
protected void (io.netty.channel.AbstractChannel)
public io.netty.channel.RecvByteBufAllocator$Handle recvBufAllocHandle ()
public final io.netty.channel.ChannelHandlerInvoker invoker ()
public final io.netty.channel.ChannelOutboundBuffer outboundBuffer ()
public final java.net.SocketAddress localAddress ()
public final java.net.SocketAddress remoteAddress ()
public final void register (io.netty.channel.EventLoop, io.netty.channel.ChannelPromise)
Throwable t
io.netty.channel.EventLoop eventLoop
io.netty.channel.ChannelPromise promise
private void register0 (io.netty.channel.ChannelPromise)
boolean firstRegistration
Throwable t
io.netty.channel.ChannelPromise promise
public final void bind (java.net.SocketAddress, io.netty.channel.ChannelPromise)
Throwable t
java.net.SocketAddress localAddress
io.netty.channel.ChannelPromise promise
boolean wasActive
public final void disconnect (io.netty.channel.ChannelPromise)
Throwable t
io.netty.channel.ChannelPromise promise
boolean wasActive
public final void close (io.netty.channel.ChannelPromise)
io.netty.channel.ChannelPromise promise
private void close (io.netty.channel.ChannelPromise, java.lang.Throwable, boolean)
io.netty.channel.ChannelPromise promise
Throwable cause
boolean notify
io.netty.channel.ChannelOutboundBuffer outboundBuffer
boolean wasActive
java.util.concurrent.Executor closeExecutor
private void doClose0 (io.netty.channel.ChannelPromise)
Throwable t
io.netty.channel.ChannelPromise promise
private void fireChannelInactiveAndDeregister (boolean)
boolean wasActive
public final void closeForcibly ()
Exception e
public final void deregister (io.netty.channel.ChannelPromise)
io.netty.channel.ChannelPromise promise
private void deregister (io.netty.channel.ChannelPromise, boolean)
io.netty.channel.ChannelPromise promise
boolean fireChannelInactive
public final void beginRead ()
Exception e
public final void write (java.lang.Object, io.netty.channel.ChannelPromise)
int size
Throwable t
Object msg
io.netty.channel.ChannelPromise promise
io.netty.channel.ChannelOutboundBuffer outboundBuffer
int size
public final void flush ()
io.netty.channel.ChannelOutboundBuffer outboundBuffer
protected void flush0 ()
Throwable t
io.netty.channel.ChannelOutboundBuffer outboundBuffer
public final io.netty.channel.ChannelPromise voidPromise ()
protected final boolean ensureOpen (io.netty.channel.ChannelPromise)
io.netty.channel.ChannelPromise promise
protected final void safeSetSuccess (io.netty.channel.ChannelPromise)
io.netty.channel.ChannelPromise promise
protected final void safeSetFailure (io.netty.channel.ChannelPromise, java.lang.Throwable)
io.netty.channel.ChannelPromise promise
Throwable cause
protected final void closeIfClosed ()
private void invokeLater (java.lang.Runnable)
java.util.concurrent.RejectedExecutionException e
Runnable task
protected final java.lang.Throwable annotateConnectException (java.lang.Throwable, java.net.SocketAddress)
Throwable newT
Throwable newT
Throwable newT
Throwable cause
java.net.SocketAddress remoteAddress
protected java.util.concurrent.Executor prepareToClose ()
static void access$100 (io.netty.channel.AbstractChannel$AbstractUnsafe, io.netty.channel.ChannelPromise)
io.netty.channel.AbstractChannel$AbstractUnsafe x0
io.netty.channel.ChannelPromise x1
static void access$600 (io.netty.channel.AbstractChannel$AbstractUnsafe, io.netty.channel.ChannelPromise)
io.netty.channel.AbstractChannel$AbstractUnsafe x0
io.netty.channel.ChannelPromise x1
static void access$700 (io.netty.channel.AbstractChannel$AbstractUnsafe, boolean)
io.netty.channel.AbstractChannel$AbstractUnsafe x0
boolean x1
static void access$800 (io.netty.channel.AbstractChannel$AbstractUnsafe, java.lang.Runnable)
io.netty.channel.AbstractChannel$AbstractUnsafe x0
Runnable x1
}
io/netty/channel/ThreadLocalPooledDirectByteBuf$1.classThreadLocalPooledDirectByteBuf.java
package io.netty.channel
io.netty.channel.ThreadLocalPooledDirectByteBuf$1 extends java.lang.Object {
}
io/netty/channel/FixedRecvByteBufAllocator.classFixedRecvByteBufAllocator.java
package io.netty.channel
public io.netty.channel.FixedRecvByteBufAllocator extends io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator {
private final int bufferSize
public void (int)
int bufferSize
public io.netty.channel.RecvByteBufAllocator$Handle newHandle ()
}
io/netty/channel/AbstractChannel$AbstractUnsafe$7.classAbstractChannel.java
package io.netty.channel
io.netty.channel.AbstractChannel$AbstractUnsafe$7 extends io.netty.util.internal.OneTimeTask {
final boolean val$fireChannelInactive
final io.netty.channel.ChannelPromise val$promise
final io.netty.channel.AbstractChannel$AbstractUnsafe this$1
void (io.netty.channel.AbstractChannel$AbstractUnsafe, boolean, io.netty.channel.ChannelPromise)
public void run ()
Throwable t
}
io/netty/channel/ChannelInboundHandler.classChannelInboundHandler.java
package io.netty.channel
public abstract io.netty.channel.ChannelInboundHandler extends java.lang.Object implements io.netty.channel.ChannelHandler {
public abstract void channelRegistered (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
public abstract void channelUnregistered (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
public abstract void channelActive (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
public abstract void channelInactive (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
public abstract void channelRead (io.netty.channel.ChannelHandlerContext, java.lang.Object) throws java.lang.Exception
public abstract void channelReadComplete (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
public abstract void userEventTriggered (io.netty.channel.ChannelHandlerContext, java.lang.Object) throws java.lang.Exception
public abstract void channelWritabilityChanged (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
public abstract void exceptionCaught (io.netty.channel.ChannelHandlerContext, java.lang.Throwable) throws java.lang.Exception
}
io/netty/channel/oio/AbstractOioChannel$DefaultOioUnsafe.classAbstractOioChannel.java
package io.netty.channel.oio
final io.netty.channel.oio.AbstractOioChannel$DefaultOioUnsafe extends io.netty.channel.AbstractChannel$AbstractUnsafe {
final io.netty.channel.oio.AbstractOioChannel this$0
private void (io.netty.channel.oio.AbstractOioChannel)
public void connect (java.net.SocketAddress, java.net.SocketAddress, io.netty.channel.ChannelPromise)
boolean wasActive
Throwable t
java.net.SocketAddress remoteAddress
java.net.SocketAddress localAddress
io.netty.channel.ChannelPromise promise
void (io.netty.channel.oio.AbstractOioChannel, io.netty.channel.oio.AbstractOioChannel$1)
io.netty.channel.oio.AbstractOioChannel x0
io.netty.channel.oio.AbstractOioChannel$1 x1
}
io/netty/channel/oio/AbstractOioByteChannel.classAbstractOioByteChannel.java
package io.netty.channel.oio
public abstract io.netty.channel.oio.AbstractOioByteChannel extends io.netty.channel.oio.AbstractOioChannel {
private static final io.netty.channel.ChannelMetadata METADATA
private static final String EXPECTED_TYPES
private volatile boolean inputShutdown
protected void (io.netty.channel.Channel)
io.netty.channel.Channel parent
protected boolean isInputShutdown ()
public io.netty.channel.ChannelMetadata metadata ()
protected boolean checkInputShutdown ()
void setInputShutdown ()
private void closeOnRead (io.netty.channel.ChannelPipeline)
io.netty.channel.ChannelPipeline pipeline
private void handleReadException (io.netty.channel.ChannelPipeline, io.netty.buffer.ByteBuf, java.lang.Throwable, boolean, io.netty.channel.RecvByteBufAllocator$Handle)
io.netty.channel.ChannelPipeline pipeline
io.netty.buffer.ByteBuf byteBuf
Throwable cause
boolean close
io.netty.channel.RecvByteBufAllocator$Handle allocHandle
protected void doRead ()
int writerIndex
int capacity
int maxCapacity
int available
Throwable t
io.netty.channel.ChannelConfig config
io.netty.channel.ChannelPipeline pipeline
io.netty.buffer.ByteBufAllocator allocator
io.netty.channel.RecvByteBufAllocator$Handle allocHandle
io.netty.buffer.ByteBuf byteBuf
boolean read
protected void doWrite (io.netty.channel.ChannelOutboundBuffer) throws java.lang.Exception
int newReadableBytes
io.netty.buffer.ByteBuf buf
int readableBytes
io.netty.channel.FileRegion region
long transfered
Object msg
io.netty.channel.ChannelOutboundBuffer in
protected final java.lang.Object filterOutboundMessage (java.lang.Object) throws java.lang.Exception
Object msg
protected abstract int available ()
protected abstract int doReadBytes (io.netty.buffer.ByteBuf) throws java.lang.Exception
protected abstract void doWriteBytes (io.netty.buffer.ByteBuf) throws java.lang.Exception
protected abstract void doWriteFileRegion (io.netty.channel.FileRegion) throws java.lang.Exception
static void ()
}
io/netty/channel/oio/OioByteStreamChannel.classOioByteStreamChannel.java
package io.netty.channel.oio
public abstract io.netty.channel.oio.OioByteStreamChannel extends io.netty.channel.oio.AbstractOioByteChannel {
private static final java.io.InputStream CLOSED_IN
private static final java.io.OutputStream CLOSED_OUT
private java.io.InputStream is
private java.io.OutputStream os
private java.nio.channels.WritableByteChannel outChannel
protected void (io.netty.channel.Channel)
io.netty.channel.Channel parent
protected final void activate (java.io.InputStream, java.io.OutputStream)
java.io.InputStream is
java.io.OutputStream os
public boolean isActive ()
java.io.InputStream is
java.io.OutputStream os
protected int available ()
java.io.IOException ignored
protected int doReadBytes (io.netty.buffer.ByteBuf) throws java.lang.Exception
io.netty.buffer.ByteBuf buf
io.netty.channel.RecvByteBufAllocator$Handle allocHandle
protected void doWriteBytes (io.netty.buffer.ByteBuf) throws java.lang.Exception
io.netty.buffer.ByteBuf buf
java.io.OutputStream os
protected void doWriteFileRegion (io.netty.channel.FileRegion) throws java.lang.Exception
long localWritten
io.netty.channel.FileRegion region
java.io.OutputStream os
long written
private static void checkEOF (io.netty.channel.FileRegion) throws java.io.IOException
io.netty.channel.FileRegion region
protected void doClose () throws java.lang.Exception
java.io.InputStream is
java.io.OutputStream os
static void ()
}
io/netty/channel/oio/AbstractOioMessageChannel.classAbstractOioMessageChannel.java
package io.netty.channel.oio
public abstract io.netty.channel.oio.AbstractOioMessageChannel extends io.netty.channel.oio.AbstractOioChannel {
private final java.util.List readBuf
protected void (io.netty.channel.Channel)
io.netty.channel.Channel parent
protected void doRead ()
int localRead
Throwable t
int i
io.netty.channel.ChannelConfig config
io.netty.channel.ChannelPipeline pipeline
io.netty.channel.RecvByteBufAllocator$Handle allocHandle
boolean closed
Throwable exception
int size
protected abstract int doReadMessages (java.util.List) throws java.lang.Exception
}
io/netty/channel/oio/AbstractOioChannel$1.classAbstractOioChannel.java
package io.netty.channel.oio
io.netty.channel.oio.AbstractOioChannel$1 extends java.lang.Object implements java.lang.Runnable {
final io.netty.channel.oio.AbstractOioChannel this$0
void (io.netty.channel.oio.AbstractOioChannel)
public void run ()
}
io/netty/channel/oio/OioByteStreamChannel$1.classOioByteStreamChannel.java
package io.netty.channel.oio
final io.netty.channel.oio.OioByteStreamChannel$1 extends java.io.InputStream {
void ()
public int read ()
}
io/netty/channel/oio/OioEventLoopGroup.classOioEventLoopGroup.java
package io.netty.channel.oio
public io.netty.channel.oio.OioEventLoopGroup extends io.netty.channel.ThreadPerChannelEventLoopGroup {
public void ()
public void (int)
int maxChannels
public void (int, java.util.concurrent.Executor)
int maxChannels
java.util.concurrent.Executor executor
public void (int, java.util.concurrent.ThreadFactory)
int maxChannels
java.util.concurrent.ThreadFactory threadFactory
}
io/netty/channel/oio/AbstractOioChannel.classAbstractOioChannel.java
package io.netty.channel.oio
public abstract io.netty.channel.oio.AbstractOioChannel extends io.netty.channel.AbstractChannel {
protected static final int SO_TIMEOUT
private volatile boolean readPending
private final Runnable readTask
protected void (io.netty.channel.Channel)
io.netty.channel.Channel parent
protected io.netty.channel.AbstractChannel$AbstractUnsafe newUnsafe ()
protected boolean isCompatible (io.netty.channel.EventLoop)
io.netty.channel.EventLoop loop
protected abstract void doConnect (java.net.SocketAddress, java.net.SocketAddress) throws java.lang.Exception
protected void doBeginRead () throws java.lang.Exception
protected abstract void doRead ()
protected boolean isReadPending ()
protected void setReadPending (boolean)
boolean readPending
}
io/netty/channel/oio/OioByteStreamChannel$2.classOioByteStreamChannel.java
package io.netty.channel.oio
final io.netty.channel.oio.OioByteStreamChannel$2 extends java.io.OutputStream {
void ()
public void write (int) throws java.io.IOException
int b
}
io/netty/channel/AbstractChannel$AbstractUnsafe$3.classAbstractChannel.java
package io.netty.channel
io.netty.channel.AbstractChannel$AbstractUnsafe$3 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.AbstractChannel$AbstractUnsafe this$1
void (io.netty.channel.AbstractChannel$AbstractUnsafe)
public void run ()
}
io/netty/channel/MaxBytesRecvByteBufAllocator.classMaxBytesRecvByteBufAllocator.java
package io.netty.channel
public abstract io.netty.channel.MaxBytesRecvByteBufAllocator extends java.lang.Object implements io.netty.channel.RecvByteBufAllocator {
public abstract int maxBytesPerRead ()
public abstract io.netty.channel.MaxBytesRecvByteBufAllocator maxBytesPerRead (int)
public abstract int maxBytesPerIndividualRead ()
public abstract io.netty.channel.MaxBytesRecvByteBufAllocator maxBytesPerIndividualRead (int)
public abstract java.util.Map$Entry maxBytesPerReadPair ()
public abstract io.netty.channel.MaxBytesRecvByteBufAllocator maxBytesPerReadPair (int, int)
}
io/netty/channel/SimpleChannelInboundHandler.classSimpleChannelInboundHandler.java
package io.netty.channel
public abstract io.netty.channel.SimpleChannelInboundHandler extends io.netty.channel.ChannelInboundHandlerAdapter {
private final io.netty.util.internal.TypeParameterMatcher matcher
private final boolean autoRelease
protected void ()
protected void (boolean)
boolean autoRelease
protected void (java.lang.Class)
Class inboundMessageType
protected void (java.lang.Class, boolean)
Class inboundMessageType
boolean autoRelease
public boolean acceptInboundMessage (java.lang.Object) throws java.lang.Exception
Object msg
public void channelRead (io.netty.channel.ChannelHandlerContext, java.lang.Object) throws java.lang.Exception
Object imsg
io.netty.channel.ChannelHandlerContext ctx
Object msg
boolean release
protected abstract void channelRead0 (io.netty.channel.ChannelHandlerContext, java.lang.Object) throws java.lang.Exception
}
io/netty/channel/ChannelOutboundHandlerAdapter.classChannelOutboundHandlerAdapter.java
package io.netty.channel
public io.netty.channel.ChannelOutboundHandlerAdapter extends io.netty.channel.ChannelHandlerAdapter implements io.netty.channel.ChannelOutboundHandler {
public void ()
public void bind (io.netty.channel.ChannelHandlerContext, java.net.SocketAddress, io.netty.channel.ChannelPromise) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
java.net.SocketAddress localAddress
io.netty.channel.ChannelPromise promise
public void connect (io.netty.channel.ChannelHandlerContext, java.net.SocketAddress, java.net.SocketAddress, io.netty.channel.ChannelPromise) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
java.net.SocketAddress remoteAddress
java.net.SocketAddress localAddress
io.netty.channel.ChannelPromise promise
public void disconnect (io.netty.channel.ChannelHandlerContext, io.netty.channel.ChannelPromise) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
io.netty.channel.ChannelPromise promise
public void close (io.netty.channel.ChannelHandlerContext, io.netty.channel.ChannelPromise) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
io.netty.channel.ChannelPromise promise
public void deregister (io.netty.channel.ChannelHandlerContext, io.netty.channel.ChannelPromise) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
io.netty.channel.ChannelPromise promise
public void read (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
public void write (io.netty.channel.ChannelHandlerContext, java.lang.Object, io.netty.channel.ChannelPromise) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
Object msg
io.netty.channel.ChannelPromise promise
public void flush (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
}
io/netty/channel/ChannelOutboundBuffer$Entry.classChannelOutboundBuffer.java
package io.netty.channel
final io.netty.channel.ChannelOutboundBuffer$Entry extends java.lang.Object {
private static final io.netty.util.Recycler RECYCLER
private final io.netty.util.Recycler$Handle handle
io.netty.channel.ChannelOutboundBuffer$Entry next
Object msg
java.nio.ByteBuffer[] bufs
java.nio.ByteBuffer buf
io.netty.channel.ChannelPromise promise
long progress
long total
int pendingSize
int count
boolean cancelled
private void (io.netty.util.Recycler$Handle)
io.netty.util.Recycler$Handle handle
static io.netty.channel.ChannelOutboundBuffer$Entry newInstance (java.lang.Object, int, long, io.netty.channel.ChannelPromise)
Object msg
int size
long total
io.netty.channel.ChannelPromise promise
io.netty.channel.ChannelOutboundBuffer$Entry entry
int cancel ()
int pSize
void recycle ()
io.netty.channel.ChannelOutboundBuffer$Entry recycleAndGetNext ()
io.netty.channel.ChannelOutboundBuffer$Entry next
void (io.netty.util.Recycler$Handle, io.netty.channel.ChannelOutboundBuffer$1)
io.netty.util.Recycler$Handle x0
io.netty.channel.ChannelOutboundBuffer$1 x1
static void ()
}
io/netty/channel/ChannelFutureListener$1.classChannelFutureListener.java
package io.netty.channel
final io.netty.channel.ChannelFutureListener$1 extends java.lang.Object implements io.netty.channel.ChannelFutureListener {
void ()
public void operationComplete (io.netty.channel.ChannelFuture)
io.netty.channel.ChannelFuture future
public volatile void operationComplete (io.netty.util.concurrent.Future) throws java.lang.Exception
}
io/netty/channel/ChannelOutboundBuffer.classChannelOutboundBuffer.java
package io.netty.channel
public final io.netty.channel.ChannelOutboundBuffer extends java.lang.Object {
private static final io.netty.util.internal.logging.InternalLogger logger
private static final io.netty.util.concurrent.FastThreadLocal NIO_BUFFERS
private final io.netty.channel.Channel channel
private io.netty.channel.ChannelOutboundBuffer$Entry flushedEntry
private io.netty.channel.ChannelOutboundBuffer$Entry unflushedEntry
private io.netty.channel.ChannelOutboundBuffer$Entry tailEntry
private int flushed
private int nioBufferCount
private long nioBufferSize
private boolean inFail
private static final java.util.concurrent.atomic.AtomicLongFieldUpdater TOTAL_PENDING_SIZE_UPDATER
private volatile long totalPendingSize
private static final java.util.concurrent.atomic.AtomicIntegerFieldUpdater UNWRITABLE_UPDATER
private volatile int unwritable
private volatile Runnable fireChannelWritabilityChangedTask
static final boolean $assertionsDisabled
void (io.netty.channel.AbstractChannel)
io.netty.channel.AbstractChannel channel
public void addMessage (java.lang.Object, int, io.netty.channel.ChannelPromise)
io.netty.channel.ChannelOutboundBuffer$Entry tail
Object msg
int size
io.netty.channel.ChannelPromise promise
io.netty.channel.ChannelOutboundBuffer$Entry entry
public void addFlush ()
int pending
io.netty.channel.ChannelOutboundBuffer$Entry entry
void incrementPendingOutboundBytes (long)
long size
private void incrementPendingOutboundBytes (long, boolean)
long size
boolean invokeLater
long newWriteBufferSize
void decrementPendingOutboundBytes (long)
long size
private void decrementPendingOutboundBytes (long, boolean, boolean)
long size
boolean invokeLater
boolean notifyWritability
long newWriteBufferSize
private static long total (java.lang.Object)
Object msg
public java.lang.Object current ()
io.netty.channel.ChannelOutboundBuffer$Entry entry
public void progress (long)
long progress
long amount
io.netty.channel.ChannelOutboundBuffer$Entry e
io.netty.channel.ChannelPromise p
public boolean remove ()
io.netty.channel.ChannelOutboundBuffer$Entry e
Object msg
io.netty.channel.ChannelPromise promise
int size
public boolean remove (java.lang.Throwable)
Throwable cause
private boolean remove0 (java.lang.Throwable, boolean)
Throwable cause
boolean notifyWritability
io.netty.channel.ChannelOutboundBuffer$Entry e
Object msg
io.netty.channel.ChannelPromise promise
int size
private void removeEntry (io.netty.channel.ChannelOutboundBuffer$Entry)
io.netty.channel.ChannelOutboundBuffer$Entry e
public void removeBytes (long)
Object msg
io.netty.buffer.ByteBuf buf
int readerIndex
int readableBytes
long writtenBytes
private void clearNioBuffers ()
int count
public java.nio.ByteBuffer[] nioBuffers ()
java.nio.ByteBuffer nioBuf
java.nio.ByteBuffer[] nioBufs
int count
int neededSpace
io.netty.buffer.ByteBuf buf
int readerIndex
int readableBytes
long nioBufferSize
int nioBufferCount
io.netty.util.internal.InternalThreadLocalMap threadLocalMap
java.nio.ByteBuffer[] nioBuffers
io.netty.channel.ChannelOutboundBuffer$Entry entry
private static int fillBufferArray (java.nio.ByteBuffer[], java.nio.ByteBuffer[], int)
java.nio.ByteBuffer nioBuf
java.nio.ByteBuffer[] arr$
int len$
int i$
java.nio.ByteBuffer[] nioBufs
java.nio.ByteBuffer[] nioBuffers
int nioBufferCount
private static java.nio.ByteBuffer[] expandNioBufferArray (java.nio.ByteBuffer[], int, int)
java.nio.ByteBuffer[] array
int neededSpace
int size
int newCapacity
java.nio.ByteBuffer[] newArray
public int nioBufferCount ()
public long nioBufferSize ()
public boolean isWritable ()
public boolean getUserDefinedWritability (int)
int index
public void setUserDefinedWritability (int, boolean)
int index
boolean writable
private void setUserDefinedWritability (int)
int oldValue
int newValue
int index
int mask
private void clearUserDefinedWritability (int)
int oldValue
int newValue
int index
int mask
private static int writabilityMask (int)
int index
private void setWritable (boolean)
int oldValue
int newValue
boolean invokeLater
private void setUnwritable (boolean)
int oldValue
int newValue
boolean invokeLater
private void fireChannelWritabilityChanged (boolean)
Runnable task
boolean invokeLater
io.netty.channel.ChannelPipeline pipeline
public int size ()
public boolean isEmpty ()
void failFlushed (java.lang.Throwable, boolean)
Throwable cause
boolean notify
void close (java.nio.channels.ClosedChannelException)
int size
io.netty.channel.ChannelOutboundBuffer$Entry e
java.nio.channels.ClosedChannelException cause
private static void safeSuccess (io.netty.channel.ChannelPromise)
io.netty.channel.ChannelPromise promise
private static void safeFail (io.netty.channel.ChannelPromise, java.lang.Throwable)
io.netty.channel.ChannelPromise promise
Throwable cause
public void recycle ()
public long totalPendingWriteBytes ()
public long bytesBeforeUnwritable ()
long bytes
public long bytesBeforeWritable ()
long bytes
public void forEachFlushedMessage (io.netty.channel.ChannelOutboundBuffer$MessageProcessor) throws java.lang.Exception
io.netty.channel.ChannelOutboundBuffer$MessageProcessor processor
io.netty.channel.ChannelOutboundBuffer$Entry entry
private boolean isFlushedEntry (io.netty.channel.ChannelOutboundBuffer$Entry)
io.netty.channel.ChannelOutboundBuffer$Entry e
static void ()
java.util.concurrent.atomic.AtomicIntegerFieldUpdater unwritableUpdater
java.util.concurrent.atomic.AtomicLongFieldUpdater pendingSizeUpdater
}
io/netty/channel/ChannelHandlerInvoker.classChannelHandlerInvoker.java
package io.netty.channel
public abstract io.netty.channel.ChannelHandlerInvoker extends java.lang.Object {
public abstract io.netty.util.concurrent.EventExecutor executor ()
public abstract void invokeChannelRegistered (io.netty.channel.ChannelHandlerContext)
public abstract void invokeChannelUnregistered (io.netty.channel.ChannelHandlerContext)
public abstract void invokeChannelActive (io.netty.channel.ChannelHandlerContext)
public abstract void invokeChannelInactive (io.netty.channel.ChannelHandlerContext)
public abstract void invokeExceptionCaught (io.netty.channel.ChannelHandlerContext, java.lang.Throwable)
public abstract void invokeUserEventTriggered (io.netty.channel.ChannelHandlerContext, java.lang.Object)
public abstract void invokeChannelRead (io.netty.channel.ChannelHandlerContext, java.lang.Object)
public abstract void invokeChannelReadComplete (io.netty.channel.ChannelHandlerContext)
public abstract void invokeChannelWritabilityChanged (io.netty.channel.ChannelHandlerContext)
public abstract void invokeBind (io.netty.channel.ChannelHandlerContext, java.net.SocketAddress, io.netty.channel.ChannelPromise)
public abstract void invokeConnect (io.netty.channel.ChannelHandlerContext, java.net.SocketAddress, java.net.SocketAddress, io.netty.channel.ChannelPromise)
public abstract void invokeDisconnect (io.netty.channel.ChannelHandlerContext, io.netty.channel.ChannelPromise)
public abstract void invokeClose (io.netty.channel.ChannelHandlerContext, io.netty.channel.ChannelPromise)
public abstract void invokeDeregister (io.netty.channel.ChannelHandlerContext, io.netty.channel.ChannelPromise)
public abstract void invokeRead (io.netty.channel.ChannelHandlerContext)
public abstract void invokeWrite (io.netty.channel.ChannelHandlerContext, java.lang.Object, io.netty.channel.ChannelPromise)
public abstract void invokeFlush (io.netty.channel.ChannelHandlerContext)
}
io/netty/channel/DefaultChannelPipeline$PendingHandlerRemovedTask.classDefaultChannelPipeline.java
package io.netty.channel
final io.netty.channel.DefaultChannelPipeline$PendingHandlerRemovedTask extends io.netty.channel.DefaultChannelPipeline$PendingHandlerCallback {
final io.netty.channel.DefaultChannelPipeline this$0
void (io.netty.channel.DefaultChannelPipeline, io.netty.channel.AbstractChannelHandlerContext)
io.netty.channel.AbstractChannelHandlerContext ctx
public void run ()
void execute ()
java.util.concurrent.RejectedExecutionException e
io.netty.util.concurrent.EventExecutor executor
}
io/netty/channel/DefaultChannelPipeline$TailContext.classDefaultChannelPipeline.java
package io.netty.channel
final io.netty.channel.DefaultChannelPipeline$TailContext extends io.netty.channel.AbstractChannelHandlerContext implements io.netty.channel.ChannelInboundHandler {
private static final String TAIL_NAME
void (io.netty.channel.DefaultChannelPipeline)
io.netty.channel.DefaultChannelPipeline pipeline
public io.netty.channel.ChannelHandler handler ()
public void channelRegistered (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
public void channelUnregistered (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
public void channelActive (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
public void channelInactive (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
public void channelWritabilityChanged (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
public void handlerAdded (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
public void handlerRemoved (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
public void userEventTriggered (io.netty.channel.ChannelHandlerContext, java.lang.Object) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
Object evt
public void exceptionCaught (io.netty.channel.ChannelHandlerContext, java.lang.Throwable) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
Throwable cause
public void channelRead (io.netty.channel.ChannelHandlerContext, java.lang.Object) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
Object msg
public void channelReadComplete (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
static void ()
}
io/netty/channel/DefaultChannelPipeline$1.classDefaultChannelPipeline.java
package io.netty.channel
final io.netty.channel.DefaultChannelPipeline$1 extends io.netty.util.concurrent.FastThreadLocal {
void ()
protected java.util.Map initialValue () throws java.lang.Exception
protected volatile java.lang.Object initialValue () throws java.lang.Exception
}
io/netty/channel/ThreadPerChannelEventLoopGroup.classThreadPerChannelEventLoopGroup.java
package io.netty.channel
public io.netty.channel.ThreadPerChannelEventLoopGroup extends io.netty.util.concurrent.AbstractEventExecutorGroup implements io.netty.channel.EventLoopGroup {
private final Object[] childArgs
private final int maxChannels
final java.util.concurrent.Executor executor
final java.util.Set activeChildren
private final java.util.Set readOnlyActiveChildren
final java.util.Queue idleChildren
private final io.netty.channel.ChannelException tooManyChannels
private volatile boolean shuttingDown
private final io.netty.util.concurrent.Promise terminationFuture
private final io.netty.util.concurrent.FutureListener childTerminationListener
protected void ()
protected void (int)
int maxChannels
protected transient void (int, java.util.concurrent.ThreadFactory, java.lang.Object[])
int maxChannels
java.util.concurrent.ThreadFactory threadFactory
Object[] args
protected transient void (int, java.util.concurrent.Executor, java.lang.Object[])
int maxChannels
java.util.concurrent.Executor executor
Object[] args
protected transient io.netty.channel.EventLoop newChild (java.lang.Object[]) throws java.lang.Exception
Object[] args
public java.util.Iterator iterator ()
public java.util.Set children ()
public io.netty.channel.EventLoop next ()
public io.netty.util.concurrent.Future shutdownGracefully (long, long, java.util.concurrent.TimeUnit)
io.netty.channel.EventLoop l
java.util.Iterator i$
io.netty.channel.EventLoop l
java.util.Iterator i$
long quietPeriod
long timeout
java.util.concurrent.TimeUnit unit
public io.netty.util.concurrent.Future terminationFuture ()
public void shutdown ()
io.netty.channel.EventLoop l
java.util.Iterator i$
io.netty.channel.EventLoop l
java.util.Iterator i$
public boolean isShuttingDown ()
io.netty.channel.EventLoop l
java.util.Iterator i$
io.netty.channel.EventLoop l
java.util.Iterator i$
public boolean isShutdown ()
io.netty.channel.EventLoop l
java.util.Iterator i$
io.netty.channel.EventLoop l
java.util.Iterator i$
public boolean isTerminated ()
io.netty.channel.EventLoop l
java.util.Iterator i$
io.netty.channel.EventLoop l
java.util.Iterator i$
public boolean awaitTermination (long, java.util.concurrent.TimeUnit) throws java.lang.InterruptedException
long timeLeft
io.netty.channel.EventLoop l
java.util.Iterator i$
long timeLeft
io.netty.channel.EventLoop l
java.util.Iterator i$
long timeout
java.util.concurrent.TimeUnit unit
long deadline
public io.netty.channel.ChannelFuture register (io.netty.channel.Channel)
io.netty.channel.EventLoop l
Throwable t
io.netty.channel.Channel channel
public io.netty.channel.ChannelFuture register (io.netty.channel.Channel, io.netty.channel.ChannelPromise)
Throwable t
io.netty.channel.Channel channel
io.netty.channel.ChannelPromise promise
private io.netty.channel.EventLoop nextChild () throws java.lang.Exception
io.netty.channel.EventLoop loop
public volatile io.netty.util.concurrent.EventExecutor next ()
static io.netty.util.concurrent.Promise access$000 (io.netty.channel.ThreadPerChannelEventLoopGroup)
io.netty.channel.ThreadPerChannelEventLoopGroup x0
}
io/netty/channel/DefaultChannelHandlerInvoker$4.classDefaultChannelHandlerInvoker.java
package io.netty.channel
io.netty.channel.DefaultChannelHandlerInvoker$4 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.ChannelHandlerContext val$ctx
final io.netty.channel.DefaultChannelHandlerInvoker this$0
void (io.netty.channel.DefaultChannelHandlerInvoker, io.netty.channel.ChannelHandlerContext)
public void run ()
}
io/netty/channel/ChannelOutboundHandler.classChannelOutboundHandler.java
package io.netty.channel
public abstract io.netty.channel.ChannelOutboundHandler extends java.lang.Object implements io.netty.channel.ChannelHandler {
public abstract void bind (io.netty.channel.ChannelHandlerContext, java.net.SocketAddress, io.netty.channel.ChannelPromise) throws java.lang.Exception
public abstract void connect (io.netty.channel.ChannelHandlerContext, java.net.SocketAddress, java.net.SocketAddress, io.netty.channel.ChannelPromise) throws java.lang.Exception
public abstract void disconnect (io.netty.channel.ChannelHandlerContext, io.netty.channel.ChannelPromise) throws java.lang.Exception
public abstract void close (io.netty.channel.ChannelHandlerContext, io.netty.channel.ChannelPromise) throws java.lang.Exception
public abstract void deregister (io.netty.channel.ChannelHandlerContext, io.netty.channel.ChannelPromise) throws java.lang.Exception
public abstract void read (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
public abstract void write (io.netty.channel.ChannelHandlerContext, java.lang.Object, io.netty.channel.ChannelPromise) throws java.lang.Exception
public abstract void flush (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
}
io/netty/channel/PendingWriteQueue$PendingWrite$1.classPendingWriteQueue.java
package io.netty.channel
final io.netty.channel.PendingWriteQueue$PendingWrite$1 extends io.netty.util.Recycler {
void ()
protected io.netty.channel.PendingWriteQueue$PendingWrite newObject (io.netty.util.Recycler$Handle)
io.netty.util.Recycler$Handle handle
protected volatile java.lang.Object newObject (io.netty.util.Recycler$Handle)
}
io/netty/channel/DefaultEventLoop.classDefaultEventLoop.java
package io.netty.channel
public io.netty.channel.DefaultEventLoop extends io.netty.channel.SingleThreadEventLoop {
public void ()
public void (java.util.concurrent.ThreadFactory)
java.util.concurrent.ThreadFactory threadFactory
public void (java.util.concurrent.Executor)
java.util.concurrent.Executor executor
public void (io.netty.channel.EventLoopGroup)
io.netty.channel.EventLoopGroup parent
public void (io.netty.channel.EventLoopGroup, java.util.concurrent.ThreadFactory)
io.netty.channel.EventLoopGroup parent
java.util.concurrent.ThreadFactory threadFactory
public void (io.netty.channel.EventLoopGroup, java.util.concurrent.Executor)
io.netty.channel.EventLoopGroup parent
java.util.concurrent.Executor executor
protected void run ()
Runnable task
}
io/netty/channel/DefaultChannelProgressivePromise.classDefaultChannelProgressivePromise.java
package io.netty.channel
public io.netty.channel.DefaultChannelProgressivePromise extends io.netty.util.concurrent.DefaultProgressivePromise implements io.netty.channel.ChannelProgressivePromise io.netty.channel.ChannelFlushPromiseNotifier$FlushCheckpoint {
private final io.netty.channel.Channel channel
private long checkpoint
public void (io.netty.channel.Channel)
io.netty.channel.Channel channel
public void (io.netty.channel.Channel, io.netty.util.concurrent.EventExecutor)
io.netty.channel.Channel channel
io.netty.util.concurrent.EventExecutor executor
protected io.netty.util.concurrent.EventExecutor executor ()
io.netty.util.concurrent.EventExecutor e
public io.netty.channel.Channel channel ()
public io.netty.channel.ChannelProgressivePromise setSuccess ()
public io.netty.channel.ChannelProgressivePromise setSuccess (java.lang.Void)
Void result
public boolean trySuccess ()
public io.netty.channel.ChannelProgressivePromise setFailure (java.lang.Throwable)
Throwable cause
public io.netty.channel.ChannelProgressivePromise setProgress (long, long)
long progress
long total
public io.netty.channel.ChannelProgressivePromise addListener (io.netty.util.concurrent.GenericFutureListener)
io.netty.util.concurrent.GenericFutureListener listener
public transient io.netty.channel.ChannelProgressivePromise addListeners (io.netty.util.concurrent.GenericFutureListener[])
io.netty.util.concurrent.GenericFutureListener[] listeners
public io.netty.channel.ChannelProgressivePromise removeListener (io.netty.util.concurrent.GenericFutureListener)
io.netty.util.concurrent.GenericFutureListener listener
public transient io.netty.channel.ChannelProgressivePromise removeListeners (io.netty.util.concurrent.GenericFutureListener[])
io.netty.util.concurrent.GenericFutureListener[] listeners
public io.netty.channel.ChannelProgressivePromise sync () throws java.lang.InterruptedException
public io.netty.channel.ChannelProgressivePromise syncUninterruptibly ()
public io.netty.channel.ChannelProgressivePromise await () throws java.lang.InterruptedException
public io.netty.channel.ChannelProgressivePromise awaitUninterruptibly ()
public long flushCheckpoint ()
public void flushCheckpoint (long)
long checkpoint
public io.netty.channel.ChannelProgressivePromise promise ()
protected void checkDeadLock ()
public io.netty.channel.ChannelProgressivePromise unvoid ()
public boolean isVoid ()
public volatile io.netty.util.concurrent.ProgressivePromise setFailure (java.lang.Throwable)
public volatile io.netty.util.concurrent.ProgressivePromise setSuccess (java.lang.Object)
public volatile io.netty.util.concurrent.ProgressivePromise awaitUninterruptibly ()
public volatile io.netty.util.concurrent.ProgressivePromise await () throws java.lang.InterruptedException
public volatile io.netty.util.concurrent.ProgressivePromise syncUninterruptibly ()
public volatile io.netty.util.concurrent.ProgressivePromise sync () throws java.lang.InterruptedException
public volatile io.netty.util.concurrent.ProgressivePromise removeListeners (io.netty.util.concurrent.GenericFutureListener[])
public volatile io.netty.util.concurrent.ProgressivePromise removeListener (io.netty.util.concurrent.GenericFutureListener)
public volatile io.netty.util.concurrent.ProgressivePromise addListeners (io.netty.util.concurrent.GenericFutureListener[])
public volatile io.netty.util.concurrent.ProgressivePromise addListener (io.netty.util.concurrent.GenericFutureListener)
public volatile io.netty.util.concurrent.ProgressivePromise setProgress (long, long)
public volatile io.netty.util.concurrent.Promise syncUninterruptibly ()
public volatile io.netty.util.concurrent.Promise sync () throws java.lang.InterruptedException
public volatile io.netty.util.concurrent.Promise awaitUninterruptibly ()
public volatile io.netty.util.concurrent.Promise await () throws java.lang.InterruptedException
public volatile io.netty.util.concurrent.Promise removeListeners (io.netty.util.concurrent.GenericFutureListener[])
public volatile io.netty.util.concurrent.Promise removeListener (io.netty.util.concurrent.GenericFutureListener)
public volatile io.netty.util.concurrent.Promise addListeners (io.netty.util.concurrent.GenericFutureListener[])
public volatile io.netty.util.concurrent.Promise addListener (io.netty.util.concurrent.GenericFutureListener)
public volatile io.netty.util.concurrent.Promise setFailure (java.lang.Throwable)
public volatile io.netty.util.concurrent.Promise setSuccess (java.lang.Object)
public volatile io.netty.util.concurrent.Future awaitUninterruptibly ()
public volatile io.netty.util.concurrent.Future await () throws java.lang.InterruptedException
public volatile io.netty.util.concurrent.Future syncUninterruptibly ()
public volatile io.netty.util.concurrent.Future sync () throws java.lang.InterruptedException
public volatile io.netty.util.concurrent.Future removeListeners (io.netty.util.concurrent.GenericFutureListener[])
public volatile io.netty.util.concurrent.Future removeListener (io.netty.util.concurrent.GenericFutureListener)
public volatile io.netty.util.concurrent.Future addListeners (io.netty.util.concurrent.GenericFutureListener[])
public volatile io.netty.util.concurrent.Future addListener (io.netty.util.concurrent.GenericFutureListener)
public volatile io.netty.util.concurrent.ProgressiveFuture awaitUninterruptibly ()
public volatile io.netty.util.concurrent.ProgressiveFuture await () throws java.lang.InterruptedException
public volatile io.netty.util.concurrent.ProgressiveFuture syncUninterruptibly ()
public volatile io.netty.util.concurrent.ProgressiveFuture sync () throws java.lang.InterruptedException
public volatile io.netty.util.concurrent.ProgressiveFuture removeListeners (io.netty.util.concurrent.GenericFutureListener[])
public volatile io.netty.util.concurrent.ProgressiveFuture removeListener (io.netty.util.concurrent.GenericFutureListener)
public volatile io.netty.util.concurrent.ProgressiveFuture addListeners (io.netty.util.concurrent.GenericFutureListener[])
public volatile io.netty.util.concurrent.ProgressiveFuture addListener (io.netty.util.concurrent.GenericFutureListener)
public volatile io.netty.channel.ChannelProgressiveFuture awaitUninterruptibly ()
public volatile io.netty.channel.ChannelProgressiveFuture await () throws java.lang.InterruptedException
public volatile io.netty.channel.ChannelProgressiveFuture syncUninterruptibly ()
public volatile io.netty.channel.ChannelProgressiveFuture sync () throws java.lang.InterruptedException
public volatile io.netty.channel.ChannelProgressiveFuture removeListeners (io.netty.util.concurrent.GenericFutureListener[])
public volatile io.netty.channel.ChannelProgressiveFuture removeListener (io.netty.util.concurrent.GenericFutureListener)
public volatile io.netty.channel.ChannelProgressiveFuture addListeners (io.netty.util.concurrent.GenericFutureListener[])
public volatile io.netty.channel.ChannelProgressiveFuture addListener (io.netty.util.concurrent.GenericFutureListener)
public volatile io.netty.channel.ChannelFuture awaitUninterruptibly ()
public volatile io.netty.channel.ChannelFuture await () throws java.lang.InterruptedException
public volatile io.netty.channel.ChannelFuture syncUninterruptibly ()
public volatile io.netty.channel.ChannelFuture sync () throws java.lang.InterruptedException
public volatile io.netty.channel.ChannelFuture removeListeners (io.netty.util.concurrent.GenericFutureListener[])
public volatile io.netty.channel.ChannelFuture removeListener (io.netty.util.concurrent.GenericFutureListener)
public volatile io.netty.channel.ChannelFuture addListeners (io.netty.util.concurrent.GenericFutureListener[])
public volatile io.netty.channel.ChannelFuture addListener (io.netty.util.concurrent.GenericFutureListener)
public volatile io.netty.channel.ChannelPromise unvoid ()
public volatile io.netty.channel.ChannelPromise awaitUninterruptibly ()
public volatile io.netty.channel.ChannelPromise await () throws java.lang.InterruptedException
public volatile io.netty.channel.ChannelPromise syncUninterruptibly ()
public volatile io.netty.channel.ChannelPromise sync () throws java.lang.InterruptedException
public volatile io.netty.channel.ChannelPromise removeListeners (io.netty.util.concurrent.GenericFutureListener[])
public volatile io.netty.channel.ChannelPromise removeListener (io.netty.util.concurrent.GenericFutureListener)
public volatile io.netty.channel.ChannelPromise addListeners (io.netty.util.concurrent.GenericFutureListener[])
public volatile io.netty.channel.ChannelPromise addListener (io.netty.util.concurrent.GenericFutureListener)
public volatile io.netty.channel.ChannelPromise setFailure (java.lang.Throwable)
public volatile io.netty.channel.ChannelPromise setSuccess ()
public volatile io.netty.channel.ChannelPromise setSuccess (java.lang.Void)
public volatile io.netty.channel.ChannelPromise promise ()
}
io/netty/channel/ChannelPromise.classChannelPromise.java
package io.netty.channel
public abstract io.netty.channel.ChannelPromise extends java.lang.Object implements io.netty.channel.ChannelFuture io.netty.util.concurrent.Promise {
public abstract io.netty.channel.Channel channel ()
public abstract io.netty.channel.ChannelPromise setSuccess (java.lang.Void)
public abstract io.netty.channel.ChannelPromise setSuccess ()
public abstract boolean trySuccess ()
public abstract io.netty.channel.ChannelPromise setFailure (java.lang.Throwable)
public abstract io.netty.channel.ChannelPromise addListener (io.netty.util.concurrent.GenericFutureListener)
public transient abstract io.netty.channel.ChannelPromise addListeners (io.netty.util.concurrent.GenericFutureListener[])
public abstract io.netty.channel.ChannelPromise removeListener (io.netty.util.concurrent.GenericFutureListener)
public transient abstract io.netty.channel.ChannelPromise removeListeners (io.netty.util.concurrent.GenericFutureListener[])
public abstract io.netty.channel.ChannelPromise sync () throws java.lang.InterruptedException
public abstract io.netty.channel.ChannelPromise syncUninterruptibly ()
public abstract io.netty.channel.ChannelPromise await () throws java.lang.InterruptedException
public abstract io.netty.channel.ChannelPromise awaitUninterruptibly ()
public abstract io.netty.channel.ChannelPromise unvoid ()
}
io/netty/channel/ChannelProgressiveFuture.classChannelProgressiveFuture.java
package io.netty.channel
public abstract io.netty.channel.ChannelProgressiveFuture extends java.lang.Object implements io.netty.channel.ChannelFuture io.netty.util.concurrent.ProgressiveFuture {
public abstract io.netty.channel.ChannelProgressiveFuture addListener (io.netty.util.concurrent.GenericFutureListener)
public transient abstract io.netty.channel.ChannelProgressiveFuture addListeners (io.netty.util.concurrent.GenericFutureListener[])
public abstract io.netty.channel.ChannelProgressiveFuture removeListener (io.netty.util.concurrent.GenericFutureListener)
public transient abstract io.netty.channel.ChannelProgressiveFuture removeListeners (io.netty.util.concurrent.GenericFutureListener[])
public abstract io.netty.channel.ChannelProgressiveFuture sync () throws java.lang.InterruptedException
public abstract io.netty.channel.ChannelProgressiveFuture syncUninterruptibly ()
public abstract io.netty.channel.ChannelProgressiveFuture await () throws java.lang.InterruptedException
public abstract io.netty.channel.ChannelProgressiveFuture awaitUninterruptibly ()
}
io/netty/channel/DefaultChannelHandlerInvoker$1.classDefaultChannelHandlerInvoker.java
package io.netty.channel
io.netty.channel.DefaultChannelHandlerInvoker$1 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.ChannelHandlerContext val$ctx
final io.netty.channel.DefaultChannelHandlerInvoker this$0
void (io.netty.channel.DefaultChannelHandlerInvoker, io.netty.channel.ChannelHandlerContext)
public void run ()
}
io/netty/channel/RecvByteBufAllocator.classRecvByteBufAllocator.java
package io.netty.channel
public abstract io.netty.channel.RecvByteBufAllocator extends java.lang.Object {
public abstract io.netty.channel.RecvByteBufAllocator$Handle newHandle ()
}
io/netty/channel/RecvByteBufAllocator$DelegatingHandle.classRecvByteBufAllocator.java
package io.netty.channel
public io.netty.channel.RecvByteBufAllocator$DelegatingHandle extends java.lang.Object implements io.netty.channel.RecvByteBufAllocator$Handle {
private final io.netty.channel.RecvByteBufAllocator$Handle delegate
public void (io.netty.channel.RecvByteBufAllocator$Handle)
io.netty.channel.RecvByteBufAllocator$Handle delegate
protected final io.netty.channel.RecvByteBufAllocator$Handle delegate ()
public io.netty.buffer.ByteBuf allocate (io.netty.buffer.ByteBufAllocator)
io.netty.buffer.ByteBufAllocator alloc
public int guess ()
public void reset (io.netty.channel.ChannelConfig)
io.netty.channel.ChannelConfig config
public void incMessagesRead (int)
int numMessages
public void lastBytesRead (int)
int bytes
public int lastBytesRead ()
public boolean continueReading ()
public int attemptedBytesRead ()
public void attemptedBytesRead (int)
int bytes
public void readComplete ()
}
io/netty/channel/PendingWriteQueue.classPendingWriteQueue.java
package io.netty.channel
public final io.netty.channel.PendingWriteQueue extends java.lang.Object {
private static final io.netty.util.internal.logging.InternalLogger logger
private final io.netty.channel.ChannelHandlerContext ctx
private final io.netty.channel.ChannelOutboundBuffer buffer
private final io.netty.channel.MessageSizeEstimator$Handle estimatorHandle
private io.netty.channel.PendingWriteQueue$PendingWrite head
private io.netty.channel.PendingWriteQueue$PendingWrite tail
private int size
static final boolean $assertionsDisabled
public void (io.netty.channel.ChannelHandlerContext)
io.netty.channel.ChannelHandlerContext ctx
public boolean isEmpty ()
public int size ()
public void add (java.lang.Object, io.netty.channel.ChannelPromise)
Object msg
io.netty.channel.ChannelPromise promise
int messageSize
io.netty.channel.PendingWriteQueue$PendingWrite write
io.netty.channel.PendingWriteQueue$PendingWrite currentTail
public void removeAndFailAll (java.lang.Throwable)
io.netty.channel.PendingWriteQueue$PendingWrite next
io.netty.channel.ChannelPromise promise
Throwable cause
io.netty.channel.PendingWriteQueue$PendingWrite write
public void removeAndFail (java.lang.Throwable)
Throwable cause
io.netty.channel.PendingWriteQueue$PendingWrite write
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelFuture removeAndWriteAll ()
io.netty.channel.PendingWriteQueue$PendingWrite next
Object msg
io.netty.channel.ChannelPromise promise
io.netty.channel.PendingWriteQueue$PendingWrite write
io.netty.channel.ChannelPromise p
io.netty.channel.ChannelPromiseAggregator aggregator
private void assertEmpty ()
public io.netty.channel.ChannelFuture removeAndWrite ()
io.netty.channel.PendingWriteQueue$PendingWrite write
Object msg
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelPromise remove ()
io.netty.channel.PendingWriteQueue$PendingWrite write
io.netty.channel.ChannelPromise promise
public java.lang.Object current ()
io.netty.channel.PendingWriteQueue$PendingWrite write
private void recycle (io.netty.channel.PendingWriteQueue$PendingWrite, boolean)
io.netty.channel.PendingWriteQueue$PendingWrite write
boolean update
io.netty.channel.PendingWriteQueue$PendingWrite next
long writeSize
private static void safeFail (io.netty.channel.ChannelPromise, java.lang.Throwable)
io.netty.channel.ChannelPromise promise
Throwable cause
static void ()
}
io/netty/channel/DefaultChannelPipeline$4.classDefaultChannelPipeline.java
package io.netty.channel
io.netty.channel.DefaultChannelPipeline$4 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.AbstractChannelHandlerContext val$ctx
final io.netty.channel.AbstractChannelHandlerContext val$newCtx
final io.netty.channel.DefaultChannelPipeline this$0
void (io.netty.channel.DefaultChannelPipeline, io.netty.channel.AbstractChannelHandlerContext, io.netty.channel.AbstractChannelHandlerContext)
public void run ()
}
io/netty/channel/AbstractChannel$AbstractUnsafe$5.classAbstractChannel.java
package io.netty.channel
io.netty.channel.AbstractChannel$AbstractUnsafe$5 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.ChannelPromise val$promise
final io.netty.channel.ChannelOutboundBuffer val$outboundBuffer
final Throwable val$cause
final boolean val$notify
final boolean val$wasActive
final io.netty.channel.AbstractChannel$AbstractUnsafe this$1
void (io.netty.channel.AbstractChannel$AbstractUnsafe, io.netty.channel.ChannelPromise, io.netty.channel.ChannelOutboundBuffer, java.lang.Throwable, boolean, boolean)
public void run ()
}
io/netty/channel/MultithreadEventLoopGroup.classMultithreadEventLoopGroup.java
package io.netty.channel
public abstract io.netty.channel.MultithreadEventLoopGroup extends io.netty.util.concurrent.MultithreadEventExecutorGroup implements io.netty.channel.EventLoopGroup {
private static final io.netty.util.internal.logging.InternalLogger logger
private static final int DEFAULT_EVENT_LOOP_THREADS
protected transient void (int, java.util.concurrent.Executor, java.lang.Object[])
int nThreads
java.util.concurrent.Executor executor
Object[] args
protected transient void (int, java.util.concurrent.ThreadFactory, java.lang.Object[])
int nThreads
java.util.concurrent.ThreadFactory threadFactory
Object[] args
protected java.util.concurrent.ThreadFactory newDefaultThreadFactory ()
public io.netty.channel.EventLoop next ()
protected transient abstract io.netty.channel.EventLoop newChild (java.util.concurrent.Executor, java.lang.Object[]) throws java.lang.Exception
public io.netty.channel.ChannelFuture register (io.netty.channel.Channel)
io.netty.channel.Channel channel
public io.netty.channel.ChannelFuture register (io.netty.channel.Channel, io.netty.channel.ChannelPromise)
io.netty.channel.Channel channel
io.netty.channel.ChannelPromise promise
protected volatile io.netty.util.concurrent.EventExecutor newChild (java.util.concurrent.Executor, java.lang.Object[]) throws java.lang.Exception
public volatile io.netty.util.concurrent.EventExecutor next ()
static void ()
}
io/netty/channel/ChannelId.classChannelId.java
package io.netty.channel
public abstract io.netty.channel.ChannelId extends java.lang.Object implements java.io.Serializable java.lang.Comparable {
public abstract java.lang.String asShortText ()
public abstract java.lang.String asLongText ()
}
io/netty/channel/group/DefaultChannelGroupFuture$1.classDefaultChannelGroupFuture.java
package io.netty.channel.group
io.netty.channel.group.DefaultChannelGroupFuture$1 extends java.lang.Object implements io.netty.channel.ChannelFutureListener {
static final boolean $assertionsDisabled
final io.netty.channel.group.DefaultChannelGroupFuture this$0
void (io.netty.channel.group.DefaultChannelGroupFuture)
public void operationComplete (io.netty.channel.ChannelFuture) throws java.lang.Exception
boolean callSetDone
io.netty.channel.ChannelFuture f
java.util.Iterator i$
java.util.List failed
io.netty.channel.ChannelFuture future
boolean success
boolean callSetDone
public volatile void operationComplete (io.netty.util.concurrent.Future) throws java.lang.Exception
static void ()
}
io/netty/channel/group/ChannelMatchers$InstanceMatcher.classChannelMatchers.java
package io.netty.channel.group
final io.netty.channel.group.ChannelMatchers$InstanceMatcher extends java.lang.Object implements io.netty.channel.group.ChannelMatcher {
private final io.netty.channel.Channel channel
void (io.netty.channel.Channel)
io.netty.channel.Channel channel
public boolean matches (io.netty.channel.Channel)
io.netty.channel.Channel ch
}
io/netty/channel/group/ChannelMatchers.classChannelMatchers.java
package io.netty.channel.group
public final io.netty.channel.group.ChannelMatchers extends java.lang.Object {
private static final io.netty.channel.group.ChannelMatcher ALL_MATCHER
private static final io.netty.channel.group.ChannelMatcher SERVER_CHANNEL_MATCHER
private static final io.netty.channel.group.ChannelMatcher NON_SERVER_CHANNEL_MATCHER
private void ()
public static io.netty.channel.group.ChannelMatcher all ()
public static io.netty.channel.group.ChannelMatcher isNot (io.netty.channel.Channel)
io.netty.channel.Channel channel
public static io.netty.channel.group.ChannelMatcher is (io.netty.channel.Channel)
io.netty.channel.Channel channel
public static io.netty.channel.group.ChannelMatcher isInstanceOf (java.lang.Class)
Class clazz
public static io.netty.channel.group.ChannelMatcher isNotInstanceOf (java.lang.Class)
Class clazz
public static io.netty.channel.group.ChannelMatcher isServerChannel ()
public static io.netty.channel.group.ChannelMatcher isNonServerChannel ()
public static io.netty.channel.group.ChannelMatcher invert (io.netty.channel.group.ChannelMatcher)
io.netty.channel.group.ChannelMatcher matcher
public static transient io.netty.channel.group.ChannelMatcher compose (io.netty.channel.group.ChannelMatcher[])
io.netty.channel.group.ChannelMatcher[] matchers
static void ()
}
io/netty/channel/group/ChannelMatchers$ClassMatcher.classChannelMatchers.java
package io.netty.channel.group
final io.netty.channel.group.ChannelMatchers$ClassMatcher extends java.lang.Object implements io.netty.channel.group.ChannelMatcher {
private final Class clazz
void (java.lang.Class)
Class clazz
public boolean matches (io.netty.channel.Channel)
io.netty.channel.Channel ch
}
io/netty/channel/group/ChannelMatchers$CompositeMatcher.classChannelMatchers.java
package io.netty.channel.group
final io.netty.channel.group.ChannelMatchers$CompositeMatcher extends java.lang.Object implements io.netty.channel.group.ChannelMatcher {
private final io.netty.channel.group.ChannelMatcher[] matchers
transient void (io.netty.channel.group.ChannelMatcher[])
io.netty.channel.group.ChannelMatcher[] matchers
public boolean matches (io.netty.channel.Channel)
io.netty.channel.group.ChannelMatcher m
io.netty.channel.group.ChannelMatcher[] arr$
int len$
int i$
io.netty.channel.Channel channel
}
io/netty/channel/group/ChannelMatchers$InvertMatcher.classChannelMatchers.java
package io.netty.channel.group
final io.netty.channel.group.ChannelMatchers$InvertMatcher extends java.lang.Object implements io.netty.channel.group.ChannelMatcher {
private final io.netty.channel.group.ChannelMatcher matcher
void (io.netty.channel.group.ChannelMatcher)
io.netty.channel.group.ChannelMatcher matcher
public boolean matches (io.netty.channel.Channel)
io.netty.channel.Channel channel
}
io/netty/channel/group/ChannelGroupFutureListener.classChannelGroupFutureListener.java
package io.netty.channel.group
public abstract io.netty.channel.group.ChannelGroupFutureListener extends java.lang.Object implements io.netty.util.concurrent.GenericFutureListener {
}
io/netty/channel/group/ChannelGroupFuture.classChannelGroupFuture.java
package io.netty.channel.group
public abstract io.netty.channel.group.ChannelGroupFuture extends java.lang.Object implements io.netty.util.concurrent.Future java.lang.Iterable {
public abstract io.netty.channel.group.ChannelGroup group ()
public abstract io.netty.channel.ChannelFuture find (io.netty.channel.Channel)
public abstract boolean isSuccess ()
public abstract io.netty.channel.group.ChannelGroupException cause ()
public abstract boolean isPartialSuccess ()
public abstract boolean isPartialFailure ()
public abstract io.netty.channel.group.ChannelGroupFuture addListener (io.netty.util.concurrent.GenericFutureListener)
public transient abstract io.netty.channel.group.ChannelGroupFuture addListeners (io.netty.util.concurrent.GenericFutureListener[])
public abstract io.netty.channel.group.ChannelGroupFuture removeListener (io.netty.util.concurrent.GenericFutureListener)
public transient abstract io.netty.channel.group.ChannelGroupFuture removeListeners (io.netty.util.concurrent.GenericFutureListener[])
public abstract io.netty.channel.group.ChannelGroupFuture await () throws java.lang.InterruptedException
public abstract io.netty.channel.group.ChannelGroupFuture awaitUninterruptibly ()
public abstract io.netty.channel.group.ChannelGroupFuture syncUninterruptibly ()
public abstract io.netty.channel.group.ChannelGroupFuture sync () throws java.lang.InterruptedException
public abstract java.util.Iterator iterator ()
}
io/netty/channel/group/ChannelGroupException.classChannelGroupException.java
package io.netty.channel.group
public io.netty.channel.group.ChannelGroupException extends io.netty.channel.ChannelException implements java.lang.Iterable {
private static final long serialVersionUID
private final java.util.Collection failed
public void (java.util.Collection)
java.util.Collection causes
public java.util.Iterator iterator ()
}
io/netty/channel/group/DefaultChannelGroupFuture$DefaultEntry.classDefaultChannelGroupFuture.java
package io.netty.channel.group
final io.netty.channel.group.DefaultChannelGroupFuture$DefaultEntry extends java.lang.Object implements java.util.Map$Entry {
private final Object key
private final Object value
void (java.lang.Object, java.lang.Object)
Object key
Object value
public java.lang.Object getKey ()
public java.lang.Object getValue ()
public java.lang.Object setValue (java.lang.Object)
Object value
}
io/netty/channel/group/ChannelGroup.classChannelGroup.java
package io.netty.channel.group
public abstract io.netty.channel.group.ChannelGroup extends java.lang.Object implements java.util.Set java.lang.Comparable {
public abstract java.lang.String name ()
public abstract io.netty.channel.Channel find (io.netty.channel.ChannelId)
public abstract io.netty.channel.group.ChannelGroupFuture write (java.lang.Object)
public abstract io.netty.channel.group.ChannelGroupFuture write (java.lang.Object, io.netty.channel.group.ChannelMatcher)
public abstract io.netty.channel.group.ChannelGroup flush ()
public abstract io.netty.channel.group.ChannelGroup flush (io.netty.channel.group.ChannelMatcher)
public abstract io.netty.channel.group.ChannelGroupFuture writeAndFlush (java.lang.Object)
public abstract io.netty.channel.group.ChannelGroupFuture flushAndWrite (java.lang.Object)
public abstract io.netty.channel.group.ChannelGroupFuture writeAndFlush (java.lang.Object, io.netty.channel.group.ChannelMatcher)
public abstract io.netty.channel.group.ChannelGroupFuture flushAndWrite (java.lang.Object, io.netty.channel.group.ChannelMatcher)
public abstract io.netty.channel.group.ChannelGroupFuture disconnect ()
public abstract io.netty.channel.group.ChannelGroupFuture disconnect (io.netty.channel.group.ChannelMatcher)
public abstract io.netty.channel.group.ChannelGroupFuture close ()
public abstract io.netty.channel.group.ChannelGroupFuture close (io.netty.channel.group.ChannelMatcher)
public abstract io.netty.channel.group.ChannelGroupFuture deregister ()
public abstract io.netty.channel.group.ChannelGroupFuture deregister (io.netty.channel.group.ChannelMatcher)
public abstract io.netty.channel.group.ChannelGroupFuture newCloseFuture ()
public abstract io.netty.channel.group.ChannelGroupFuture newCloseFuture (io.netty.channel.group.ChannelMatcher)
}
io/netty/channel/group/ChannelMatcher.classChannelMatcher.java
package io.netty.channel.group
public abstract io.netty.channel.group.ChannelMatcher extends java.lang.Object {
public abstract boolean matches (io.netty.channel.Channel)
}
io/netty/channel/group/DefaultChannelGroup$1.classDefaultChannelGroup.java
package io.netty.channel.group
io.netty.channel.group.DefaultChannelGroup$1 extends java.lang.Object implements io.netty.channel.ChannelFutureListener {
final io.netty.channel.group.DefaultChannelGroup this$0
void (io.netty.channel.group.DefaultChannelGroup)
public void operationComplete (io.netty.channel.ChannelFuture) throws java.lang.Exception
io.netty.channel.ChannelFuture future
public volatile void operationComplete (io.netty.util.concurrent.Future) throws java.lang.Exception
}
io/netty/channel/group/DefaultChannelGroup.classDefaultChannelGroup.java
package io.netty.channel.group
public io.netty.channel.group.DefaultChannelGroup extends java.util.AbstractSet implements io.netty.channel.group.ChannelGroup {
private static final java.util.concurrent.atomic.AtomicInteger nextId
private final String name
private final io.netty.util.concurrent.EventExecutor executor
private final java.util.concurrent.ConcurrentMap serverChannels
private final java.util.concurrent.ConcurrentMap nonServerChannels
private final io.netty.channel.ChannelFutureListener remover
private final boolean stayClosed
private volatile boolean closed
public void (io.netty.util.concurrent.EventExecutor)
io.netty.util.concurrent.EventExecutor executor
public void (java.lang.String, io.netty.util.concurrent.EventExecutor)
String name
io.netty.util.concurrent.EventExecutor executor
public void (io.netty.util.concurrent.EventExecutor, boolean)
io.netty.util.concurrent.EventExecutor executor
boolean stayClosed
public void (java.lang.String, io.netty.util.concurrent.EventExecutor, boolean)
String name
io.netty.util.concurrent.EventExecutor executor
boolean stayClosed
public java.lang.String name ()
public io.netty.channel.Channel find (io.netty.channel.ChannelId)
io.netty.channel.ChannelId id
io.netty.channel.Channel c
public boolean isEmpty ()
public int size ()
public boolean contains (java.lang.Object)
io.netty.channel.Channel c
Object o
public boolean add (io.netty.channel.Channel)
io.netty.channel.Channel channel
java.util.concurrent.ConcurrentMap map
boolean added
public boolean remove (java.lang.Object)
Object o
io.netty.channel.Channel c
public void clear ()
public java.util.Iterator iterator ()
public java.lang.Object[] toArray ()
java.util.Collection channels
public java.lang.Object[] toArray (java.lang.Object[])
Object[] a
java.util.Collection channels
public io.netty.channel.group.ChannelGroupFuture close ()
public io.netty.channel.group.ChannelGroupFuture disconnect ()
public io.netty.channel.group.ChannelGroupFuture deregister ()
public io.netty.channel.group.ChannelGroupFuture write (java.lang.Object)
Object message
private static java.lang.Object safeDuplicate (java.lang.Object)
Object message
public io.netty.channel.group.ChannelGroupFuture write (java.lang.Object, io.netty.channel.group.ChannelMatcher)
io.netty.channel.Channel c
java.util.Iterator i$
Object message
io.netty.channel.group.ChannelMatcher matcher
java.util.Map futures
public io.netty.channel.group.ChannelGroup flush ()
public io.netty.channel.group.ChannelGroupFuture flushAndWrite (java.lang.Object)
Object message
public io.netty.channel.group.ChannelGroupFuture writeAndFlush (java.lang.Object)
Object message
public io.netty.channel.group.ChannelGroupFuture disconnect (io.netty.channel.group.ChannelMatcher)
io.netty.channel.Channel c
java.util.Iterator i$
io.netty.channel.Channel c
java.util.Iterator i$
io.netty.channel.group.ChannelMatcher matcher
java.util.Map futures
public io.netty.channel.group.ChannelGroupFuture close (io.netty.channel.group.ChannelMatcher)
io.netty.channel.Channel c
java.util.Iterator i$
io.netty.channel.Channel c
java.util.Iterator i$
io.netty.channel.group.ChannelMatcher matcher
java.util.Map futures
public io.netty.channel.group.ChannelGroupFuture deregister (io.netty.channel.group.ChannelMatcher)
io.netty.channel.Channel c
java.util.Iterator i$
io.netty.channel.Channel c
java.util.Iterator i$
io.netty.channel.group.ChannelMatcher matcher
java.util.Map futures
public io.netty.channel.group.ChannelGroup flush (io.netty.channel.group.ChannelMatcher)
io.netty.channel.Channel c
java.util.Iterator i$
io.netty.channel.group.ChannelMatcher matcher
public io.netty.channel.group.ChannelGroupFuture flushAndWrite (java.lang.Object, io.netty.channel.group.ChannelMatcher)
Object message
io.netty.channel.group.ChannelMatcher matcher
public io.netty.channel.group.ChannelGroupFuture writeAndFlush (java.lang.Object, io.netty.channel.group.ChannelMatcher)
io.netty.channel.Channel c
java.util.Iterator i$
Object message
io.netty.channel.group.ChannelMatcher matcher
java.util.Map futures
public io.netty.channel.group.ChannelGroupFuture newCloseFuture ()
public io.netty.channel.group.ChannelGroupFuture newCloseFuture (io.netty.channel.group.ChannelMatcher)
io.netty.channel.Channel c
java.util.Iterator i$
io.netty.channel.Channel c
java.util.Iterator i$
io.netty.channel.group.ChannelMatcher matcher
java.util.Map futures
public int hashCode ()
public boolean equals (java.lang.Object)
Object o
public int compareTo (io.netty.channel.group.ChannelGroup)
io.netty.channel.group.ChannelGroup o
int v
public java.lang.String toString ()
public volatile boolean add (java.lang.Object)
public volatile int compareTo (java.lang.Object)
static void ()
}
io/netty/channel/group/ChannelMatchers$1.classChannelMatchers.java
package io.netty.channel.group
final io.netty.channel.group.ChannelMatchers$1 extends java.lang.Object implements io.netty.channel.group.ChannelMatcher {
void ()
public boolean matches (io.netty.channel.Channel)
io.netty.channel.Channel channel
}
io/netty/channel/group/CombinedIterator.classCombinedIterator.java
package io.netty.channel.group
final io.netty.channel.group.CombinedIterator extends java.lang.Object implements java.util.Iterator {
private final java.util.Iterator i1
private final java.util.Iterator i2
private java.util.Iterator currentIterator
void (java.util.Iterator, java.util.Iterator)
java.util.Iterator i1
java.util.Iterator i2
public boolean hasNext ()
public java.lang.Object next ()
java.util.NoSuchElementException e
public void remove ()
}
io/netty/channel/group/DefaultChannelGroupFuture.classDefaultChannelGroupFuture.java
package io.netty.channel.group
final io.netty.channel.group.DefaultChannelGroupFuture extends io.netty.util.concurrent.DefaultPromise implements io.netty.channel.group.ChannelGroupFuture {
private final io.netty.channel.group.ChannelGroup group
private final java.util.Map futures
private int successCount
private int failureCount
private final io.netty.channel.ChannelFutureListener childListener
void (io.netty.channel.group.ChannelGroup, java.util.Collection, io.netty.util.concurrent.EventExecutor)
io.netty.channel.ChannelFuture f
java.util.Iterator i$
io.netty.channel.ChannelFuture f
java.util.Iterator i$
io.netty.channel.group.ChannelGroup group
java.util.Collection futures
io.netty.util.concurrent.EventExecutor executor
java.util.Map futureMap
void (io.netty.channel.group.ChannelGroup, java.util.Map, io.netty.util.concurrent.EventExecutor)
io.netty.channel.ChannelFuture f
java.util.Iterator i$
io.netty.channel.group.ChannelGroup group
java.util.Map futures
io.netty.util.concurrent.EventExecutor executor
public io.netty.channel.group.ChannelGroup group ()
public io.netty.channel.ChannelFuture find (io.netty.channel.Channel)
io.netty.channel.Channel channel
public java.util.Iterator iterator ()
public synchronized boolean isPartialSuccess ()
public synchronized boolean isPartialFailure ()
public io.netty.channel.group.DefaultChannelGroupFuture addListener (io.netty.util.concurrent.GenericFutureListener)
io.netty.util.concurrent.GenericFutureListener listener
public transient io.netty.channel.group.DefaultChannelGroupFuture addListeners (io.netty.util.concurrent.GenericFutureListener[])
io.netty.util.concurrent.GenericFutureListener[] listeners
public io.netty.channel.group.DefaultChannelGroupFuture removeListener (io.netty.util.concurrent.GenericFutureListener)
io.netty.util.concurrent.GenericFutureListener listener
public transient io.netty.channel.group.DefaultChannelGroupFuture removeListeners (io.netty.util.concurrent.GenericFutureListener[])
io.netty.util.concurrent.GenericFutureListener[] listeners
public io.netty.channel.group.DefaultChannelGroupFuture await () throws java.lang.InterruptedException
public io.netty.channel.group.DefaultChannelGroupFuture awaitUninterruptibly ()
public io.netty.channel.group.DefaultChannelGroupFuture syncUninterruptibly ()
public io.netty.channel.group.DefaultChannelGroupFuture sync () throws java.lang.InterruptedException
public io.netty.channel.group.ChannelGroupException cause ()
private void setSuccess0 ()
private void setFailure0 (io.netty.channel.group.ChannelGroupException)
io.netty.channel.group.ChannelGroupException cause
public io.netty.channel.group.DefaultChannelGroupFuture setSuccess (java.lang.Void)
Void result
public boolean trySuccess (java.lang.Void)
Void result
public io.netty.channel.group.DefaultChannelGroupFuture setFailure (java.lang.Throwable)
Throwable cause
public boolean tryFailure (java.lang.Throwable)
Throwable cause
protected void checkDeadLock ()
io.netty.util.concurrent.EventExecutor e
public volatile io.netty.util.concurrent.Promise setFailure (java.lang.Throwable)
public volatile boolean trySuccess (java.lang.Object)
public volatile io.netty.util.concurrent.Promise setSuccess (java.lang.Object)
public volatile io.netty.util.concurrent.Promise awaitUninterruptibly ()
public volatile io.netty.util.concurrent.Promise await () throws java.lang.InterruptedException
public volatile io.netty.util.concurrent.Promise syncUninterruptibly ()
public volatile io.netty.util.concurrent.Promise sync () throws java.lang.InterruptedException
public volatile io.netty.util.concurrent.Promise removeListeners (io.netty.util.concurrent.GenericFutureListener[])
public volatile io.netty.util.concurrent.Promise removeListener (io.netty.util.concurrent.GenericFutureListener)
public volatile io.netty.util.concurrent.Promise addListeners (io.netty.util.concurrent.GenericFutureListener[])
public volatile io.netty.util.concurrent.Promise addListener (io.netty.util.concurrent.GenericFutureListener)
public volatile java.lang.Throwable cause ()
public volatile io.netty.util.concurrent.Future awaitUninterruptibly ()
public volatile io.netty.util.concurrent.Future await () throws java.lang.InterruptedException
public volatile io.netty.util.concurrent.Future syncUninterruptibly ()
public volatile io.netty.util.concurrent.Future sync () throws java.lang.InterruptedException
public volatile io.netty.util.concurrent.Future removeListeners (io.netty.util.concurrent.GenericFutureListener[])
public volatile io.netty.util.concurrent.Future removeListener (io.netty.util.concurrent.GenericFutureListener)
public volatile io.netty.util.concurrent.Future addListeners (io.netty.util.concurrent.GenericFutureListener[])
public volatile io.netty.util.concurrent.Future addListener (io.netty.util.concurrent.GenericFutureListener)
public volatile io.netty.channel.group.ChannelGroupFuture sync () throws java.lang.InterruptedException
public volatile io.netty.channel.group.ChannelGroupFuture syncUninterruptibly ()
public volatile io.netty.channel.group.ChannelGroupFuture awaitUninterruptibly ()
public volatile io.netty.channel.group.ChannelGroupFuture await () throws java.lang.InterruptedException
public volatile io.netty.channel.group.ChannelGroupFuture removeListeners (io.netty.util.concurrent.GenericFutureListener[])
public volatile io.netty.channel.group.ChannelGroupFuture removeListener (io.netty.util.concurrent.GenericFutureListener)
public volatile io.netty.channel.group.ChannelGroupFuture addListeners (io.netty.util.concurrent.GenericFutureListener[])
public volatile io.netty.channel.group.ChannelGroupFuture addListener (io.netty.util.concurrent.GenericFutureListener)
static int access$008 (io.netty.channel.group.DefaultChannelGroupFuture)
io.netty.channel.group.DefaultChannelGroupFuture x0
static int access$108 (io.netty.channel.group.DefaultChannelGroupFuture)
io.netty.channel.group.DefaultChannelGroupFuture x0
static int access$000 (io.netty.channel.group.DefaultChannelGroupFuture)
io.netty.channel.group.DefaultChannelGroupFuture x0
static int access$100 (io.netty.channel.group.DefaultChannelGroupFuture)
io.netty.channel.group.DefaultChannelGroupFuture x0
static java.util.Map access$200 (io.netty.channel.group.DefaultChannelGroupFuture)
io.netty.channel.group.DefaultChannelGroupFuture x0
static void access$300 (io.netty.channel.group.DefaultChannelGroupFuture, io.netty.channel.group.ChannelGroupException)
io.netty.channel.group.DefaultChannelGroupFuture x0
io.netty.channel.group.ChannelGroupException x1
static void access$400 (io.netty.channel.group.DefaultChannelGroupFuture)
io.netty.channel.group.DefaultChannelGroupFuture x0
}
io/netty/channel/DefaultChannelPipeline.classDefaultChannelPipeline.java
package io.netty.channel
final io.netty.channel.DefaultChannelPipeline extends java.lang.Object implements io.netty.channel.ChannelPipeline {
static final io.netty.util.internal.logging.InternalLogger logger
private static final io.netty.util.concurrent.FastThreadLocal nameCaches
final io.netty.channel.AbstractChannel channel
final io.netty.channel.AbstractChannelHandlerContext head
final io.netty.channel.AbstractChannelHandlerContext tail
private final boolean touch
private java.util.Map childInvokers
private io.netty.channel.DefaultChannelPipeline$PendingHandlerCallback pendingHandlerCallbackHead
private boolean registered
static final boolean $assertionsDisabled
void (io.netty.channel.AbstractChannel)
io.netty.channel.AbstractChannel channel
java.lang.Object touch (java.lang.Object, io.netty.channel.AbstractChannelHandlerContext)
Object msg
io.netty.channel.AbstractChannelHandlerContext next
public io.netty.channel.Channel channel ()
public io.netty.channel.ChannelPipeline addFirst (java.lang.String, io.netty.channel.ChannelHandler)
String name
io.netty.channel.ChannelHandler handler
public io.netty.channel.ChannelPipeline addFirst (io.netty.util.concurrent.EventExecutorGroup, java.lang.String, io.netty.channel.ChannelHandler)
io.netty.util.concurrent.EventExecutorGroup group
String name
io.netty.channel.ChannelHandler handler
public io.netty.channel.ChannelPipeline addFirst (io.netty.channel.ChannelHandlerInvoker, java.lang.String, io.netty.channel.ChannelHandler)
io.netty.channel.ChannelHandlerInvoker invoker
String name
io.netty.channel.ChannelHandler handler
private io.netty.channel.ChannelPipeline addFirst (io.netty.util.concurrent.EventExecutorGroup, io.netty.channel.ChannelHandlerInvoker, java.lang.String, io.netty.channel.ChannelHandler)
io.netty.channel.AbstractChannelHandlerContext newCtx
io.netty.util.concurrent.EventExecutor executor
boolean inEventLoop
io.netty.util.concurrent.EventExecutorGroup group
io.netty.channel.ChannelHandlerInvoker invoker
String name
io.netty.channel.ChannelHandler handler
io.netty.channel.AbstractChannelHandlerContext newCtx
io.netty.util.concurrent.EventExecutor executor
boolean inEventLoop
private void addFirst0 (io.netty.channel.AbstractChannelHandlerContext)
io.netty.channel.AbstractChannelHandlerContext newCtx
io.netty.channel.AbstractChannelHandlerContext nextCtx
public io.netty.channel.ChannelPipeline addLast (java.lang.String, io.netty.channel.ChannelHandler)
String name
io.netty.channel.ChannelHandler handler
public io.netty.channel.ChannelPipeline addLast (io.netty.util.concurrent.EventExecutorGroup, java.lang.String, io.netty.channel.ChannelHandler)
io.netty.util.concurrent.EventExecutorGroup group
String name
io.netty.channel.ChannelHandler handler
public io.netty.channel.ChannelPipeline addLast (io.netty.channel.ChannelHandlerInvoker, java.lang.String, io.netty.channel.ChannelHandler)
io.netty.channel.ChannelHandlerInvoker invoker
String name
io.netty.channel.ChannelHandler handler
private io.netty.channel.ChannelPipeline addLast (io.netty.util.concurrent.EventExecutorGroup, io.netty.channel.ChannelHandlerInvoker, java.lang.String, io.netty.channel.ChannelHandler)
io.netty.util.concurrent.EventExecutor executor
io.netty.channel.AbstractChannelHandlerContext newCtx
boolean inEventLoop
io.netty.util.concurrent.EventExecutorGroup group
io.netty.channel.ChannelHandlerInvoker invoker
String name
io.netty.channel.ChannelHandler handler
io.netty.util.concurrent.EventExecutor executor
io.netty.channel.AbstractChannelHandlerContext newCtx
boolean inEventLoop
private void addLast0 (io.netty.channel.AbstractChannelHandlerContext)
io.netty.channel.AbstractChannelHandlerContext newCtx
io.netty.channel.AbstractChannelHandlerContext prev
public io.netty.channel.ChannelPipeline addBefore (java.lang.String, java.lang.String, io.netty.channel.ChannelHandler)
String baseName
String name
io.netty.channel.ChannelHandler handler
public io.netty.channel.ChannelPipeline addBefore (io.netty.util.concurrent.EventExecutorGroup, java.lang.String, java.lang.String, io.netty.channel.ChannelHandler)
io.netty.util.concurrent.EventExecutorGroup group
String baseName
String name
io.netty.channel.ChannelHandler handler
public io.netty.channel.ChannelPipeline addBefore (io.netty.channel.ChannelHandlerInvoker, java.lang.String, java.lang.String, io.netty.channel.ChannelHandler)
io.netty.channel.ChannelHandlerInvoker invoker
String baseName
String name
io.netty.channel.ChannelHandler handler
private io.netty.channel.ChannelPipeline addBefore (io.netty.util.concurrent.EventExecutorGroup, io.netty.channel.ChannelHandlerInvoker, java.lang.String, java.lang.String, io.netty.channel.ChannelHandler)
io.netty.util.concurrent.EventExecutor executor
io.netty.channel.AbstractChannelHandlerContext newCtx
io.netty.channel.AbstractChannelHandlerContext ctx
boolean inEventLoop
io.netty.util.concurrent.EventExecutorGroup group
io.netty.channel.ChannelHandlerInvoker invoker
String baseName
String name
io.netty.channel.ChannelHandler handler
io.netty.util.concurrent.EventExecutor executor
io.netty.channel.AbstractChannelHandlerContext newCtx
io.netty.channel.AbstractChannelHandlerContext ctx
boolean inEventLoop
private static void addBefore0 (io.netty.channel.AbstractChannelHandlerContext, io.netty.channel.AbstractChannelHandlerContext)
io.netty.channel.AbstractChannelHandlerContext ctx
io.netty.channel.AbstractChannelHandlerContext newCtx
public io.netty.channel.ChannelPipeline addAfter (java.lang.String, java.lang.String, io.netty.channel.ChannelHandler)
String baseName
String name
io.netty.channel.ChannelHandler handler
public io.netty.channel.ChannelPipeline addAfter (io.netty.util.concurrent.EventExecutorGroup, java.lang.String, java.lang.String, io.netty.channel.ChannelHandler)
io.netty.util.concurrent.EventExecutorGroup group
String baseName
String name
io.netty.channel.ChannelHandler handler
public io.netty.channel.ChannelPipeline addAfter (io.netty.channel.ChannelHandlerInvoker, java.lang.String, java.lang.String, io.netty.channel.ChannelHandler)
io.netty.channel.ChannelHandlerInvoker invoker
String baseName
String name
io.netty.channel.ChannelHandler handler
private io.netty.channel.ChannelPipeline addAfter (io.netty.util.concurrent.EventExecutorGroup, io.netty.channel.ChannelHandlerInvoker, java.lang.String, java.lang.String, io.netty.channel.ChannelHandler)
io.netty.util.concurrent.EventExecutor executor
io.netty.channel.AbstractChannelHandlerContext newCtx
io.netty.channel.AbstractChannelHandlerContext ctx
boolean inEventLoop
io.netty.util.concurrent.EventExecutorGroup group
io.netty.channel.ChannelHandlerInvoker invoker
String baseName
String name
io.netty.channel.ChannelHandler handler
io.netty.util.concurrent.EventExecutor executor
io.netty.channel.AbstractChannelHandlerContext newCtx
io.netty.channel.AbstractChannelHandlerContext ctx
boolean inEventLoop
private static void addAfter0 (io.netty.channel.AbstractChannelHandlerContext, io.netty.channel.AbstractChannelHandlerContext)
io.netty.channel.AbstractChannelHandlerContext ctx
io.netty.channel.AbstractChannelHandlerContext newCtx
public transient io.netty.channel.ChannelPipeline addFirst (io.netty.channel.ChannelHandler[])
io.netty.channel.ChannelHandler[] handlers
public transient io.netty.channel.ChannelPipeline addFirst (io.netty.util.concurrent.EventExecutorGroup, io.netty.channel.ChannelHandler[])
io.netty.channel.ChannelHandler h
int i
io.netty.util.concurrent.EventExecutorGroup group
io.netty.channel.ChannelHandler[] handlers
int size
public transient io.netty.channel.ChannelPipeline addFirst (io.netty.channel.ChannelHandlerInvoker, io.netty.channel.ChannelHandler[])
io.netty.channel.ChannelHandler h
int i
io.netty.channel.ChannelHandlerInvoker invoker
io.netty.channel.ChannelHandler[] handlers
int size
public transient io.netty.channel.ChannelPipeline addLast (io.netty.channel.ChannelHandler[])
io.netty.channel.ChannelHandler[] handlers
public transient io.netty.channel.ChannelPipeline addLast (io.netty.util.concurrent.EventExecutorGroup, io.netty.channel.ChannelHandler[])
io.netty.channel.ChannelHandler h
io.netty.channel.ChannelHandler[] arr$
int len$
int i$
io.netty.util.concurrent.EventExecutorGroup group
io.netty.channel.ChannelHandler[] handlers
public transient io.netty.channel.ChannelPipeline addLast (io.netty.channel.ChannelHandlerInvoker, io.netty.channel.ChannelHandler[])
io.netty.channel.ChannelHandler h
io.netty.channel.ChannelHandler[] arr$
int len$
int i$
io.netty.channel.ChannelHandlerInvoker invoker
io.netty.channel.ChannelHandler[] handlers
private io.netty.channel.ChannelHandlerInvoker findInvoker (io.netty.util.concurrent.EventExecutorGroup)
io.netty.util.concurrent.EventExecutor executor
io.netty.util.concurrent.EventExecutorGroup group
java.util.Map childInvokers
io.netty.channel.ChannelHandlerInvoker invoker
private java.lang.String generateName (io.netty.channel.ChannelHandler)
String newName
int i
String baseName
io.netty.channel.ChannelHandler handler
java.util.Map cache
Class handlerType
String name
private static java.lang.String generateName0 (java.lang.Class)
Class handlerType
public io.netty.channel.ChannelPipeline remove (io.netty.channel.ChannelHandler)
io.netty.channel.ChannelHandler handler
public io.netty.channel.ChannelHandler remove (java.lang.String)
String name
public io.netty.channel.ChannelHandler remove (java.lang.Class)
Class handlerType
private io.netty.channel.AbstractChannelHandlerContext remove (io.netty.channel.AbstractChannelHandlerContext)
io.netty.util.concurrent.EventExecutor executor
boolean inEventLoop
io.netty.channel.AbstractChannelHandlerContext ctx
io.netty.util.concurrent.EventExecutor executor
boolean inEventLoop
private static void remove0 (io.netty.channel.AbstractChannelHandlerContext)
io.netty.channel.AbstractChannelHandlerContext ctx
io.netty.channel.AbstractChannelHandlerContext prev
io.netty.channel.AbstractChannelHandlerContext next
public io.netty.channel.ChannelHandler removeFirst ()
public io.netty.channel.ChannelHandler removeLast ()
public io.netty.channel.ChannelPipeline replace (io.netty.channel.ChannelHandler, java.lang.String, io.netty.channel.ChannelHandler)
io.netty.channel.ChannelHandler oldHandler
String newName
io.netty.channel.ChannelHandler newHandler
public io.netty.channel.ChannelHandler replace (java.lang.String, java.lang.String, io.netty.channel.ChannelHandler)
String oldName
String newName
io.netty.channel.ChannelHandler newHandler
public io.netty.channel.ChannelHandler replace (java.lang.Class, java.lang.String, io.netty.channel.ChannelHandler)
Class oldHandlerType
String newName
io.netty.channel.ChannelHandler newHandler
private io.netty.channel.ChannelHandler replace (io.netty.channel.AbstractChannelHandlerContext, java.lang.String, io.netty.channel.ChannelHandler)
io.netty.channel.AbstractChannelHandlerContext newCtx
io.netty.util.concurrent.EventExecutor executor
boolean inEventLoop
io.netty.channel.AbstractChannelHandlerContext ctx
String newName
io.netty.channel.ChannelHandler newHandler
io.netty.channel.AbstractChannelHandlerContext newCtx
io.netty.util.concurrent.EventExecutor executor
boolean inEventLoop
private static void replace0 (io.netty.channel.AbstractChannelHandlerContext, io.netty.channel.AbstractChannelHandlerContext)
io.netty.channel.AbstractChannelHandlerContext oldCtx
io.netty.channel.AbstractChannelHandlerContext newCtx
io.netty.channel.AbstractChannelHandlerContext prev
io.netty.channel.AbstractChannelHandlerContext next
private static void checkMultiplicity (io.netty.channel.ChannelHandler)
io.netty.channel.ChannelHandlerAdapter h
io.netty.channel.ChannelHandler handler
private void callHandlerAdded0 (io.netty.channel.AbstractChannelHandlerContext)
Throwable t2
boolean removed
Throwable t
io.netty.channel.AbstractChannelHandlerContext ctx
private void callHandlerRemoved0 (io.netty.channel.AbstractChannelHandlerContext)
Throwable t
io.netty.channel.AbstractChannelHandlerContext ctx
private static void waitForFuture (java.util.concurrent.Future)
java.util.concurrent.ExecutionException ex
InterruptedException ex
java.util.concurrent.Future future
public io.netty.channel.ChannelHandler first ()
io.netty.channel.ChannelHandlerContext first
public io.netty.channel.ChannelHandlerContext firstContext ()
io.netty.channel.AbstractChannelHandlerContext first
public io.netty.channel.ChannelHandler last ()
io.netty.channel.AbstractChannelHandlerContext last
public io.netty.channel.ChannelHandlerContext lastContext ()
io.netty.channel.AbstractChannelHandlerContext last
public io.netty.channel.ChannelHandler get (java.lang.String)
String name
io.netty.channel.ChannelHandlerContext ctx
public io.netty.channel.ChannelHandler get (java.lang.Class)
Class handlerType
io.netty.channel.ChannelHandlerContext ctx
public io.netty.channel.ChannelHandlerContext context (java.lang.String)
String name
public io.netty.channel.ChannelHandlerContext context (io.netty.channel.ChannelHandler)
io.netty.channel.ChannelHandler handler
io.netty.channel.AbstractChannelHandlerContext ctx
public io.netty.channel.ChannelHandlerContext context (java.lang.Class)
Class handlerType
io.netty.channel.AbstractChannelHandlerContext ctx
public java.util.List names ()
java.util.List list
io.netty.channel.AbstractChannelHandlerContext ctx
public java.util.Map toMap ()
java.util.Map map
io.netty.channel.AbstractChannelHandlerContext ctx
public java.util.Iterator iterator ()
public java.lang.String toString ()
StringBuilder buf
io.netty.channel.AbstractChannelHandlerContext ctx
public io.netty.channel.ChannelPipeline fireChannelRegistered ()
public io.netty.channel.ChannelPipeline fireChannelUnregistered ()
private synchronized void destroy ()
private void destroyUp (io.netty.channel.AbstractChannelHandlerContext, boolean)
io.netty.channel.AbstractChannelHandlerContext finalCtx
io.netty.util.concurrent.EventExecutor executor
io.netty.channel.AbstractChannelHandlerContext ctx
boolean inEventLoop
Thread currentThread
io.netty.channel.AbstractChannelHandlerContext tail
private void destroyDown (java.lang.Thread, io.netty.channel.AbstractChannelHandlerContext, boolean)
io.netty.channel.AbstractChannelHandlerContext finalCtx
io.netty.util.concurrent.EventExecutor executor
Thread currentThread
io.netty.channel.AbstractChannelHandlerContext ctx
boolean inEventLoop
io.netty.channel.AbstractChannelHandlerContext head
public io.netty.channel.ChannelPipeline fireChannelActive ()
public io.netty.channel.ChannelPipeline fireChannelInactive ()
public io.netty.channel.ChannelPipeline fireExceptionCaught (java.lang.Throwable)
Throwable cause
public io.netty.channel.ChannelPipeline fireUserEventTriggered (java.lang.Object)
Object event
public io.netty.channel.ChannelPipeline fireChannelRead (java.lang.Object)
Object msg
public io.netty.channel.ChannelPipeline fireChannelReadComplete ()
public io.netty.channel.ChannelPipeline fireChannelWritabilityChanged ()
public io.netty.channel.ChannelFuture bind (java.net.SocketAddress)
java.net.SocketAddress localAddress
public io.netty.channel.ChannelFuture connect (java.net.SocketAddress)
java.net.SocketAddress remoteAddress
public io.netty.channel.ChannelFuture connect (java.net.SocketAddress, java.net.SocketAddress)
java.net.SocketAddress remoteAddress
java.net.SocketAddress localAddress
public io.netty.channel.ChannelFuture disconnect ()
public io.netty.channel.ChannelFuture close ()
public io.netty.channel.ChannelFuture deregister ()
public io.netty.channel.ChannelPipeline flush ()
public io.netty.channel.ChannelFuture bind (java.net.SocketAddress, io.netty.channel.ChannelPromise)
java.net.SocketAddress localAddress
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelFuture connect (java.net.SocketAddress, io.netty.channel.ChannelPromise)
java.net.SocketAddress remoteAddress
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelFuture connect (java.net.SocketAddress, java.net.SocketAddress, io.netty.channel.ChannelPromise)
java.net.SocketAddress remoteAddress
java.net.SocketAddress localAddress
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelFuture disconnect (io.netty.channel.ChannelPromise)
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelFuture close (io.netty.channel.ChannelPromise)
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelFuture deregister (io.netty.channel.ChannelPromise)
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelPipeline read ()
public io.netty.channel.ChannelFuture write (java.lang.Object)
Object msg
public io.netty.channel.ChannelFuture write (java.lang.Object, io.netty.channel.ChannelPromise)
Object msg
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelFuture writeAndFlush (java.lang.Object, io.netty.channel.ChannelPromise)
Object msg
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelFuture writeAndFlush (java.lang.Object)
Object msg
private java.lang.String filterName (java.lang.String, io.netty.channel.ChannelHandler)
String name
io.netty.channel.ChannelHandler handler
private io.netty.channel.AbstractChannelHandlerContext context0 (java.lang.String)
String name
io.netty.channel.AbstractChannelHandlerContext context
private io.netty.channel.AbstractChannelHandlerContext getContextOrDie (java.lang.String)
String name
io.netty.channel.AbstractChannelHandlerContext ctx
private io.netty.channel.AbstractChannelHandlerContext getContextOrDie (io.netty.channel.ChannelHandler)
io.netty.channel.ChannelHandler handler
io.netty.channel.AbstractChannelHandlerContext ctx
private io.netty.channel.AbstractChannelHandlerContext getContextOrDie (java.lang.Class)
Class handlerType
io.netty.channel.AbstractChannelHandlerContext ctx
void callHandlerAddedForAllHandlers ()
io.netty.channel.DefaultChannelPipeline$PendingHandlerCallback pendingHandlerCallbackHead
io.netty.channel.DefaultChannelPipeline$PendingHandlerCallback pendingHandlerCallbackHead
io.netty.channel.DefaultChannelPipeline$PendingHandlerCallback task
private void callHandlerCallbackLater (io.netty.channel.AbstractChannelHandlerContext, boolean)
io.netty.channel.AbstractChannelHandlerContext ctx
boolean added
io.netty.channel.DefaultChannelPipeline$PendingHandlerCallback task
io.netty.channel.DefaultChannelPipeline$PendingHandlerCallback pending
private io.netty.util.concurrent.EventExecutor executorSafe (io.netty.channel.ChannelHandlerInvoker)
io.netty.channel.ChannelHandlerInvoker invoker
private static void assertGroupAndInvoker (io.netty.util.concurrent.EventExecutorGroup, io.netty.channel.ChannelHandlerInvoker)
io.netty.util.concurrent.EventExecutorGroup group
io.netty.channel.ChannelHandlerInvoker invoker
static void access$000 (io.netty.channel.DefaultChannelPipeline, io.netty.channel.AbstractChannelHandlerContext)
io.netty.channel.DefaultChannelPipeline x0
io.netty.channel.AbstractChannelHandlerContext x1
static void access$100 (io.netty.channel.DefaultChannelPipeline, io.netty.channel.AbstractChannelHandlerContext)
io.netty.channel.DefaultChannelPipeline x0
io.netty.channel.AbstractChannelHandlerContext x1
static void access$200 (io.netty.channel.DefaultChannelPipeline, io.netty.channel.AbstractChannelHandlerContext)
io.netty.channel.DefaultChannelPipeline x0
io.netty.channel.AbstractChannelHandlerContext x1
static void access$300 (io.netty.channel.AbstractChannelHandlerContext, io.netty.channel.AbstractChannelHandlerContext)
io.netty.channel.AbstractChannelHandlerContext x0
io.netty.channel.AbstractChannelHandlerContext x1
static void access$400 (io.netty.channel.AbstractChannelHandlerContext, io.netty.channel.AbstractChannelHandlerContext)
io.netty.channel.AbstractChannelHandlerContext x0
io.netty.channel.AbstractChannelHandlerContext x1
static void access$500 (io.netty.channel.AbstractChannelHandlerContext)
io.netty.channel.AbstractChannelHandlerContext x0
static void access$600 (io.netty.channel.DefaultChannelPipeline, io.netty.channel.AbstractChannelHandlerContext)
io.netty.channel.DefaultChannelPipeline x0
io.netty.channel.AbstractChannelHandlerContext x1
static void access$700 (io.netty.channel.AbstractChannelHandlerContext, io.netty.channel.AbstractChannelHandlerContext)
io.netty.channel.AbstractChannelHandlerContext x0
io.netty.channel.AbstractChannelHandlerContext x1
static void access$800 (io.netty.channel.DefaultChannelPipeline, io.netty.channel.AbstractChannelHandlerContext, boolean)
io.netty.channel.DefaultChannelPipeline x0
io.netty.channel.AbstractChannelHandlerContext x1
boolean x2
static void access$900 (io.netty.channel.DefaultChannelPipeline, java.lang.Thread, io.netty.channel.AbstractChannelHandlerContext, boolean)
io.netty.channel.DefaultChannelPipeline x0
Thread x1
io.netty.channel.AbstractChannelHandlerContext x2
boolean x3
static java.lang.String access$1000 (java.lang.Class)
Class x0
static void ()
}
io/netty/channel/ThreadLocalPooledDirectByteBuf$ThreadLocalDirectByteBuf$1.classThreadLocalPooledDirectByteBuf.java
package io.netty.channel
final io.netty.channel.ThreadLocalPooledDirectByteBuf$ThreadLocalDirectByteBuf$1 extends io.netty.util.Recycler {
void ()
protected io.netty.channel.ThreadLocalPooledDirectByteBuf$ThreadLocalDirectByteBuf newObject (io.netty.util.Recycler$Handle)
io.netty.util.Recycler$Handle handle
protected volatile java.lang.Object newObject (io.netty.util.Recycler$Handle)
}
io/netty/channel/DefaultChannelHandlerInvoker$13.classDefaultChannelHandlerInvoker.java
package io.netty.channel
io.netty.channel.DefaultChannelHandlerInvoker$13 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.ChannelHandlerContext val$ctx
final io.netty.channel.ChannelPromise val$promise
final io.netty.channel.DefaultChannelHandlerInvoker this$0
void (io.netty.channel.DefaultChannelHandlerInvoker, io.netty.channel.ChannelHandlerContext, io.netty.channel.ChannelPromise)
public void run ()
}
io/netty/channel/DefaultChannelPipeline$8.classDefaultChannelPipeline.java
package io.netty.channel
io.netty.channel.DefaultChannelPipeline$8 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.AbstractChannelHandlerContext val$finalCtx
final io.netty.channel.DefaultChannelPipeline this$0
void (io.netty.channel.DefaultChannelPipeline, io.netty.channel.AbstractChannelHandlerContext)
public void run ()
}
io/netty/channel/AbstractChannel$AbstractUnsafe$4.classAbstractChannel.java
package io.netty.channel
io.netty.channel.AbstractChannel$AbstractUnsafe$4 extends java.lang.Object implements io.netty.channel.ChannelFutureListener {
final io.netty.channel.ChannelPromise val$promise
final io.netty.channel.AbstractChannel$AbstractUnsafe this$1
void (io.netty.channel.AbstractChannel$AbstractUnsafe, io.netty.channel.ChannelPromise)
public void operationComplete (io.netty.channel.ChannelFuture) throws java.lang.Exception
io.netty.channel.ChannelFuture future
public volatile void operationComplete (io.netty.util.concurrent.Future) throws java.lang.Exception
}
io/netty/channel/DefaultChannelPipeline$PendingHandlerAddedTask.classDefaultChannelPipeline.java
package io.netty.channel
final io.netty.channel.DefaultChannelPipeline$PendingHandlerAddedTask extends io.netty.channel.DefaultChannelPipeline$PendingHandlerCallback {
final io.netty.channel.DefaultChannelPipeline this$0
void (io.netty.channel.DefaultChannelPipeline, io.netty.channel.AbstractChannelHandlerContext)
io.netty.channel.AbstractChannelHandlerContext ctx
public void run ()
void execute ()
java.util.concurrent.RejectedExecutionException e
io.netty.util.concurrent.EventExecutor executor
}
io/netty/channel/DefaultChannelHandlerInvoker$8.classDefaultChannelHandlerInvoker.java
package io.netty.channel
io.netty.channel.DefaultChannelHandlerInvoker$8 extends java.lang.Object implements java.lang.Runnable {
final io.netty.channel.ChannelHandlerContext val$ctx
final io.netty.channel.DefaultChannelHandlerInvoker this$0
void (io.netty.channel.DefaultChannelHandlerInvoker, io.netty.channel.ChannelHandlerContext)
public void run ()
}
io/netty/channel/ChannelFlushPromiseNotifier$FlushCheckpoint.classChannelFlushPromiseNotifier.java
package io.netty.channel
abstract io.netty.channel.ChannelFlushPromiseNotifier$FlushCheckpoint extends java.lang.Object {
public abstract long flushCheckpoint ()
public abstract void flushCheckpoint (long)
public abstract io.netty.channel.ChannelPromise promise ()
}
io/netty/channel/ChannelOutboundBuffer$Entry$1.classChannelOutboundBuffer.java
package io.netty.channel
final io.netty.channel.ChannelOutboundBuffer$Entry$1 extends io.netty.util.Recycler {
void ()
protected io.netty.channel.ChannelOutboundBuffer$Entry newObject (io.netty.util.Recycler$Handle)
io.netty.util.Recycler$Handle handle
protected volatile java.lang.Object newObject (io.netty.util.Recycler$Handle)
}
io/netty/channel/DefaultEventLoopGroup.classDefaultEventLoopGroup.java
package io.netty.channel
public io.netty.channel.DefaultEventLoopGroup extends io.netty.channel.MultithreadEventLoopGroup {
public void ()
public void (int)
int nThreads
public void (int, java.util.concurrent.ThreadFactory)
int nThreads
java.util.concurrent.ThreadFactory threadFactory
protected transient io.netty.channel.EventLoop newChild (java.util.concurrent.Executor, java.lang.Object[]) throws java.lang.Exception
java.util.concurrent.Executor executor
Object[] args
protected volatile io.netty.util.concurrent.EventExecutor newChild (java.util.concurrent.Executor, java.lang.Object[]) throws java.lang.Exception
}
io/netty/channel/DefaultChannelHandlerInvoker$9.classDefaultChannelHandlerInvoker.java
package io.netty.channel
io.netty.channel.DefaultChannelHandlerInvoker$9 extends java.lang.Object implements java.lang.Runnable {
final io.netty.channel.ChannelHandlerContext val$ctx
final io.netty.channel.DefaultChannelHandlerInvoker this$0
void (io.netty.channel.DefaultChannelHandlerInvoker, io.netty.channel.ChannelHandlerContext)
public void run ()
}
io/netty/channel/ChannelOutboundBuffer$1.classChannelOutboundBuffer.java
package io.netty.channel
final io.netty.channel.ChannelOutboundBuffer$1 extends io.netty.util.concurrent.FastThreadLocal {
void ()
protected java.nio.ByteBuffer[] initialValue () throws java.lang.Exception
protected volatile java.lang.Object initialValue () throws java.lang.Exception
}
io/netty/channel/ThreadLocalPooledDirectByteBuf$ThreadLocalDirectByteBuf.classThreadLocalPooledDirectByteBuf.java
package io.netty.channel
final io.netty.channel.ThreadLocalPooledDirectByteBuf$ThreadLocalDirectByteBuf extends io.netty.buffer.UnpooledDirectByteBuf {
private static final io.netty.util.Recycler RECYCLER
private final io.netty.util.Recycler$Handle handle
static io.netty.channel.ThreadLocalPooledDirectByteBuf$ThreadLocalDirectByteBuf newInstance ()
io.netty.channel.ThreadLocalPooledDirectByteBuf$ThreadLocalDirectByteBuf buf
private void (io.netty.util.Recycler$Handle)
io.netty.util.Recycler$Handle handle
protected void deallocate ()
void (io.netty.util.Recycler$Handle, io.netty.channel.ThreadLocalPooledDirectByteBuf$1)
io.netty.util.Recycler$Handle x0
io.netty.channel.ThreadLocalPooledDirectByteBuf$1 x1
static void ()
}
io/netty/channel/CompleteChannelFuture.classCompleteChannelFuture.java
package io.netty.channel
abstract io.netty.channel.CompleteChannelFuture extends io.netty.util.concurrent.CompleteFuture implements io.netty.channel.ChannelFuture {
private final io.netty.channel.Channel channel
protected void (io.netty.channel.Channel, io.netty.util.concurrent.EventExecutor)
io.netty.channel.Channel channel
io.netty.util.concurrent.EventExecutor executor
protected io.netty.util.concurrent.EventExecutor executor ()
io.netty.util.concurrent.EventExecutor e
public io.netty.channel.ChannelFuture addListener (io.netty.util.concurrent.GenericFutureListener)
io.netty.util.concurrent.GenericFutureListener listener
public transient io.netty.channel.ChannelFuture addListeners (io.netty.util.concurrent.GenericFutureListener[])
io.netty.util.concurrent.GenericFutureListener[] listeners
public io.netty.channel.ChannelFuture removeListener (io.netty.util.concurrent.GenericFutureListener)
io.netty.util.concurrent.GenericFutureListener listener
public transient io.netty.channel.ChannelFuture removeListeners (io.netty.util.concurrent.GenericFutureListener[])
io.netty.util.concurrent.GenericFutureListener[] listeners
public io.netty.channel.ChannelFuture syncUninterruptibly ()
public io.netty.channel.ChannelFuture sync () throws java.lang.InterruptedException
public io.netty.channel.ChannelFuture await () throws java.lang.InterruptedException
public io.netty.channel.ChannelFuture awaitUninterruptibly ()
public io.netty.channel.Channel channel ()
public java.lang.Void getNow ()
public boolean isVoid ()
public volatile io.netty.util.concurrent.Future awaitUninterruptibly ()
public volatile io.netty.util.concurrent.Future syncUninterruptibly ()
public volatile io.netty.util.concurrent.Future sync () throws java.lang.InterruptedException
public volatile io.netty.util.concurrent.Future await () throws java.lang.InterruptedException
public volatile io.netty.util.concurrent.Future removeListeners (io.netty.util.concurrent.GenericFutureListener[])
public volatile io.netty.util.concurrent.Future removeListener (io.netty.util.concurrent.GenericFutureListener)
public volatile io.netty.util.concurrent.Future addListeners (io.netty.util.concurrent.GenericFutureListener[])
public volatile io.netty.util.concurrent.Future addListener (io.netty.util.concurrent.GenericFutureListener)
public volatile java.lang.Object getNow ()
}
io/netty/channel/ChannelPromiseAggregator.classChannelPromiseAggregator.java
package io.netty.channel
public final io.netty.channel.ChannelPromiseAggregator extends io.netty.util.concurrent.PromiseAggregator implements io.netty.channel.ChannelFutureListener {
public void (io.netty.channel.ChannelPromise)
io.netty.channel.ChannelPromise aggregatePromise
}
io/netty/channel/ServerChannel.classServerChannel.java
package io.netty.channel
public abstract io.netty.channel.ServerChannel extends java.lang.Object implements io.netty.channel.Channel {
}
io/netty/channel/DefaultChannelHandlerInvoker$2.classDefaultChannelHandlerInvoker.java
package io.netty.channel
io.netty.channel.DefaultChannelHandlerInvoker$2 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.ChannelHandlerContext val$ctx
final io.netty.channel.DefaultChannelHandlerInvoker this$0
void (io.netty.channel.DefaultChannelHandlerInvoker, io.netty.channel.ChannelHandlerContext)
public void run ()
}
io/netty/channel/ChannelFutureListener$3.classChannelFutureListener.java
package io.netty.channel
final io.netty.channel.ChannelFutureListener$3 extends java.lang.Object implements io.netty.channel.ChannelFutureListener {
void ()
public void operationComplete (io.netty.channel.ChannelFuture)
io.netty.channel.ChannelFuture future
public volatile void operationComplete (io.netty.util.concurrent.Future) throws java.lang.Exception
}
io/netty/channel/DefaultChannelHandlerInvoker$WriteTask.classDefaultChannelHandlerInvoker.java
package io.netty.channel
final io.netty.channel.DefaultChannelHandlerInvoker$WriteTask extends io.netty.util.internal.RecyclableMpscLinkedQueueNode implements io.netty.channel.SingleThreadEventLoop$NonWakeupRunnable {
private static final boolean ESTIMATE_TASK_SIZE_ON_SUBMIT
private static final int WRITE_TASK_OVERHEAD
private io.netty.channel.ChannelHandlerContext ctx
private Object msg
private io.netty.channel.ChannelPromise promise
private int size
private static final io.netty.util.Recycler RECYCLER
private static io.netty.channel.DefaultChannelHandlerInvoker$WriteTask newInstance (io.netty.channel.ChannelHandlerContext, java.lang.Object, io.netty.channel.ChannelPromise)
io.netty.channel.ChannelOutboundBuffer buffer
io.netty.channel.ChannelHandlerContext ctx
Object msg
io.netty.channel.ChannelPromise promise
io.netty.channel.DefaultChannelHandlerInvoker$WriteTask task
private void (io.netty.util.Recycler$Handle)
io.netty.util.Recycler$Handle handle
public void run ()
io.netty.channel.ChannelOutboundBuffer buffer
public io.netty.channel.SingleThreadEventLoop$NonWakeupRunnable value ()
public volatile java.lang.Object value ()
static io.netty.channel.DefaultChannelHandlerInvoker$WriteTask access$000 (io.netty.channel.ChannelHandlerContext, java.lang.Object, io.netty.channel.ChannelPromise)
io.netty.channel.ChannelHandlerContext x0
Object x1
io.netty.channel.ChannelPromise x2
void (io.netty.util.Recycler$Handle, io.netty.channel.DefaultChannelHandlerInvoker$1)
io.netty.util.Recycler$Handle x0
io.netty.channel.DefaultChannelHandlerInvoker$1 x1
static void ()
}
io/netty/channel/AddressedEnvelope.classAddressedEnvelope.java
package io.netty.channel
public abstract io.netty.channel.AddressedEnvelope extends java.lang.Object implements io.netty.util.ReferenceCounted {
public abstract java.lang.Object content ()
public abstract java.net.SocketAddress sender ()
public abstract java.net.SocketAddress recipient ()
public abstract io.netty.channel.AddressedEnvelope retain ()
public abstract io.netty.channel.AddressedEnvelope retain (int)
public abstract io.netty.channel.AddressedEnvelope touch ()
public abstract io.netty.channel.AddressedEnvelope touch (java.lang.Object)
}
io/netty/channel/DefaultChannelPipeline$2.classDefaultChannelPipeline.java
package io.netty.channel
io.netty.channel.DefaultChannelPipeline$2 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.AbstractChannelHandlerContext val$newCtx
final io.netty.channel.DefaultChannelPipeline this$0
void (io.netty.channel.DefaultChannelPipeline, io.netty.channel.AbstractChannelHandlerContext)
public void run ()
}
io/netty/channel/DefaultMaxMessagesRecvByteBufAllocator$MaxMessageHandle.classDefaultMaxMessagesRecvByteBufAllocator.java
package io.netty.channel
public abstract io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator$MaxMessageHandle extends java.lang.Object implements io.netty.channel.RecvByteBufAllocator$Handle {
private io.netty.channel.ChannelConfig config
private int maxMessagePerRead
private int totalMessages
private int totalBytesRead
private int attemptedBytesRead
private int lastBytesRead
final io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator this$0
public void (io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator)
public void reset (io.netty.channel.ChannelConfig)
io.netty.channel.ChannelConfig config
public io.netty.buffer.ByteBuf allocate (io.netty.buffer.ByteBufAllocator)
io.netty.buffer.ByteBufAllocator alloc
public final void incMessagesRead (int)
int amt
public final void lastBytesRead (int)
int bytes
public final int lastBytesRead ()
public boolean continueReading ()
public void readComplete ()
public int attemptedBytesRead ()
public void attemptedBytesRead (int)
int bytes
protected final int totalBytesRead ()
}
io/netty/channel/embedded/EmbeddedEventLoop.classEmbeddedEventLoop.java
package io.netty.channel.embedded
final io.netty.channel.embedded.EmbeddedEventLoop extends io.netty.util.concurrent.AbstractScheduledEventExecutor implements io.netty.channel.ChannelHandlerInvoker io.netty.channel.EventLoop {
private final java.util.Queue tasks
void ()
public io.netty.channel.EventLoopGroup parent ()
public io.netty.channel.EventLoop next ()
public void execute (java.lang.Runnable)
Runnable command
void runTasks ()
Runnable task
long runScheduledTasks ()
Runnable task
long time
long nextScheduledTask ()
protected void cancelScheduledTasks ()
public io.netty.util.concurrent.Future shutdownGracefully (long, long, java.util.concurrent.TimeUnit)
long quietPeriod
long timeout
java.util.concurrent.TimeUnit unit
public io.netty.util.concurrent.Future terminationFuture ()
public void shutdown ()
public boolean isShuttingDown ()
public boolean isShutdown ()
public boolean isTerminated ()
public boolean awaitTermination (long, java.util.concurrent.TimeUnit)
long timeout
java.util.concurrent.TimeUnit unit
public io.netty.channel.ChannelFuture register (io.netty.channel.Channel)
io.netty.channel.Channel channel
public io.netty.channel.ChannelFuture register (io.netty.channel.Channel, io.netty.channel.ChannelPromise)
io.netty.channel.Channel channel
io.netty.channel.ChannelPromise promise
public boolean inEventLoop ()
public boolean inEventLoop (java.lang.Thread)
Thread thread
public io.netty.channel.ChannelHandlerInvoker asInvoker ()
public io.netty.util.concurrent.EventExecutor executor ()
public void invokeChannelRegistered (io.netty.channel.ChannelHandlerContext)
io.netty.channel.ChannelHandlerContext ctx
public void invokeChannelUnregistered (io.netty.channel.ChannelHandlerContext)
io.netty.channel.ChannelHandlerContext ctx
public void invokeChannelActive (io.netty.channel.ChannelHandlerContext)
io.netty.channel.ChannelHandlerContext ctx
public void invokeChannelInactive (io.netty.channel.ChannelHandlerContext)
io.netty.channel.ChannelHandlerContext ctx
public void invokeExceptionCaught (io.netty.channel.ChannelHandlerContext, java.lang.Throwable)
io.netty.channel.ChannelHandlerContext ctx
Throwable cause
public void invokeUserEventTriggered (io.netty.channel.ChannelHandlerContext, java.lang.Object)
io.netty.channel.ChannelHandlerContext ctx
Object event
public void invokeChannelRead (io.netty.channel.ChannelHandlerContext, java.lang.Object)
io.netty.channel.ChannelHandlerContext ctx
Object msg
public void invokeChannelReadComplete (io.netty.channel.ChannelHandlerContext)
io.netty.channel.ChannelHandlerContext ctx
public void invokeChannelWritabilityChanged (io.netty.channel.ChannelHandlerContext)
io.netty.channel.ChannelHandlerContext ctx
public void invokeBind (io.netty.channel.ChannelHandlerContext, java.net.SocketAddress, io.netty.channel.ChannelPromise)
io.netty.channel.ChannelHandlerContext ctx
java.net.SocketAddress localAddress
io.netty.channel.ChannelPromise promise
public void invokeConnect (io.netty.channel.ChannelHandlerContext, java.net.SocketAddress, java.net.SocketAddress, io.netty.channel.ChannelPromise)
io.netty.channel.ChannelHandlerContext ctx
java.net.SocketAddress remoteAddress
java.net.SocketAddress localAddress
io.netty.channel.ChannelPromise promise
public void invokeDisconnect (io.netty.channel.ChannelHandlerContext, io.netty.channel.ChannelPromise)
io.netty.channel.ChannelHandlerContext ctx
io.netty.channel.ChannelPromise promise
public void invokeClose (io.netty.channel.ChannelHandlerContext, io.netty.channel.ChannelPromise)
io.netty.channel.ChannelHandlerContext ctx
io.netty.channel.ChannelPromise promise
public void invokeDeregister (io.netty.channel.ChannelHandlerContext, io.netty.channel.ChannelPromise)
io.netty.channel.ChannelHandlerContext ctx
io.netty.channel.ChannelPromise promise
public void invokeRead (io.netty.channel.ChannelHandlerContext)
io.netty.channel.ChannelHandlerContext ctx
public void invokeWrite (io.netty.channel.ChannelHandlerContext, java.lang.Object, io.netty.channel.ChannelPromise)
io.netty.channel.ChannelHandlerContext ctx
Object msg
io.netty.channel.ChannelPromise promise
public void invokeFlush (io.netty.channel.ChannelHandlerContext)
io.netty.channel.ChannelHandlerContext ctx
public volatile io.netty.util.concurrent.EventExecutor next ()
public volatile io.netty.util.concurrent.EventExecutorGroup parent ()
}
io/netty/channel/embedded/EmbeddedChannel$LastInboundHandler.classEmbeddedChannel.java
package io.netty.channel.embedded
final io.netty.channel.embedded.EmbeddedChannel$LastInboundHandler extends io.netty.channel.ChannelInboundHandlerAdapter {
final io.netty.channel.embedded.EmbeddedChannel this$0
private void (io.netty.channel.embedded.EmbeddedChannel)
public void channelRead (io.netty.channel.ChannelHandlerContext, java.lang.Object) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
Object msg
public void exceptionCaught (io.netty.channel.ChannelHandlerContext, java.lang.Throwable) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
Throwable cause
void (io.netty.channel.embedded.EmbeddedChannel, io.netty.channel.embedded.EmbeddedChannel$1)
io.netty.channel.embedded.EmbeddedChannel x0
io.netty.channel.embedded.EmbeddedChannel$1 x1
}
io/netty/channel/embedded/EmbeddedSocketAddress.classEmbeddedSocketAddress.java
package io.netty.channel.embedded
final io.netty.channel.embedded.EmbeddedSocketAddress extends java.net.SocketAddress {
private static final long serialVersionUID
void ()
public java.lang.String toString ()
}
io/netty/channel/embedded/EmbeddedChannel$1.classEmbeddedChannel.java
package io.netty.channel.embedded
io.netty.channel.embedded.EmbeddedChannel$1 extends io.netty.channel.ChannelInitializer {
final io.netty.channel.ChannelHandler[] val$handlers
final io.netty.channel.embedded.EmbeddedChannel this$0
void (io.netty.channel.embedded.EmbeddedChannel, io.netty.channel.ChannelHandler[])
protected void initChannel (io.netty.channel.Channel) throws java.lang.Exception
io.netty.channel.ChannelHandler h
io.netty.channel.ChannelHandler[] arr$
int len$
int i$
io.netty.channel.Channel ch
io.netty.channel.ChannelPipeline pipeline
}
io/netty/channel/embedded/EmbeddedChannel$State.classEmbeddedChannel.java
package io.netty.channel.embedded
final io.netty.channel.embedded.EmbeddedChannel$State extends java.lang.Enum {
public static final io.netty.channel.embedded.EmbeddedChannel$State OPEN
public static final io.netty.channel.embedded.EmbeddedChannel$State ACTIVE
public static final io.netty.channel.embedded.EmbeddedChannel$State CLOSED
private static final io.netty.channel.embedded.EmbeddedChannel$State[] $VALUES
public static io.netty.channel.embedded.EmbeddedChannel$State[] values ()
public static io.netty.channel.embedded.EmbeddedChannel$State valueOf (java.lang.String)
String name
private void (java.lang.String, int)
static void ()
}
io/netty/channel/embedded/EmbeddedChannel$DefaultUnsafe.classEmbeddedChannel.java
package io.netty.channel.embedded
io.netty.channel.embedded.EmbeddedChannel$DefaultUnsafe extends io.netty.channel.AbstractChannel$AbstractUnsafe {
final io.netty.channel.embedded.EmbeddedChannel this$0
private void (io.netty.channel.embedded.EmbeddedChannel)
public void connect (java.net.SocketAddress, java.net.SocketAddress, io.netty.channel.ChannelPromise)
java.net.SocketAddress remoteAddress
java.net.SocketAddress localAddress
io.netty.channel.ChannelPromise promise
void (io.netty.channel.embedded.EmbeddedChannel, io.netty.channel.embedded.EmbeddedChannel$1)
io.netty.channel.embedded.EmbeddedChannel x0
io.netty.channel.embedded.EmbeddedChannel$1 x1
}
io/netty/channel/embedded/EmbeddedChannel.classEmbeddedChannel.java
package io.netty.channel.embedded
public io.netty.channel.embedded.EmbeddedChannel extends io.netty.channel.AbstractChannel {
private static final java.net.SocketAddress LOCAL_ADDRESS
private static final java.net.SocketAddress REMOTE_ADDRESS
private static final io.netty.channel.ChannelHandler[] EMPTY_HANDLERS
private static final io.netty.util.internal.logging.InternalLogger logger
private static final io.netty.channel.ChannelMetadata METADATA_NO_DISCONNECT
private static final io.netty.channel.ChannelMetadata METADATA_DISCONNECT
private final io.netty.channel.embedded.EmbeddedEventLoop loop
private final io.netty.channel.ChannelMetadata metadata
private final io.netty.channel.ChannelConfig config
private java.util.Queue inboundMessages
private java.util.Queue outboundMessages
private Throwable lastException
private io.netty.channel.embedded.EmbeddedChannel$State state
static final boolean $assertionsDisabled
public void ()
public void (io.netty.channel.ChannelId)
io.netty.channel.ChannelId channelId
public transient void (io.netty.channel.ChannelHandler[])
io.netty.channel.ChannelHandler[] handlers
public transient void (boolean, io.netty.channel.ChannelHandler[])
boolean hasDisconnect
io.netty.channel.ChannelHandler[] handlers
public transient void (io.netty.channel.ChannelId, io.netty.channel.ChannelHandler[])
io.netty.channel.ChannelId channelId
io.netty.channel.ChannelHandler[] handlers
public transient void (io.netty.channel.ChannelId, boolean, io.netty.channel.ChannelHandler[])
io.netty.channel.ChannelId channelId
boolean hasDisconnect
io.netty.channel.ChannelHandler[] handlers
io.netty.channel.ChannelPipeline p
io.netty.channel.ChannelFuture future
public io.netty.channel.ChannelMetadata metadata ()
public io.netty.channel.ChannelConfig config ()
public boolean isOpen ()
public boolean isActive ()
public java.util.Queue inboundMessages ()
public java.util.Queue lastInboundBuffer ()
public java.util.Queue outboundMessages ()
public java.util.Queue lastOutboundBuffer ()
public java.lang.Object readInbound ()
public java.lang.Object readOutbound ()
public transient boolean writeInbound (java.lang.Object[])
Object m
Object[] arr$
int len$
int i$
Object[] msgs
io.netty.channel.ChannelPipeline p
public transient boolean writeOutbound (java.lang.Object[])
Object m
Object[] arr$
int len$
int i$
io.netty.channel.ChannelFuture future
int i
int size
Object[] msgs
io.netty.util.internal.RecyclableArrayList futures
public boolean finish ()
private void finishPendingTasks (boolean)
boolean cancel
public final io.netty.channel.ChannelFuture close ()
public final io.netty.channel.ChannelFuture disconnect ()
public final io.netty.channel.ChannelFuture close (io.netty.channel.ChannelPromise)
io.netty.channel.ChannelPromise promise
io.netty.channel.ChannelFuture future
public final io.netty.channel.ChannelFuture disconnect (io.netty.channel.ChannelPromise)
io.netty.channel.ChannelPromise promise
io.netty.channel.ChannelFuture future
private static boolean isNotEmpty (java.util.Queue)
java.util.Queue queue
private static java.lang.Object poll (java.util.Queue)
java.util.Queue queue
public void runPendingTasks ()
Exception e
Exception e
public long runScheduledPendingTasks ()
Exception e
private void recordException (java.lang.Throwable)
Throwable cause
public void checkException ()
Throwable t
protected final void ensureOpen ()
protected boolean isCompatible (io.netty.channel.EventLoop)
io.netty.channel.EventLoop loop
protected java.net.SocketAddress localAddress0 ()
protected java.net.SocketAddress remoteAddress0 ()
protected void doRegister () throws java.lang.Exception
protected void doBind (java.net.SocketAddress) throws java.lang.Exception
java.net.SocketAddress localAddress
protected void doDisconnect () throws java.lang.Exception
protected void doClose () throws java.lang.Exception
protected void doBeginRead () throws java.lang.Exception
protected io.netty.channel.AbstractChannel$AbstractUnsafe newUnsafe ()
protected void doWrite (io.netty.channel.ChannelOutboundBuffer) throws java.lang.Exception
Object msg
io.netty.channel.ChannelOutboundBuffer in
static void access$200 (io.netty.channel.embedded.EmbeddedChannel, java.lang.Throwable)
io.netty.channel.embedded.EmbeddedChannel x0
Throwable x1
static void ()
}
io/netty/channel/embedded/EmbeddedChannelId.classEmbeddedChannelId.java
package io.netty.channel.embedded
final io.netty.channel.embedded.EmbeddedChannelId extends java.lang.Object implements io.netty.channel.ChannelId {
private static final long serialVersionUID
static final io.netty.channel.ChannelId INSTANCE
private void ()
public java.lang.String asShortText ()
public java.lang.String asLongText ()
public int compareTo (io.netty.channel.ChannelId)
io.netty.channel.ChannelId o
public int hashCode ()
public boolean equals (java.lang.Object)
Object obj
public java.lang.String toString ()
public volatile int compareTo (java.lang.Object)
static void ()
}
io/netty/channel/Channel$Unsafe.classChannel.java
package io.netty.channel
public abstract io.netty.channel.Channel$Unsafe extends java.lang.Object {
public abstract io.netty.channel.RecvByteBufAllocator$Handle recvBufAllocHandle ()
public abstract io.netty.channel.ChannelHandlerInvoker invoker ()
public abstract java.net.SocketAddress localAddress ()
public abstract java.net.SocketAddress remoteAddress ()
public abstract void register (io.netty.channel.EventLoop, io.netty.channel.ChannelPromise)
public abstract void bind (java.net.SocketAddress, io.netty.channel.ChannelPromise)
public abstract void connect (java.net.SocketAddress, java.net.SocketAddress, io.netty.channel.ChannelPromise)
public abstract void disconnect (io.netty.channel.ChannelPromise)
public abstract void close (io.netty.channel.ChannelPromise)
public abstract void closeForcibly ()
public abstract void deregister (io.netty.channel.ChannelPromise)
public abstract void beginRead ()
public abstract void write (java.lang.Object, io.netty.channel.ChannelPromise)
public abstract void flush ()
public abstract io.netty.channel.ChannelPromise voidPromise ()
public abstract io.netty.channel.ChannelOutboundBuffer outboundBuffer ()
}
io/netty/channel/DefaultMaxMessagesRecvByteBufAllocator.classDefaultMaxMessagesRecvByteBufAllocator.java
package io.netty.channel
public abstract io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator extends java.lang.Object implements io.netty.channel.MaxMessagesRecvByteBufAllocator {
private volatile int maxMessagesPerRead
public void ()
public void (int)
int maxMessagesPerRead
public int maxMessagesPerRead ()
public io.netty.channel.MaxMessagesRecvByteBufAllocator maxMessagesPerRead (int)
int maxMessagesPerRead
}
io/netty/channel/DefaultChannelHandlerInvoker$7.classDefaultChannelHandlerInvoker.java
package io.netty.channel
io.netty.channel.DefaultChannelHandlerInvoker$7 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.ChannelHandlerContext val$ctx
final Object val$msg
final io.netty.channel.DefaultChannelHandlerInvoker this$0
void (io.netty.channel.DefaultChannelHandlerInvoker, io.netty.channel.ChannelHandlerContext, java.lang.Object)
public void run ()
}
io/netty/channel/PendingWriteQueue$PendingWrite.classPendingWriteQueue.java
package io.netty.channel
final io.netty.channel.PendingWriteQueue$PendingWrite extends java.lang.Object {
private static final io.netty.util.Recycler RECYCLER
private final io.netty.util.Recycler$Handle handle
private io.netty.channel.PendingWriteQueue$PendingWrite next
private long size
private io.netty.channel.ChannelPromise promise
private Object msg
private void (io.netty.util.Recycler$Handle)
io.netty.util.Recycler$Handle handle
static io.netty.channel.PendingWriteQueue$PendingWrite newInstance (java.lang.Object, int, io.netty.channel.ChannelPromise)
Object msg
int size
io.netty.channel.ChannelPromise promise
io.netty.channel.PendingWriteQueue$PendingWrite write
private void recycle ()
static io.netty.channel.PendingWriteQueue$PendingWrite access$002 (io.netty.channel.PendingWriteQueue$PendingWrite, io.netty.channel.PendingWriteQueue$PendingWrite)
io.netty.channel.PendingWriteQueue$PendingWrite x0
io.netty.channel.PendingWriteQueue$PendingWrite x1
static long access$100 (io.netty.channel.PendingWriteQueue$PendingWrite)
io.netty.channel.PendingWriteQueue$PendingWrite x0
static io.netty.channel.PendingWriteQueue$PendingWrite access$000 (io.netty.channel.PendingWriteQueue$PendingWrite)
io.netty.channel.PendingWriteQueue$PendingWrite x0
static java.lang.Object access$200 (io.netty.channel.PendingWriteQueue$PendingWrite)
io.netty.channel.PendingWriteQueue$PendingWrite x0
static io.netty.channel.ChannelPromise access$300 (io.netty.channel.PendingWriteQueue$PendingWrite)
io.netty.channel.PendingWriteQueue$PendingWrite x0
static void access$400 (io.netty.channel.PendingWriteQueue$PendingWrite)
io.netty.channel.PendingWriteQueue$PendingWrite x0
void (io.netty.util.Recycler$Handle, io.netty.channel.PendingWriteQueue$1)
io.netty.util.Recycler$Handle x0
io.netty.channel.PendingWriteQueue$1 x1
static void ()
}
io/netty/channel/ThreadLocalPooledDirectByteBuf.classThreadLocalPooledDirectByteBuf.java
package io.netty.channel
final io.netty.channel.ThreadLocalPooledDirectByteBuf extends java.lang.Object {
private static final io.netty.util.internal.logging.InternalLogger logger
public static final int threadLocalDirectBufferSize
public static io.netty.buffer.ByteBuf newInstance ()
private void ()
static void ()
}
io/netty/channel/DefaultChannelPipeline$HeadContext.classDefaultChannelPipeline.java
package io.netty.channel
final io.netty.channel.DefaultChannelPipeline$HeadContext extends io.netty.channel.AbstractChannelHandlerContext implements io.netty.channel.ChannelOutboundHandler {
private static final String HEAD_NAME
private final io.netty.channel.Channel$Unsafe unsafe
void (io.netty.channel.DefaultChannelPipeline)
io.netty.channel.DefaultChannelPipeline pipeline
public io.netty.channel.ChannelHandler handler ()
public void handlerAdded (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
public void handlerRemoved (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
public void exceptionCaught (io.netty.channel.ChannelHandlerContext, java.lang.Throwable) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
Throwable cause
public void bind (io.netty.channel.ChannelHandlerContext, java.net.SocketAddress, io.netty.channel.ChannelPromise) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
java.net.SocketAddress localAddress
io.netty.channel.ChannelPromise promise
public void connect (io.netty.channel.ChannelHandlerContext, java.net.SocketAddress, java.net.SocketAddress, io.netty.channel.ChannelPromise) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
java.net.SocketAddress remoteAddress
java.net.SocketAddress localAddress
io.netty.channel.ChannelPromise promise
public void disconnect (io.netty.channel.ChannelHandlerContext, io.netty.channel.ChannelPromise) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
io.netty.channel.ChannelPromise promise
public void close (io.netty.channel.ChannelHandlerContext, io.netty.channel.ChannelPromise) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
io.netty.channel.ChannelPromise promise
public void deregister (io.netty.channel.ChannelHandlerContext, io.netty.channel.ChannelPromise) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
io.netty.channel.ChannelPromise promise
public void read (io.netty.channel.ChannelHandlerContext)
io.netty.channel.ChannelHandlerContext ctx
public void write (io.netty.channel.ChannelHandlerContext, java.lang.Object, io.netty.channel.ChannelPromise) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
Object msg
io.netty.channel.ChannelPromise promise
public void flush (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
static void ()
}
io/netty/channel/ChannelPromiseNotifier.classChannelPromiseNotifier.java
package io.netty.channel
public final io.netty.channel.ChannelPromiseNotifier extends io.netty.util.concurrent.PromiseNotifier implements io.netty.channel.ChannelFutureListener {
public transient void (io.netty.channel.ChannelPromise[])
io.netty.channel.ChannelPromise[] promises
}
io/netty/channel/DefaultChannelHandlerInvoker$3.classDefaultChannelHandlerInvoker.java
package io.netty.channel
io.netty.channel.DefaultChannelHandlerInvoker$3 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.ChannelHandlerContext val$ctx
final io.netty.channel.DefaultChannelHandlerInvoker this$0
void (io.netty.channel.DefaultChannelHandlerInvoker, io.netty.channel.ChannelHandlerContext)
public void run ()
}
io/netty/channel/AbstractEventLoop.classAbstractEventLoop.java
package io.netty.channel
public abstract io.netty.channel.AbstractEventLoop extends io.netty.util.concurrent.AbstractEventExecutor implements io.netty.channel.EventLoop {
protected void ()
protected void (io.netty.channel.EventLoopGroup)
io.netty.channel.EventLoopGroup parent
public io.netty.channel.EventLoopGroup parent ()
public io.netty.channel.EventLoop next ()
public volatile io.netty.util.concurrent.EventExecutor next ()
public volatile io.netty.util.concurrent.EventExecutorGroup parent ()
}
io/netty/channel/DefaultChannelPromise.classDefaultChannelPromise.java
package io.netty.channel
public io.netty.channel.DefaultChannelPromise extends io.netty.util.concurrent.DefaultPromise implements io.netty.channel.ChannelPromise io.netty.channel.ChannelFlushPromiseNotifier$FlushCheckpoint {
private final io.netty.channel.Channel channel
private long checkpoint
public void (io.netty.channel.Channel)
io.netty.channel.Channel channel
public void (io.netty.channel.Channel, io.netty.util.concurrent.EventExecutor)
io.netty.channel.Channel channel
io.netty.util.concurrent.EventExecutor executor
protected io.netty.util.concurrent.EventExecutor executor ()
io.netty.util.concurrent.EventExecutor e
public io.netty.channel.Channel channel ()
public io.netty.channel.ChannelPromise setSuccess ()
public io.netty.channel.ChannelPromise setSuccess (java.lang.Void)
Void result
public boolean trySuccess ()
public io.netty.channel.ChannelPromise setFailure (java.lang.Throwable)
Throwable cause
public io.netty.channel.ChannelPromise addListener (io.netty.util.concurrent.GenericFutureListener)
io.netty.util.concurrent.GenericFutureListener listener
public transient io.netty.channel.ChannelPromise addListeners (io.netty.util.concurrent.GenericFutureListener[])
io.netty.util.concurrent.GenericFutureListener[] listeners
public io.netty.channel.ChannelPromise removeListener (io.netty.util.concurrent.GenericFutureListener)
io.netty.util.concurrent.GenericFutureListener listener
public transient io.netty.channel.ChannelPromise removeListeners (io.netty.util.concurrent.GenericFutureListener[])
io.netty.util.concurrent.GenericFutureListener[] listeners
public io.netty.channel.ChannelPromise sync () throws java.lang.InterruptedException
public io.netty.channel.ChannelPromise syncUninterruptibly ()
public io.netty.channel.ChannelPromise await () throws java.lang.InterruptedException
public io.netty.channel.ChannelPromise awaitUninterruptibly ()
public long flushCheckpoint ()
public void flushCheckpoint (long)
long checkpoint
public io.netty.channel.ChannelPromise promise ()
protected void checkDeadLock ()
public io.netty.channel.ChannelPromise unvoid ()
public boolean isVoid ()
public volatile io.netty.util.concurrent.Promise setFailure (java.lang.Throwable)
public volatile io.netty.util.concurrent.Promise setSuccess (java.lang.Object)
public volatile io.netty.util.concurrent.Promise awaitUninterruptibly ()
public volatile io.netty.util.concurrent.Promise await () throws java.lang.InterruptedException
public volatile io.netty.util.concurrent.Promise syncUninterruptibly ()
public volatile io.netty.util.concurrent.Promise sync () throws java.lang.InterruptedException
public volatile io.netty.util.concurrent.Promise removeListeners (io.netty.util.concurrent.GenericFutureListener[])
public volatile io.netty.util.concurrent.Promise removeListener (io.netty.util.concurrent.GenericFutureListener)
public volatile io.netty.util.concurrent.Promise addListeners (io.netty.util.concurrent.GenericFutureListener[])
public volatile io.netty.util.concurrent.Promise addListener (io.netty.util.concurrent.GenericFutureListener)
public volatile io.netty.util.concurrent.Future awaitUninterruptibly ()
public volatile io.netty.util.concurrent.Future await () throws java.lang.InterruptedException
public volatile io.netty.util.concurrent.Future syncUninterruptibly ()
public volatile io.netty.util.concurrent.Future sync () throws java.lang.InterruptedException
public volatile io.netty.util.concurrent.Future removeListeners (io.netty.util.concurrent.GenericFutureListener[])
public volatile io.netty.util.concurrent.Future removeListener (io.netty.util.concurrent.GenericFutureListener)
public volatile io.netty.util.concurrent.Future addListeners (io.netty.util.concurrent.GenericFutureListener[])
public volatile io.netty.util.concurrent.Future addListener (io.netty.util.concurrent.GenericFutureListener)
public volatile io.netty.channel.ChannelFuture awaitUninterruptibly ()
public volatile io.netty.channel.ChannelFuture await () throws java.lang.InterruptedException
public volatile io.netty.channel.ChannelFuture syncUninterruptibly ()
public volatile io.netty.channel.ChannelFuture sync () throws java.lang.InterruptedException
public volatile io.netty.channel.ChannelFuture removeListeners (io.netty.util.concurrent.GenericFutureListener[])
public volatile io.netty.channel.ChannelFuture removeListener (io.netty.util.concurrent.GenericFutureListener)
public volatile io.netty.channel.ChannelFuture addListeners (io.netty.util.concurrent.GenericFutureListener[])
public volatile io.netty.channel.ChannelFuture addListener (io.netty.util.concurrent.GenericFutureListener)
}
io/netty/channel/ThreadPerChannelEventLoop.classThreadPerChannelEventLoop.java
package io.netty.channel
public io.netty.channel.ThreadPerChannelEventLoop extends io.netty.channel.SingleThreadEventLoop {
private final io.netty.channel.ThreadPerChannelEventLoopGroup parent
private io.netty.channel.Channel ch
public void (io.netty.channel.ThreadPerChannelEventLoopGroup)
io.netty.channel.ThreadPerChannelEventLoopGroup parent
public io.netty.channel.ChannelFuture register (io.netty.channel.Channel, io.netty.channel.ChannelPromise)
io.netty.channel.Channel channel
io.netty.channel.ChannelPromise promise
protected void run ()
Runnable task
io.netty.channel.Channel ch
protected void deregister ()
static io.netty.channel.Channel access$002 (io.netty.channel.ThreadPerChannelEventLoop, io.netty.channel.Channel)
io.netty.channel.ThreadPerChannelEventLoop x0
io.netty.channel.Channel x1
}
io/netty/channel/DefaultChannelPipeline$7.classDefaultChannelPipeline.java
package io.netty.channel
io.netty.channel.DefaultChannelPipeline$7 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.AbstractChannelHandlerContext val$ctx
final io.netty.channel.AbstractChannelHandlerContext val$newCtx
final io.netty.channel.DefaultChannelPipeline this$0
void (io.netty.channel.DefaultChannelPipeline, io.netty.channel.AbstractChannelHandlerContext, io.netty.channel.AbstractChannelHandlerContext)
public void run ()
}
io/netty/channel/AdaptiveRecvByteBufAllocator$HandleImpl.classAdaptiveRecvByteBufAllocator.java
package io.netty.channel
final io.netty.channel.AdaptiveRecvByteBufAllocator$HandleImpl extends io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator$MaxMessageHandle {
private final int minIndex
private final int maxIndex
private int index
private int nextReceiveBufferSize
private boolean decreaseNow
final io.netty.channel.AdaptiveRecvByteBufAllocator this$0
public void (io.netty.channel.AdaptiveRecvByteBufAllocator, int, int, int)
int minIndex
int maxIndex
int initial
public int guess ()
private void record (int)
int actualReadBytes
public void readComplete ()
}
io/netty/channel/ChannelOption.classChannelOption.java
package io.netty.channel
public io.netty.channel.ChannelOption extends io.netty.util.AbstractConstant {
private static final io.netty.util.ConstantPool pool
public static final io.netty.channel.ChannelOption ALLOCATOR
public static final io.netty.channel.ChannelOption RCVBUF_ALLOCATOR
public static final io.netty.channel.ChannelOption MESSAGE_SIZE_ESTIMATOR
public static final io.netty.channel.ChannelOption CONNECT_TIMEOUT_MILLIS
public static final io.netty.channel.ChannelOption MAX_MESSAGES_PER_READ
public static final io.netty.channel.ChannelOption WRITE_SPIN_COUNT
public static final io.netty.channel.ChannelOption WRITE_BUFFER_HIGH_WATER_MARK
public static final io.netty.channel.ChannelOption WRITE_BUFFER_LOW_WATER_MARK
public static final io.netty.channel.ChannelOption ALLOW_HALF_CLOSURE
public static final io.netty.channel.ChannelOption AUTO_READ
public static final io.netty.channel.ChannelOption AUTO_CLOSE
public static final io.netty.channel.ChannelOption SO_BROADCAST
public static final io.netty.channel.ChannelOption SO_KEEPALIVE
public static final io.netty.channel.ChannelOption SO_SNDBUF
public static final io.netty.channel.ChannelOption SO_RCVBUF
public static final io.netty.channel.ChannelOption SO_REUSEADDR
public static final io.netty.channel.ChannelOption SO_LINGER
public static final io.netty.channel.ChannelOption SO_BACKLOG
public static final io.netty.channel.ChannelOption SO_TIMEOUT
public static final io.netty.channel.ChannelOption IP_TOS
public static final io.netty.channel.ChannelOption IP_MULTICAST_ADDR
public static final io.netty.channel.ChannelOption IP_MULTICAST_IF
public static final io.netty.channel.ChannelOption IP_MULTICAST_TTL
public static final io.netty.channel.ChannelOption IP_MULTICAST_LOOP_DISABLED
public static final io.netty.channel.ChannelOption TCP_NODELAY
public static final io.netty.channel.ChannelOption DATAGRAM_CHANNEL_ACTIVE_ON_REGISTRATION
public static io.netty.channel.ChannelOption valueOf (java.lang.String)
String name
public static io.netty.channel.ChannelOption valueOf (java.lang.Class, java.lang.String)
Class firstNameComponent
String secondNameComponent
public static boolean exists (java.lang.String)
String name
public static io.netty.channel.ChannelOption newInstance (java.lang.String)
String name
private void (int, java.lang.String)
int id
String name
protected void (java.lang.String)
String name
public void validate (java.lang.Object)
Object value
void (int, java.lang.String, io.netty.channel.ChannelOption$1)
int x0
String x1
io.netty.channel.ChannelOption$1 x2
static void ()
}
io/netty/channel/ChannelException.classChannelException.java
package io.netty.channel
public io.netty.channel.ChannelException extends java.lang.RuntimeException {
private static final long serialVersionUID
public void ()
public void (java.lang.String, java.lang.Throwable)
String message
Throwable cause
public void (java.lang.String)
String message
public void (java.lang.Throwable)
Throwable cause
}
io/netty/channel/AbstractChannelHandlerContext.classAbstractChannelHandlerContext.java
package io.netty.channel
abstract io.netty.channel.AbstractChannelHandlerContext extends java.lang.Object implements io.netty.channel.ChannelHandlerContext io.netty.util.ResourceLeakHint {
volatile io.netty.channel.AbstractChannelHandlerContext next
volatile io.netty.channel.AbstractChannelHandlerContext prev
private final boolean inbound
private final boolean outbound
private final io.netty.channel.DefaultChannelPipeline pipeline
private final String name
private boolean handlerRemoved
final io.netty.channel.ChannelHandlerInvoker invoker
private io.netty.channel.ChannelFuture succeededFuture
volatile Runnable invokeChannelReadCompleteTask
volatile Runnable invokeReadTask
volatile Runnable invokeChannelWritableStateChangedTask
volatile Runnable invokeFlushTask
void (io.netty.channel.DefaultChannelPipeline, io.netty.channel.ChannelHandlerInvoker, java.lang.String, boolean, boolean)
io.netty.channel.DefaultChannelPipeline pipeline
io.netty.channel.ChannelHandlerInvoker invoker
String name
boolean inbound
boolean outbound
public io.netty.channel.Channel channel ()
public io.netty.channel.ChannelPipeline pipeline ()
public io.netty.buffer.ByteBufAllocator alloc ()
public io.netty.util.concurrent.EventExecutor executor ()
public java.lang.String name ()
public io.netty.util.Attribute attr (io.netty.util.AttributeKey)
io.netty.util.AttributeKey key
public boolean hasAttr (io.netty.util.AttributeKey)
io.netty.util.AttributeKey key
public io.netty.channel.ChannelHandlerContext fireChannelRegistered ()
io.netty.channel.AbstractChannelHandlerContext next
public io.netty.channel.ChannelHandlerContext fireChannelUnregistered ()
io.netty.channel.AbstractChannelHandlerContext next
public io.netty.channel.ChannelHandlerContext fireChannelActive ()
io.netty.channel.AbstractChannelHandlerContext next
public io.netty.channel.ChannelHandlerContext fireChannelInactive ()
io.netty.channel.AbstractChannelHandlerContext next
public io.netty.channel.ChannelHandlerContext fireExceptionCaught (java.lang.Throwable)
Throwable cause
io.netty.channel.AbstractChannelHandlerContext next
public io.netty.channel.ChannelHandlerContext fireUserEventTriggered (java.lang.Object)
Object event
io.netty.channel.AbstractChannelHandlerContext next
public io.netty.channel.ChannelHandlerContext fireChannelRead (java.lang.Object)
Object msg
io.netty.channel.AbstractChannelHandlerContext next
public io.netty.channel.ChannelHandlerContext fireChannelReadComplete ()
io.netty.channel.AbstractChannelHandlerContext next
public io.netty.channel.ChannelHandlerContext fireChannelWritabilityChanged ()
io.netty.channel.AbstractChannelHandlerContext next
public io.netty.channel.ChannelFuture bind (java.net.SocketAddress)
java.net.SocketAddress localAddress
public io.netty.channel.ChannelFuture connect (java.net.SocketAddress)
java.net.SocketAddress remoteAddress
public io.netty.channel.ChannelFuture connect (java.net.SocketAddress, java.net.SocketAddress)
java.net.SocketAddress remoteAddress
java.net.SocketAddress localAddress
public io.netty.channel.ChannelFuture disconnect ()
public io.netty.channel.ChannelFuture close ()
public io.netty.channel.ChannelFuture deregister ()
public io.netty.channel.ChannelFuture bind (java.net.SocketAddress, io.netty.channel.ChannelPromise)
java.net.SocketAddress localAddress
io.netty.channel.ChannelPromise promise
io.netty.channel.AbstractChannelHandlerContext next
public io.netty.channel.ChannelFuture connect (java.net.SocketAddress, io.netty.channel.ChannelPromise)
java.net.SocketAddress remoteAddress
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelFuture connect (java.net.SocketAddress, java.net.SocketAddress, io.netty.channel.ChannelPromise)
java.net.SocketAddress remoteAddress
java.net.SocketAddress localAddress
io.netty.channel.ChannelPromise promise
io.netty.channel.AbstractChannelHandlerContext next
public io.netty.channel.ChannelFuture disconnect (io.netty.channel.ChannelPromise)
io.netty.channel.ChannelPromise promise
io.netty.channel.AbstractChannelHandlerContext next
public io.netty.channel.ChannelFuture close (io.netty.channel.ChannelPromise)
io.netty.channel.ChannelPromise promise
io.netty.channel.AbstractChannelHandlerContext next
public io.netty.channel.ChannelFuture deregister (io.netty.channel.ChannelPromise)
io.netty.channel.ChannelPromise promise
io.netty.channel.AbstractChannelHandlerContext next
public io.netty.channel.ChannelHandlerContext read ()
io.netty.channel.AbstractChannelHandlerContext next
public io.netty.channel.ChannelFuture write (java.lang.Object)
Object msg
public io.netty.channel.ChannelFuture write (java.lang.Object, io.netty.channel.ChannelPromise)
Object msg
io.netty.channel.ChannelPromise promise
io.netty.channel.AbstractChannelHandlerContext next
public io.netty.channel.ChannelHandlerContext flush ()
io.netty.channel.AbstractChannelHandlerContext next
public io.netty.channel.ChannelFuture writeAndFlush (java.lang.Object, io.netty.channel.ChannelPromise)
Object msg
io.netty.channel.ChannelPromise promise
io.netty.channel.AbstractChannelHandlerContext next
public io.netty.channel.ChannelFuture writeAndFlush (java.lang.Object)
Object msg
public io.netty.channel.ChannelPromise newPromise ()
public io.netty.channel.ChannelProgressivePromise newProgressivePromise ()
public io.netty.channel.ChannelFuture newSucceededFuture ()
io.netty.channel.ChannelFuture succeededFuture
public io.netty.channel.ChannelFuture newFailedFuture (java.lang.Throwable)
Throwable cause
private io.netty.channel.AbstractChannelHandlerContext findContextInbound ()
io.netty.channel.AbstractChannelHandlerContext ctx
private io.netty.channel.AbstractChannelHandlerContext findContextOutbound ()
io.netty.channel.AbstractChannelHandlerContext ctx
public io.netty.channel.ChannelPromise voidPromise ()
void setRemoved ()
public boolean isRemoved ()
final void invokeChannelRegistered ()
final void invokeChannelUnregistered ()
final void invokeChannelActive ()
final void invokeChannelInactive ()
final void invokeExceptionCaught (java.lang.Throwable)
Throwable cause
final void invokeUserEventTriggered (java.lang.Object)
Object event
final void invokeChannelRead (java.lang.Object)
Object msg
final void invokeChannelReadComplete ()
final void invokeChannelWritabilityChanged ()
final void invokeBind (java.net.SocketAddress, io.netty.channel.ChannelPromise)
java.net.SocketAddress localAddress
io.netty.channel.ChannelPromise promise
final void invokeConnect (java.net.SocketAddress, java.net.SocketAddress, io.netty.channel.ChannelPromise)
java.net.SocketAddress remoteAddress
java.net.SocketAddress localAddress
io.netty.channel.ChannelPromise promise
final void invokeDisconnect (io.netty.channel.ChannelPromise)
io.netty.channel.ChannelPromise promise
final void invokeClose (io.netty.channel.ChannelPromise)
io.netty.channel.ChannelPromise promise
final void invokeDeregister (io.netty.channel.ChannelPromise)
io.netty.channel.ChannelPromise promise
final void invokeRead ()
final void invokeWrite (java.lang.Object, io.netty.channel.ChannelPromise)
Object msg
io.netty.channel.ChannelPromise promise
final void invokeFlush ()
final void invokeWriteAndFlush (java.lang.Object, io.netty.channel.ChannelPromise)
Object msg
io.netty.channel.ChannelPromise promise
io.netty.channel.ChannelHandlerInvoker invoker
public io.netty.channel.ChannelHandlerInvoker invoker ()
public java.lang.String toHintString ()
public java.lang.String toString ()
}
io/netty/channel/ChannelConfig.classChannelConfig.java
package io.netty.channel
public abstract io.netty.channel.ChannelConfig extends java.lang.Object {
public abstract java.util.Map getOptions ()
public abstract boolean setOptions (java.util.Map)
public abstract java.lang.Object getOption (io.netty.channel.ChannelOption)
public abstract boolean setOption (io.netty.channel.ChannelOption, java.lang.Object)
public abstract int getConnectTimeoutMillis ()
public abstract io.netty.channel.ChannelConfig setConnectTimeoutMillis (int)
public abstract int getMaxMessagesPerRead ()
public abstract io.netty.channel.ChannelConfig setMaxMessagesPerRead (int)
public abstract int getWriteSpinCount ()
public abstract io.netty.channel.ChannelConfig setWriteSpinCount (int)
public abstract io.netty.buffer.ByteBufAllocator getAllocator ()
public abstract io.netty.channel.ChannelConfig setAllocator (io.netty.buffer.ByteBufAllocator)
public abstract io.netty.channel.RecvByteBufAllocator getRecvByteBufAllocator ()
public abstract io.netty.channel.ChannelConfig setRecvByteBufAllocator (io.netty.channel.RecvByteBufAllocator)
public abstract boolean isAutoRead ()
public abstract io.netty.channel.ChannelConfig setAutoRead (boolean)
public abstract boolean isAutoClose ()
public abstract io.netty.channel.ChannelConfig setAutoClose (boolean)
public abstract int getWriteBufferHighWaterMark ()
public abstract io.netty.channel.ChannelConfig setWriteBufferHighWaterMark (int)
public abstract int getWriteBufferLowWaterMark ()
public abstract io.netty.channel.ChannelConfig setWriteBufferLowWaterMark (int)
public abstract io.netty.channel.MessageSizeEstimator getMessageSizeEstimator ()
public abstract io.netty.channel.ChannelConfig setMessageSizeEstimator (io.netty.channel.MessageSizeEstimator)
}
io/netty/channel/AbstractChannel$AbstractUnsafe$6.classAbstractChannel.java
package io.netty.channel
io.netty.channel.AbstractChannel$AbstractUnsafe$6 extends io.netty.util.internal.OneTimeTask {
final boolean val$wasActive
final io.netty.channel.AbstractChannel$AbstractUnsafe this$1
void (io.netty.channel.AbstractChannel$AbstractUnsafe, boolean)
public void run ()
}
io/netty/channel/DefaultMaxBytesRecvByteBufAllocator$1.classDefaultMaxBytesRecvByteBufAllocator.java
package io.netty.channel
io.netty.channel.DefaultMaxBytesRecvByteBufAllocator$1 extends java.lang.Object {
}
io/netty/channel/DefaultMessageSizeEstimator.classDefaultMessageSizeEstimator.java
package io.netty.channel
public final io.netty.channel.DefaultMessageSizeEstimator extends java.lang.Object implements io.netty.channel.MessageSizeEstimator {
public static final io.netty.channel.MessageSizeEstimator DEFAULT
private final io.netty.channel.MessageSizeEstimator$Handle handle
public void (int)
int unknownSize
public io.netty.channel.MessageSizeEstimator$Handle newHandle ()
static void ()
}
io/netty/channel/EventLoopGroup.classEventLoopGroup.java
package io.netty.channel
public abstract io.netty.channel.EventLoopGroup extends java.lang.Object implements io.netty.util.concurrent.EventExecutorGroup {
public abstract io.netty.channel.EventLoop next ()
public abstract io.netty.channel.ChannelFuture register (io.netty.channel.Channel)
public abstract io.netty.channel.ChannelFuture register (io.netty.channel.Channel, io.netty.channel.ChannelPromise)
}
io/netty/channel/AbstractChannel$AbstractUnsafe$1.classAbstractChannel.java
package io.netty.channel
io.netty.channel.AbstractChannel$AbstractUnsafe$1 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.ChannelPromise val$promise
final io.netty.channel.AbstractChannel$AbstractUnsafe this$1
void (io.netty.channel.AbstractChannel$AbstractUnsafe, io.netty.channel.ChannelPromise)
public void run ()
}
io/netty/channel/DefaultChannelHandlerInvoker$12.classDefaultChannelHandlerInvoker.java
package io.netty.channel
io.netty.channel.DefaultChannelHandlerInvoker$12 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.ChannelHandlerContext val$ctx
final io.netty.channel.ChannelPromise val$promise
final io.netty.channel.DefaultChannelHandlerInvoker this$0
void (io.netty.channel.DefaultChannelHandlerInvoker, io.netty.channel.ChannelHandlerContext, io.netty.channel.ChannelPromise)
public void run ()
}
io/netty/channel/ChannelHandler.classChannelHandler.java
package io.netty.channel
public abstract io.netty.channel.ChannelHandler extends java.lang.Object {
public abstract void handlerAdded (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
public abstract void handlerRemoved (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
public abstract void exceptionCaught (io.netty.channel.ChannelHandlerContext, java.lang.Throwable) throws java.lang.Exception
}
io/netty/channel/SingleThreadEventLoop$NonWakeupRunnable.classSingleThreadEventLoop.java
package io.netty.channel
abstract io.netty.channel.SingleThreadEventLoop$NonWakeupRunnable extends java.lang.Object implements java.lang.Runnable {
}
io/netty/channel/MaxMessagesRecvByteBufAllocator.classMaxMessagesRecvByteBufAllocator.java
package io.netty.channel
public abstract io.netty.channel.MaxMessagesRecvByteBufAllocator extends java.lang.Object implements io.netty.channel.RecvByteBufAllocator {
public abstract int maxMessagesPerRead ()
public abstract io.netty.channel.MaxMessagesRecvByteBufAllocator maxMessagesPerRead (int)
}
io/netty/channel/ChannelFuture.classChannelFuture.java
package io.netty.channel
public abstract io.netty.channel.ChannelFuture extends java.lang.Object implements io.netty.util.concurrent.Future {
public abstract io.netty.channel.Channel channel ()
public abstract io.netty.channel.ChannelFuture addListener (io.netty.util.concurrent.GenericFutureListener)
public transient abstract io.netty.channel.ChannelFuture addListeners (io.netty.util.concurrent.GenericFutureListener[])
public abstract io.netty.channel.ChannelFuture removeListener (io.netty.util.concurrent.GenericFutureListener)
public transient abstract io.netty.channel.ChannelFuture removeListeners (io.netty.util.concurrent.GenericFutureListener[])
public abstract io.netty.channel.ChannelFuture sync () throws java.lang.InterruptedException
public abstract io.netty.channel.ChannelFuture syncUninterruptibly ()
public abstract io.netty.channel.ChannelFuture await () throws java.lang.InterruptedException
public abstract io.netty.channel.ChannelFuture awaitUninterruptibly ()
public abstract boolean isVoid ()
}
io/netty/channel/ChannelFutureListener.classChannelFutureListener.java
package io.netty.channel
public abstract io.netty.channel.ChannelFutureListener extends java.lang.Object implements io.netty.util.concurrent.GenericFutureListener {
public static final io.netty.channel.ChannelFutureListener CLOSE
public static final io.netty.channel.ChannelFutureListener CLOSE_ON_FAILURE
public static final io.netty.channel.ChannelFutureListener FIRE_EXCEPTION_ON_FAILURE
static void ()
}
io/netty/channel/local/LocalChannel.classLocalChannel.java
package io.netty.channel.local
public io.netty.channel.local.LocalChannel extends io.netty.channel.AbstractChannel {
private static final java.util.concurrent.atomic.AtomicReferenceFieldUpdater FINISH_READ_FUTURE_UPDATER
private static final io.netty.channel.ChannelMetadata METADATA
private static final int MAX_READER_STACK_DEPTH
private static final java.nio.channels.ClosedChannelException CLOSED_CHANNEL_EXCEPTION
private final io.netty.channel.ChannelConfig config
private final java.util.Queue inboundBuffer
private final Runnable readTask
private final Runnable shutdownHook
private volatile io.netty.channel.local.LocalChannel$State state
private volatile io.netty.channel.local.LocalChannel peer
private volatile io.netty.channel.local.LocalAddress localAddress
private volatile io.netty.channel.local.LocalAddress remoteAddress
private volatile io.netty.channel.ChannelPromise connectPromise
private volatile boolean readInProgress
private volatile boolean registerInProgress
private volatile boolean writeInProgress
private volatile io.netty.util.concurrent.Future finishReadFuture
public void ()
void (io.netty.channel.local.LocalServerChannel, io.netty.channel.local.LocalChannel)
io.netty.channel.local.LocalServerChannel parent
io.netty.channel.local.LocalChannel peer
public io.netty.channel.ChannelMetadata metadata ()
public io.netty.channel.ChannelConfig config ()
public io.netty.channel.local.LocalServerChannel parent ()
public io.netty.channel.local.LocalAddress localAddress ()
public io.netty.channel.local.LocalAddress remoteAddress ()
public boolean isOpen ()
public boolean isActive ()
protected io.netty.channel.AbstractChannel$AbstractUnsafe newUnsafe ()
protected boolean isCompatible (io.netty.channel.EventLoop)
io.netty.channel.EventLoop loop
protected java.net.SocketAddress localAddress0 ()
protected java.net.SocketAddress remoteAddress0 ()
protected void doRegister () throws java.lang.Exception
io.netty.channel.local.LocalChannel peer
protected void doBind (java.net.SocketAddress) throws java.lang.Exception
java.net.SocketAddress localAddress
protected void doDisconnect () throws java.lang.Exception
protected void doClose () throws java.lang.Exception
io.netty.channel.ChannelPromise promise
RuntimeException e
boolean peerWriteInProgress
io.netty.channel.local.LocalChannel peer
private void doPeerClose (io.netty.channel.local.LocalChannel, boolean)
io.netty.channel.local.LocalChannel peer
boolean peerWriteInProgress
protected void doDeregister () throws java.lang.Exception
protected void doBeginRead () throws java.lang.Exception
Object received
RuntimeException e
io.netty.channel.ChannelPipeline pipeline
java.util.Queue inboundBuffer
io.netty.util.internal.InternalThreadLocalMap threadLocals
Integer stackDepth
protected void doWrite (io.netty.channel.ChannelOutboundBuffer) throws java.lang.Exception
Throwable cause
Object msg
io.netty.channel.ChannelOutboundBuffer in
io.netty.channel.local.LocalChannel peer
private void finishPeerRead (io.netty.channel.local.LocalChannel)
io.netty.channel.local.LocalChannel peer
private void runFinishPeerReadTask (io.netty.channel.local.LocalChannel)
RuntimeException e
io.netty.channel.local.LocalChannel peer
Runnable finishPeerReadTask
private void releaseInboundBuffers ()
Object o
private void finishPeerRead0 (io.netty.channel.local.LocalChannel)
Object received
io.netty.channel.local.LocalChannel peer
io.netty.util.concurrent.Future peerFinishReadFuture
io.netty.channel.ChannelPipeline peerPipeline
public volatile java.net.SocketAddress remoteAddress ()
public volatile java.net.SocketAddress localAddress ()
public volatile io.netty.channel.Channel parent ()
static java.util.Queue access$000 (io.netty.channel.local.LocalChannel)
io.netty.channel.local.LocalChannel x0
static boolean access$202 (io.netty.channel.local.LocalChannel, boolean)
io.netty.channel.local.LocalChannel x0
boolean x1
static io.netty.channel.ChannelPromise access$300 (io.netty.channel.local.LocalChannel)
io.netty.channel.local.LocalChannel x0
static void access$400 (io.netty.channel.local.LocalChannel, io.netty.channel.local.LocalChannel, boolean)
io.netty.channel.local.LocalChannel x0
io.netty.channel.local.LocalChannel x1
boolean x2
static void access$500 (io.netty.channel.local.LocalChannel, io.netty.channel.local.LocalChannel)
io.netty.channel.local.LocalChannel x0
io.netty.channel.local.LocalChannel x1
static io.netty.channel.local.LocalChannel$State access$600 (io.netty.channel.local.LocalChannel)
io.netty.channel.local.LocalChannel x0
static io.netty.channel.ChannelPromise access$302 (io.netty.channel.local.LocalChannel, io.netty.channel.ChannelPromise)
io.netty.channel.local.LocalChannel x0
io.netty.channel.ChannelPromise x1
static io.netty.channel.local.LocalChannel access$702 (io.netty.channel.local.LocalChannel, io.netty.channel.local.LocalChannel)
io.netty.channel.local.LocalChannel x0
io.netty.channel.local.LocalChannel x1
static void ()
java.util.concurrent.atomic.AtomicReferenceFieldUpdater finishReadFutureUpdater
}
io/netty/channel/local/LocalChannel$3.classLocalChannel.java
package io.netty.channel.local
io.netty.channel.local.LocalChannel$3 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.local.LocalChannel val$peer
final io.netty.channel.local.LocalChannel this$0
void (io.netty.channel.local.LocalChannel, io.netty.channel.local.LocalChannel)
public void run ()
io.netty.channel.ChannelPromise promise
}
io/netty/channel/local/LocalServerChannel$1.classLocalServerChannel.java
package io.netty.channel.local
io.netty.channel.local.LocalServerChannel$1 extends java.lang.Object implements java.lang.Runnable {
final io.netty.channel.local.LocalServerChannel this$0
void (io.netty.channel.local.LocalServerChannel)
public void run ()
}
io/netty/channel/local/LocalAddress.classLocalAddress.java
package io.netty.channel.local
public final io.netty.channel.local.LocalAddress extends java.net.SocketAddress implements java.lang.Comparable {
private static final long serialVersionUID
public static final io.netty.channel.local.LocalAddress ANY
private final String id
private final String strVal
void (io.netty.channel.Channel)
io.netty.channel.Channel channel
StringBuilder buf
public void (java.lang.String)
String id
public java.lang.String id ()
public int hashCode ()
public boolean equals (java.lang.Object)
Object o
public int compareTo (io.netty.channel.local.LocalAddress)
io.netty.channel.local.LocalAddress o
public java.lang.String toString ()
public volatile int compareTo (java.lang.Object)
static void ()
}
io/netty/channel/local/LocalChannel$State.classLocalChannel.java
package io.netty.channel.local
final io.netty.channel.local.LocalChannel$State extends java.lang.Enum {
public static final io.netty.channel.local.LocalChannel$State OPEN
public static final io.netty.channel.local.LocalChannel$State BOUND
public static final io.netty.channel.local.LocalChannel$State CONNECTED
public static final io.netty.channel.local.LocalChannel$State CLOSED
private static final io.netty.channel.local.LocalChannel$State[] $VALUES
public static io.netty.channel.local.LocalChannel$State[] values ()
public static io.netty.channel.local.LocalChannel$State valueOf (java.lang.String)
String name
private void (java.lang.String, int)
static void ()
}
io/netty/channel/local/LocalChannel$4.classLocalChannel.java
package io.netty.channel.local
io.netty.channel.local.LocalChannel$4 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.local.LocalChannel val$peer
final boolean val$peerWriteInProgress
final io.netty.channel.local.LocalChannel this$0
void (io.netty.channel.local.LocalChannel, io.netty.channel.local.LocalChannel, boolean)
public void run ()
}
io/netty/channel/local/LocalChannel$1.classLocalChannel.java
package io.netty.channel.local
io.netty.channel.local.LocalChannel$1 extends java.lang.Object implements java.lang.Runnable {
final io.netty.channel.local.LocalChannel this$0
void (io.netty.channel.local.LocalChannel)
public void run ()
Object m
io.netty.channel.ChannelPipeline pipeline
}
io/netty/channel/local/LocalServerChannel$2.classLocalServerChannel.java
package io.netty.channel.local
io.netty.channel.local.LocalServerChannel$2 extends java.lang.Object implements java.lang.Runnable {
final io.netty.channel.local.LocalChannel val$child
final io.netty.channel.local.LocalServerChannel this$0
void (io.netty.channel.local.LocalServerChannel, io.netty.channel.local.LocalChannel)
public void run ()
}
io/netty/channel/local/LocalChannel$2.classLocalChannel.java
package io.netty.channel.local
io.netty.channel.local.LocalChannel$2 extends java.lang.Object implements java.lang.Runnable {
final io.netty.channel.local.LocalChannel this$0
void (io.netty.channel.local.LocalChannel)
public void run ()
}
io/netty/channel/local/LocalChannel$6.classLocalChannel.java
package io.netty.channel.local
io.netty.channel.local.LocalChannel$6 extends java.lang.Object {
static final int[] $SwitchMap$io$netty$channel$local$LocalChannel$State
static void ()
}
io/netty/channel/local/LocalEventLoopGroup.classLocalEventLoopGroup.java
package io.netty.channel.local
public io.netty.channel.local.LocalEventLoopGroup extends io.netty.channel.DefaultEventLoopGroup {
public void ()
public void (int)
int nThreads
public void (int, java.util.concurrent.ThreadFactory)
int nThreads
java.util.concurrent.ThreadFactory threadFactory
}
io/netty/channel/local/LocalServerChannel.classLocalServerChannel.java
package io.netty.channel.local
public io.netty.channel.local.LocalServerChannel extends io.netty.channel.AbstractServerChannel {
private final io.netty.channel.ChannelConfig config
private final java.util.Queue inboundBuffer
private final Runnable shutdownHook
private volatile int state
private volatile io.netty.channel.local.LocalAddress localAddress
private volatile boolean acceptInProgress
public void ()
public io.netty.channel.ChannelConfig config ()
public io.netty.channel.local.LocalAddress localAddress ()
public io.netty.channel.local.LocalAddress remoteAddress ()
public boolean isOpen ()
public boolean isActive ()
protected boolean isCompatible (io.netty.channel.EventLoop)
io.netty.channel.EventLoop loop
protected java.net.SocketAddress localAddress0 ()
protected void doRegister () throws java.lang.Exception
protected void doBind (java.net.SocketAddress) throws java.lang.Exception
java.net.SocketAddress localAddress
protected void doClose () throws java.lang.Exception
protected void doDeregister () throws java.lang.Exception
protected void doBeginRead () throws java.lang.Exception
Object m
java.util.Queue inboundBuffer
io.netty.channel.ChannelPipeline pipeline
io.netty.channel.local.LocalChannel serve (io.netty.channel.local.LocalChannel)
io.netty.channel.local.LocalChannel peer
io.netty.channel.local.LocalChannel child
private void serve0 (io.netty.channel.local.LocalChannel)
Object m
io.netty.channel.ChannelPipeline pipeline
io.netty.channel.local.LocalChannel child
public volatile java.net.SocketAddress remoteAddress ()
public volatile java.net.SocketAddress localAddress ()
static void access$000 (io.netty.channel.local.LocalServerChannel, io.netty.channel.local.LocalChannel)
io.netty.channel.local.LocalServerChannel x0
io.netty.channel.local.LocalChannel x1
}
io/netty/channel/local/LocalChannel$LocalUnsafe.classLocalChannel.java
package io.netty.channel.local
io.netty.channel.local.LocalChannel$LocalUnsafe extends io.netty.channel.AbstractChannel$AbstractUnsafe {
final io.netty.channel.local.LocalChannel this$0
private void (io.netty.channel.local.LocalChannel)
public void connect (java.net.SocketAddress, java.net.SocketAddress, io.netty.channel.ChannelPromise)
Exception cause
Throwable t
Exception cause
java.net.SocketAddress remoteAddress
java.net.SocketAddress localAddress
io.netty.channel.ChannelPromise promise
io.netty.channel.Channel boundChannel
io.netty.channel.local.LocalServerChannel serverChannel
void (io.netty.channel.local.LocalChannel, io.netty.channel.local.LocalChannel$1)
io.netty.channel.local.LocalChannel x0
io.netty.channel.local.LocalChannel$1 x1
}
io/netty/channel/local/LocalChannel$5.classLocalChannel.java
package io.netty.channel.local
io.netty.channel.local.LocalChannel$5 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.local.LocalChannel val$peer
final io.netty.channel.local.LocalChannel this$0
void (io.netty.channel.local.LocalChannel, io.netty.channel.local.LocalChannel)
public void run ()
}
io/netty/channel/local/LocalChannelRegistry.classLocalChannelRegistry.java
package io.netty.channel.local
final io.netty.channel.local.LocalChannelRegistry extends java.lang.Object {
private static final java.util.concurrent.ConcurrentMap boundChannels
static io.netty.channel.local.LocalAddress register (io.netty.channel.Channel, io.netty.channel.local.LocalAddress, java.net.SocketAddress)
io.netty.channel.Channel channel
io.netty.channel.local.LocalAddress oldLocalAddress
java.net.SocketAddress localAddress
io.netty.channel.local.LocalAddress addr
io.netty.channel.Channel boundChannel
static io.netty.channel.Channel get (java.net.SocketAddress)
java.net.SocketAddress localAddress
static void unregister (io.netty.channel.local.LocalAddress)
io.netty.channel.local.LocalAddress localAddress
private void ()
static void ()
}
io/netty/channel/ChannelProgressiveFutureListener.classChannelProgressiveFutureListener.java
package io.netty.channel
public abstract io.netty.channel.ChannelProgressiveFutureListener extends java.lang.Object implements io.netty.util.concurrent.GenericProgressiveFutureListener {
}
io/netty/channel/AbstractChannel$AbstractUnsafe$8.classAbstractChannel.java
package io.netty.channel
io.netty.channel.AbstractChannel$AbstractUnsafe$8 extends io.netty.util.internal.OneTimeTask {
final Exception val$e
final io.netty.channel.AbstractChannel$AbstractUnsafe this$1
void (io.netty.channel.AbstractChannel$AbstractUnsafe, java.lang.Exception)
public void run ()
}
io/netty/channel/CombinedChannelDuplexHandler.classCombinedChannelDuplexHandler.java
package io.netty.channel
public io.netty.channel.CombinedChannelDuplexHandler extends io.netty.channel.ChannelDuplexHandler {
private static final io.netty.util.internal.logging.InternalLogger logger
private io.netty.channel.CombinedChannelDuplexHandler$DelegatingChannelHandlerContext inboundCtx
private io.netty.channel.CombinedChannelDuplexHandler$DelegatingChannelHandlerContext outboundCtx
private volatile boolean handlerAdded
private io.netty.channel.ChannelInboundHandler inboundHandler
private io.netty.channel.ChannelOutboundHandler outboundHandler
static final boolean $assertionsDisabled
protected void ()
public void (io.netty.channel.ChannelInboundHandler, io.netty.channel.ChannelOutboundHandler)
io.netty.channel.ChannelInboundHandler inboundHandler
io.netty.channel.ChannelOutboundHandler outboundHandler
protected final void init (io.netty.channel.ChannelInboundHandler, io.netty.channel.ChannelOutboundHandler)
io.netty.channel.ChannelInboundHandler inboundHandler
io.netty.channel.ChannelOutboundHandler outboundHandler
private void validate (io.netty.channel.ChannelInboundHandler, io.netty.channel.ChannelOutboundHandler)
io.netty.channel.ChannelInboundHandler inboundHandler
io.netty.channel.ChannelOutboundHandler outboundHandler
protected final io.netty.channel.ChannelInboundHandler inboundHandler ()
protected final io.netty.channel.ChannelOutboundHandler outboundHandler ()
private void checkAdded ()
public final void removeInboundHandler ()
public final void removeOutboundHandler ()
public void handlerAdded (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
public void handlerRemoved (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
public void channelRegistered (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
public void channelUnregistered (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
public void channelActive (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
public void channelInactive (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
public void exceptionCaught (io.netty.channel.ChannelHandlerContext, java.lang.Throwable) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
Throwable cause
public void userEventTriggered (io.netty.channel.ChannelHandlerContext, java.lang.Object) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
Object evt
public void channelRead (io.netty.channel.ChannelHandlerContext, java.lang.Object) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
Object msg
public void channelReadComplete (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
public void channelWritabilityChanged (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
public void bind (io.netty.channel.ChannelHandlerContext, java.net.SocketAddress, io.netty.channel.ChannelPromise) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
java.net.SocketAddress localAddress
io.netty.channel.ChannelPromise promise
public void connect (io.netty.channel.ChannelHandlerContext, java.net.SocketAddress, java.net.SocketAddress, io.netty.channel.ChannelPromise) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
java.net.SocketAddress remoteAddress
java.net.SocketAddress localAddress
io.netty.channel.ChannelPromise promise
public void disconnect (io.netty.channel.ChannelHandlerContext, io.netty.channel.ChannelPromise) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
io.netty.channel.ChannelPromise promise
public void close (io.netty.channel.ChannelHandlerContext, io.netty.channel.ChannelPromise) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
io.netty.channel.ChannelPromise promise
public void deregister (io.netty.channel.ChannelHandlerContext, io.netty.channel.ChannelPromise) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
io.netty.channel.ChannelPromise promise
public void read (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
public void write (io.netty.channel.ChannelHandlerContext, java.lang.Object, io.netty.channel.ChannelPromise) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
Object msg
io.netty.channel.ChannelPromise promise
public void flush (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
static io.netty.channel.CombinedChannelDuplexHandler$DelegatingChannelHandlerContext access$000 (io.netty.channel.CombinedChannelDuplexHandler)
io.netty.channel.CombinedChannelDuplexHandler x0
static io.netty.channel.ChannelOutboundHandler access$100 (io.netty.channel.CombinedChannelDuplexHandler)
io.netty.channel.CombinedChannelDuplexHandler x0
static io.netty.util.internal.logging.InternalLogger access$200 ()
static void ()
}
io/netty/channel/AbstractChannel$CloseFuture.classAbstractChannel.java
package io.netty.channel
final io.netty.channel.AbstractChannel$CloseFuture extends io.netty.channel.DefaultChannelPromise {
void (io.netty.channel.AbstractChannel)
io.netty.channel.AbstractChannel ch
public io.netty.channel.ChannelPromise setSuccess ()
public io.netty.channel.ChannelPromise setFailure (java.lang.Throwable)
Throwable cause
public boolean trySuccess ()
public boolean tryFailure (java.lang.Throwable)
Throwable cause
boolean setClosed ()
public volatile io.netty.util.concurrent.Promise setFailure (java.lang.Throwable)
}
io/netty/channel/ChannelFlushPromiseNotifier.classChannelFlushPromiseNotifier.java
package io.netty.channel
public final io.netty.channel.ChannelFlushPromiseNotifier extends java.lang.Object {
private long writeCounter
private final java.util.Queue flushCheckpoints
private final boolean tryNotify
public void (boolean)
boolean tryNotify
public void ()
public io.netty.channel.ChannelFlushPromiseNotifier add (io.netty.channel.ChannelPromise, int)
io.netty.channel.ChannelPromise promise
int pendingDataSize
public io.netty.channel.ChannelFlushPromiseNotifier add (io.netty.channel.ChannelPromise, long)
io.netty.channel.ChannelFlushPromiseNotifier$FlushCheckpoint cp
io.netty.channel.ChannelPromise promise
long pendingDataSize
long checkpoint
public io.netty.channel.ChannelFlushPromiseNotifier increaseWriteCounter (long)
long delta
public long writeCounter ()
public io.netty.channel.ChannelFlushPromiseNotifier notifyPromises ()
public io.netty.channel.ChannelFlushPromiseNotifier notifyFlushFutures ()
public io.netty.channel.ChannelFlushPromiseNotifier notifyPromises (java.lang.Throwable)
io.netty.channel.ChannelFlushPromiseNotifier$FlushCheckpoint cp
Throwable cause
public io.netty.channel.ChannelFlushPromiseNotifier notifyFlushFutures (java.lang.Throwable)
Throwable cause
public io.netty.channel.ChannelFlushPromiseNotifier notifyPromises (java.lang.Throwable, java.lang.Throwable)
io.netty.channel.ChannelFlushPromiseNotifier$FlushCheckpoint cp
Throwable cause1
Throwable cause2
public io.netty.channel.ChannelFlushPromiseNotifier notifyFlushFutures (java.lang.Throwable, java.lang.Throwable)
Throwable cause1
Throwable cause2
private void notifyPromises0 (java.lang.Throwable)
io.netty.channel.ChannelFlushPromiseNotifier$FlushCheckpoint cp
io.netty.channel.ChannelPromise promise
io.netty.channel.ChannelFlushPromiseNotifier$FlushCheckpoint cp
java.util.Iterator i$
Throwable cause
long writeCounter
long newWriteCounter
}
io/netty/channel/DefaultMaxBytesRecvByteBufAllocator$HandleImpl.classDefaultMaxBytesRecvByteBufAllocator.java
package io.netty.channel
final io.netty.channel.DefaultMaxBytesRecvByteBufAllocator$HandleImpl extends java.lang.Object implements io.netty.channel.RecvByteBufAllocator$Handle {
private int individualReadMax
private int bytesToRead
private int lastBytesRead
private int attemptBytesRead
final io.netty.channel.DefaultMaxBytesRecvByteBufAllocator this$0
private void (io.netty.channel.DefaultMaxBytesRecvByteBufAllocator)
public io.netty.buffer.ByteBuf allocate (io.netty.buffer.ByteBufAllocator)
io.netty.buffer.ByteBufAllocator alloc
public int guess ()
public void reset (io.netty.channel.ChannelConfig)
io.netty.channel.ChannelConfig config
public void incMessagesRead (int)
int amt
public void lastBytesRead (int)
int bytes
public int lastBytesRead ()
public boolean continueReading ()
public void readComplete ()
public void attemptedBytesRead (int)
int bytes
public int attemptedBytesRead ()
void (io.netty.channel.DefaultMaxBytesRecvByteBufAllocator, io.netty.channel.DefaultMaxBytesRecvByteBufAllocator$1)
io.netty.channel.DefaultMaxBytesRecvByteBufAllocator x0
io.netty.channel.DefaultMaxBytesRecvByteBufAllocator$1 x1
}
io/netty/channel/PendingWriteQueue$1.classPendingWriteQueue.java
package io.netty.channel
io.netty.channel.PendingWriteQueue$1 extends java.lang.Object {
}
io/netty/channel/ChannelProgressivePromise.classChannelProgressivePromise.java
package io.netty.channel
public abstract io.netty.channel.ChannelProgressivePromise extends java.lang.Object implements io.netty.util.concurrent.ProgressivePromise io.netty.channel.ChannelProgressiveFuture io.netty.channel.ChannelPromise {
public abstract io.netty.channel.ChannelProgressivePromise addListener (io.netty.util.concurrent.GenericFutureListener)
public transient abstract io.netty.channel.ChannelProgressivePromise addListeners (io.netty.util.concurrent.GenericFutureListener[])
public abstract io.netty.channel.ChannelProgressivePromise removeListener (io.netty.util.concurrent.GenericFutureListener)
public transient abstract io.netty.channel.ChannelProgressivePromise removeListeners (io.netty.util.concurrent.GenericFutureListener[])
public abstract io.netty.channel.ChannelProgressivePromise sync () throws java.lang.InterruptedException
public abstract io.netty.channel.ChannelProgressivePromise syncUninterruptibly ()
public abstract io.netty.channel.ChannelProgressivePromise await () throws java.lang.InterruptedException
public abstract io.netty.channel.ChannelProgressivePromise awaitUninterruptibly ()
public abstract io.netty.channel.ChannelProgressivePromise setSuccess (java.lang.Void)
public abstract io.netty.channel.ChannelProgressivePromise setSuccess ()
public abstract io.netty.channel.ChannelProgressivePromise setFailure (java.lang.Throwable)
public abstract io.netty.channel.ChannelProgressivePromise setProgress (long, long)
public abstract io.netty.channel.ChannelProgressivePromise unvoid ()
}
io/netty/channel/FileRegion.classFileRegion.java
package io.netty.channel
public abstract io.netty.channel.FileRegion extends java.lang.Object implements io.netty.util.ReferenceCounted {
public abstract long position ()
public abstract long transfered ()
public abstract long count ()
public abstract long transferTo (java.nio.channels.WritableByteChannel, long) throws java.io.IOException
public abstract io.netty.channel.FileRegion retain ()
public abstract io.netty.channel.FileRegion retain (int)
public abstract io.netty.channel.FileRegion touch ()
public abstract io.netty.channel.FileRegion touch (java.lang.Object)
}
io/netty/channel/ChannelHandler$Sharable.classChannelHandler.java
package io.netty.channel
public abstract io.netty.channel.ChannelHandler$Sharable extends java.lang.Object implements java.lang.annotation.Annotation {
}
io/netty/channel/ChannelFutureListener$2.classChannelFutureListener.java
package io.netty.channel
final io.netty.channel.ChannelFutureListener$2 extends java.lang.Object implements io.netty.channel.ChannelFutureListener {
void ()
public void operationComplete (io.netty.channel.ChannelFuture)
io.netty.channel.ChannelFuture future
public volatile void operationComplete (io.netty.util.concurrent.Future) throws java.lang.Exception
}
io/netty/channel/VoidChannelPromise.classVoidChannelPromise.java
package io.netty.channel
final io.netty.channel.VoidChannelPromise extends io.netty.util.concurrent.AbstractFuture implements io.netty.channel.ChannelPromise {
private final io.netty.channel.Channel channel
private final boolean fireException
void (io.netty.channel.Channel, boolean)
io.netty.channel.Channel channel
boolean fireException
public io.netty.channel.VoidChannelPromise addListener (io.netty.util.concurrent.GenericFutureListener)
io.netty.util.concurrent.GenericFutureListener listener
public transient io.netty.channel.VoidChannelPromise addListeners (io.netty.util.concurrent.GenericFutureListener[])
io.netty.util.concurrent.GenericFutureListener[] listeners
public io.netty.channel.VoidChannelPromise removeListener (io.netty.util.concurrent.GenericFutureListener)
io.netty.util.concurrent.GenericFutureListener listener
public transient io.netty.channel.VoidChannelPromise removeListeners (io.netty.util.concurrent.GenericFutureListener[])
io.netty.util.concurrent.GenericFutureListener[] listeners
public io.netty.channel.VoidChannelPromise await () throws java.lang.InterruptedException
public boolean await (long, java.util.concurrent.TimeUnit)
long timeout
java.util.concurrent.TimeUnit unit
public boolean await (long)
long timeoutMillis
public io.netty.channel.VoidChannelPromise awaitUninterruptibly ()
public boolean awaitUninterruptibly (long, java.util.concurrent.TimeUnit)
long timeout
java.util.concurrent.TimeUnit unit
public boolean awaitUninterruptibly (long)
long timeoutMillis
public io.netty.channel.Channel channel ()
public boolean isDone ()
public boolean isSuccess ()
public boolean setUncancellable ()
public boolean isCancellable ()
public boolean isCancelled ()
public java.lang.Throwable cause ()
public io.netty.channel.VoidChannelPromise sync ()
public io.netty.channel.VoidChannelPromise syncUninterruptibly ()
public io.netty.channel.VoidChannelPromise setFailure (java.lang.Throwable)
Throwable cause
public io.netty.channel.VoidChannelPromise setSuccess ()
public boolean tryFailure (java.lang.Throwable)
Throwable cause
public boolean cancel (boolean)
boolean mayInterruptIfRunning
public boolean trySuccess ()
private static void fail ()
public io.netty.channel.VoidChannelPromise setSuccess (java.lang.Void)
Void result
public boolean trySuccess (java.lang.Void)
Void result
public java.lang.Void getNow ()
public io.netty.channel.ChannelPromise unvoid ()
io.netty.channel.ChannelPromise promise
public boolean isVoid ()
private void fireException (java.lang.Throwable)
Throwable cause
public volatile java.lang.Object getNow ()
public volatile io.netty.util.concurrent.Future awaitUninterruptibly ()
public volatile io.netty.util.concurrent.Future await () throws java.lang.InterruptedException
public volatile io.netty.util.concurrent.Future syncUninterruptibly ()
public volatile io.netty.util.concurrent.Future sync () throws java.lang.InterruptedException
public volatile io.netty.util.concurrent.Future removeListeners (io.netty.util.concurrent.GenericFutureListener[])
public volatile io.netty.util.concurrent.Future removeListener (io.netty.util.concurrent.GenericFutureListener)
public volatile io.netty.util.concurrent.Future addListeners (io.netty.util.concurrent.GenericFutureListener[])
public volatile io.netty.util.concurrent.Future addListener (io.netty.util.concurrent.GenericFutureListener)
public volatile io.netty.channel.ChannelPromise awaitUninterruptibly ()
public volatile io.netty.channel.ChannelPromise await () throws java.lang.InterruptedException
public volatile io.netty.channel.ChannelPromise syncUninterruptibly ()
public volatile io.netty.channel.ChannelPromise sync () throws java.lang.InterruptedException
public volatile io.netty.channel.ChannelPromise removeListeners (io.netty.util.concurrent.GenericFutureListener[])
public volatile io.netty.channel.ChannelPromise removeListener (io.netty.util.concurrent.GenericFutureListener)
public volatile io.netty.channel.ChannelPromise addListeners (io.netty.util.concurrent.GenericFutureListener[])
public volatile io.netty.channel.ChannelPromise addListener (io.netty.util.concurrent.GenericFutureListener)
public volatile io.netty.channel.ChannelPromise setFailure (java.lang.Throwable)
public volatile io.netty.channel.ChannelPromise setSuccess ()
public volatile io.netty.channel.ChannelPromise setSuccess (java.lang.Void)
public volatile io.netty.channel.ChannelFuture awaitUninterruptibly ()
public volatile io.netty.channel.ChannelFuture await () throws java.lang.InterruptedException
public volatile io.netty.channel.ChannelFuture syncUninterruptibly ()
public volatile io.netty.channel.ChannelFuture sync () throws java.lang.InterruptedException
public volatile io.netty.channel.ChannelFuture removeListeners (io.netty.util.concurrent.GenericFutureListener[])
public volatile io.netty.channel.ChannelFuture removeListener (io.netty.util.concurrent.GenericFutureListener)
public volatile io.netty.channel.ChannelFuture addListeners (io.netty.util.concurrent.GenericFutureListener[])
public volatile io.netty.channel.ChannelFuture addListener (io.netty.util.concurrent.GenericFutureListener)
public volatile io.netty.util.concurrent.Promise syncUninterruptibly ()
public volatile io.netty.util.concurrent.Promise sync () throws java.lang.InterruptedException
public volatile io.netty.util.concurrent.Promise awaitUninterruptibly ()
public volatile io.netty.util.concurrent.Promise await () throws java.lang.InterruptedException
public volatile io.netty.util.concurrent.Promise removeListeners (io.netty.util.concurrent.GenericFutureListener[])
public volatile io.netty.util.concurrent.Promise removeListener (io.netty.util.concurrent.GenericFutureListener)
public volatile io.netty.util.concurrent.Promise addListeners (io.netty.util.concurrent.GenericFutureListener[])
public volatile io.netty.util.concurrent.Promise addListener (io.netty.util.concurrent.GenericFutureListener)
public volatile io.netty.util.concurrent.Promise setFailure (java.lang.Throwable)
public volatile boolean trySuccess (java.lang.Object)
public volatile io.netty.util.concurrent.Promise setSuccess (java.lang.Object)
static void access$000 (io.netty.channel.VoidChannelPromise, java.lang.Throwable)
io.netty.channel.VoidChannelPromise x0
Throwable x1
}
io/netty/channel/RecvByteBufAllocator$Handle.classRecvByteBufAllocator.java
package io.netty.channel
public abstract io.netty.channel.RecvByteBufAllocator$Handle extends java.lang.Object {
public abstract io.netty.buffer.ByteBuf allocate (io.netty.buffer.ByteBufAllocator)
public abstract int guess ()
public abstract void reset (io.netty.channel.ChannelConfig)
public abstract void incMessagesRead (int)
public abstract void lastBytesRead (int)
public abstract int lastBytesRead ()
public abstract void attemptedBytesRead (int)
public abstract int attemptedBytesRead ()
public abstract boolean continueReading ()
public abstract void readComplete ()
}
io/netty/channel/CoalescingBufferQueue.classCoalescingBufferQueue.java
package io.netty.channel
public final io.netty.channel.CoalescingBufferQueue extends java.lang.Object {
private final io.netty.channel.Channel channel
private final java.util.ArrayDeque bufAndListenerPairs
private int readableBytes
static final boolean $assertionsDisabled
public void (io.netty.channel.Channel)
io.netty.channel.Channel channel
public void add (io.netty.buffer.ByteBuf)
io.netty.buffer.ByteBuf buf
public void add (io.netty.buffer.ByteBuf, io.netty.channel.ChannelPromise)
io.netty.buffer.ByteBuf buf
io.netty.channel.ChannelPromise promise
public void add (io.netty.buffer.ByteBuf, io.netty.channel.ChannelFutureListener)
io.netty.buffer.ByteBuf buf
io.netty.channel.ChannelFutureListener listener
public io.netty.buffer.ByteBuf remove (int, io.netty.channel.ChannelPromise)
Object entry
io.netty.buffer.ByteBuf entryBuffer
int bytes
io.netty.channel.ChannelPromise aggregatePromise
io.netty.buffer.ByteBuf toReturn
int originalBytes
private io.netty.buffer.ByteBuf compose (io.netty.buffer.ByteBuf, io.netty.buffer.ByteBuf)
io.netty.buffer.CompositeByteBuf composite
io.netty.buffer.ByteBuf current
io.netty.buffer.ByteBuf next
io.netty.buffer.CompositeByteBuf composite
public int readableBytes ()
public boolean isEmpty ()
public void releaseAndFailAll (java.lang.Throwable)
Throwable cause
private void releaseAndCompleteAll (io.netty.channel.ChannelFuture)
Throwable t
Object entry
io.netty.channel.ChannelFuture future
Throwable pending
public void copyTo (io.netty.channel.CoalescingBufferQueue)
io.netty.channel.CoalescingBufferQueue dest
static void ()
}
io/netty/channel/VoidChannelPromise$1.classVoidChannelPromise.java
package io.netty.channel
io.netty.channel.VoidChannelPromise$1 extends java.lang.Object implements io.netty.channel.ChannelFutureListener {
final io.netty.channel.VoidChannelPromise this$0
void (io.netty.channel.VoidChannelPromise)
public void operationComplete (io.netty.channel.ChannelFuture) throws java.lang.Exception
io.netty.channel.ChannelFuture future
public volatile void operationComplete (io.netty.util.concurrent.Future) throws java.lang.Exception
}
io/netty/channel/AbstractServerChannel$DefaultServerUnsafe.classAbstractServerChannel.java
package io.netty.channel
final io.netty.channel.AbstractServerChannel$DefaultServerUnsafe extends io.netty.channel.AbstractChannel$AbstractUnsafe {
final io.netty.channel.AbstractServerChannel this$0
private void (io.netty.channel.AbstractServerChannel)
public void connect (java.net.SocketAddress, java.net.SocketAddress, io.netty.channel.ChannelPromise)
java.net.SocketAddress remoteAddress
java.net.SocketAddress localAddress
io.netty.channel.ChannelPromise promise
void (io.netty.channel.AbstractServerChannel, io.netty.channel.AbstractServerChannel$1)
io.netty.channel.AbstractServerChannel x0
io.netty.channel.AbstractServerChannel$1 x1
}
io/netty/channel/MessageSizeEstimator.classMessageSizeEstimator.java
package io.netty.channel
public abstract io.netty.channel.MessageSizeEstimator extends java.lang.Object {
public abstract io.netty.channel.MessageSizeEstimator$Handle newHandle ()
}
io/netty/channel/DefaultChannelConfig.classDefaultChannelConfig.java
package io.netty.channel
public io.netty.channel.DefaultChannelConfig extends java.lang.Object implements io.netty.channel.ChannelConfig {
private static final io.netty.channel.MessageSizeEstimator DEFAULT_MSG_SIZE_ESTIMATOR
private static final int DEFAULT_CONNECT_TIMEOUT
private static final java.util.concurrent.atomic.AtomicIntegerFieldUpdater AUTOREAD_UPDATER
protected final io.netty.channel.Channel channel
private volatile io.netty.buffer.ByteBufAllocator allocator
private volatile io.netty.channel.RecvByteBufAllocator rcvBufAllocator
private volatile io.netty.channel.MessageSizeEstimator msgSizeEstimator
private volatile int connectTimeoutMillis
private volatile int writeSpinCount
private volatile int autoRead
private volatile boolean autoClose
private volatile int writeBufferHighWaterMark
private volatile int writeBufferLowWaterMark
public void (io.netty.channel.Channel)
io.netty.channel.Channel channel
protected void (io.netty.channel.Channel, io.netty.channel.RecvByteBufAllocator)
io.netty.channel.Channel channel
io.netty.channel.RecvByteBufAllocator allocator
public java.util.Map getOptions ()
protected transient java.util.Map getOptions (java.util.Map, io.netty.channel.ChannelOption[])
io.netty.channel.ChannelOption o
io.netty.channel.ChannelOption[] arr$
int len$
int i$
java.util.Map result
io.netty.channel.ChannelOption[] options
public boolean setOptions (java.util.Map)
java.util.Map$Entry e
java.util.Iterator i$
java.util.Map options
boolean setAllOptions
public java.lang.Object getOption (io.netty.channel.ChannelOption)
io.netty.channel.ChannelOption option
public boolean setOption (io.netty.channel.ChannelOption, java.lang.Object)
io.netty.channel.ChannelOption option
Object value
protected void validate (io.netty.channel.ChannelOption, java.lang.Object)
io.netty.channel.ChannelOption option
Object value
public int getConnectTimeoutMillis ()
public io.netty.channel.ChannelConfig setConnectTimeoutMillis (int)
int connectTimeoutMillis
public int getMaxMessagesPerRead ()
io.netty.channel.MaxMessagesRecvByteBufAllocator allocator
ClassCastException e
public io.netty.channel.ChannelConfig setMaxMessagesPerRead (int)
io.netty.channel.MaxMessagesRecvByteBufAllocator allocator
ClassCastException e
int maxMessagesPerRead
public int getWriteSpinCount ()
public io.netty.channel.ChannelConfig setWriteSpinCount (int)
int writeSpinCount
public io.netty.buffer.ByteBufAllocator getAllocator ()
public io.netty.channel.ChannelConfig setAllocator (io.netty.buffer.ByteBufAllocator)
io.netty.buffer.ByteBufAllocator allocator
public io.netty.channel.RecvByteBufAllocator getRecvByteBufAllocator ()
public io.netty.channel.ChannelConfig setRecvByteBufAllocator (io.netty.channel.RecvByteBufAllocator)
io.netty.channel.RecvByteBufAllocator allocator
private void setRecvByteBufAllocator (io.netty.channel.RecvByteBufAllocator, io.netty.channel.ChannelMetadata)
io.netty.channel.RecvByteBufAllocator allocator
io.netty.channel.ChannelMetadata metadata
public boolean isAutoRead ()
public io.netty.channel.ChannelConfig setAutoRead (boolean)
boolean autoRead
boolean oldAutoRead
protected void autoReadCleared ()
public boolean isAutoClose ()
public io.netty.channel.ChannelConfig setAutoClose (boolean)
boolean autoClose
public int getWriteBufferHighWaterMark ()
public io.netty.channel.ChannelConfig setWriteBufferHighWaterMark (int)
int writeBufferHighWaterMark
public int getWriteBufferLowWaterMark ()
public io.netty.channel.ChannelConfig setWriteBufferLowWaterMark (int)
int writeBufferLowWaterMark
public io.netty.channel.MessageSizeEstimator getMessageSizeEstimator ()
public io.netty.channel.ChannelConfig setMessageSizeEstimator (io.netty.channel.MessageSizeEstimator)
io.netty.channel.MessageSizeEstimator estimator
static void ()
java.util.concurrent.atomic.AtomicIntegerFieldUpdater autoReadUpdater
}
io/netty/channel/SucceededChannelFuture.classSucceededChannelFuture.java
package io.netty.channel
final io.netty.channel.SucceededChannelFuture extends io.netty.channel.CompleteChannelFuture {
void (io.netty.channel.Channel, io.netty.util.concurrent.EventExecutor)
io.netty.channel.Channel channel
io.netty.util.concurrent.EventExecutor executor
public java.lang.Throwable cause ()
public boolean isSuccess ()
}
io/netty/channel/AbstractChannel$AbstractUnsafe$5$1.classAbstractChannel.java
package io.netty.channel
io.netty.channel.AbstractChannel$AbstractUnsafe$5$1 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.AbstractChannel$AbstractUnsafe$5 this$2
void (io.netty.channel.AbstractChannel$AbstractUnsafe$5)
public void run ()
}
io/netty/channel/ThreadPerChannelEventLoopGroup$1.classThreadPerChannelEventLoopGroup.java
package io.netty.channel
io.netty.channel.ThreadPerChannelEventLoopGroup$1 extends java.lang.Object implements io.netty.util.concurrent.FutureListener {
final io.netty.channel.ThreadPerChannelEventLoopGroup this$0
void (io.netty.channel.ThreadPerChannelEventLoopGroup)
public void operationComplete (io.netty.util.concurrent.Future) throws java.lang.Exception
io.netty.util.concurrent.Future future
}
io/netty/channel/DefaultChannelPipeline$PendingHandlerCallback.classDefaultChannelPipeline.java
package io.netty.channel
abstract io.netty.channel.DefaultChannelPipeline$PendingHandlerCallback extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.AbstractChannelHandlerContext ctx
io.netty.channel.DefaultChannelPipeline$PendingHandlerCallback next
void (io.netty.channel.AbstractChannelHandlerContext)
io.netty.channel.AbstractChannelHandlerContext ctx
abstract void execute ()
}
io/netty/channel/CombinedChannelDuplexHandler$1.classCombinedChannelDuplexHandler.java
package io.netty.channel
io.netty.channel.CombinedChannelDuplexHandler$1 extends io.netty.channel.CombinedChannelDuplexHandler$DelegatingChannelHandlerContext {
final io.netty.channel.CombinedChannelDuplexHandler this$0
void (io.netty.channel.CombinedChannelDuplexHandler, io.netty.channel.ChannelHandlerContext, io.netty.channel.ChannelHandler)
io.netty.channel.ChannelHandlerContext x0
io.netty.channel.ChannelHandler x1
public io.netty.channel.ChannelHandlerContext fireExceptionCaught (java.lang.Throwable)
Throwable error
Throwable cause
}
io/netty/channel/DefaultFileRegion.classDefaultFileRegion.java
package io.netty.channel
public io.netty.channel.DefaultFileRegion extends io.netty.util.AbstractReferenceCounted implements io.netty.channel.FileRegion {
private static final io.netty.util.internal.logging.InternalLogger logger
private final java.io.File f
private final long position
private final long count
private long transfered
private java.nio.channels.FileChannel file
public void (java.nio.channels.FileChannel, long, long)
java.nio.channels.FileChannel file
long position
long count
public void (java.io.File, long, long)
java.io.File f
long position
long count
public boolean isOpen ()
public void open () throws java.io.IOException
public long position ()
public long count ()
public long transfered ()
public long transferTo (java.nio.channels.WritableByteChannel, long) throws java.io.IOException
java.nio.channels.WritableByteChannel target
long position
long count
long written
protected void deallocate ()
java.io.IOException e
java.nio.channels.FileChannel file
public io.netty.channel.FileRegion retain ()
public io.netty.channel.FileRegion retain (int)
int increment
public io.netty.channel.FileRegion touch ()
public io.netty.channel.FileRegion touch (java.lang.Object)
Object hint
public volatile io.netty.util.ReferenceCounted touch ()
public volatile io.netty.util.ReferenceCounted retain (int)
public volatile io.netty.util.ReferenceCounted retain ()
public volatile io.netty.util.ReferenceCounted touch (java.lang.Object)
static void ()
}
io/netty/channel/CombinedChannelDuplexHandler$DelegatingChannelHandlerContext$1.classCombinedChannelDuplexHandler.java
package io.netty.channel
io.netty.channel.CombinedChannelDuplexHandler$DelegatingChannelHandlerContext$1 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.CombinedChannelDuplexHandler$DelegatingChannelHandlerContext this$0
void (io.netty.channel.CombinedChannelDuplexHandler$DelegatingChannelHandlerContext)
public void run ()
}
io/netty/channel/ThreadLocalPooledDirectByteBuf$ThreadLocalUnsafeDirectByteBuf.classThreadLocalPooledDirectByteBuf.java
package io.netty.channel
final io.netty.channel.ThreadLocalPooledDirectByteBuf$ThreadLocalUnsafeDirectByteBuf extends io.netty.buffer.UnpooledUnsafeDirectByteBuf {
private static final io.netty.util.Recycler RECYCLER
private final io.netty.util.Recycler$Handle handle
static io.netty.channel.ThreadLocalPooledDirectByteBuf$ThreadLocalUnsafeDirectByteBuf newInstance ()
io.netty.channel.ThreadLocalPooledDirectByteBuf$ThreadLocalUnsafeDirectByteBuf buf
private void (io.netty.util.Recycler$Handle)
io.netty.util.Recycler$Handle handle
protected void deallocate ()
void (io.netty.util.Recycler$Handle, io.netty.channel.ThreadLocalPooledDirectByteBuf$1)
io.netty.util.Recycler$Handle x0
io.netty.channel.ThreadLocalPooledDirectByteBuf$1 x1
static void ()
}
io/netty/channel/DefaultChannelId.classDefaultChannelId.java
package io.netty.channel
final io.netty.channel.DefaultChannelId extends java.lang.Object implements io.netty.channel.ChannelId {
private static final long serialVersionUID
private static final io.netty.util.internal.logging.InternalLogger logger
private static final java.util.regex.Pattern MACHINE_ID_PATTERN
private static final int MACHINE_ID_LEN
private static final byte[] MACHINE_ID
private static final int PROCESS_ID_LEN
private static final int MAX_PROCESS_ID
private static final int PROCESS_ID
private static final int SEQUENCE_LEN
private static final int TIMESTAMP_LEN
private static final int RANDOM_LEN
private static final java.util.concurrent.atomic.AtomicInteger nextSequence
private final byte[] data
private int hashCode
private transient String shortValue
private transient String longValue
static final boolean $assertionsDisabled
void ()
static io.netty.channel.ChannelId newInstance ()
io.netty.channel.DefaultChannelId id
private static byte[] parseMachineId (java.lang.String)
int i
String value
byte[] machineId
private static byte[] defaultMachineId ()
byte[] bestMacAddr
private static int defaultProcessId ()
Class mgmtFactoryType
Class runtimeMxBeanType
java.lang.reflect.Method getRuntimeMXBean
Object bean
java.lang.reflect.Method getName
String value
Class processType
java.lang.reflect.Method myPid
String value
Exception e2
Exception e
int pid
NumberFormatException e
ClassLoader loader
String value
int atIndex
int pid
private void init ()
int i
int random
private int writeInt (int, int)
int i
int value
private int writeLong (int, long)
int i
long value
public java.lang.String asShortText ()
String shortValue
public java.lang.String asLongText ()
String longValue
private java.lang.String newLongValue ()
StringBuilder buf
int i
private int appendHexDumpField (java.lang.StringBuilder, int, int)
StringBuilder buf
int i
int length
public int hashCode ()
public int compareTo (io.netty.channel.ChannelId)
io.netty.channel.ChannelId o
public boolean equals (java.lang.Object)
Object obj
public java.lang.String toString ()
public volatile int compareTo (java.lang.Object)
static void ()
int processId
String customProcessId
byte[] machineId
String customMachineId
}
io/netty/channel/ChannelInboundHandlerAdapter.classChannelInboundHandlerAdapter.java
package io.netty.channel
public io.netty.channel.ChannelInboundHandlerAdapter extends io.netty.channel.ChannelHandlerAdapter implements io.netty.channel.ChannelInboundHandler {
public void ()
public void channelRegistered (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
public void channelUnregistered (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
public void channelActive (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
public void channelInactive (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
public void channelRead (io.netty.channel.ChannelHandlerContext, java.lang.Object) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
Object msg
public void channelReadComplete (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
public void userEventTriggered (io.netty.channel.ChannelHandlerContext, java.lang.Object) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
Object evt
public void channelWritabilityChanged (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
public void exceptionCaught (io.netty.channel.ChannelHandlerContext, java.lang.Throwable) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
Throwable cause
}
io/netty/channel/DefaultChannelPipeline$5.classDefaultChannelPipeline.java
package io.netty.channel
io.netty.channel.DefaultChannelPipeline$5 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.AbstractChannelHandlerContext val$ctx
final io.netty.channel.AbstractChannelHandlerContext val$newCtx
final io.netty.channel.DefaultChannelPipeline this$0
void (io.netty.channel.DefaultChannelPipeline, io.netty.channel.AbstractChannelHandlerContext, io.netty.channel.AbstractChannelHandlerContext)
public void run ()
}
io/netty/channel/ChannelHandlerInvokerUtil.classChannelHandlerInvokerUtil.java
package io.netty.channel
public final io.netty.channel.ChannelHandlerInvokerUtil extends java.lang.Object {
public static void invokeChannelRegisteredNow (io.netty.channel.ChannelHandlerContext)
Throwable t
io.netty.channel.ChannelHandlerContext ctx
public static void invokeChannelUnregisteredNow (io.netty.channel.ChannelHandlerContext)
Throwable t
io.netty.channel.ChannelHandlerContext ctx
public static void invokeChannelActiveNow (io.netty.channel.ChannelHandlerContext)
Throwable t
io.netty.channel.ChannelHandlerContext ctx
public static void invokeChannelInactiveNow (io.netty.channel.ChannelHandlerContext)
Throwable t
io.netty.channel.ChannelHandlerContext ctx
public static void invokeExceptionCaughtNow (io.netty.channel.ChannelHandlerContext, java.lang.Throwable)
Throwable t
io.netty.channel.ChannelHandlerContext ctx
Throwable cause
public static void invokeUserEventTriggeredNow (io.netty.channel.ChannelHandlerContext, java.lang.Object)
Throwable t
io.netty.channel.ChannelHandlerContext ctx
Object event
public static void invokeChannelReadNow (io.netty.channel.ChannelHandlerContext, java.lang.Object)
Throwable t
io.netty.channel.ChannelHandlerContext ctx
Object msg
public static void invokeChannelReadCompleteNow (io.netty.channel.ChannelHandlerContext)
Throwable t
io.netty.channel.ChannelHandlerContext ctx
public static void invokeChannelWritabilityChangedNow (io.netty.channel.ChannelHandlerContext)
Throwable t
io.netty.channel.ChannelHandlerContext ctx
public static void invokeBindNow (io.netty.channel.ChannelHandlerContext, java.net.SocketAddress, io.netty.channel.ChannelPromise)
Throwable t
io.netty.channel.ChannelHandlerContext ctx
java.net.SocketAddress localAddress
io.netty.channel.ChannelPromise promise
public static void invokeConnectNow (io.netty.channel.ChannelHandlerContext, java.net.SocketAddress, java.net.SocketAddress, io.netty.channel.ChannelPromise)
Throwable t
io.netty.channel.ChannelHandlerContext ctx
java.net.SocketAddress remoteAddress
java.net.SocketAddress localAddress
io.netty.channel.ChannelPromise promise
public static void invokeDisconnectNow (io.netty.channel.ChannelHandlerContext, io.netty.channel.ChannelPromise)
Throwable t
io.netty.channel.ChannelHandlerContext ctx
io.netty.channel.ChannelPromise promise
public static void invokeCloseNow (io.netty.channel.ChannelHandlerContext, io.netty.channel.ChannelPromise)
Throwable t
io.netty.channel.ChannelHandlerContext ctx
io.netty.channel.ChannelPromise promise
public static void invokeDeregisterNow (io.netty.channel.ChannelHandlerContext, io.netty.channel.ChannelPromise)
Throwable t
io.netty.channel.ChannelHandlerContext ctx
io.netty.channel.ChannelPromise promise
public static void invokeReadNow (io.netty.channel.ChannelHandlerContext)
Throwable t
io.netty.channel.ChannelHandlerContext ctx
public static void invokeWriteNow (io.netty.channel.ChannelHandlerContext, java.lang.Object, io.netty.channel.ChannelPromise)
Throwable t
io.netty.channel.ChannelHandlerContext ctx
Object msg
io.netty.channel.ChannelPromise promise
public static void invokeFlushNow (io.netty.channel.ChannelHandlerContext)
Throwable t
io.netty.channel.ChannelHandlerContext ctx
public static boolean validatePromise (io.netty.channel.ChannelHandlerContext, io.netty.channel.ChannelPromise, boolean)
io.netty.channel.ChannelHandlerContext ctx
io.netty.channel.ChannelPromise promise
boolean allowVoidPromise
private static void notifyHandlerException (io.netty.channel.ChannelHandlerContext, java.lang.Throwable)
io.netty.channel.ChannelHandlerContext ctx
Throwable cause
private static void notifyOutboundHandlerException (java.lang.Throwable, io.netty.channel.ChannelPromise)
Throwable cause
io.netty.channel.ChannelPromise promise
private static boolean inExceptionCaught (java.lang.Throwable)
StackTraceElement t
StackTraceElement[] arr$
int len$
int i$
StackTraceElement[] trace
Throwable cause
private void ()
}
io/netty/channel/ChannelOutboundBuffer$3.classChannelOutboundBuffer.java
package io.netty.channel
io.netty.channel.ChannelOutboundBuffer$3 extends io.netty.util.internal.OneTimeTask {
final java.nio.channels.ClosedChannelException val$cause
final io.netty.channel.ChannelOutboundBuffer this$0
void (io.netty.channel.ChannelOutboundBuffer, java.nio.channels.ClosedChannelException)
public void run ()
}
io/netty/channel/DefaultChannelPipeline$6.classDefaultChannelPipeline.java
package io.netty.channel
io.netty.channel.DefaultChannelPipeline$6 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.AbstractChannelHandlerContext val$ctx
final io.netty.channel.DefaultChannelPipeline this$0
void (io.netty.channel.DefaultChannelPipeline, io.netty.channel.AbstractChannelHandlerContext)
public void run ()
}
io/netty/channel/EventLoop.classEventLoop.java
package io.netty.channel
public abstract io.netty.channel.EventLoop extends java.lang.Object implements io.netty.util.concurrent.EventExecutor io.netty.channel.EventLoopGroup {
public abstract io.netty.channel.EventLoopGroup parent ()
public abstract io.netty.channel.ChannelHandlerInvoker asInvoker ()
}
io/netty/channel/CombinedChannelDuplexHandler$DelegatingChannelHandlerContext.classCombinedChannelDuplexHandler.java
package io.netty.channel
io.netty.channel.CombinedChannelDuplexHandler$DelegatingChannelHandlerContext extends java.lang.Object implements io.netty.channel.ChannelHandlerContext {
private final io.netty.channel.ChannelHandlerContext ctx
private final io.netty.channel.ChannelHandler handler
boolean removed
void (io.netty.channel.ChannelHandlerContext, io.netty.channel.ChannelHandler)
io.netty.channel.ChannelHandlerContext ctx
io.netty.channel.ChannelHandler handler
public io.netty.channel.Channel channel ()
public io.netty.util.concurrent.EventExecutor executor ()
public io.netty.channel.ChannelHandlerInvoker invoker ()
public java.lang.String name ()
public io.netty.channel.ChannelHandler handler ()
public boolean isRemoved ()
public io.netty.channel.ChannelHandlerContext fireChannelRegistered ()
public io.netty.channel.ChannelHandlerContext fireChannelUnregistered ()
public io.netty.channel.ChannelHandlerContext fireChannelActive ()
public io.netty.channel.ChannelHandlerContext fireChannelInactive ()
public io.netty.channel.ChannelHandlerContext fireExceptionCaught (java.lang.Throwable)
Throwable cause
public io.netty.channel.ChannelHandlerContext fireUserEventTriggered (java.lang.Object)
Object event
public io.netty.channel.ChannelHandlerContext fireChannelRead (java.lang.Object)
Object msg
public io.netty.channel.ChannelHandlerContext fireChannelReadComplete ()
public io.netty.channel.ChannelHandlerContext fireChannelWritabilityChanged ()
public io.netty.channel.ChannelFuture bind (java.net.SocketAddress)
java.net.SocketAddress localAddress
public io.netty.channel.ChannelFuture connect (java.net.SocketAddress)
java.net.SocketAddress remoteAddress
public io.netty.channel.ChannelFuture connect (java.net.SocketAddress, java.net.SocketAddress)
java.net.SocketAddress remoteAddress
java.net.SocketAddress localAddress
public io.netty.channel.ChannelFuture disconnect ()
public io.netty.channel.ChannelFuture close ()
public io.netty.channel.ChannelFuture deregister ()
public io.netty.channel.ChannelFuture bind (java.net.SocketAddress, io.netty.channel.ChannelPromise)
java.net.SocketAddress localAddress
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelFuture connect (java.net.SocketAddress, io.netty.channel.ChannelPromise)
java.net.SocketAddress remoteAddress
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelFuture connect (java.net.SocketAddress, java.net.SocketAddress, io.netty.channel.ChannelPromise)
java.net.SocketAddress remoteAddress
java.net.SocketAddress localAddress
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelFuture disconnect (io.netty.channel.ChannelPromise)
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelFuture close (io.netty.channel.ChannelPromise)
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelFuture deregister (io.netty.channel.ChannelPromise)
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelHandlerContext read ()
public io.netty.channel.ChannelFuture write (java.lang.Object)
Object msg
public io.netty.channel.ChannelFuture write (java.lang.Object, io.netty.channel.ChannelPromise)
Object msg
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelHandlerContext flush ()
public io.netty.channel.ChannelFuture writeAndFlush (java.lang.Object, io.netty.channel.ChannelPromise)
Object msg
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelFuture writeAndFlush (java.lang.Object)
Object msg
public io.netty.channel.ChannelPipeline pipeline ()
public io.netty.buffer.ByteBufAllocator alloc ()
public io.netty.channel.ChannelPromise newPromise ()
public io.netty.channel.ChannelProgressivePromise newProgressivePromise ()
public io.netty.channel.ChannelFuture newSucceededFuture ()
public io.netty.channel.ChannelFuture newFailedFuture (java.lang.Throwable)
Throwable cause
public io.netty.channel.ChannelPromise voidPromise ()
public io.netty.util.Attribute attr (io.netty.util.AttributeKey)
io.netty.util.AttributeKey key
public boolean hasAttr (io.netty.util.AttributeKey)
io.netty.util.AttributeKey key
final void remove ()
io.netty.util.concurrent.EventExecutor executor
private void remove0 ()
Throwable cause
static io.netty.channel.ChannelHandlerContext access$300 (io.netty.channel.CombinedChannelDuplexHandler$DelegatingChannelHandlerContext)
io.netty.channel.CombinedChannelDuplexHandler$DelegatingChannelHandlerContext x0
static void access$400 (io.netty.channel.CombinedChannelDuplexHandler$DelegatingChannelHandlerContext)
io.netty.channel.CombinedChannelDuplexHandler$DelegatingChannelHandlerContext x0
}
io/netty/channel/socket/ServerSocketChannelConfig.classServerSocketChannelConfig.java
package io.netty.channel.socket
public abstract io.netty.channel.socket.ServerSocketChannelConfig extends java.lang.Object implements io.netty.channel.ChannelConfig {
public abstract int getBacklog ()
public abstract io.netty.channel.socket.ServerSocketChannelConfig setBacklog (int)
public abstract boolean isReuseAddress ()
public abstract io.netty.channel.socket.ServerSocketChannelConfig setReuseAddress (boolean)
public abstract int getReceiveBufferSize ()
public abstract io.netty.channel.socket.ServerSocketChannelConfig setReceiveBufferSize (int)
public abstract io.netty.channel.socket.ServerSocketChannelConfig setPerformancePreferences (int, int, int)
public abstract io.netty.channel.socket.ServerSocketChannelConfig setConnectTimeoutMillis (int)
public abstract io.netty.channel.socket.ServerSocketChannelConfig setMaxMessagesPerRead (int)
public abstract io.netty.channel.socket.ServerSocketChannelConfig setWriteSpinCount (int)
public abstract io.netty.channel.socket.ServerSocketChannelConfig setAllocator (io.netty.buffer.ByteBufAllocator)
public abstract io.netty.channel.socket.ServerSocketChannelConfig setRecvByteBufAllocator (io.netty.channel.RecvByteBufAllocator)
public abstract io.netty.channel.socket.ServerSocketChannelConfig setAutoRead (boolean)
public abstract io.netty.channel.socket.ServerSocketChannelConfig setMessageSizeEstimator (io.netty.channel.MessageSizeEstimator)
}
io/netty/channel/socket/ChannelInputShutdownEvent.classChannelInputShutdownEvent.java
package io.netty.channel.socket
public final io.netty.channel.socket.ChannelInputShutdownEvent extends java.lang.Object {
public static final io.netty.channel.socket.ChannelInputShutdownEvent INSTANCE
private void ()
static void ()
}
io/netty/channel/socket/oio/OioServerSocketChannel.classOioServerSocketChannel.java
package io.netty.channel.socket.oio
public io.netty.channel.socket.oio.OioServerSocketChannel extends io.netty.channel.oio.AbstractOioMessageChannel implements io.netty.channel.socket.ServerSocketChannel {
private static final io.netty.util.internal.logging.InternalLogger logger
private static final io.netty.channel.ChannelMetadata METADATA
final java.net.ServerSocket socket
final java.util.concurrent.locks.Lock shutdownLock
private final io.netty.channel.socket.oio.OioServerSocketChannelConfig config
private static java.net.ServerSocket newServerSocket ()
java.io.IOException e
public void ()
public void (java.net.ServerSocket)
java.io.IOException e
java.io.IOException e
java.io.IOException e
java.net.ServerSocket socket
boolean success
public java.net.InetSocketAddress localAddress ()
public io.netty.channel.ChannelMetadata metadata ()
public io.netty.channel.socket.oio.OioServerSocketChannelConfig config ()
public java.net.InetSocketAddress remoteAddress ()
public boolean isOpen ()
public boolean isActive ()
protected java.net.SocketAddress localAddress0 ()
protected void doBind (java.net.SocketAddress) throws java.lang.Exception
java.net.SocketAddress localAddress
protected void doClose () throws java.lang.Exception
protected int doReadMessages (java.util.List) throws java.lang.Exception
Throwable t2
Throwable t
java.net.Socket s
java.util.List buf
protected void doWrite (io.netty.channel.ChannelOutboundBuffer) throws java.lang.Exception
io.netty.channel.ChannelOutboundBuffer in
protected java.lang.Object filterOutboundMessage (java.lang.Object) throws java.lang.Exception
Object msg
protected void doConnect (java.net.SocketAddress, java.net.SocketAddress) throws java.lang.Exception
java.net.SocketAddress remoteAddress
java.net.SocketAddress localAddress
protected java.net.SocketAddress remoteAddress0 ()
protected void doDisconnect () throws java.lang.Exception
protected void setReadPending (boolean)
boolean readPending
public volatile java.net.SocketAddress remoteAddress ()
public volatile java.net.SocketAddress localAddress ()
public volatile io.netty.channel.ChannelConfig config ()
public volatile io.netty.channel.socket.ServerSocketChannelConfig config ()
static void ()
}
io/netty/channel/socket/oio/OioDatagramChannel.classOioDatagramChannel.java
package io.netty.channel.socket.oio
public io.netty.channel.socket.oio.OioDatagramChannel extends io.netty.channel.oio.AbstractOioMessageChannel implements io.netty.channel.socket.DatagramChannel {
private static final io.netty.util.internal.logging.InternalLogger logger
private static final io.netty.channel.ChannelMetadata METADATA
private static final String EXPECTED_TYPES
private final java.net.MulticastSocket socket
private final io.netty.channel.socket.DatagramChannelConfig config
private final java.net.DatagramPacket tmpPacket
private static java.net.MulticastSocket newSocket ()
Exception e
public void ()
public void (java.net.MulticastSocket)
java.net.SocketException e
java.net.MulticastSocket socket
boolean success
public io.netty.channel.ChannelMetadata metadata ()
public io.netty.channel.socket.DatagramChannelConfig config ()
public boolean isOpen ()
public boolean isActive ()
public boolean isConnected ()
protected java.net.SocketAddress localAddress0 ()
protected java.net.SocketAddress remoteAddress0 ()
protected void doBind (java.net.SocketAddress) throws java.lang.Exception
java.net.SocketAddress localAddress
public java.net.InetSocketAddress localAddress ()
public java.net.InetSocketAddress remoteAddress ()
protected void doConnect (java.net.SocketAddress, java.net.SocketAddress) throws java.lang.Exception
Throwable t
Throwable t
java.net.SocketAddress remoteAddress
java.net.SocketAddress localAddress
boolean success
protected void doDisconnect () throws java.lang.Exception
protected void doClose () throws java.lang.Exception
protected int doReadMessages (java.util.List) throws java.lang.Exception
java.net.InetSocketAddress remoteAddr
java.net.SocketTimeoutException e
java.net.SocketException e
Throwable cause
java.util.List buf
io.netty.channel.socket.DatagramChannelConfig config
io.netty.channel.RecvByteBufAllocator$Handle allocHandle
io.netty.buffer.ByteBuf data
boolean free
protected void doWrite (io.netty.channel.ChannelOutboundBuffer) throws java.lang.Exception
io.netty.channel.AddressedEnvelope envelope
io.netty.buffer.ByteBuf data
java.net.SocketAddress remoteAddress
byte[] tmp
java.io.IOException e
Object o
io.netty.buffer.ByteBuf data
java.net.SocketAddress remoteAddress
int length
io.netty.channel.ChannelOutboundBuffer in
protected java.lang.Object filterOutboundMessage (java.lang.Object)
io.netty.channel.AddressedEnvelope e
Object msg
public io.netty.channel.ChannelFuture joinGroup (java.net.InetAddress)
java.net.InetAddress multicastAddress
public io.netty.channel.ChannelFuture joinGroup (java.net.InetAddress, io.netty.channel.ChannelPromise)
java.io.IOException e
java.net.InetAddress multicastAddress
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelFuture joinGroup (java.net.InetSocketAddress, java.net.NetworkInterface)
java.net.InetSocketAddress multicastAddress
java.net.NetworkInterface networkInterface
public io.netty.channel.ChannelFuture joinGroup (java.net.InetSocketAddress, java.net.NetworkInterface, io.netty.channel.ChannelPromise)
java.io.IOException e
java.net.InetSocketAddress multicastAddress
java.net.NetworkInterface networkInterface
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelFuture joinGroup (java.net.InetAddress, java.net.NetworkInterface, java.net.InetAddress)
java.net.InetAddress multicastAddress
java.net.NetworkInterface networkInterface
java.net.InetAddress source
public io.netty.channel.ChannelFuture joinGroup (java.net.InetAddress, java.net.NetworkInterface, java.net.InetAddress, io.netty.channel.ChannelPromise)
java.net.InetAddress multicastAddress
java.net.NetworkInterface networkInterface
java.net.InetAddress source
io.netty.channel.ChannelPromise promise
private void ensureBound ()
public io.netty.channel.ChannelFuture leaveGroup (java.net.InetAddress)
java.net.InetAddress multicastAddress
public io.netty.channel.ChannelFuture leaveGroup (java.net.InetAddress, io.netty.channel.ChannelPromise)
java.io.IOException e
java.net.InetAddress multicastAddress
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelFuture leaveGroup (java.net.InetSocketAddress, java.net.NetworkInterface)
java.net.InetSocketAddress multicastAddress
java.net.NetworkInterface networkInterface
public io.netty.channel.ChannelFuture leaveGroup (java.net.InetSocketAddress, java.net.NetworkInterface, io.netty.channel.ChannelPromise)
java.io.IOException e
java.net.InetSocketAddress multicastAddress
java.net.NetworkInterface networkInterface
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelFuture leaveGroup (java.net.InetAddress, java.net.NetworkInterface, java.net.InetAddress)
java.net.InetAddress multicastAddress
java.net.NetworkInterface networkInterface
java.net.InetAddress source
public io.netty.channel.ChannelFuture leaveGroup (java.net.InetAddress, java.net.NetworkInterface, java.net.InetAddress, io.netty.channel.ChannelPromise)
java.net.InetAddress multicastAddress
java.net.NetworkInterface networkInterface
java.net.InetAddress source
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelFuture block (java.net.InetAddress, java.net.NetworkInterface, java.net.InetAddress)
java.net.InetAddress multicastAddress
java.net.NetworkInterface networkInterface
java.net.InetAddress sourceToBlock
public io.netty.channel.ChannelFuture block (java.net.InetAddress, java.net.NetworkInterface, java.net.InetAddress, io.netty.channel.ChannelPromise)
java.net.InetAddress multicastAddress
java.net.NetworkInterface networkInterface
java.net.InetAddress sourceToBlock
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelFuture block (java.net.InetAddress, java.net.InetAddress)
java.net.InetAddress multicastAddress
java.net.InetAddress sourceToBlock
public io.netty.channel.ChannelFuture block (java.net.InetAddress, java.net.InetAddress, io.netty.channel.ChannelPromise)
java.net.InetAddress multicastAddress
java.net.InetAddress sourceToBlock
io.netty.channel.ChannelPromise promise
public volatile java.net.SocketAddress remoteAddress ()
public volatile java.net.SocketAddress localAddress ()
public volatile io.netty.channel.ChannelConfig config ()
static void ()
}
io/netty/channel/socket/oio/DefaultOioSocketChannelConfig.classDefaultOioSocketChannelConfig.java
package io.netty.channel.socket.oio
public io.netty.channel.socket.oio.DefaultOioSocketChannelConfig extends io.netty.channel.socket.DefaultSocketChannelConfig implements io.netty.channel.socket.oio.OioSocketChannelConfig {
public void (io.netty.channel.socket.SocketChannel, java.net.Socket)
io.netty.channel.socket.SocketChannel channel
java.net.Socket javaSocket
void (io.netty.channel.socket.oio.OioSocketChannel, java.net.Socket)
io.netty.channel.socket.oio.OioSocketChannel channel
java.net.Socket javaSocket
public java.util.Map getOptions ()
public java.lang.Object getOption (io.netty.channel.ChannelOption)
io.netty.channel.ChannelOption option
public boolean setOption (io.netty.channel.ChannelOption, java.lang.Object)
io.netty.channel.ChannelOption option
Object value
public io.netty.channel.socket.oio.OioSocketChannelConfig setSoTimeout (int)
java.io.IOException e
int timeout
public int getSoTimeout ()
java.io.IOException e
public io.netty.channel.socket.oio.OioSocketChannelConfig setTcpNoDelay (boolean)
boolean tcpNoDelay
public io.netty.channel.socket.oio.OioSocketChannelConfig setSoLinger (int)
int soLinger
public io.netty.channel.socket.oio.OioSocketChannelConfig setSendBufferSize (int)
int sendBufferSize
public io.netty.channel.socket.oio.OioSocketChannelConfig setReceiveBufferSize (int)
int receiveBufferSize
public io.netty.channel.socket.oio.OioSocketChannelConfig setKeepAlive (boolean)
boolean keepAlive
public io.netty.channel.socket.oio.OioSocketChannelConfig setTrafficClass (int)
int trafficClass
public io.netty.channel.socket.oio.OioSocketChannelConfig setReuseAddress (boolean)
boolean reuseAddress
public io.netty.channel.socket.oio.OioSocketChannelConfig setPerformancePreferences (int, int, int)
int connectionTime
int latency
int bandwidth
public io.netty.channel.socket.oio.OioSocketChannelConfig setAllowHalfClosure (boolean)
boolean allowHalfClosure
public io.netty.channel.socket.oio.OioSocketChannelConfig setConnectTimeoutMillis (int)
int connectTimeoutMillis
public io.netty.channel.socket.oio.OioSocketChannelConfig setMaxMessagesPerRead (int)
int maxMessagesPerRead
public io.netty.channel.socket.oio.OioSocketChannelConfig setWriteSpinCount (int)
int writeSpinCount
public io.netty.channel.socket.oio.OioSocketChannelConfig setAllocator (io.netty.buffer.ByteBufAllocator)
io.netty.buffer.ByteBufAllocator allocator
public io.netty.channel.socket.oio.OioSocketChannelConfig setRecvByteBufAllocator (io.netty.channel.RecvByteBufAllocator)
io.netty.channel.RecvByteBufAllocator allocator
public io.netty.channel.socket.oio.OioSocketChannelConfig setAutoRead (boolean)
boolean autoRead
protected void autoReadCleared ()
public io.netty.channel.socket.oio.OioSocketChannelConfig setAutoClose (boolean)
boolean autoClose
public io.netty.channel.socket.oio.OioSocketChannelConfig setWriteBufferHighWaterMark (int)
int writeBufferHighWaterMark
public io.netty.channel.socket.oio.OioSocketChannelConfig setWriteBufferLowWaterMark (int)
int writeBufferLowWaterMark
public io.netty.channel.socket.oio.OioSocketChannelConfig setMessageSizeEstimator (io.netty.channel.MessageSizeEstimator)
io.netty.channel.MessageSizeEstimator estimator
public volatile io.netty.channel.socket.SocketChannelConfig setMessageSizeEstimator (io.netty.channel.MessageSizeEstimator)
public volatile io.netty.channel.socket.SocketChannelConfig setWriteBufferLowWaterMark (int)
public volatile io.netty.channel.socket.SocketChannelConfig setWriteBufferHighWaterMark (int)
public volatile io.netty.channel.socket.SocketChannelConfig setAutoClose (boolean)
public volatile io.netty.channel.socket.SocketChannelConfig setAutoRead (boolean)
public volatile io.netty.channel.socket.SocketChannelConfig setRecvByteBufAllocator (io.netty.channel.RecvByteBufAllocator)
public volatile io.netty.channel.socket.SocketChannelConfig setAllocator (io.netty.buffer.ByteBufAllocator)
public volatile io.netty.channel.socket.SocketChannelConfig setWriteSpinCount (int)
public volatile io.netty.channel.socket.SocketChannelConfig setMaxMessagesPerRead (int)
public volatile io.netty.channel.socket.SocketChannelConfig setConnectTimeoutMillis (int)
public volatile io.netty.channel.socket.SocketChannelConfig setAllowHalfClosure (boolean)
public volatile io.netty.channel.socket.SocketChannelConfig setTrafficClass (int)
public volatile io.netty.channel.socket.SocketChannelConfig setTcpNoDelay (boolean)
public volatile io.netty.channel.socket.SocketChannelConfig setSoLinger (int)
public volatile io.netty.channel.socket.SocketChannelConfig setSendBufferSize (int)
public volatile io.netty.channel.socket.SocketChannelConfig setReuseAddress (boolean)
public volatile io.netty.channel.socket.SocketChannelConfig setReceiveBufferSize (int)
public volatile io.netty.channel.socket.SocketChannelConfig setPerformancePreferences (int, int, int)
public volatile io.netty.channel.socket.SocketChannelConfig setKeepAlive (boolean)
public volatile io.netty.channel.ChannelConfig setMessageSizeEstimator (io.netty.channel.MessageSizeEstimator)
public volatile io.netty.channel.ChannelConfig setWriteBufferLowWaterMark (int)
public volatile io.netty.channel.ChannelConfig setWriteBufferHighWaterMark (int)
public volatile io.netty.channel.ChannelConfig setAutoClose (boolean)
public volatile io.netty.channel.ChannelConfig setAutoRead (boolean)
public volatile io.netty.channel.ChannelConfig setRecvByteBufAllocator (io.netty.channel.RecvByteBufAllocator)
public volatile io.netty.channel.ChannelConfig setAllocator (io.netty.buffer.ByteBufAllocator)
public volatile io.netty.channel.ChannelConfig setWriteSpinCount (int)
public volatile io.netty.channel.ChannelConfig setMaxMessagesPerRead (int)
public volatile io.netty.channel.ChannelConfig setConnectTimeoutMillis (int)
}
io/netty/channel/socket/oio/DefaultOioServerSocketChannelConfig.classDefaultOioServerSocketChannelConfig.java
package io.netty.channel.socket.oio
public io.netty.channel.socket.oio.DefaultOioServerSocketChannelConfig extends io.netty.channel.socket.DefaultServerSocketChannelConfig implements io.netty.channel.socket.oio.OioServerSocketChannelConfig {
public void (io.netty.channel.socket.ServerSocketChannel, java.net.ServerSocket)
io.netty.channel.socket.ServerSocketChannel channel
java.net.ServerSocket javaSocket
void (io.netty.channel.socket.oio.OioServerSocketChannel, java.net.ServerSocket)
io.netty.channel.socket.oio.OioServerSocketChannel channel
java.net.ServerSocket javaSocket
public java.util.Map getOptions ()
public java.lang.Object getOption (io.netty.channel.ChannelOption)
io.netty.channel.ChannelOption option
public boolean setOption (io.netty.channel.ChannelOption, java.lang.Object)
io.netty.channel.ChannelOption option
Object value
public io.netty.channel.socket.oio.OioServerSocketChannelConfig setSoTimeout (int)
java.io.IOException e
int timeout
public int getSoTimeout ()
java.io.IOException e
public io.netty.channel.socket.oio.OioServerSocketChannelConfig setBacklog (int)
int backlog
public io.netty.channel.socket.oio.OioServerSocketChannelConfig setReuseAddress (boolean)
boolean reuseAddress
public io.netty.channel.socket.oio.OioServerSocketChannelConfig setReceiveBufferSize (int)
int receiveBufferSize
public io.netty.channel.socket.oio.OioServerSocketChannelConfig setPerformancePreferences (int, int, int)
int connectionTime
int latency
int bandwidth
public io.netty.channel.socket.oio.OioServerSocketChannelConfig setConnectTimeoutMillis (int)
int connectTimeoutMillis
public io.netty.channel.socket.oio.OioServerSocketChannelConfig setMaxMessagesPerRead (int)
int maxMessagesPerRead
public io.netty.channel.socket.oio.OioServerSocketChannelConfig setWriteSpinCount (int)
int writeSpinCount
public io.netty.channel.socket.oio.OioServerSocketChannelConfig setAllocator (io.netty.buffer.ByteBufAllocator)
io.netty.buffer.ByteBufAllocator allocator
public io.netty.channel.socket.oio.OioServerSocketChannelConfig setRecvByteBufAllocator (io.netty.channel.RecvByteBufAllocator)
io.netty.channel.RecvByteBufAllocator allocator
public io.netty.channel.socket.oio.OioServerSocketChannelConfig setAutoRead (boolean)
boolean autoRead
protected void autoReadCleared ()
public io.netty.channel.socket.oio.OioServerSocketChannelConfig setAutoClose (boolean)
boolean autoClose
public io.netty.channel.socket.oio.OioServerSocketChannelConfig setWriteBufferHighWaterMark (int)
int writeBufferHighWaterMark
public io.netty.channel.socket.oio.OioServerSocketChannelConfig setWriteBufferLowWaterMark (int)
int writeBufferLowWaterMark
public io.netty.channel.socket.oio.OioServerSocketChannelConfig setMessageSizeEstimator (io.netty.channel.MessageSizeEstimator)
io.netty.channel.MessageSizeEstimator estimator
public volatile io.netty.channel.socket.ServerSocketChannelConfig setMessageSizeEstimator (io.netty.channel.MessageSizeEstimator)
public volatile io.netty.channel.socket.ServerSocketChannelConfig setWriteBufferLowWaterMark (int)
public volatile io.netty.channel.socket.ServerSocketChannelConfig setWriteBufferHighWaterMark (int)
public volatile io.netty.channel.socket.ServerSocketChannelConfig setAutoRead (boolean)
public volatile io.netty.channel.socket.ServerSocketChannelConfig setRecvByteBufAllocator (io.netty.channel.RecvByteBufAllocator)
public volatile io.netty.channel.socket.ServerSocketChannelConfig setAllocator (io.netty.buffer.ByteBufAllocator)
public volatile io.netty.channel.socket.ServerSocketChannelConfig setWriteSpinCount (int)
public volatile io.netty.channel.socket.ServerSocketChannelConfig setMaxMessagesPerRead (int)
public volatile io.netty.channel.socket.ServerSocketChannelConfig setConnectTimeoutMillis (int)
public volatile io.netty.channel.socket.ServerSocketChannelConfig setBacklog (int)
public volatile io.netty.channel.socket.ServerSocketChannelConfig setPerformancePreferences (int, int, int)
public volatile io.netty.channel.socket.ServerSocketChannelConfig setReceiveBufferSize (int)
public volatile io.netty.channel.socket.ServerSocketChannelConfig setReuseAddress (boolean)
public volatile io.netty.channel.ChannelConfig setMessageSizeEstimator (io.netty.channel.MessageSizeEstimator)
public volatile io.netty.channel.ChannelConfig setWriteBufferLowWaterMark (int)
public volatile io.netty.channel.ChannelConfig setWriteBufferHighWaterMark (int)
public volatile io.netty.channel.ChannelConfig setAutoClose (boolean)
public volatile io.netty.channel.ChannelConfig setAutoRead (boolean)
public volatile io.netty.channel.ChannelConfig setRecvByteBufAllocator (io.netty.channel.RecvByteBufAllocator)
public volatile io.netty.channel.ChannelConfig setAllocator (io.netty.buffer.ByteBufAllocator)
public volatile io.netty.channel.ChannelConfig setWriteSpinCount (int)
public volatile io.netty.channel.ChannelConfig setMaxMessagesPerRead (int)
public volatile io.netty.channel.ChannelConfig setConnectTimeoutMillis (int)
}
io/netty/channel/socket/oio/OioSocketChannel$1.classOioSocketChannel.java
package io.netty.channel.socket.oio
io.netty.channel.socket.oio.OioSocketChannel$1 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.ChannelPromise val$future
final io.netty.channel.socket.oio.OioSocketChannel this$0
void (io.netty.channel.socket.oio.OioSocketChannel, io.netty.channel.ChannelPromise)
public void run ()
}
io/netty/channel/socket/oio/OioSocketChannel.classOioSocketChannel.java
package io.netty.channel.socket.oio
public io.netty.channel.socket.oio.OioSocketChannel extends io.netty.channel.oio.OioByteStreamChannel implements io.netty.channel.socket.SocketChannel {
private static final io.netty.util.internal.logging.InternalLogger logger
private final java.net.Socket socket
private final io.netty.channel.socket.oio.OioSocketChannelConfig config
public void ()
public void (java.net.Socket)
java.net.Socket socket
public void (io.netty.channel.Channel, java.net.Socket)
java.io.IOException e
Exception e
java.io.IOException e
io.netty.channel.Channel parent
java.net.Socket socket
boolean success
public io.netty.channel.socket.ServerSocketChannel parent ()
public io.netty.channel.socket.oio.OioSocketChannelConfig config ()
public boolean isOpen ()
public boolean isActive ()
public boolean isInputShutdown ()
public boolean isOutputShutdown ()
public io.netty.channel.ChannelFuture shutdownOutput ()
protected int doReadBytes (io.netty.buffer.ByteBuf) throws java.lang.Exception
java.net.SocketTimeoutException ignored
io.netty.buffer.ByteBuf buf
public io.netty.channel.ChannelFuture shutdownOutput (io.netty.channel.ChannelPromise)
Throwable t
io.netty.channel.ChannelPromise future
io.netty.channel.EventLoop loop
public java.net.InetSocketAddress localAddress ()
public java.net.InetSocketAddress remoteAddress ()
protected java.net.SocketAddress localAddress0 ()
protected java.net.SocketAddress remoteAddress0 ()
protected void doBind (java.net.SocketAddress) throws java.lang.Exception
java.net.SocketAddress localAddress
protected void doConnect (java.net.SocketAddress, java.net.SocketAddress) throws java.lang.Exception
io.netty.channel.ConnectTimeoutException cause
java.net.SocketTimeoutException e
java.net.SocketAddress remoteAddress
java.net.SocketAddress localAddress
boolean success
protected void doDisconnect () throws java.lang.Exception
protected void doClose () throws java.lang.Exception
protected boolean checkInputShutdown ()
protected void setReadPending (boolean)
boolean readPending
public volatile java.net.SocketAddress remoteAddress ()
public volatile java.net.SocketAddress localAddress ()
public volatile io.netty.channel.Channel parent ()
public volatile io.netty.channel.ChannelConfig config ()
public volatile io.netty.channel.socket.SocketChannelConfig config ()
static void ()
}
io/netty/channel/socket/oio/OioServerSocketChannelConfig.classOioServerSocketChannelConfig.java
package io.netty.channel.socket.oio
public abstract io.netty.channel.socket.oio.OioServerSocketChannelConfig extends java.lang.Object implements io.netty.channel.socket.ServerSocketChannelConfig {
public abstract io.netty.channel.socket.oio.OioServerSocketChannelConfig setSoTimeout (int)
public abstract int getSoTimeout ()
public abstract io.netty.channel.socket.oio.OioServerSocketChannelConfig setBacklog (int)
public abstract io.netty.channel.socket.oio.OioServerSocketChannelConfig setReuseAddress (boolean)
public abstract io.netty.channel.socket.oio.OioServerSocketChannelConfig setReceiveBufferSize (int)
public abstract io.netty.channel.socket.oio.OioServerSocketChannelConfig setPerformancePreferences (int, int, int)
public abstract io.netty.channel.socket.oio.OioServerSocketChannelConfig setConnectTimeoutMillis (int)
public abstract io.netty.channel.socket.oio.OioServerSocketChannelConfig setMaxMessagesPerRead (int)
public abstract io.netty.channel.socket.oio.OioServerSocketChannelConfig setWriteSpinCount (int)
public abstract io.netty.channel.socket.oio.OioServerSocketChannelConfig setAllocator (io.netty.buffer.ByteBufAllocator)
public abstract io.netty.channel.socket.oio.OioServerSocketChannelConfig setRecvByteBufAllocator (io.netty.channel.RecvByteBufAllocator)
public abstract io.netty.channel.socket.oio.OioServerSocketChannelConfig setAutoRead (boolean)
public abstract io.netty.channel.socket.oio.OioServerSocketChannelConfig setAutoClose (boolean)
public abstract io.netty.channel.socket.oio.OioServerSocketChannelConfig setWriteBufferHighWaterMark (int)
public abstract io.netty.channel.socket.oio.OioServerSocketChannelConfig setWriteBufferLowWaterMark (int)
public abstract io.netty.channel.socket.oio.OioServerSocketChannelConfig setMessageSizeEstimator (io.netty.channel.MessageSizeEstimator)
}
io/netty/channel/socket/oio/OioSocketChannelConfig.classOioSocketChannelConfig.java
package io.netty.channel.socket.oio
public abstract io.netty.channel.socket.oio.OioSocketChannelConfig extends java.lang.Object implements io.netty.channel.socket.SocketChannelConfig {
public abstract io.netty.channel.socket.oio.OioSocketChannelConfig setSoTimeout (int)
public abstract int getSoTimeout ()
public abstract io.netty.channel.socket.oio.OioSocketChannelConfig setTcpNoDelay (boolean)
public abstract io.netty.channel.socket.oio.OioSocketChannelConfig setSoLinger (int)
public abstract io.netty.channel.socket.oio.OioSocketChannelConfig setSendBufferSize (int)
public abstract io.netty.channel.socket.oio.OioSocketChannelConfig setReceiveBufferSize (int)
public abstract io.netty.channel.socket.oio.OioSocketChannelConfig setKeepAlive (boolean)
public abstract io.netty.channel.socket.oio.OioSocketChannelConfig setTrafficClass (int)
public abstract io.netty.channel.socket.oio.OioSocketChannelConfig setReuseAddress (boolean)
public abstract io.netty.channel.socket.oio.OioSocketChannelConfig setPerformancePreferences (int, int, int)
public abstract io.netty.channel.socket.oio.OioSocketChannelConfig setAllowHalfClosure (boolean)
public abstract io.netty.channel.socket.oio.OioSocketChannelConfig setConnectTimeoutMillis (int)
public abstract io.netty.channel.socket.oio.OioSocketChannelConfig setMaxMessagesPerRead (int)
public abstract io.netty.channel.socket.oio.OioSocketChannelConfig setWriteSpinCount (int)
public abstract io.netty.channel.socket.oio.OioSocketChannelConfig setAllocator (io.netty.buffer.ByteBufAllocator)
public abstract io.netty.channel.socket.oio.OioSocketChannelConfig setRecvByteBufAllocator (io.netty.channel.RecvByteBufAllocator)
public abstract io.netty.channel.socket.oio.OioSocketChannelConfig setAutoRead (boolean)
public abstract io.netty.channel.socket.oio.OioSocketChannelConfig setAutoClose (boolean)
public abstract io.netty.channel.socket.oio.OioSocketChannelConfig setWriteBufferHighWaterMark (int)
public abstract io.netty.channel.socket.oio.OioSocketChannelConfig setWriteBufferLowWaterMark (int)
public abstract io.netty.channel.socket.oio.OioSocketChannelConfig setMessageSizeEstimator (io.netty.channel.MessageSizeEstimator)
}
io/netty/channel/socket/DefaultServerSocketChannelConfig.classDefaultServerSocketChannelConfig.java
package io.netty.channel.socket
public io.netty.channel.socket.DefaultServerSocketChannelConfig extends io.netty.channel.DefaultChannelConfig implements io.netty.channel.socket.ServerSocketChannelConfig {
protected final java.net.ServerSocket javaSocket
private volatile int backlog
public void (io.netty.channel.socket.ServerSocketChannel, java.net.ServerSocket)
io.netty.channel.socket.ServerSocketChannel channel
java.net.ServerSocket javaSocket
public java.util.Map getOptions ()
public java.lang.Object getOption (io.netty.channel.ChannelOption)
io.netty.channel.ChannelOption option
public boolean setOption (io.netty.channel.ChannelOption, java.lang.Object)
io.netty.channel.ChannelOption option
Object value
public boolean isReuseAddress ()
java.net.SocketException e
public io.netty.channel.socket.ServerSocketChannelConfig setReuseAddress (boolean)
java.net.SocketException e
boolean reuseAddress
public int getReceiveBufferSize ()
java.net.SocketException e
public io.netty.channel.socket.ServerSocketChannelConfig setReceiveBufferSize (int)
java.net.SocketException e
int receiveBufferSize
public io.netty.channel.socket.ServerSocketChannelConfig setPerformancePreferences (int, int, int)
int connectionTime
int latency
int bandwidth
public int getBacklog ()
public io.netty.channel.socket.ServerSocketChannelConfig setBacklog (int)
int backlog
public io.netty.channel.socket.ServerSocketChannelConfig setConnectTimeoutMillis (int)
int connectTimeoutMillis
public io.netty.channel.socket.ServerSocketChannelConfig setMaxMessagesPerRead (int)
int maxMessagesPerRead
public io.netty.channel.socket.ServerSocketChannelConfig setWriteSpinCount (int)
int writeSpinCount
public io.netty.channel.socket.ServerSocketChannelConfig setAllocator (io.netty.buffer.ByteBufAllocator)
io.netty.buffer.ByteBufAllocator allocator
public io.netty.channel.socket.ServerSocketChannelConfig setRecvByteBufAllocator (io.netty.channel.RecvByteBufAllocator)
io.netty.channel.RecvByteBufAllocator allocator
public io.netty.channel.socket.ServerSocketChannelConfig setAutoRead (boolean)
boolean autoRead
public io.netty.channel.socket.ServerSocketChannelConfig setWriteBufferHighWaterMark (int)
int writeBufferHighWaterMark
public io.netty.channel.socket.ServerSocketChannelConfig setWriteBufferLowWaterMark (int)
int writeBufferLowWaterMark
public io.netty.channel.socket.ServerSocketChannelConfig setMessageSizeEstimator (io.netty.channel.MessageSizeEstimator)
io.netty.channel.MessageSizeEstimator estimator
public volatile io.netty.channel.ChannelConfig setMessageSizeEstimator (io.netty.channel.MessageSizeEstimator)
public volatile io.netty.channel.ChannelConfig setWriteBufferLowWaterMark (int)
public volatile io.netty.channel.ChannelConfig setWriteBufferHighWaterMark (int)
public volatile io.netty.channel.ChannelConfig setAutoRead (boolean)
public volatile io.netty.channel.ChannelConfig setRecvByteBufAllocator (io.netty.channel.RecvByteBufAllocator)
public volatile io.netty.channel.ChannelConfig setAllocator (io.netty.buffer.ByteBufAllocator)
public volatile io.netty.channel.ChannelConfig setWriteSpinCount (int)
public volatile io.netty.channel.ChannelConfig setMaxMessagesPerRead (int)
public volatile io.netty.channel.ChannelConfig setConnectTimeoutMillis (int)
}
io/netty/channel/socket/SocketChannel.classSocketChannel.java
package io.netty.channel.socket
public abstract io.netty.channel.socket.SocketChannel extends java.lang.Object implements io.netty.channel.socket.DuplexChannel {
public abstract io.netty.channel.socket.ServerSocketChannel parent ()
public abstract io.netty.channel.socket.SocketChannelConfig config ()
public abstract java.net.InetSocketAddress localAddress ()
public abstract java.net.InetSocketAddress remoteAddress ()
}
io/netty/channel/socket/DefaultDatagramChannelConfig.classDefaultDatagramChannelConfig.java
package io.netty.channel.socket
public io.netty.channel.socket.DefaultDatagramChannelConfig extends io.netty.channel.DefaultChannelConfig implements io.netty.channel.socket.DatagramChannelConfig {
private static final io.netty.util.internal.logging.InternalLogger logger
private final java.net.DatagramSocket javaSocket
private volatile boolean activeOnOpen
public void (io.netty.channel.socket.DatagramChannel, java.net.DatagramSocket)
io.netty.channel.socket.DatagramChannel channel
java.net.DatagramSocket javaSocket
public java.util.Map getOptions ()
public java.lang.Object getOption (io.netty.channel.ChannelOption)
io.netty.channel.ChannelOption option
public boolean setOption (io.netty.channel.ChannelOption, java.lang.Object)
io.netty.channel.ChannelOption option
Object value
private void setActiveOnOpen (boolean)
boolean activeOnOpen
public boolean isBroadcast ()
java.net.SocketException e
public io.netty.channel.socket.DatagramChannelConfig setBroadcast (boolean)
java.net.SocketException e
boolean broadcast
public java.net.InetAddress getInterface ()
java.net.SocketException e
public io.netty.channel.socket.DatagramChannelConfig setInterface (java.net.InetAddress)
java.net.SocketException e
java.net.InetAddress interfaceAddress
public boolean isLoopbackModeDisabled ()
java.net.SocketException e
public io.netty.channel.socket.DatagramChannelConfig setLoopbackModeDisabled (boolean)
java.net.SocketException e
boolean loopbackModeDisabled
public java.net.NetworkInterface getNetworkInterface ()
java.net.SocketException e
public io.netty.channel.socket.DatagramChannelConfig setNetworkInterface (java.net.NetworkInterface)
java.net.SocketException e
java.net.NetworkInterface networkInterface
public boolean isReuseAddress ()
java.net.SocketException e
public io.netty.channel.socket.DatagramChannelConfig setReuseAddress (boolean)
java.net.SocketException e
boolean reuseAddress
public int getReceiveBufferSize ()
java.net.SocketException e
public io.netty.channel.socket.DatagramChannelConfig setReceiveBufferSize (int)
java.net.SocketException e
int receiveBufferSize
public int getSendBufferSize ()
java.net.SocketException e
public io.netty.channel.socket.DatagramChannelConfig setSendBufferSize (int)
java.net.SocketException e
int sendBufferSize
public int getTimeToLive ()
java.io.IOException e
public io.netty.channel.socket.DatagramChannelConfig setTimeToLive (int)
java.io.IOException e
int ttl
public int getTrafficClass ()
java.net.SocketException e
public io.netty.channel.socket.DatagramChannelConfig setTrafficClass (int)
java.net.SocketException e
int trafficClass
public io.netty.channel.socket.DatagramChannelConfig setWriteSpinCount (int)
int writeSpinCount
public io.netty.channel.socket.DatagramChannelConfig setConnectTimeoutMillis (int)
int connectTimeoutMillis
public io.netty.channel.socket.DatagramChannelConfig setMaxMessagesPerRead (int)
int maxMessagesPerRead
public io.netty.channel.socket.DatagramChannelConfig setAllocator (io.netty.buffer.ByteBufAllocator)
io.netty.buffer.ByteBufAllocator allocator
public io.netty.channel.socket.DatagramChannelConfig setRecvByteBufAllocator (io.netty.channel.RecvByteBufAllocator)
io.netty.channel.RecvByteBufAllocator allocator
public io.netty.channel.socket.DatagramChannelConfig setAutoRead (boolean)
boolean autoRead
public io.netty.channel.socket.DatagramChannelConfig setAutoClose (boolean)
boolean autoClose
public io.netty.channel.socket.DatagramChannelConfig setWriteBufferHighWaterMark (int)
int writeBufferHighWaterMark
public io.netty.channel.socket.DatagramChannelConfig setWriteBufferLowWaterMark (int)
int writeBufferLowWaterMark
public io.netty.channel.socket.DatagramChannelConfig setMessageSizeEstimator (io.netty.channel.MessageSizeEstimator)
io.netty.channel.MessageSizeEstimator estimator
public volatile io.netty.channel.ChannelConfig setMessageSizeEstimator (io.netty.channel.MessageSizeEstimator)
public volatile io.netty.channel.ChannelConfig setWriteBufferLowWaterMark (int)
public volatile io.netty.channel.ChannelConfig setWriteBufferHighWaterMark (int)
public volatile io.netty.channel.ChannelConfig setAutoClose (boolean)
public volatile io.netty.channel.ChannelConfig setAutoRead (boolean)
public volatile io.netty.channel.ChannelConfig setRecvByteBufAllocator (io.netty.channel.RecvByteBufAllocator)
public volatile io.netty.channel.ChannelConfig setAllocator (io.netty.buffer.ByteBufAllocator)
public volatile io.netty.channel.ChannelConfig setWriteSpinCount (int)
public volatile io.netty.channel.ChannelConfig setMaxMessagesPerRead (int)
public volatile io.netty.channel.ChannelConfig setConnectTimeoutMillis (int)
static void ()
}
io/netty/channel/socket/DatagramChannel.classDatagramChannel.java
package io.netty.channel.socket
public abstract io.netty.channel.socket.DatagramChannel extends java.lang.Object implements io.netty.channel.Channel {
public abstract io.netty.channel.socket.DatagramChannelConfig config ()
public abstract java.net.InetSocketAddress localAddress ()
public abstract java.net.InetSocketAddress remoteAddress ()
public abstract boolean isConnected ()
public abstract io.netty.channel.ChannelFuture joinGroup (java.net.InetAddress)
public abstract io.netty.channel.ChannelFuture joinGroup (java.net.InetAddress, io.netty.channel.ChannelPromise)
public abstract io.netty.channel.ChannelFuture joinGroup (java.net.InetSocketAddress, java.net.NetworkInterface)
public abstract io.netty.channel.ChannelFuture joinGroup (java.net.InetSocketAddress, java.net.NetworkInterface, io.netty.channel.ChannelPromise)
public abstract io.netty.channel.ChannelFuture joinGroup (java.net.InetAddress, java.net.NetworkInterface, java.net.InetAddress)
public abstract io.netty.channel.ChannelFuture joinGroup (java.net.InetAddress, java.net.NetworkInterface, java.net.InetAddress, io.netty.channel.ChannelPromise)
public abstract io.netty.channel.ChannelFuture leaveGroup (java.net.InetAddress)
public abstract io.netty.channel.ChannelFuture leaveGroup (java.net.InetAddress, io.netty.channel.ChannelPromise)
public abstract io.netty.channel.ChannelFuture leaveGroup (java.net.InetSocketAddress, java.net.NetworkInterface)
public abstract io.netty.channel.ChannelFuture leaveGroup (java.net.InetSocketAddress, java.net.NetworkInterface, io.netty.channel.ChannelPromise)
public abstract io.netty.channel.ChannelFuture leaveGroup (java.net.InetAddress, java.net.NetworkInterface, java.net.InetAddress)
public abstract io.netty.channel.ChannelFuture leaveGroup (java.net.InetAddress, java.net.NetworkInterface, java.net.InetAddress, io.netty.channel.ChannelPromise)
public abstract io.netty.channel.ChannelFuture block (java.net.InetAddress, java.net.NetworkInterface, java.net.InetAddress)
public abstract io.netty.channel.ChannelFuture block (java.net.InetAddress, java.net.NetworkInterface, java.net.InetAddress, io.netty.channel.ChannelPromise)
public abstract io.netty.channel.ChannelFuture block (java.net.InetAddress, java.net.InetAddress)
public abstract io.netty.channel.ChannelFuture block (java.net.InetAddress, java.net.InetAddress, io.netty.channel.ChannelPromise)
}
io/netty/channel/socket/DatagramPacket.classDatagramPacket.java
package io.netty.channel.socket
public final io.netty.channel.socket.DatagramPacket extends io.netty.channel.DefaultAddressedEnvelope implements io.netty.buffer.ByteBufHolder {
public void (io.netty.buffer.ByteBuf, java.net.InetSocketAddress)
io.netty.buffer.ByteBuf data
java.net.InetSocketAddress recipient
public void (io.netty.buffer.ByteBuf, java.net.InetSocketAddress, java.net.InetSocketAddress)
io.netty.buffer.ByteBuf data
java.net.InetSocketAddress recipient
java.net.InetSocketAddress sender
public io.netty.channel.socket.DatagramPacket copy ()
public io.netty.channel.socket.DatagramPacket duplicate ()
public io.netty.channel.socket.DatagramPacket retain ()
public io.netty.channel.socket.DatagramPacket retain (int)
int increment
public io.netty.channel.socket.DatagramPacket touch ()
public io.netty.channel.socket.DatagramPacket touch (java.lang.Object)
Object hint
public volatile io.netty.channel.AddressedEnvelope touch (java.lang.Object)
public volatile io.netty.channel.AddressedEnvelope touch ()
public volatile io.netty.channel.AddressedEnvelope retain (int)
public volatile io.netty.channel.AddressedEnvelope retain ()
public volatile io.netty.util.ReferenceCounted touch (java.lang.Object)
public volatile io.netty.util.ReferenceCounted touch ()
public volatile io.netty.util.ReferenceCounted retain (int)
public volatile io.netty.util.ReferenceCounted retain ()
public volatile io.netty.buffer.ByteBufHolder touch (java.lang.Object)
public volatile io.netty.buffer.ByteBufHolder touch ()
public volatile io.netty.buffer.ByteBufHolder retain (int)
public volatile io.netty.buffer.ByteBufHolder retain ()
public volatile io.netty.buffer.ByteBufHolder duplicate ()
public volatile io.netty.buffer.ByteBufHolder copy ()
public volatile io.netty.buffer.ByteBuf content ()
}
io/netty/channel/socket/DefaultSocketChannelConfig.classDefaultSocketChannelConfig.java
package io.netty.channel.socket
public io.netty.channel.socket.DefaultSocketChannelConfig extends io.netty.channel.DefaultChannelConfig implements io.netty.channel.socket.SocketChannelConfig {
protected final java.net.Socket javaSocket
private volatile boolean allowHalfClosure
public void (io.netty.channel.socket.SocketChannel, java.net.Socket)
io.netty.channel.socket.SocketChannel channel
java.net.Socket javaSocket
public java.util.Map getOptions ()
public java.lang.Object getOption (io.netty.channel.ChannelOption)
io.netty.channel.ChannelOption option
public boolean setOption (io.netty.channel.ChannelOption, java.lang.Object)
io.netty.channel.ChannelOption option
Object value
public int getReceiveBufferSize ()
java.net.SocketException e
public int getSendBufferSize ()
java.net.SocketException e
public int getSoLinger ()
java.net.SocketException e
public int getTrafficClass ()
java.net.SocketException e
public boolean isKeepAlive ()
java.net.SocketException e
public boolean isReuseAddress ()
java.net.SocketException e
public boolean isTcpNoDelay ()
java.net.SocketException e
public io.netty.channel.socket.SocketChannelConfig setKeepAlive (boolean)
java.net.SocketException e
boolean keepAlive
public io.netty.channel.socket.SocketChannelConfig setPerformancePreferences (int, int, int)
int connectionTime
int latency
int bandwidth
public io.netty.channel.socket.SocketChannelConfig setReceiveBufferSize (int)
java.net.SocketException e
int receiveBufferSize
public io.netty.channel.socket.SocketChannelConfig setReuseAddress (boolean)
java.net.SocketException e
boolean reuseAddress
public io.netty.channel.socket.SocketChannelConfig setSendBufferSize (int)
java.net.SocketException e
int sendBufferSize
public io.netty.channel.socket.SocketChannelConfig setSoLinger (int)
java.net.SocketException e
int soLinger
public io.netty.channel.socket.SocketChannelConfig setTcpNoDelay (boolean)
java.net.SocketException e
boolean tcpNoDelay
public io.netty.channel.socket.SocketChannelConfig setTrafficClass (int)
java.net.SocketException e
int trafficClass
public boolean isAllowHalfClosure ()
public io.netty.channel.socket.SocketChannelConfig setAllowHalfClosure (boolean)
boolean allowHalfClosure
public io.netty.channel.socket.SocketChannelConfig setConnectTimeoutMillis (int)
int connectTimeoutMillis
public io.netty.channel.socket.SocketChannelConfig setMaxMessagesPerRead (int)
int maxMessagesPerRead
public io.netty.channel.socket.SocketChannelConfig setWriteSpinCount (int)
int writeSpinCount
public io.netty.channel.socket.SocketChannelConfig setAllocator (io.netty.buffer.ByteBufAllocator)
io.netty.buffer.ByteBufAllocator allocator
public io.netty.channel.socket.SocketChannelConfig setRecvByteBufAllocator (io.netty.channel.RecvByteBufAllocator)
io.netty.channel.RecvByteBufAllocator allocator
public io.netty.channel.socket.SocketChannelConfig setAutoRead (boolean)
boolean autoRead
public io.netty.channel.socket.SocketChannelConfig setAutoClose (boolean)
boolean autoClose
public io.netty.channel.socket.SocketChannelConfig setWriteBufferHighWaterMark (int)
int writeBufferHighWaterMark
public io.netty.channel.socket.SocketChannelConfig setWriteBufferLowWaterMark (int)
int writeBufferLowWaterMark
public io.netty.channel.socket.SocketChannelConfig setMessageSizeEstimator (io.netty.channel.MessageSizeEstimator)
io.netty.channel.MessageSizeEstimator estimator
public volatile io.netty.channel.ChannelConfig setMessageSizeEstimator (io.netty.channel.MessageSizeEstimator)
public volatile io.netty.channel.ChannelConfig setWriteBufferLowWaterMark (int)
public volatile io.netty.channel.ChannelConfig setWriteBufferHighWaterMark (int)
public volatile io.netty.channel.ChannelConfig setAutoClose (boolean)
public volatile io.netty.channel.ChannelConfig setAutoRead (boolean)
public volatile io.netty.channel.ChannelConfig setRecvByteBufAllocator (io.netty.channel.RecvByteBufAllocator)
public volatile io.netty.channel.ChannelConfig setAllocator (io.netty.buffer.ByteBufAllocator)
public volatile io.netty.channel.ChannelConfig setWriteSpinCount (int)
public volatile io.netty.channel.ChannelConfig setMaxMessagesPerRead (int)
public volatile io.netty.channel.ChannelConfig setConnectTimeoutMillis (int)
}
io/netty/channel/socket/DuplexChannel.classDuplexChannel.java
package io.netty.channel.socket
public abstract io.netty.channel.socket.DuplexChannel extends java.lang.Object implements io.netty.channel.Channel {
public abstract boolean isInputShutdown ()
public abstract boolean isOutputShutdown ()
public abstract io.netty.channel.ChannelFuture shutdownOutput ()
public abstract io.netty.channel.ChannelFuture shutdownOutput (io.netty.channel.ChannelPromise)
}
io/netty/channel/socket/DatagramChannelConfig.classDatagramChannelConfig.java
package io.netty.channel.socket
public abstract io.netty.channel.socket.DatagramChannelConfig extends java.lang.Object implements io.netty.channel.ChannelConfig {
public abstract int getSendBufferSize ()
public abstract io.netty.channel.socket.DatagramChannelConfig setSendBufferSize (int)
public abstract int getReceiveBufferSize ()
public abstract io.netty.channel.socket.DatagramChannelConfig setReceiveBufferSize (int)
public abstract int getTrafficClass ()
public abstract io.netty.channel.socket.DatagramChannelConfig setTrafficClass (int)
public abstract boolean isReuseAddress ()
public abstract io.netty.channel.socket.DatagramChannelConfig setReuseAddress (boolean)
public abstract boolean isBroadcast ()
public abstract io.netty.channel.socket.DatagramChannelConfig setBroadcast (boolean)
public abstract boolean isLoopbackModeDisabled ()
public abstract io.netty.channel.socket.DatagramChannelConfig setLoopbackModeDisabled (boolean)
public abstract int getTimeToLive ()
public abstract io.netty.channel.socket.DatagramChannelConfig setTimeToLive (int)
public abstract java.net.InetAddress getInterface ()
public abstract io.netty.channel.socket.DatagramChannelConfig setInterface (java.net.InetAddress)
public abstract java.net.NetworkInterface getNetworkInterface ()
public abstract io.netty.channel.socket.DatagramChannelConfig setNetworkInterface (java.net.NetworkInterface)
public abstract io.netty.channel.socket.DatagramChannelConfig setMaxMessagesPerRead (int)
public abstract io.netty.channel.socket.DatagramChannelConfig setWriteSpinCount (int)
public abstract io.netty.channel.socket.DatagramChannelConfig setConnectTimeoutMillis (int)
public abstract io.netty.channel.socket.DatagramChannelConfig setAllocator (io.netty.buffer.ByteBufAllocator)
public abstract io.netty.channel.socket.DatagramChannelConfig setRecvByteBufAllocator (io.netty.channel.RecvByteBufAllocator)
public abstract io.netty.channel.socket.DatagramChannelConfig setAutoRead (boolean)
public abstract io.netty.channel.socket.DatagramChannelConfig setAutoClose (boolean)
public abstract io.netty.channel.socket.DatagramChannelConfig setMessageSizeEstimator (io.netty.channel.MessageSizeEstimator)
}
io/netty/channel/socket/ServerSocketChannel.classServerSocketChannel.java
package io.netty.channel.socket
public abstract io.netty.channel.socket.ServerSocketChannel extends java.lang.Object implements io.netty.channel.ServerChannel {
public abstract io.netty.channel.socket.ServerSocketChannelConfig config ()
public abstract java.net.InetSocketAddress localAddress ()
public abstract java.net.InetSocketAddress remoteAddress ()
}
io/netty/channel/socket/InternetProtocolFamily.classInternetProtocolFamily.java
package io.netty.channel.socket
public final io.netty.channel.socket.InternetProtocolFamily extends java.lang.Enum {
public static final io.netty.channel.socket.InternetProtocolFamily IPv4
public static final io.netty.channel.socket.InternetProtocolFamily IPv6
private final Class addressType
private static final io.netty.channel.socket.InternetProtocolFamily[] $VALUES
public static io.netty.channel.socket.InternetProtocolFamily[] values ()
public static io.netty.channel.socket.InternetProtocolFamily valueOf (java.lang.String)
String name
private void (java.lang.String, int, java.lang.Class)
Class addressType
public java.lang.Class addressType ()
static void ()
}
io/netty/channel/socket/SocketChannelConfig.classSocketChannelConfig.java
package io.netty.channel.socket
public abstract io.netty.channel.socket.SocketChannelConfig extends java.lang.Object implements io.netty.channel.ChannelConfig {
public abstract boolean isTcpNoDelay ()
public abstract io.netty.channel.socket.SocketChannelConfig setTcpNoDelay (boolean)
public abstract int getSoLinger ()
public abstract io.netty.channel.socket.SocketChannelConfig setSoLinger (int)
public abstract int getSendBufferSize ()
public abstract io.netty.channel.socket.SocketChannelConfig setSendBufferSize (int)
public abstract int getReceiveBufferSize ()
public abstract io.netty.channel.socket.SocketChannelConfig setReceiveBufferSize (int)
public abstract boolean isKeepAlive ()
public abstract io.netty.channel.socket.SocketChannelConfig setKeepAlive (boolean)
public abstract int getTrafficClass ()
public abstract io.netty.channel.socket.SocketChannelConfig setTrafficClass (int)
public abstract boolean isReuseAddress ()
public abstract io.netty.channel.socket.SocketChannelConfig setReuseAddress (boolean)
public abstract io.netty.channel.socket.SocketChannelConfig setPerformancePreferences (int, int, int)
public abstract boolean isAllowHalfClosure ()
public abstract io.netty.channel.socket.SocketChannelConfig setAllowHalfClosure (boolean)
public abstract io.netty.channel.socket.SocketChannelConfig setConnectTimeoutMillis (int)
public abstract io.netty.channel.socket.SocketChannelConfig setMaxMessagesPerRead (int)
public abstract io.netty.channel.socket.SocketChannelConfig setWriteSpinCount (int)
public abstract io.netty.channel.socket.SocketChannelConfig setAllocator (io.netty.buffer.ByteBufAllocator)
public abstract io.netty.channel.socket.SocketChannelConfig setRecvByteBufAllocator (io.netty.channel.RecvByteBufAllocator)
public abstract io.netty.channel.socket.SocketChannelConfig setAutoRead (boolean)
public abstract io.netty.channel.socket.SocketChannelConfig setAutoClose (boolean)
public abstract io.netty.channel.socket.SocketChannelConfig setMessageSizeEstimator (io.netty.channel.MessageSizeEstimator)
}
io/netty/channel/socket/nio/NioSocketChannel$1.classNioSocketChannel.java
package io.netty.channel.socket.nio
io.netty.channel.socket.nio.NioSocketChannel$1 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.ChannelPromise val$promise
final io.netty.channel.socket.nio.NioSocketChannel this$0
void (io.netty.channel.socket.nio.NioSocketChannel, io.netty.channel.ChannelPromise)
public void run ()
}
io/netty/channel/socket/nio/NioSocketChannel$2.classNioSocketChannel.java
package io.netty.channel.socket.nio
io.netty.channel.socket.nio.NioSocketChannel$2 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.ChannelPromise val$promise
final io.netty.channel.socket.nio.NioSocketChannel this$0
void (io.netty.channel.socket.nio.NioSocketChannel, io.netty.channel.ChannelPromise)
public void run ()
}
io/netty/channel/socket/nio/NioDatagramChannelConfig.classNioDatagramChannelConfig.java
package io.netty.channel.socket.nio
io.netty.channel.socket.nio.NioDatagramChannelConfig extends io.netty.channel.socket.DefaultDatagramChannelConfig {
private static final Object IP_MULTICAST_TTL
private static final Object IP_MULTICAST_IF
private static final Object IP_MULTICAST_LOOP
private static final java.lang.reflect.Method GET_OPTION
private static final java.lang.reflect.Method SET_OPTION
private final java.nio.channels.DatagramChannel javaChannel
void (io.netty.channel.socket.nio.NioDatagramChannel, java.nio.channels.DatagramChannel)
io.netty.channel.socket.nio.NioDatagramChannel channel
java.nio.channels.DatagramChannel javaChannel
public int getTimeToLive ()
public io.netty.channel.socket.DatagramChannelConfig setTimeToLive (int)
int ttl
public java.net.InetAddress getInterface ()
java.util.Enumeration addresses
java.net.NetworkInterface inf
public io.netty.channel.socket.DatagramChannelConfig setInterface (java.net.InetAddress)
java.net.SocketException e
java.net.InetAddress interfaceAddress
public java.net.NetworkInterface getNetworkInterface ()
public io.netty.channel.socket.DatagramChannelConfig setNetworkInterface (java.net.NetworkInterface)
java.net.NetworkInterface networkInterface
public boolean isLoopbackModeDisabled ()
public io.netty.channel.socket.DatagramChannelConfig setLoopbackModeDisabled (boolean)
boolean loopbackModeDisabled
public io.netty.channel.socket.DatagramChannelConfig setAutoRead (boolean)
boolean autoRead
protected void autoReadCleared ()
private java.lang.Object getOption0 (java.lang.Object)
Exception e
Object option
private void setOption0 (java.lang.Object, java.lang.Object)
Exception e
Object option
Object value
public volatile io.netty.channel.ChannelConfig setAutoRead (boolean)
static void ()
Exception e
Exception e
Exception e
Exception e
Exception e
ClassLoader classLoader
Class socketOptionType
Class stdSocketOptionType
Object ipMulticastTtl
Object ipMulticastIf
Object ipMulticastLoop
java.lang.reflect.Method getOption
java.lang.reflect.Method setOption
}
io/netty/channel/socket/nio/NioServerSocketChannel.classNioServerSocketChannel.java
package io.netty.channel.socket.nio
public io.netty.channel.socket.nio.NioServerSocketChannel extends io.netty.channel.nio.AbstractNioMessageChannel implements io.netty.channel.socket.ServerSocketChannel {
private static final io.netty.channel.ChannelMetadata METADATA
private static final java.nio.channels.spi.SelectorProvider DEFAULT_SELECTOR_PROVIDER
private static final io.netty.util.internal.logging.InternalLogger logger
private final io.netty.channel.socket.ServerSocketChannelConfig config
private static java.nio.channels.ServerSocketChannel newSocket (java.nio.channels.spi.SelectorProvider)
java.io.IOException e
java.nio.channels.spi.SelectorProvider provider
public void ()
public void (java.nio.channels.spi.SelectorProvider)
java.nio.channels.spi.SelectorProvider provider
public void (java.nio.channels.ServerSocketChannel)
java.nio.channels.ServerSocketChannel channel
public java.net.InetSocketAddress localAddress ()
public io.netty.channel.ChannelMetadata metadata ()
public io.netty.channel.socket.ServerSocketChannelConfig config ()
public boolean isActive ()
public java.net.InetSocketAddress remoteAddress ()
protected java.nio.channels.ServerSocketChannel javaChannel ()
protected java.net.SocketAddress localAddress0 ()
protected void doBind (java.net.SocketAddress) throws java.lang.Exception
java.net.SocketAddress localAddress
protected void doClose () throws java.lang.Exception
protected int doReadMessages (java.util.List) throws java.lang.Exception
Throwable t2
Throwable t
java.util.List buf
java.nio.channels.SocketChannel ch
protected boolean doConnect (java.net.SocketAddress, java.net.SocketAddress) throws java.lang.Exception
java.net.SocketAddress remoteAddress
java.net.SocketAddress localAddress
protected void doFinishConnect () throws java.lang.Exception
protected java.net.SocketAddress remoteAddress0 ()
protected void doDisconnect () throws java.lang.Exception
protected boolean doWriteMessage (java.lang.Object, io.netty.channel.ChannelOutboundBuffer) throws java.lang.Exception
Object msg
io.netty.channel.ChannelOutboundBuffer in
protected final java.lang.Object filterOutboundMessage (java.lang.Object) throws java.lang.Exception
Object msg
protected volatile java.nio.channels.SelectableChannel javaChannel ()
public volatile java.net.SocketAddress remoteAddress ()
public volatile java.net.SocketAddress localAddress ()
public volatile io.netty.channel.ChannelConfig config ()
static void access$100 (io.netty.channel.socket.nio.NioServerSocketChannel, boolean)
io.netty.channel.socket.nio.NioServerSocketChannel x0
boolean x1
static void ()
}
io/netty/channel/socket/nio/NioServerSocketChannel$1.classNioServerSocketChannel.java
package io.netty.channel.socket.nio
io.netty.channel.socket.nio.NioServerSocketChannel$1 extends java.lang.Object {
}
io/netty/channel/socket/nio/NioSocketChannel$NioSocketChannelUnsafe.classNioSocketChannel.java
package io.netty.channel.socket.nio
final io.netty.channel.socket.nio.NioSocketChannel$NioSocketChannelUnsafe extends io.netty.channel.nio.AbstractNioByteChannel$NioByteUnsafe {
final io.netty.channel.socket.nio.NioSocketChannel this$0
private void (io.netty.channel.socket.nio.NioSocketChannel)
protected java.util.concurrent.Executor prepareToClose ()
void (io.netty.channel.socket.nio.NioSocketChannel, io.netty.channel.socket.nio.NioSocketChannel$1)
io.netty.channel.socket.nio.NioSocketChannel x0
io.netty.channel.socket.nio.NioSocketChannel$1 x1
}
io/netty/channel/socket/nio/ProtocolFamilyConverter$1.classProtocolFamilyConverter.java
package io.netty.channel.socket.nio
io.netty.channel.socket.nio.ProtocolFamilyConverter$1 extends java.lang.Object {
static final int[] $SwitchMap$io$netty$channel$socket$InternetProtocolFamily
static void ()
}
io/netty/channel/socket/nio/NioDatagramChannel.classNioDatagramChannel.java
package io.netty.channel.socket.nio
public final io.netty.channel.socket.nio.NioDatagramChannel extends io.netty.channel.nio.AbstractNioMessageChannel implements io.netty.channel.socket.DatagramChannel {
private static final io.netty.channel.ChannelMetadata METADATA
private static final java.nio.channels.spi.SelectorProvider DEFAULT_SELECTOR_PROVIDER
private static final String EXPECTED_TYPES
private final io.netty.channel.socket.DatagramChannelConfig config
private java.util.Map memberships
private static java.nio.channels.DatagramChannel newSocket (java.nio.channels.spi.SelectorProvider)
java.io.IOException e
java.nio.channels.spi.SelectorProvider provider
private static java.nio.channels.DatagramChannel newSocket (java.nio.channels.spi.SelectorProvider, io.netty.channel.socket.InternetProtocolFamily)
java.io.IOException e
java.nio.channels.spi.SelectorProvider provider
io.netty.channel.socket.InternetProtocolFamily ipFamily
private static void checkJavaVersion ()
public void ()
public void (java.nio.channels.spi.SelectorProvider)
java.nio.channels.spi.SelectorProvider provider
public void (io.netty.channel.socket.InternetProtocolFamily)
io.netty.channel.socket.InternetProtocolFamily ipFamily
public void (java.nio.channels.spi.SelectorProvider, io.netty.channel.socket.InternetProtocolFamily)
java.nio.channels.spi.SelectorProvider provider
io.netty.channel.socket.InternetProtocolFamily ipFamily
public void (java.nio.channels.DatagramChannel)
java.nio.channels.DatagramChannel socket
public io.netty.channel.ChannelMetadata metadata ()
public io.netty.channel.socket.DatagramChannelConfig config ()
public boolean isActive ()
java.nio.channels.DatagramChannel ch
public boolean isConnected ()
protected java.nio.channels.DatagramChannel javaChannel ()
protected java.net.SocketAddress localAddress0 ()
protected java.net.SocketAddress remoteAddress0 ()
protected void doBind (java.net.SocketAddress) throws java.lang.Exception
java.net.SocketAddress localAddress
protected boolean doConnect (java.net.SocketAddress, java.net.SocketAddress) throws java.lang.Exception
java.net.SocketAddress remoteAddress
java.net.SocketAddress localAddress
boolean success
protected void doFinishConnect () throws java.lang.Exception
protected void doDisconnect () throws java.lang.Exception
protected void doClose () throws java.lang.Exception
protected int doReadMessages (java.util.List) throws java.lang.Exception
java.nio.ByteBuffer nioData
int pos
java.net.InetSocketAddress remoteAddress
Throwable cause
java.util.List buf
java.nio.channels.DatagramChannel ch
io.netty.channel.socket.DatagramChannelConfig config
io.netty.channel.RecvByteBufAllocator$Handle allocHandle
io.netty.buffer.ByteBuf data
boolean free
protected boolean doWriteMessage (java.lang.Object, io.netty.channel.ChannelOutboundBuffer) throws java.lang.Exception
io.netty.channel.AddressedEnvelope envelope
java.net.SocketAddress remoteAddress
io.netty.buffer.ByteBuf data
int writtenBytes
Object msg
io.netty.channel.ChannelOutboundBuffer in
java.net.SocketAddress remoteAddress
io.netty.buffer.ByteBuf data
int dataLen
java.nio.ByteBuffer nioData
int writtenBytes
protected java.lang.Object filterOutboundMessage (java.lang.Object)
io.netty.channel.socket.DatagramPacket p
io.netty.buffer.ByteBuf content
io.netty.buffer.ByteBuf buf
io.netty.buffer.ByteBuf content
io.netty.channel.AddressedEnvelope e
Object msg
private static boolean isSingleDirectBuffer (io.netty.buffer.ByteBuf)
io.netty.buffer.ByteBuf buf
protected boolean continueOnWriteError ()
public java.net.InetSocketAddress localAddress ()
public java.net.InetSocketAddress remoteAddress ()
public io.netty.channel.ChannelFuture joinGroup (java.net.InetAddress)
java.net.InetAddress multicastAddress
public io.netty.channel.ChannelFuture joinGroup (java.net.InetAddress, io.netty.channel.ChannelPromise)
java.net.SocketException e
java.net.InetAddress multicastAddress
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelFuture joinGroup (java.net.InetSocketAddress, java.net.NetworkInterface)
java.net.InetSocketAddress multicastAddress
java.net.NetworkInterface networkInterface
public io.netty.channel.ChannelFuture joinGroup (java.net.InetSocketAddress, java.net.NetworkInterface, io.netty.channel.ChannelPromise)
java.net.InetSocketAddress multicastAddress
java.net.NetworkInterface networkInterface
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelFuture joinGroup (java.net.InetAddress, java.net.NetworkInterface, java.net.InetAddress)
java.net.InetAddress multicastAddress
java.net.NetworkInterface networkInterface
java.net.InetAddress source
public io.netty.channel.ChannelFuture joinGroup (java.net.InetAddress, java.net.NetworkInterface, java.net.InetAddress, io.netty.channel.ChannelPromise)
java.nio.channels.MembershipKey key
java.util.List keys
java.nio.channels.MembershipKey key
Throwable e
java.net.InetAddress multicastAddress
java.net.NetworkInterface networkInterface
java.net.InetAddress source
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelFuture leaveGroup (java.net.InetAddress)
java.net.InetAddress multicastAddress
public io.netty.channel.ChannelFuture leaveGroup (java.net.InetAddress, io.netty.channel.ChannelPromise)
java.net.SocketException e
java.net.InetAddress multicastAddress
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelFuture leaveGroup (java.net.InetSocketAddress, java.net.NetworkInterface)
java.net.InetSocketAddress multicastAddress
java.net.NetworkInterface networkInterface
public io.netty.channel.ChannelFuture leaveGroup (java.net.InetSocketAddress, java.net.NetworkInterface, io.netty.channel.ChannelPromise)
java.net.InetSocketAddress multicastAddress
java.net.NetworkInterface networkInterface
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelFuture leaveGroup (java.net.InetAddress, java.net.NetworkInterface, java.net.InetAddress)
java.net.InetAddress multicastAddress
java.net.NetworkInterface networkInterface
java.net.InetAddress source
public io.netty.channel.ChannelFuture leaveGroup (java.net.InetAddress, java.net.NetworkInterface, java.net.InetAddress, io.netty.channel.ChannelPromise)
java.nio.channels.MembershipKey key
java.util.Iterator keyIt
java.util.List keys
java.net.InetAddress multicastAddress
java.net.NetworkInterface networkInterface
java.net.InetAddress source
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelFuture block (java.net.InetAddress, java.net.NetworkInterface, java.net.InetAddress)
java.net.InetAddress multicastAddress
java.net.NetworkInterface networkInterface
java.net.InetAddress sourceToBlock
public io.netty.channel.ChannelFuture block (java.net.InetAddress, java.net.NetworkInterface, java.net.InetAddress, io.netty.channel.ChannelPromise)
java.io.IOException e
java.nio.channels.MembershipKey key
java.util.Iterator i$
java.util.List keys
java.net.InetAddress multicastAddress
java.net.NetworkInterface networkInterface
java.net.InetAddress sourceToBlock
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelFuture block (java.net.InetAddress, java.net.InetAddress)
java.net.InetAddress multicastAddress
java.net.InetAddress sourceToBlock
public io.netty.channel.ChannelFuture block (java.net.InetAddress, java.net.InetAddress, io.netty.channel.ChannelPromise)
java.net.SocketException e
java.net.InetAddress multicastAddress
java.net.InetAddress sourceToBlock
io.netty.channel.ChannelPromise promise
protected void setReadPending (boolean)
boolean readPending
protected volatile java.nio.channels.SelectableChannel javaChannel ()
public volatile java.net.SocketAddress remoteAddress ()
public volatile java.net.SocketAddress localAddress ()
public volatile io.netty.channel.ChannelConfig config ()
static void ()
}
io/netty/channel/socket/nio/NioSocketChannel.classNioSocketChannel.java
package io.netty.channel.socket.nio
public io.netty.channel.socket.nio.NioSocketChannel extends io.netty.channel.nio.AbstractNioByteChannel implements io.netty.channel.socket.SocketChannel {
private static final io.netty.channel.ChannelMetadata METADATA
private static final java.nio.channels.spi.SelectorProvider DEFAULT_SELECTOR_PROVIDER
private final io.netty.channel.socket.SocketChannelConfig config
private static java.nio.channels.SocketChannel newSocket (java.nio.channels.spi.SelectorProvider)
java.io.IOException e
java.nio.channels.spi.SelectorProvider provider
public void ()
public void (java.nio.channels.spi.SelectorProvider)
java.nio.channels.spi.SelectorProvider provider
public void (java.nio.channels.SocketChannel)
java.nio.channels.SocketChannel socket
public void (io.netty.channel.Channel, java.nio.channels.SocketChannel)
io.netty.channel.Channel parent
java.nio.channels.SocketChannel socket
public io.netty.channel.socket.ServerSocketChannel parent ()
public io.netty.channel.ChannelMetadata metadata ()
public io.netty.channel.socket.SocketChannelConfig config ()
protected java.nio.channels.SocketChannel javaChannel ()
public boolean isActive ()
java.nio.channels.SocketChannel ch
public boolean isInputShutdown ()
public java.net.InetSocketAddress localAddress ()
public java.net.InetSocketAddress remoteAddress ()
public boolean isOutputShutdown ()
public io.netty.channel.ChannelFuture shutdownOutput ()
public io.netty.channel.ChannelFuture shutdownOutput (io.netty.channel.ChannelPromise)
io.netty.channel.EventLoop loop
io.netty.channel.ChannelPromise promise
java.util.concurrent.Executor closeExecutor
private void shutdownOutput0 (io.netty.channel.ChannelPromise)
Throwable t
io.netty.channel.ChannelPromise promise
protected java.net.SocketAddress localAddress0 ()
protected java.net.SocketAddress remoteAddress0 ()
protected void doBind (java.net.SocketAddress) throws java.lang.Exception
java.net.SocketAddress localAddress
protected boolean doConnect (java.net.SocketAddress, java.net.SocketAddress) throws java.lang.Exception
boolean connected
java.net.SocketAddress remoteAddress
java.net.SocketAddress localAddress
boolean success
protected void doFinishConnect () throws java.lang.Exception
protected void doDisconnect () throws java.lang.Exception
protected void doClose () throws java.lang.Exception
protected int doReadBytes (io.netty.buffer.ByteBuf) throws java.lang.Exception
io.netty.buffer.ByteBuf byteBuf
io.netty.channel.RecvByteBufAllocator$Handle allocHandle
protected int doWriteBytes (io.netty.buffer.ByteBuf) throws java.lang.Exception
io.netty.buffer.ByteBuf buf
int expectedWrittenBytes
protected long doWriteFileRegion (io.netty.channel.FileRegion) throws java.lang.Exception
io.netty.channel.FileRegion region
long position
protected void doWrite (io.netty.channel.ChannelOutboundBuffer) throws java.lang.Exception
int localWrittenBytes
int i
java.nio.ByteBuffer nioBuffer
long localWrittenBytes
int i
int size
long writtenBytes
boolean done
boolean setOpWrite
java.nio.ByteBuffer[] nioBuffers
int nioBufferCnt
long expectedWrittenBytes
java.nio.channels.SocketChannel ch
io.netty.channel.ChannelOutboundBuffer in
protected io.netty.channel.nio.AbstractNioChannel$AbstractNioUnsafe newUnsafe ()
protected volatile java.nio.channels.SelectableChannel javaChannel ()
protected volatile io.netty.channel.AbstractChannel$AbstractUnsafe newUnsafe ()
public volatile java.net.SocketAddress remoteAddress ()
public volatile java.net.SocketAddress localAddress ()
public volatile io.netty.channel.Channel parent ()
public volatile io.netty.channel.ChannelConfig config ()
static void access$100 (io.netty.channel.socket.nio.NioSocketChannel, io.netty.channel.ChannelPromise)
io.netty.channel.socket.nio.NioSocketChannel x0
io.netty.channel.ChannelPromise x1
static void access$300 (io.netty.channel.socket.nio.NioSocketChannel) throws java.lang.Exception
io.netty.channel.socket.nio.NioSocketChannel x0
static void access$400 (io.netty.channel.socket.nio.NioSocketChannel, boolean)
io.netty.channel.socket.nio.NioSocketChannel x0
boolean x1
static void ()
}
io/netty/channel/socket/nio/ProtocolFamilyConverter.classProtocolFamilyConverter.java
package io.netty.channel.socket.nio
final io.netty.channel.socket.nio.ProtocolFamilyConverter extends java.lang.Object {
private void ()
public static java.net.ProtocolFamily convert (io.netty.channel.socket.InternetProtocolFamily)
io.netty.channel.socket.InternetProtocolFamily family
}
io/netty/channel/socket/nio/NioSocketChannel$NioSocketChannelConfig.classNioSocketChannel.java
package io.netty.channel.socket.nio
final io.netty.channel.socket.nio.NioSocketChannel$NioSocketChannelConfig extends io.netty.channel.socket.DefaultSocketChannelConfig {
final io.netty.channel.socket.nio.NioSocketChannel this$0
private void (io.netty.channel.socket.nio.NioSocketChannel, io.netty.channel.socket.nio.NioSocketChannel, java.net.Socket)
io.netty.channel.socket.nio.NioSocketChannel channel
java.net.Socket javaSocket
protected void autoReadCleared ()
void (io.netty.channel.socket.nio.NioSocketChannel, io.netty.channel.socket.nio.NioSocketChannel, java.net.Socket, io.netty.channel.socket.nio.NioSocketChannel$1)
io.netty.channel.socket.nio.NioSocketChannel x0
io.netty.channel.socket.nio.NioSocketChannel x1
java.net.Socket x2
io.netty.channel.socket.nio.NioSocketChannel$1 x3
}
io/netty/channel/socket/nio/NioServerSocketChannel$NioServerSocketChannelConfig.classNioServerSocketChannel.java
package io.netty.channel.socket.nio
final io.netty.channel.socket.nio.NioServerSocketChannel$NioServerSocketChannelConfig extends io.netty.channel.socket.DefaultServerSocketChannelConfig {
final io.netty.channel.socket.nio.NioServerSocketChannel this$0
private void (io.netty.channel.socket.nio.NioServerSocketChannel, io.netty.channel.socket.nio.NioServerSocketChannel, java.net.ServerSocket)
io.netty.channel.socket.nio.NioServerSocketChannel channel
java.net.ServerSocket javaSocket
protected void autoReadCleared ()
void (io.netty.channel.socket.nio.NioServerSocketChannel, io.netty.channel.socket.nio.NioServerSocketChannel, java.net.ServerSocket, io.netty.channel.socket.nio.NioServerSocketChannel$1)
io.netty.channel.socket.nio.NioServerSocketChannel x0
io.netty.channel.socket.nio.NioServerSocketChannel x1
java.net.ServerSocket x2
io.netty.channel.socket.nio.NioServerSocketChannel$1 x3
}
io/netty/channel/ConnectTimeoutException.classConnectTimeoutException.java
package io.netty.channel
public io.netty.channel.ConnectTimeoutException extends java.net.ConnectException {
private static final long serialVersionUID
public void (java.lang.String)
String msg
public void ()
}
io/netty/channel/DefaultMaxBytesRecvByteBufAllocator.classDefaultMaxBytesRecvByteBufAllocator.java
package io.netty.channel
public io.netty.channel.DefaultMaxBytesRecvByteBufAllocator extends java.lang.Object implements io.netty.channel.MaxBytesRecvByteBufAllocator {
private volatile int maxBytesPerRead
private volatile int maxBytesPerIndividualRead
public void ()
public void (int, int)
int maxBytesPerRead
int maxBytesPerIndividualRead
public io.netty.channel.RecvByteBufAllocator$Handle newHandle ()
public int maxBytesPerRead ()
public io.netty.channel.DefaultMaxBytesRecvByteBufAllocator maxBytesPerRead (int)
int maxBytesPerIndividualRead
int maxBytesPerRead
public int maxBytesPerIndividualRead ()
public io.netty.channel.DefaultMaxBytesRecvByteBufAllocator maxBytesPerIndividualRead (int)
int maxBytesPerRead
int maxBytesPerIndividualRead
public synchronized java.util.Map$Entry maxBytesPerReadPair ()
private void checkMaxBytesPerReadPair (int, int)
int maxBytesPerRead
int maxBytesPerIndividualRead
public io.netty.channel.DefaultMaxBytesRecvByteBufAllocator maxBytesPerReadPair (int, int)
int maxBytesPerRead
int maxBytesPerIndividualRead
public volatile io.netty.channel.MaxBytesRecvByteBufAllocator maxBytesPerReadPair (int, int)
public volatile io.netty.channel.MaxBytesRecvByteBufAllocator maxBytesPerIndividualRead (int)
public volatile io.netty.channel.MaxBytesRecvByteBufAllocator maxBytesPerRead (int)
}
io/netty/channel/MessageSizeEstimator$Handle.classMessageSizeEstimator.java
package io.netty.channel
public abstract io.netty.channel.MessageSizeEstimator$Handle extends java.lang.Object {
public abstract int size (java.lang.Object)
}
io/netty/channel/DefaultChannelHandlerInvoker.classDefaultChannelHandlerInvoker.java
package io.netty.channel
public io.netty.channel.DefaultChannelHandlerInvoker extends java.lang.Object implements io.netty.channel.ChannelHandlerInvoker {
private final io.netty.util.concurrent.EventExecutor executor
public void (io.netty.util.concurrent.EventExecutor)
io.netty.util.concurrent.EventExecutor executor
public io.netty.util.concurrent.EventExecutor executor ()
public void invokeChannelRegistered (io.netty.channel.ChannelHandlerContext)
io.netty.channel.ChannelHandlerContext ctx
public void invokeChannelUnregistered (io.netty.channel.ChannelHandlerContext)
io.netty.channel.ChannelHandlerContext ctx
public void invokeChannelActive (io.netty.channel.ChannelHandlerContext)
io.netty.channel.ChannelHandlerContext ctx
public void invokeChannelInactive (io.netty.channel.ChannelHandlerContext)
io.netty.channel.ChannelHandlerContext ctx
public void invokeExceptionCaught (io.netty.channel.ChannelHandlerContext, java.lang.Throwable)
Throwable t
io.netty.channel.ChannelHandlerContext ctx
Throwable cause
public void invokeUserEventTriggered (io.netty.channel.ChannelHandlerContext, java.lang.Object)
io.netty.channel.ChannelHandlerContext ctx
Object event
public void invokeChannelRead (io.netty.channel.ChannelHandlerContext, java.lang.Object)
io.netty.channel.ChannelHandlerContext ctx
Object msg
public void invokeChannelReadComplete (io.netty.channel.ChannelHandlerContext)
io.netty.channel.AbstractChannelHandlerContext dctx
Runnable task
io.netty.channel.ChannelHandlerContext ctx
public void invokeChannelWritabilityChanged (io.netty.channel.ChannelHandlerContext)
io.netty.channel.AbstractChannelHandlerContext dctx
Runnable task
io.netty.channel.ChannelHandlerContext ctx
public void invokeBind (io.netty.channel.ChannelHandlerContext, java.net.SocketAddress, io.netty.channel.ChannelPromise)
io.netty.channel.ChannelHandlerContext ctx
java.net.SocketAddress localAddress
io.netty.channel.ChannelPromise promise
public void invokeConnect (io.netty.channel.ChannelHandlerContext, java.net.SocketAddress, java.net.SocketAddress, io.netty.channel.ChannelPromise)
io.netty.channel.ChannelHandlerContext ctx
java.net.SocketAddress remoteAddress
java.net.SocketAddress localAddress
io.netty.channel.ChannelPromise promise
public void invokeDisconnect (io.netty.channel.ChannelHandlerContext, io.netty.channel.ChannelPromise)
io.netty.channel.ChannelHandlerContext ctx
io.netty.channel.ChannelPromise promise
public void invokeClose (io.netty.channel.ChannelHandlerContext, io.netty.channel.ChannelPromise)
io.netty.channel.ChannelHandlerContext ctx
io.netty.channel.ChannelPromise promise
public void invokeDeregister (io.netty.channel.ChannelHandlerContext, io.netty.channel.ChannelPromise)
io.netty.channel.ChannelHandlerContext ctx
io.netty.channel.ChannelPromise promise
public void invokeRead (io.netty.channel.ChannelHandlerContext)
io.netty.channel.AbstractChannelHandlerContext dctx
Runnable task
io.netty.channel.ChannelHandlerContext ctx
public void invokeWrite (io.netty.channel.ChannelHandlerContext, java.lang.Object, io.netty.channel.ChannelPromise)
io.netty.channel.ChannelHandlerContext ctx
Object msg
io.netty.channel.ChannelPromise promise
public void invokeFlush (io.netty.channel.ChannelHandlerContext)
io.netty.channel.AbstractChannelHandlerContext dctx
Runnable task
io.netty.channel.ChannelHandlerContext ctx
private void safeExecuteInbound (java.lang.Runnable, java.lang.Object)
Runnable task
Object msg
boolean success
private void safeExecuteOutbound (java.lang.Runnable, io.netty.channel.ChannelPromise)
Throwable cause
Runnable task
io.netty.channel.ChannelPromise promise
private void safeExecuteOutbound (java.lang.Runnable, io.netty.channel.ChannelPromise, java.lang.Object)
Throwable cause
Runnable task
io.netty.channel.ChannelPromise promise
Object msg
}
io/netty/channel/ChannelPipeline.classChannelPipeline.java
package io.netty.channel
public abstract io.netty.channel.ChannelPipeline extends java.lang.Object implements java.lang.Iterable {
public abstract io.netty.channel.ChannelPipeline addFirst (java.lang.String, io.netty.channel.ChannelHandler)
public abstract io.netty.channel.ChannelPipeline addFirst (io.netty.util.concurrent.EventExecutorGroup, java.lang.String, io.netty.channel.ChannelHandler)
public abstract io.netty.channel.ChannelPipeline addFirst (io.netty.channel.ChannelHandlerInvoker, java.lang.String, io.netty.channel.ChannelHandler)
public abstract io.netty.channel.ChannelPipeline addLast (java.lang.String, io.netty.channel.ChannelHandler)
public abstract io.netty.channel.ChannelPipeline addLast (io.netty.util.concurrent.EventExecutorGroup, java.lang.String, io.netty.channel.ChannelHandler)
public abstract io.netty.channel.ChannelPipeline addLast (io.netty.channel.ChannelHandlerInvoker, java.lang.String, io.netty.channel.ChannelHandler)
public abstract io.netty.channel.ChannelPipeline addBefore (java.lang.String, java.lang.String, io.netty.channel.ChannelHandler)
public abstract io.netty.channel.ChannelPipeline addBefore (io.netty.util.concurrent.EventExecutorGroup, java.lang.String, java.lang.String, io.netty.channel.ChannelHandler)
public abstract io.netty.channel.ChannelPipeline addBefore (io.netty.channel.ChannelHandlerInvoker, java.lang.String, java.lang.String, io.netty.channel.ChannelHandler)
public abstract io.netty.channel.ChannelPipeline addAfter (java.lang.String, java.lang.String, io.netty.channel.ChannelHandler)
public abstract io.netty.channel.ChannelPipeline addAfter (io.netty.util.concurrent.EventExecutorGroup, java.lang.String, java.lang.String, io.netty.channel.ChannelHandler)
public abstract io.netty.channel.ChannelPipeline addAfter (io.netty.channel.ChannelHandlerInvoker, java.lang.String, java.lang.String, io.netty.channel.ChannelHandler)
public transient abstract io.netty.channel.ChannelPipeline addFirst (io.netty.channel.ChannelHandler[])
public transient abstract io.netty.channel.ChannelPipeline addFirst (io.netty.util.concurrent.EventExecutorGroup, io.netty.channel.ChannelHandler[])
public transient abstract io.netty.channel.ChannelPipeline addFirst (io.netty.channel.ChannelHandlerInvoker, io.netty.channel.ChannelHandler[])
public transient abstract io.netty.channel.ChannelPipeline addLast (io.netty.channel.ChannelHandler[])
public transient abstract io.netty.channel.ChannelPipeline addLast (io.netty.util.concurrent.EventExecutorGroup, io.netty.channel.ChannelHandler[])
public transient abstract io.netty.channel.ChannelPipeline addLast (io.netty.channel.ChannelHandlerInvoker, io.netty.channel.ChannelHandler[])
public abstract io.netty.channel.ChannelPipeline remove (io.netty.channel.ChannelHandler)
public abstract io.netty.channel.ChannelHandler remove (java.lang.String)
public abstract io.netty.channel.ChannelHandler remove (java.lang.Class)
public abstract io.netty.channel.ChannelHandler removeFirst ()
public abstract io.netty.channel.ChannelHandler removeLast ()
public abstract io.netty.channel.ChannelPipeline replace (io.netty.channel.ChannelHandler, java.lang.String, io.netty.channel.ChannelHandler)
public abstract io.netty.channel.ChannelHandler replace (java.lang.String, java.lang.String, io.netty.channel.ChannelHandler)
public abstract io.netty.channel.ChannelHandler replace (java.lang.Class, java.lang.String, io.netty.channel.ChannelHandler)
public abstract io.netty.channel.ChannelHandler first ()
public abstract io.netty.channel.ChannelHandlerContext firstContext ()
public abstract io.netty.channel.ChannelHandler last ()
public abstract io.netty.channel.ChannelHandlerContext lastContext ()
public abstract io.netty.channel.ChannelHandler get (java.lang.String)
public abstract io.netty.channel.ChannelHandler get (java.lang.Class)
public abstract io.netty.channel.ChannelHandlerContext context (io.netty.channel.ChannelHandler)
public abstract io.netty.channel.ChannelHandlerContext context (java.lang.String)
public abstract io.netty.channel.ChannelHandlerContext context (java.lang.Class)
public abstract io.netty.channel.Channel channel ()
public abstract java.util.List names ()
public abstract java.util.Map toMap ()
public abstract io.netty.channel.ChannelPipeline fireChannelRegistered ()
public abstract io.netty.channel.ChannelPipeline fireChannelUnregistered ()
public abstract io.netty.channel.ChannelPipeline fireChannelActive ()
public abstract io.netty.channel.ChannelPipeline fireChannelInactive ()
public abstract io.netty.channel.ChannelPipeline fireExceptionCaught (java.lang.Throwable)
public abstract io.netty.channel.ChannelPipeline fireUserEventTriggered (java.lang.Object)
public abstract io.netty.channel.ChannelPipeline fireChannelRead (java.lang.Object)
public abstract io.netty.channel.ChannelPipeline fireChannelReadComplete ()
public abstract io.netty.channel.ChannelPipeline fireChannelWritabilityChanged ()
public abstract io.netty.channel.ChannelFuture bind (java.net.SocketAddress)
public abstract io.netty.channel.ChannelFuture connect (java.net.SocketAddress)
public abstract io.netty.channel.ChannelFuture connect (java.net.SocketAddress, java.net.SocketAddress)
public abstract io.netty.channel.ChannelFuture disconnect ()
public abstract io.netty.channel.ChannelFuture close ()
public abstract io.netty.channel.ChannelFuture deregister ()
public abstract io.netty.channel.ChannelFuture bind (java.net.SocketAddress, io.netty.channel.ChannelPromise)
public abstract io.netty.channel.ChannelFuture connect (java.net.SocketAddress, io.netty.channel.ChannelPromise)
public abstract io.netty.channel.ChannelFuture connect (java.net.SocketAddress, java.net.SocketAddress, io.netty.channel.ChannelPromise)
public abstract io.netty.channel.ChannelFuture disconnect (io.netty.channel.ChannelPromise)
public abstract io.netty.channel.ChannelFuture close (io.netty.channel.ChannelPromise)
public abstract io.netty.channel.ChannelFuture deregister (io.netty.channel.ChannelPromise)
public abstract io.netty.channel.ChannelPipeline read ()
public abstract io.netty.channel.ChannelFuture write (java.lang.Object)
public abstract io.netty.channel.ChannelFuture write (java.lang.Object, io.netty.channel.ChannelPromise)
public abstract io.netty.channel.ChannelPipeline flush ()
public abstract io.netty.channel.ChannelFuture writeAndFlush (java.lang.Object, io.netty.channel.ChannelPromise)
public abstract io.netty.channel.ChannelFuture writeAndFlush (java.lang.Object)
}
io/netty/channel/AbstractChannel.classAbstractChannel.java
package io.netty.channel
public abstract io.netty.channel.AbstractChannel extends io.netty.util.DefaultAttributeMap implements io.netty.channel.Channel {
private static final io.netty.util.internal.logging.InternalLogger logger
static final java.nio.channels.ClosedChannelException CLOSED_CHANNEL_EXCEPTION
static final java.nio.channels.NotYetConnectedException NOT_YET_CONNECTED_EXCEPTION
private io.netty.channel.MessageSizeEstimator$Handle estimatorHandle
private final io.netty.channel.Channel parent
private final io.netty.channel.ChannelId id
private final io.netty.channel.Channel$Unsafe unsafe
private final io.netty.channel.DefaultChannelPipeline pipeline
private final io.netty.channel.ChannelFuture succeededFuture
private final io.netty.channel.VoidChannelPromise voidPromise
private final io.netty.channel.VoidChannelPromise unsafeVoidPromise
private final io.netty.channel.AbstractChannel$CloseFuture closeFuture
private volatile java.net.SocketAddress localAddress
private volatile java.net.SocketAddress remoteAddress
private volatile io.netty.channel.EventLoop eventLoop
private volatile boolean registered
private boolean strValActive
private String strVal
protected void (io.netty.channel.Channel)
io.netty.channel.Channel parent
protected void (io.netty.channel.Channel, io.netty.channel.ChannelId)
io.netty.channel.Channel parent
io.netty.channel.ChannelId id
public final io.netty.channel.ChannelId id ()
protected io.netty.channel.ChannelId newId ()
public boolean isWritable ()
io.netty.channel.ChannelOutboundBuffer buf
public long bytesBeforeUnwritable ()
io.netty.channel.ChannelOutboundBuffer buf
public long bytesBeforeWritable ()
io.netty.channel.ChannelOutboundBuffer buf
public io.netty.channel.Channel parent ()
public io.netty.channel.ChannelPipeline pipeline ()
public io.netty.buffer.ByteBufAllocator alloc ()
public io.netty.channel.EventLoop eventLoop ()
io.netty.channel.EventLoop eventLoop
public java.net.SocketAddress localAddress ()
Throwable t
java.net.SocketAddress localAddress
protected void invalidateLocalAddress ()
public java.net.SocketAddress remoteAddress ()
Throwable t
java.net.SocketAddress remoteAddress
protected void invalidateRemoteAddress ()
public boolean isRegistered ()
public io.netty.channel.ChannelFuture bind (java.net.SocketAddress)
java.net.SocketAddress localAddress
public io.netty.channel.ChannelFuture connect (java.net.SocketAddress)
java.net.SocketAddress remoteAddress
public io.netty.channel.ChannelFuture connect (java.net.SocketAddress, java.net.SocketAddress)
java.net.SocketAddress remoteAddress
java.net.SocketAddress localAddress
public io.netty.channel.ChannelFuture disconnect ()
public io.netty.channel.ChannelFuture close ()
public io.netty.channel.ChannelFuture deregister ()
public io.netty.channel.Channel flush ()
public io.netty.channel.ChannelFuture bind (java.net.SocketAddress, io.netty.channel.ChannelPromise)
java.net.SocketAddress localAddress
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelFuture connect (java.net.SocketAddress, io.netty.channel.ChannelPromise)
java.net.SocketAddress remoteAddress
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelFuture connect (java.net.SocketAddress, java.net.SocketAddress, io.netty.channel.ChannelPromise)
java.net.SocketAddress remoteAddress
java.net.SocketAddress localAddress
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelFuture disconnect (io.netty.channel.ChannelPromise)
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelFuture close (io.netty.channel.ChannelPromise)
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelFuture deregister (io.netty.channel.ChannelPromise)
io.netty.channel.ChannelPromise promise
public io.netty.channel.Channel read ()
public io.netty.channel.ChannelFuture write (java.lang.Object)
Object msg
public io.netty.channel.ChannelFuture write (java.lang.Object, io.netty.channel.ChannelPromise)
Object msg
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelFuture writeAndFlush (java.lang.Object)
Object msg
public io.netty.channel.ChannelFuture writeAndFlush (java.lang.Object, io.netty.channel.ChannelPromise)
Object msg
io.netty.channel.ChannelPromise promise
public io.netty.channel.ChannelPromise newPromise ()
public io.netty.channel.ChannelProgressivePromise newProgressivePromise ()
public io.netty.channel.ChannelFuture newSucceededFuture ()
public io.netty.channel.ChannelFuture newFailedFuture (java.lang.Throwable)
Throwable cause
public io.netty.channel.ChannelFuture closeFuture ()
public io.netty.channel.Channel$Unsafe unsafe ()
protected abstract io.netty.channel.AbstractChannel$AbstractUnsafe newUnsafe ()
public final int hashCode ()
public final boolean equals (java.lang.Object)
Object o
public final int compareTo (io.netty.channel.Channel)
io.netty.channel.Channel o
public java.lang.String toString ()
StringBuilder buf
StringBuilder buf
StringBuilder buf
boolean active
java.net.SocketAddress remoteAddr
java.net.SocketAddress localAddr
public final io.netty.channel.ChannelPromise voidPromise ()
final io.netty.channel.MessageSizeEstimator$Handle estimatorHandle ()
protected abstract boolean isCompatible (io.netty.channel.EventLoop)
protected abstract java.net.SocketAddress localAddress0 ()
protected abstract java.net.SocketAddress remoteAddress0 ()
protected void doRegister () throws java.lang.Exception
protected abstract void doBind (java.net.SocketAddress) throws java.lang.Exception
protected abstract void doDisconnect () throws java.lang.Exception
protected abstract void doClose () throws java.lang.Exception
protected void doDeregister () throws java.lang.Exception
protected abstract void doBeginRead () throws java.lang.Exception
protected abstract void doWrite (io.netty.channel.ChannelOutboundBuffer) throws java.lang.Exception
protected java.lang.Object filterOutboundMessage (java.lang.Object) throws java.lang.Exception
Object msg
public volatile int compareTo (java.lang.Object)
static io.netty.channel.EventLoop access$002 (io.netty.channel.AbstractChannel, io.netty.channel.EventLoop)
io.netty.channel.AbstractChannel x0
io.netty.channel.EventLoop x1
static io.netty.util.internal.logging.InternalLogger access$200 ()
static io.netty.channel.AbstractChannel$CloseFuture access$300 (io.netty.channel.AbstractChannel)
io.netty.channel.AbstractChannel x0
static boolean access$402 (io.netty.channel.AbstractChannel, boolean)
io.netty.channel.AbstractChannel x0
boolean x1
static io.netty.channel.DefaultChannelPipeline access$500 (io.netty.channel.AbstractChannel)
io.netty.channel.AbstractChannel x0
static boolean access$400 (io.netty.channel.AbstractChannel)
io.netty.channel.AbstractChannel x0
static io.netty.channel.VoidChannelPromise access$900 (io.netty.channel.AbstractChannel)
io.netty.channel.AbstractChannel x0
static void ()
}
io/netty/channel/DefaultChannelHandlerInvoker$6.classDefaultChannelHandlerInvoker.java
package io.netty.channel
io.netty.channel.DefaultChannelHandlerInvoker$6 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.ChannelHandlerContext val$ctx
final Object val$event
final io.netty.channel.DefaultChannelHandlerInvoker this$0
void (io.netty.channel.DefaultChannelHandlerInvoker, io.netty.channel.ChannelHandlerContext, java.lang.Object)
public void run ()
}
io/netty/channel/ChannelHandlerAdapter.classChannelHandlerAdapter.java
package io.netty.channel
public abstract io.netty.channel.ChannelHandlerAdapter extends java.lang.Object implements io.netty.channel.ChannelHandler {
boolean added
public void ()
public boolean isSharable ()
Class clazz
java.util.Map cache
Boolean sharable
public void handlerAdded (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
public void handlerRemoved (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
public void exceptionCaught (io.netty.channel.ChannelHandlerContext, java.lang.Throwable) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
Throwable cause
}
io/netty/channel/ChannelOutboundBuffer$MessageProcessor.classChannelOutboundBuffer.java
package io.netty.channel
public abstract io.netty.channel.ChannelOutboundBuffer$MessageProcessor extends java.lang.Object {
public abstract boolean processMessage (java.lang.Object) throws java.lang.Exception
}
io/netty/channel/Channel.classChannel.java
package io.netty.channel
public abstract io.netty.channel.Channel extends java.lang.Object implements io.netty.util.AttributeMap java.lang.Comparable {
public abstract io.netty.channel.ChannelId id ()
public abstract io.netty.channel.EventLoop eventLoop ()
public abstract io.netty.channel.Channel parent ()
public abstract io.netty.channel.ChannelConfig config ()
public abstract boolean isOpen ()
public abstract boolean isRegistered ()
public abstract boolean isActive ()
public abstract io.netty.channel.ChannelMetadata metadata ()
public abstract java.net.SocketAddress localAddress ()
public abstract java.net.SocketAddress remoteAddress ()
public abstract io.netty.channel.ChannelFuture closeFuture ()
public abstract boolean isWritable ()
public abstract long bytesBeforeUnwritable ()
public abstract long bytesBeforeWritable ()
public abstract io.netty.channel.Channel$Unsafe unsafe ()
public abstract io.netty.channel.ChannelPipeline pipeline ()
public abstract io.netty.buffer.ByteBufAllocator alloc ()
public abstract io.netty.channel.ChannelPromise newPromise ()
public abstract io.netty.channel.ChannelProgressivePromise newProgressivePromise ()
public abstract io.netty.channel.ChannelFuture newSucceededFuture ()
public abstract io.netty.channel.ChannelFuture newFailedFuture (java.lang.Throwable)
public abstract io.netty.channel.ChannelPromise voidPromise ()
public abstract io.netty.channel.ChannelFuture bind (java.net.SocketAddress)
public abstract io.netty.channel.ChannelFuture connect (java.net.SocketAddress)
public abstract io.netty.channel.ChannelFuture connect (java.net.SocketAddress, java.net.SocketAddress)
public abstract io.netty.channel.ChannelFuture disconnect ()
public abstract io.netty.channel.ChannelFuture close ()
public abstract io.netty.channel.ChannelFuture deregister ()
public abstract io.netty.channel.ChannelFuture bind (java.net.SocketAddress, io.netty.channel.ChannelPromise)
public abstract io.netty.channel.ChannelFuture connect (java.net.SocketAddress, io.netty.channel.ChannelPromise)
public abstract io.netty.channel.ChannelFuture connect (java.net.SocketAddress, java.net.SocketAddress, io.netty.channel.ChannelPromise)
public abstract io.netty.channel.ChannelFuture disconnect (io.netty.channel.ChannelPromise)
public abstract io.netty.channel.ChannelFuture close (io.netty.channel.ChannelPromise)
public abstract io.netty.channel.ChannelFuture deregister (io.netty.channel.ChannelPromise)
public abstract io.netty.channel.Channel read ()
public abstract io.netty.channel.ChannelFuture write (java.lang.Object)
public abstract io.netty.channel.ChannelFuture write (java.lang.Object, io.netty.channel.ChannelPromise)
public abstract io.netty.channel.Channel flush ()
public abstract io.netty.channel.ChannelFuture writeAndFlush (java.lang.Object, io.netty.channel.ChannelPromise)
public abstract io.netty.channel.ChannelFuture writeAndFlush (java.lang.Object)
}
io/netty/channel/AdaptiveRecvByteBufAllocator.classAdaptiveRecvByteBufAllocator.java
package io.netty.channel
public io.netty.channel.AdaptiveRecvByteBufAllocator extends io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator {
static final int DEFAULT_MINIMUM
static final int DEFAULT_INITIAL
static final int DEFAULT_MAXIMUM
private static final int INDEX_INCREMENT
private static final int INDEX_DECREMENT
private static final int[] SIZE_TABLE
public static final io.netty.channel.AdaptiveRecvByteBufAllocator DEFAULT
private final int minIndex
private final int maxIndex
private final int initial
private static int getSizeTableIndex (int)
int mid
int a
int b
int low
int high
int size
public void ()
public void (int, int, int)
int minimum
int initial
int maximum
int minIndex
int maxIndex
public io.netty.channel.RecvByteBufAllocator$Handle newHandle ()
static int access$000 (int)
int x0
static int[] access$100 ()
static void ()
int i
int i
int i
java.util.List sizeTable
}
io/netty/channel/ChannelMetadata.classChannelMetadata.java
package io.netty.channel
public final io.netty.channel.ChannelMetadata extends java.lang.Object {
private final boolean hasDisconnect
private final int defaultMaxMessagesPerRead
public void (boolean)
boolean hasDisconnect
public void (boolean, int)
boolean hasDisconnect
int defaultMaxMessagesPerRead
public boolean hasDisconnect ()
public int defaultMaxMessagesPerRead ()
}
io/netty/channel/AbstractServerChannel$1.classAbstractServerChannel.java
package io.netty.channel
io.netty.channel.AbstractServerChannel$1 extends java.lang.Object {
}
io/netty/channel/ThreadPerChannelEventLoop$1.classThreadPerChannelEventLoop.java
package io.netty.channel
io.netty.channel.ThreadPerChannelEventLoop$1 extends java.lang.Object implements io.netty.channel.ChannelFutureListener {
final io.netty.channel.ThreadPerChannelEventLoop this$0
void (io.netty.channel.ThreadPerChannelEventLoop)
public void operationComplete (io.netty.channel.ChannelFuture) throws java.lang.Exception
io.netty.channel.ChannelFuture future
public volatile void operationComplete (io.netty.util.concurrent.Future) throws java.lang.Exception
}
io/netty/channel/DefaultChannelPipeline$9.classDefaultChannelPipeline.java
package io.netty.channel
io.netty.channel.DefaultChannelPipeline$9 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.AbstractChannelHandlerContext val$finalCtx
final io.netty.channel.DefaultChannelPipeline this$0
void (io.netty.channel.DefaultChannelPipeline, io.netty.channel.AbstractChannelHandlerContext)
public void run ()
}
io/netty/channel/AbstractChannel$AbstractUnsafe$2.classAbstractChannel.java
package io.netty.channel
io.netty.channel.AbstractChannel$AbstractUnsafe$2 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.AbstractChannel$AbstractUnsafe this$1
void (io.netty.channel.AbstractChannel$AbstractUnsafe)
public void run ()
}
io/netty/channel/ThreadLocalPooledDirectByteBuf$ThreadLocalUnsafeDirectByteBuf$1.classThreadLocalPooledDirectByteBuf.java
package io.netty.channel
final io.netty.channel.ThreadLocalPooledDirectByteBuf$ThreadLocalUnsafeDirectByteBuf$1 extends io.netty.util.Recycler {
void ()
protected io.netty.channel.ThreadLocalPooledDirectByteBuf$ThreadLocalUnsafeDirectByteBuf newObject (io.netty.util.Recycler$Handle)
io.netty.util.Recycler$Handle handle
protected volatile java.lang.Object newObject (io.netty.util.Recycler$Handle)
}
io/netty/channel/FixedRecvByteBufAllocator$HandleImpl.classFixedRecvByteBufAllocator.java
package io.netty.channel
final io.netty.channel.FixedRecvByteBufAllocator$HandleImpl extends io.netty.channel.DefaultMaxMessagesRecvByteBufAllocator$MaxMessageHandle {
private final int bufferSize
final io.netty.channel.FixedRecvByteBufAllocator this$0
public void (io.netty.channel.FixedRecvByteBufAllocator, int)
int bufferSize
public int guess ()
}
io/netty/channel/DefaultChannelHandlerInvoker$11.classDefaultChannelHandlerInvoker.java
package io.netty.channel
io.netty.channel.DefaultChannelHandlerInvoker$11 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.ChannelHandlerContext val$ctx
final java.net.SocketAddress val$remoteAddress
final java.net.SocketAddress val$localAddress
final io.netty.channel.ChannelPromise val$promise
final io.netty.channel.DefaultChannelHandlerInvoker this$0
void (io.netty.channel.DefaultChannelHandlerInvoker, io.netty.channel.ChannelHandlerContext, java.net.SocketAddress, java.net.SocketAddress, io.netty.channel.ChannelPromise)
public void run ()
}
io/netty/channel/FailedChannelFuture.classFailedChannelFuture.java
package io.netty.channel
final io.netty.channel.FailedChannelFuture extends io.netty.channel.CompleteChannelFuture {
private final Throwable cause
void (io.netty.channel.Channel, io.netty.util.concurrent.EventExecutor, java.lang.Throwable)
io.netty.channel.Channel channel
io.netty.util.concurrent.EventExecutor executor
Throwable cause
public java.lang.Throwable cause ()
public boolean isSuccess ()
public io.netty.channel.ChannelFuture sync ()
public io.netty.channel.ChannelFuture syncUninterruptibly ()
public volatile io.netty.util.concurrent.Future syncUninterruptibly ()
public volatile io.netty.util.concurrent.Future sync () throws java.lang.InterruptedException
}
io/netty/channel/ReflectiveChannelFactory.classReflectiveChannelFactory.java
package io.netty.channel
public io.netty.channel.ReflectiveChannelFactory extends java.lang.Object implements io.netty.channel.ChannelFactory {
private final Class clazz
public void (java.lang.Class)
Class clazz
public io.netty.channel.Channel newChannel ()
Throwable t
public java.lang.String toString ()
}
io/netty/channel/ChannelOutboundBuffer$2.classChannelOutboundBuffer.java
package io.netty.channel
io.netty.channel.ChannelOutboundBuffer$2 extends java.lang.Object implements java.lang.Runnable {
final io.netty.channel.ChannelPipeline val$pipeline
final io.netty.channel.ChannelOutboundBuffer this$0
void (io.netty.channel.ChannelOutboundBuffer, io.netty.channel.ChannelPipeline)
public void run ()
}
io/netty/channel/DefaultMessageSizeEstimator$1.classDefaultMessageSizeEstimator.java
package io.netty.channel
io.netty.channel.DefaultMessageSizeEstimator$1 extends java.lang.Object {
}
io/netty/channel/DefaultChannelHandlerInvoker$16.classDefaultChannelHandlerInvoker.java
package io.netty.channel
io.netty.channel.DefaultChannelHandlerInvoker$16 extends java.lang.Object implements java.lang.Runnable {
final io.netty.channel.ChannelHandlerContext val$ctx
final io.netty.channel.DefaultChannelHandlerInvoker this$0
void (io.netty.channel.DefaultChannelHandlerInvoker, io.netty.channel.ChannelHandlerContext)
public void run ()
}
io/netty/channel/DefaultMessageSizeEstimator$HandleImpl.classDefaultMessageSizeEstimator.java
package io.netty.channel
final io.netty.channel.DefaultMessageSizeEstimator$HandleImpl extends java.lang.Object implements io.netty.channel.MessageSizeEstimator$Handle {
private final int unknownSize
private void (int)
int unknownSize
public int size (java.lang.Object)
Object msg
void (int, io.netty.channel.DefaultMessageSizeEstimator$1)
int x0
io.netty.channel.DefaultMessageSizeEstimator$1 x1
}
io/netty/channel/ChannelHandlerContext.classChannelHandlerContext.java
package io.netty.channel
public abstract io.netty.channel.ChannelHandlerContext extends java.lang.Object implements io.netty.util.AttributeMap {
public abstract io.netty.channel.Channel channel ()
public abstract io.netty.util.concurrent.EventExecutor executor ()
public abstract io.netty.channel.ChannelHandlerInvoker invoker ()
public abstract java.lang.String name ()
public abstract io.netty.channel.ChannelHandler handler ()
public abstract boolean isRemoved ()
public abstract io.netty.channel.ChannelHandlerContext fireChannelRegistered ()
public abstract io.netty.channel.ChannelHandlerContext fireChannelUnregistered ()
public abstract io.netty.channel.ChannelHandlerContext fireChannelActive ()
public abstract io.netty.channel.ChannelHandlerContext fireChannelInactive ()
public abstract io.netty.channel.ChannelHandlerContext fireExceptionCaught (java.lang.Throwable)
public abstract io.netty.channel.ChannelHandlerContext fireUserEventTriggered (java.lang.Object)
public abstract io.netty.channel.ChannelHandlerContext fireChannelRead (java.lang.Object)
public abstract io.netty.channel.ChannelHandlerContext fireChannelReadComplete ()
public abstract io.netty.channel.ChannelHandlerContext fireChannelWritabilityChanged ()
public abstract io.netty.channel.ChannelFuture bind (java.net.SocketAddress)
public abstract io.netty.channel.ChannelFuture connect (java.net.SocketAddress)
public abstract io.netty.channel.ChannelFuture connect (java.net.SocketAddress, java.net.SocketAddress)
public abstract io.netty.channel.ChannelFuture disconnect ()
public abstract io.netty.channel.ChannelFuture close ()
public abstract io.netty.channel.ChannelFuture deregister ()
public abstract io.netty.channel.ChannelFuture bind (java.net.SocketAddress, io.netty.channel.ChannelPromise)
public abstract io.netty.channel.ChannelFuture connect (java.net.SocketAddress, io.netty.channel.ChannelPromise)
public abstract io.netty.channel.ChannelFuture connect (java.net.SocketAddress, java.net.SocketAddress, io.netty.channel.ChannelPromise)
public abstract io.netty.channel.ChannelFuture disconnect (io.netty.channel.ChannelPromise)
public abstract io.netty.channel.ChannelFuture close (io.netty.channel.ChannelPromise)
public abstract io.netty.channel.ChannelFuture deregister (io.netty.channel.ChannelPromise)
public abstract io.netty.channel.ChannelHandlerContext read ()
public abstract io.netty.channel.ChannelFuture write (java.lang.Object)
public abstract io.netty.channel.ChannelFuture write (java.lang.Object, io.netty.channel.ChannelPromise)
public abstract io.netty.channel.ChannelHandlerContext flush ()
public abstract io.netty.channel.ChannelFuture writeAndFlush (java.lang.Object, io.netty.channel.ChannelPromise)
public abstract io.netty.channel.ChannelFuture writeAndFlush (java.lang.Object)
public abstract io.netty.channel.ChannelPipeline pipeline ()
public abstract io.netty.buffer.ByteBufAllocator alloc ()
public abstract io.netty.channel.ChannelPromise newPromise ()
public abstract io.netty.channel.ChannelProgressivePromise newProgressivePromise ()
public abstract io.netty.channel.ChannelFuture newSucceededFuture ()
public abstract io.netty.channel.ChannelFuture newFailedFuture (java.lang.Throwable)
public abstract io.netty.channel.ChannelPromise voidPromise ()
}
io/netty/channel/ChannelInitializer.classChannelInitializer.java
package io.netty.channel
public abstract io.netty.channel.ChannelInitializer extends io.netty.channel.ChannelInboundHandlerAdapter {
private static final io.netty.util.internal.logging.InternalLogger logger
public void ()
protected abstract void initChannel (io.netty.channel.Channel) throws java.lang.Exception
public final void channelRegistered (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
public void exceptionCaught (io.netty.channel.ChannelHandlerContext, java.lang.Throwable) throws java.lang.Exception
io.netty.channel.ChannelPipeline pipeline
io.netty.channel.ChannelHandlerContext ctx
Throwable cause
static void ()
}
io/netty/channel/ChannelFactory.classChannelFactory.java
package io.netty.channel
public abstract io.netty.channel.ChannelFactory extends java.lang.Object implements io.netty.bootstrap.ChannelFactory {
public abstract io.netty.channel.Channel newChannel ()
}
io/netty/channel/DefaultChannelPipeline$3.classDefaultChannelPipeline.java
package io.netty.channel
io.netty.channel.DefaultChannelPipeline$3 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.AbstractChannelHandlerContext val$newCtx
final io.netty.channel.DefaultChannelPipeline this$0
void (io.netty.channel.DefaultChannelPipeline, io.netty.channel.AbstractChannelHandlerContext)
public void run ()
}
io/netty/channel/AbstractServerChannel.classAbstractServerChannel.java
package io.netty.channel
public abstract io.netty.channel.AbstractServerChannel extends io.netty.channel.AbstractChannel implements io.netty.channel.ServerChannel {
private static final io.netty.channel.ChannelMetadata METADATA
protected void ()
public io.netty.channel.ChannelMetadata metadata ()
public java.net.SocketAddress remoteAddress ()
protected java.net.SocketAddress remoteAddress0 ()
protected void doDisconnect () throws java.lang.Exception
protected io.netty.channel.AbstractChannel$AbstractUnsafe newUnsafe ()
protected void doWrite (io.netty.channel.ChannelOutboundBuffer) throws java.lang.Exception
io.netty.channel.ChannelOutboundBuffer in
protected final java.lang.Object filterOutboundMessage (java.lang.Object)
Object msg
static void ()
}
io/netty/channel/ChannelFlushPromiseNotifier$DefaultFlushCheckpoint.classChannelFlushPromiseNotifier.java
package io.netty.channel
io.netty.channel.ChannelFlushPromiseNotifier$DefaultFlushCheckpoint extends java.lang.Object implements io.netty.channel.ChannelFlushPromiseNotifier$FlushCheckpoint {
private long checkpoint
private final io.netty.channel.ChannelPromise future
void (long, io.netty.channel.ChannelPromise)
long checkpoint
io.netty.channel.ChannelPromise future
public long flushCheckpoint ()
public void flushCheckpoint (long)
long checkpoint
public io.netty.channel.ChannelPromise promise ()
}
io/netty/channel/nio/AbstractNioChannel$AbstractNioUnsafe$2.classAbstractNioChannel.java
package io.netty.channel.nio
io.netty.channel.nio.AbstractNioChannel$AbstractNioUnsafe$2 extends java.lang.Object implements io.netty.channel.ChannelFutureListener {
final io.netty.channel.nio.AbstractNioChannel$AbstractNioUnsafe this$1
void (io.netty.channel.nio.AbstractNioChannel$AbstractNioUnsafe)
public void operationComplete (io.netty.channel.ChannelFuture) throws java.lang.Exception
io.netty.channel.ChannelFuture future
public volatile void operationComplete (io.netty.util.concurrent.Future) throws java.lang.Exception
}
io/netty/channel/nio/NioTask.classNioTask.java
package io.netty.channel.nio
public abstract io.netty.channel.nio.NioTask extends java.lang.Object {
public abstract void channelReady (java.nio.channels.SelectableChannel, java.nio.channels.SelectionKey) throws java.lang.Exception
public abstract void channelUnregistered (java.nio.channels.SelectableChannel, java.lang.Throwable) throws java.lang.Exception
}
io/netty/channel/nio/AbstractNioByteChannel$NioByteUnsafe.classAbstractNioByteChannel.java
package io.netty.channel.nio
public io.netty.channel.nio.AbstractNioByteChannel$NioByteUnsafe extends io.netty.channel.nio.AbstractNioChannel$AbstractNioUnsafe {
final io.netty.channel.nio.AbstractNioByteChannel this$0
protected void (io.netty.channel.nio.AbstractNioByteChannel)
private void closeOnRead (io.netty.channel.ChannelPipeline)
io.netty.channel.ChannelPipeline pipeline
java.nio.channels.SelectionKey key
private void handleReadException (io.netty.channel.ChannelPipeline, io.netty.buffer.ByteBuf, java.lang.Throwable, boolean, io.netty.channel.RecvByteBufAllocator$Handle)
io.netty.channel.ChannelPipeline pipeline
io.netty.buffer.ByteBuf byteBuf
Throwable cause
boolean close
io.netty.channel.RecvByteBufAllocator$Handle allocHandle
public final void read ()
boolean needReadPendingReset
Throwable t
io.netty.channel.ChannelConfig config
io.netty.channel.ChannelPipeline pipeline
io.netty.buffer.ByteBufAllocator allocator
io.netty.channel.RecvByteBufAllocator$Handle allocHandle
io.netty.buffer.ByteBuf byteBuf
}
io/netty/channel/nio/SelectedSelectionKeySet.classSelectedSelectionKeySet.java
package io.netty.channel.nio
final io.netty.channel.nio.SelectedSelectionKeySet extends java.util.AbstractSet {
private java.nio.channels.SelectionKey[] keysA
private int keysASize
private java.nio.channels.SelectionKey[] keysB
private int keysBSize
private boolean isA
void ()
public boolean add (java.nio.channels.SelectionKey)
int size
int size
java.nio.channels.SelectionKey o
private void doubleCapacityA ()
java.nio.channels.SelectionKey[] newKeysA
private void doubleCapacityB ()
java.nio.channels.SelectionKey[] newKeysB
java.nio.channels.SelectionKey[] flip ()
public int size ()
public boolean remove (java.lang.Object)
Object o
public boolean contains (java.lang.Object)
Object o
public java.util.Iterator iterator ()
public volatile boolean add (java.lang.Object)
}
io/netty/channel/nio/AbstractNioMessageChannel.classAbstractNioMessageChannel.java
package io.netty.channel.nio
public abstract io.netty.channel.nio.AbstractNioMessageChannel extends io.netty.channel.nio.AbstractNioChannel {
protected void (io.netty.channel.Channel, java.nio.channels.SelectableChannel, int)
io.netty.channel.Channel parent
java.nio.channels.SelectableChannel ch
int readInterestOp
protected io.netty.channel.nio.AbstractNioChannel$AbstractNioUnsafe newUnsafe ()
protected void doWrite (io.netty.channel.ChannelOutboundBuffer) throws java.lang.Exception
int i
boolean done
java.io.IOException e
Object msg
io.netty.channel.ChannelOutboundBuffer in
java.nio.channels.SelectionKey key
int interestOps
protected boolean continueOnWriteError ()
protected abstract int doReadMessages (java.util.List) throws java.lang.Exception
protected abstract boolean doWriteMessage (java.lang.Object, io.netty.channel.ChannelOutboundBuffer) throws java.lang.Exception
protected volatile io.netty.channel.AbstractChannel$AbstractUnsafe newUnsafe ()
}
io/netty/channel/nio/AbstractNioChannel$AbstractNioUnsafe.classAbstractNioChannel.java
package io.netty.channel.nio
public abstract io.netty.channel.nio.AbstractNioChannel$AbstractNioUnsafe extends io.netty.channel.AbstractChannel$AbstractUnsafe implements io.netty.channel.nio.AbstractNioChannel$NioUnsafe {
static final boolean $assertionsDisabled
final io.netty.channel.nio.AbstractNioChannel this$0
protected void (io.netty.channel.nio.AbstractNioChannel)
protected final void removeReadOp ()
java.nio.channels.SelectionKey key
int interestOps
public final java.nio.channels.SelectableChannel ch ()
public final void connect (java.net.SocketAddress, java.net.SocketAddress, io.netty.channel.ChannelPromise)
int connectTimeoutMillis
boolean wasActive
Throwable t
java.net.SocketAddress remoteAddress
java.net.SocketAddress localAddress
io.netty.channel.ChannelPromise promise
private void fulfillConnectPromise (io.netty.channel.ChannelPromise, boolean)
io.netty.channel.ChannelPromise promise
boolean wasActive
boolean promiseSet
private void fulfillConnectPromise (io.netty.channel.ChannelPromise, java.lang.Throwable)
io.netty.channel.ChannelPromise promise
Throwable cause
public final void finishConnect ()
boolean wasActive
Throwable t
protected final void flush0 ()
public final void forceFlush ()
private boolean isFlushPending ()
java.nio.channels.SelectionKey selectionKey
static void ()
}
io/netty/channel/nio/NioEventLoopGroup.classNioEventLoopGroup.java
package io.netty.channel.nio
public io.netty.channel.nio.NioEventLoopGroup extends io.netty.channel.MultithreadEventLoopGroup {
public void ()
public void (int)
int nThreads
public void (int, java.util.concurrent.ThreadFactory)
int nThreads
java.util.concurrent.ThreadFactory threadFactory
public void (int, java.util.concurrent.Executor)
int nThreads
java.util.concurrent.Executor executor
public void (int, java.util.concurrent.ThreadFactory, java.nio.channels.spi.SelectorProvider)
int nThreads
java.util.concurrent.ThreadFactory threadFactory
java.nio.channels.spi.SelectorProvider selectorProvider
public void (int, java.util.concurrent.Executor, java.nio.channels.spi.SelectorProvider)
int nThreads
java.util.concurrent.Executor executor
java.nio.channels.spi.SelectorProvider selectorProvider
public void setIoRatio (int)
io.netty.util.concurrent.EventExecutor e
java.util.Iterator i$
int ioRatio
public void rebuildSelectors ()
io.netty.util.concurrent.EventExecutor e
java.util.Iterator i$
protected transient io.netty.channel.EventLoop newChild (java.util.concurrent.Executor, java.lang.Object[]) throws java.lang.Exception
java.util.concurrent.Executor executor
Object[] args
protected volatile io.netty.util.concurrent.EventExecutor newChild (java.util.concurrent.Executor, java.lang.Object[]) throws java.lang.Exception
}
io/netty/channel/nio/AbstractNioByteChannel$1.classAbstractNioByteChannel.java
package io.netty.channel.nio
io.netty.channel.nio.AbstractNioByteChannel$1 extends java.lang.Object implements java.lang.Runnable {
final io.netty.channel.nio.AbstractNioByteChannel this$0
void (io.netty.channel.nio.AbstractNioByteChannel)
public void run ()
}
io/netty/channel/nio/NioEventLoop.classNioEventLoop.java
package io.netty.channel.nio
public final io.netty.channel.nio.NioEventLoop extends io.netty.channel.SingleThreadEventLoop {
private static final io.netty.util.internal.logging.InternalLogger logger
private static final int CLEANUP_INTERVAL
private static final boolean DISABLE_KEYSET_OPTIMIZATION
private static final int MIN_PREMATURE_SELECTOR_RETURNS
private static final int SELECTOR_AUTO_REBUILD_THRESHOLD
java.nio.channels.Selector selector
private io.netty.channel.nio.SelectedSelectionKeySet selectedKeys
private final java.nio.channels.spi.SelectorProvider provider
private final java.util.concurrent.atomic.AtomicBoolean wakenUp
private volatile int ioRatio
private int cancelledKeys
private boolean needsToSelectAgain
void (io.netty.channel.nio.NioEventLoopGroup, java.util.concurrent.Executor, java.nio.channels.spi.SelectorProvider)
io.netty.channel.nio.NioEventLoopGroup parent
java.util.concurrent.Executor executor
java.nio.channels.spi.SelectorProvider selectorProvider
private java.nio.channels.Selector openSelector ()
java.nio.channels.Selector selector
java.io.IOException e
io.netty.channel.nio.SelectedSelectionKeySet selectedKeySet
Class selectorImplClass
java.lang.reflect.Field selectedKeysField
java.lang.reflect.Field publicSelectedKeysField
Throwable t
java.nio.channels.Selector selector
protected java.util.Queue newTaskQueue ()
public void register (java.nio.channels.SelectableChannel, int, io.netty.channel.nio.NioTask)
Exception e
java.nio.channels.SelectableChannel ch
int interestOps
io.netty.channel.nio.NioTask task
public int getIoRatio ()
public void setIoRatio (int)
int ioRatio
public void rebuildSelector ()
java.nio.channels.Selector newSelector
Exception e
int interestOps
java.nio.channels.SelectionKey newKey
io.netty.channel.nio.AbstractNioChannel ch
io.netty.channel.nio.NioTask task
Exception e
Object a
java.nio.channels.SelectionKey key
java.util.Iterator i$
java.util.ConcurrentModificationException e
Throwable t
java.nio.channels.Selector oldSelector
java.nio.channels.Selector newSelector
int nChannels
protected void run ()
long ioStartTime
long ioTime
int ioRatio
Throwable t
boolean oldWakenUp
private void processSelectedKeys ()
protected void cleanup ()
java.io.IOException e
void cancel (java.nio.channels.SelectionKey)
java.nio.channels.SelectionKey key
protected java.lang.Runnable pollTask ()
Runnable task
private void processSelectedKeysPlain (java.util.Set)
io.netty.channel.nio.NioTask task
java.nio.channels.SelectionKey k
Object a
java.util.Set selectedKeys
java.util.Iterator i
private void processSelectedKeysOptimized (java.nio.channels.SelectionKey[])
io.netty.channel.nio.NioTask task
java.nio.channels.SelectionKey k
Object a
int i
java.nio.channels.SelectionKey[] selectedKeys
private static void processSelectedKey (java.nio.channels.SelectionKey, io.netty.channel.nio.AbstractNioChannel)
int ops
int readyOps
java.nio.channels.CancelledKeyException ignored
java.nio.channels.SelectionKey k
io.netty.channel.nio.AbstractNioChannel ch
io.netty.channel.nio.AbstractNioChannel$NioUnsafe unsafe
private static void processSelectedKey (java.nio.channels.SelectionKey, io.netty.channel.nio.NioTask)
Exception e
java.nio.channels.SelectionKey k
io.netty.channel.nio.NioTask task
int state
private void closeAll ()
io.netty.channel.nio.NioTask task
Object a
java.nio.channels.SelectionKey k
java.util.Iterator i$
io.netty.channel.nio.AbstractNioChannel ch
java.util.Iterator i$
java.util.Set keys
java.util.Collection channels
private static void invokeChannelUnregistered (io.netty.channel.nio.NioTask, java.nio.channels.SelectionKey, java.lang.Throwable)
Exception e
io.netty.channel.nio.NioTask task
java.nio.channels.SelectionKey k
Throwable cause
protected void wakeup (boolean)
boolean inEventLoop
void selectNow () throws java.io.IOException
private void select (boolean) throws java.io.IOException
long timeoutMillis
int selectedKeys
long time
int selectCnt
long currentTimeNanos
long selectDeadLineNanos
java.nio.channels.CancelledKeyException e
boolean oldWakenUp
java.nio.channels.Selector selector
private void selectAgain ()
Throwable t
static void ()
String buglevel
SecurityException e
String key
int selectorAutoRebuildThreshold
}
io/netty/channel/nio/AbstractNioByteChannel.classAbstractNioByteChannel.java
package io.netty.channel.nio
public abstract io.netty.channel.nio.AbstractNioByteChannel extends io.netty.channel.nio.AbstractNioChannel {
private static final String EXPECTED_TYPES
private Runnable flushTask
protected void (io.netty.channel.Channel, java.nio.channels.SelectableChannel)
io.netty.channel.Channel parent
java.nio.channels.SelectableChannel ch
protected io.netty.channel.nio.AbstractNioChannel$AbstractNioUnsafe newUnsafe ()
protected void doWrite (io.netty.channel.ChannelOutboundBuffer) throws java.lang.Exception
int localFlushedAmount
int i
io.netty.buffer.ByteBuf buf
int readableBytes
boolean done
long flushedAmount
long localFlushedAmount
int i
long flushedAmount
io.netty.channel.FileRegion region
boolean done
Object msg
io.netty.channel.ChannelOutboundBuffer in
int writeSpinCount
boolean setOpWrite
protected final java.lang.Object filterOutboundMessage (java.lang.Object)
io.netty.buffer.ByteBuf buf
Object msg
protected final void incompleteWrite (boolean)
Runnable flushTask
boolean setOpWrite
protected abstract long doWriteFileRegion (io.netty.channel.FileRegion) throws java.lang.Exception
protected abstract int doReadBytes (io.netty.buffer.ByteBuf) throws java.lang.Exception
protected abstract int doWriteBytes (io.netty.buffer.ByteBuf) throws java.lang.Exception
protected final void setOpWrite ()
java.nio.channels.SelectionKey key
int interestOps
protected final void clearOpWrite ()
java.nio.channels.SelectionKey key
int interestOps
protected volatile io.netty.channel.AbstractChannel$AbstractUnsafe newUnsafe ()
static void ()
}
io/netty/channel/nio/AbstractNioChannel$AbstractNioUnsafe$1.classAbstractNioChannel.java
package io.netty.channel.nio
io.netty.channel.nio.AbstractNioChannel$AbstractNioUnsafe$1 extends io.netty.util.internal.OneTimeTask {
final java.net.SocketAddress val$remoteAddress
final io.netty.channel.nio.AbstractNioChannel$AbstractNioUnsafe this$1
void (io.netty.channel.nio.AbstractNioChannel$AbstractNioUnsafe, java.net.SocketAddress)
public void run ()
io.netty.channel.ChannelPromise connectPromise
io.netty.channel.ConnectTimeoutException cause
}
io/netty/channel/nio/AbstractNioMessageChannel$NioMessageUnsafe.classAbstractNioMessageChannel.java
package io.netty.channel.nio
final io.netty.channel.nio.AbstractNioMessageChannel$NioMessageUnsafe extends io.netty.channel.nio.AbstractNioChannel$AbstractNioUnsafe {
private final java.util.List readBuf
static final boolean $assertionsDisabled
final io.netty.channel.nio.AbstractNioMessageChannel this$0
private void (io.netty.channel.nio.AbstractNioMessageChannel)
public void read ()
int localRead
boolean needReadPendingReset
Throwable t
int i
int size
io.netty.channel.ChannelConfig config
io.netty.channel.ChannelPipeline pipeline
io.netty.channel.RecvByteBufAllocator$Handle allocHandle
boolean closed
Throwable exception
void (io.netty.channel.nio.AbstractNioMessageChannel, io.netty.channel.nio.AbstractNioMessageChannel$1)
io.netty.channel.nio.AbstractNioMessageChannel x0
io.netty.channel.nio.AbstractNioMessageChannel$1 x1
static void ()
}
io/netty/channel/nio/NioEventLoop$1.classNioEventLoop.java
package io.netty.channel.nio
io.netty.channel.nio.NioEventLoop$1 extends java.lang.Object implements java.lang.Runnable {
final io.netty.channel.nio.NioEventLoop this$0
void (io.netty.channel.nio.NioEventLoop)
public void run ()
}
io/netty/channel/nio/AbstractNioChannel.classAbstractNioChannel.java
package io.netty.channel.nio
public abstract io.netty.channel.nio.AbstractNioChannel extends io.netty.channel.AbstractChannel {
private static final io.netty.util.internal.logging.InternalLogger logger
private static final java.nio.channels.ClosedChannelException CLOSED_CHANNEL_EXCEPTION
private final java.nio.channels.SelectableChannel ch
protected final int readInterestOp
volatile java.nio.channels.SelectionKey selectionKey
private volatile boolean inputShutdown
private volatile boolean readPending
private io.netty.channel.ChannelPromise connectPromise
private java.util.concurrent.ScheduledFuture connectTimeoutFuture
private java.net.SocketAddress requestedRemoteAddress
static final boolean $assertionsDisabled
protected void (io.netty.channel.Channel, java.nio.channels.SelectableChannel, int)
java.io.IOException e2
java.io.IOException e
io.netty.channel.Channel parent
java.nio.channels.SelectableChannel ch
int readInterestOp
public boolean isOpen ()
public io.netty.channel.nio.AbstractNioChannel$NioUnsafe unsafe ()
protected java.nio.channels.SelectableChannel javaChannel ()
public io.netty.channel.nio.NioEventLoop eventLoop ()
protected java.nio.channels.SelectionKey selectionKey ()
protected boolean isReadPending ()
protected void setReadPending (boolean)
boolean readPending
protected boolean isInputShutdown ()
void setInputShutdown ()
protected boolean isCompatible (io.netty.channel.EventLoop)
io.netty.channel.EventLoop loop
protected void doRegister () throws java.lang.Exception
java.nio.channels.CancelledKeyException e
boolean selected
protected void doDeregister () throws java.lang.Exception
protected void doBeginRead () throws java.lang.Exception
java.nio.channels.SelectionKey selectionKey
int interestOps
protected abstract boolean doConnect (java.net.SocketAddress, java.net.SocketAddress) throws java.lang.Exception
protected abstract void doFinishConnect () throws java.lang.Exception
protected final io.netty.buffer.ByteBuf newDirectBuffer (io.netty.buffer.ByteBuf)
io.netty.buffer.ByteBuf directBuf
io.netty.buffer.ByteBuf buf
int readableBytes
io.netty.buffer.ByteBufAllocator alloc
io.netty.buffer.ByteBuf directBuf
protected final io.netty.buffer.ByteBuf newDirectBuffer (io.netty.util.ReferenceCounted, io.netty.buffer.ByteBuf)
io.netty.buffer.ByteBuf directBuf
io.netty.util.ReferenceCounted holder
io.netty.buffer.ByteBuf buf
int readableBytes
io.netty.buffer.ByteBufAllocator alloc
io.netty.buffer.ByteBuf directBuf
protected void doClose () throws java.lang.Exception
io.netty.channel.ChannelPromise promise
java.util.concurrent.ScheduledFuture future
public volatile io.netty.channel.Channel$Unsafe unsafe ()
public volatile io.netty.channel.EventLoop eventLoop ()
static io.netty.channel.ChannelPromise access$000 (io.netty.channel.nio.AbstractNioChannel)
io.netty.channel.nio.AbstractNioChannel x0
static io.netty.channel.ChannelPromise access$002 (io.netty.channel.nio.AbstractNioChannel, io.netty.channel.ChannelPromise)
io.netty.channel.nio.AbstractNioChannel x0
io.netty.channel.ChannelPromise x1
static java.net.SocketAddress access$102 (io.netty.channel.nio.AbstractNioChannel, java.net.SocketAddress)
io.netty.channel.nio.AbstractNioChannel x0
java.net.SocketAddress x1
static java.util.concurrent.ScheduledFuture access$202 (io.netty.channel.nio.AbstractNioChannel, java.util.concurrent.ScheduledFuture)
io.netty.channel.nio.AbstractNioChannel x0
java.util.concurrent.ScheduledFuture x1
static java.util.concurrent.ScheduledFuture access$200 (io.netty.channel.nio.AbstractNioChannel)
io.netty.channel.nio.AbstractNioChannel x0
static java.net.SocketAddress access$100 (io.netty.channel.nio.AbstractNioChannel)
io.netty.channel.nio.AbstractNioChannel x0
static void ()
}
io/netty/channel/nio/AbstractNioChannel$NioUnsafe.classAbstractNioChannel.java
package io.netty.channel.nio
public abstract io.netty.channel.nio.AbstractNioChannel$NioUnsafe extends java.lang.Object implements io.netty.channel.Channel$Unsafe {
public abstract java.nio.channels.SelectableChannel ch ()
public abstract void finishConnect ()
public abstract void read ()
public abstract void forceFlush ()
}
io/netty/channel/nio/AbstractNioMessageChannel$1.classAbstractNioMessageChannel.java
package io.netty.channel.nio
io.netty.channel.nio.AbstractNioMessageChannel$1 extends java.lang.Object {
}
io/netty/channel/DefaultChannelHandlerInvoker$5.classDefaultChannelHandlerInvoker.java
package io.netty.channel
io.netty.channel.DefaultChannelHandlerInvoker$5 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.ChannelHandlerContext val$ctx
final Throwable val$cause
final io.netty.channel.DefaultChannelHandlerInvoker this$0
void (io.netty.channel.DefaultChannelHandlerInvoker, io.netty.channel.ChannelHandlerContext, java.lang.Throwable)
public void run ()
}
io/netty/channel/DefaultChannelHandlerInvoker$WriteTask$1.classDefaultChannelHandlerInvoker.java
package io.netty.channel
final io.netty.channel.DefaultChannelHandlerInvoker$WriteTask$1 extends io.netty.util.Recycler {
void ()
protected io.netty.channel.DefaultChannelHandlerInvoker$WriteTask newObject (io.netty.util.Recycler$Handle)
io.netty.util.Recycler$Handle handle
protected volatile java.lang.Object newObject (io.netty.util.Recycler$Handle)
}
io/netty/channel/ChannelDuplexHandler.classChannelDuplexHandler.java
package io.netty.channel
public io.netty.channel.ChannelDuplexHandler extends io.netty.channel.ChannelInboundHandlerAdapter implements io.netty.channel.ChannelOutboundHandler {
public void ()
public void bind (io.netty.channel.ChannelHandlerContext, java.net.SocketAddress, io.netty.channel.ChannelPromise) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
java.net.SocketAddress localAddress
io.netty.channel.ChannelPromise future
public void connect (io.netty.channel.ChannelHandlerContext, java.net.SocketAddress, java.net.SocketAddress, io.netty.channel.ChannelPromise) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
java.net.SocketAddress remoteAddress
java.net.SocketAddress localAddress
io.netty.channel.ChannelPromise future
public void disconnect (io.netty.channel.ChannelHandlerContext, io.netty.channel.ChannelPromise) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
io.netty.channel.ChannelPromise future
public void close (io.netty.channel.ChannelHandlerContext, io.netty.channel.ChannelPromise) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
io.netty.channel.ChannelPromise future
public void deregister (io.netty.channel.ChannelHandlerContext, io.netty.channel.ChannelPromise) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
io.netty.channel.ChannelPromise future
public void read (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
public void write (io.netty.channel.ChannelHandlerContext, java.lang.Object, io.netty.channel.ChannelPromise) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
Object msg
io.netty.channel.ChannelPromise promise
public void flush (io.netty.channel.ChannelHandlerContext) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
}
io/netty/channel/EventLoopException.classEventLoopException.java
package io.netty.channel
public io.netty.channel.EventLoopException extends io.netty.channel.ChannelException {
private static final long serialVersionUID
public void ()
public void (java.lang.String, java.lang.Throwable)
String message
Throwable cause
public void (java.lang.String)
String message
public void (java.lang.Throwable)
Throwable cause
}
io/netty/channel/DefaultChannelHandlerInvoker$15.classDefaultChannelHandlerInvoker.java
package io.netty.channel
io.netty.channel.DefaultChannelHandlerInvoker$15 extends java.lang.Object implements java.lang.Runnable {
final io.netty.channel.ChannelHandlerContext val$ctx
final io.netty.channel.DefaultChannelHandlerInvoker this$0
void (io.netty.channel.DefaultChannelHandlerInvoker, io.netty.channel.ChannelHandlerContext)
public void run ()
}
io/netty/channel/ChannelOption$1.classChannelOption.java
package io.netty.channel
final io.netty.channel.ChannelOption$1 extends io.netty.util.ConstantPool {
void ()
protected io.netty.channel.ChannelOption newConstant (int, java.lang.String)
int id
String name
protected volatile io.netty.util.Constant newConstant (int, java.lang.String)
}
io/netty/channel/DefaultChannelHandlerInvoker$10.classDefaultChannelHandlerInvoker.java
package io.netty.channel
io.netty.channel.DefaultChannelHandlerInvoker$10 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.ChannelHandlerContext val$ctx
final java.net.SocketAddress val$localAddress
final io.netty.channel.ChannelPromise val$promise
final io.netty.channel.DefaultChannelHandlerInvoker this$0
void (io.netty.channel.DefaultChannelHandlerInvoker, io.netty.channel.ChannelHandlerContext, java.net.SocketAddress, io.netty.channel.ChannelPromise)
public void run ()
}
io/netty/channel/pool/ChannelPoolMap.classChannelPoolMap.java
package io.netty.channel.pool
public abstract io.netty.channel.pool.ChannelPoolMap extends java.lang.Object {
public abstract io.netty.channel.pool.ChannelPool get (java.lang.Object)
public abstract boolean contains (java.lang.Object)
}
io/netty/channel/pool/FixedChannelPool$AcquireListener.classFixedChannelPool.java
package io.netty.channel.pool
io.netty.channel.pool.FixedChannelPool$AcquireListener extends java.lang.Object implements io.netty.util.concurrent.FutureListener {
private final io.netty.util.concurrent.Promise originalPromise
protected boolean acquired
static final boolean $assertionsDisabled
final io.netty.channel.pool.FixedChannelPool this$0
void (io.netty.channel.pool.FixedChannelPool, io.netty.util.concurrent.Promise)
io.netty.util.concurrent.Promise originalPromise
public void operationComplete (io.netty.util.concurrent.Future) throws java.lang.Exception
io.netty.util.concurrent.Future future
public void acquired ()
static void ()
}
io/netty/channel/pool/SimpleChannelPool$2.classSimpleChannelPool.java
package io.netty.channel.pool
io.netty.channel.pool.SimpleChannelPool$2 extends java.lang.Object implements io.netty.channel.ChannelFutureListener {
final io.netty.util.concurrent.Promise val$promise
final io.netty.channel.pool.SimpleChannelPool this$0
void (io.netty.channel.pool.SimpleChannelPool, io.netty.util.concurrent.Promise)
public void operationComplete (io.netty.channel.ChannelFuture) throws java.lang.Exception
io.netty.channel.ChannelFuture future
public volatile void operationComplete (io.netty.util.concurrent.Future) throws java.lang.Exception
}
io/netty/channel/pool/ChannelHealthChecker.classChannelHealthChecker.java
package io.netty.channel.pool
public abstract io.netty.channel.pool.ChannelHealthChecker extends java.lang.Object {
public static final io.netty.channel.pool.ChannelHealthChecker ACTIVE
public abstract io.netty.util.concurrent.Future isHealthy (io.netty.channel.Channel)
static void ()
}
io/netty/channel/pool/FixedChannelPool.classFixedChannelPool.java
package io.netty.channel.pool
public final io.netty.channel.pool.FixedChannelPool extends io.netty.channel.pool.SimpleChannelPool {
private static final IllegalStateException FULL_EXCEPTION
private static final java.util.concurrent.TimeoutException TIMEOUT_EXCEPTION
private final io.netty.util.concurrent.EventExecutor executor
private final long acquireTimeoutNanos
private final Runnable timeoutTask
private final java.util.Queue pendingAcquireQueue
private final int maxConnections
private final int maxPendingAcquires
private int acquiredChannelCount
private int pendingAcquireCount
private boolean closed
static final boolean $assertionsDisabled
public void (io.netty.bootstrap.Bootstrap, io.netty.channel.pool.ChannelPoolHandler, int)
io.netty.bootstrap.Bootstrap bootstrap
io.netty.channel.pool.ChannelPoolHandler handler
int maxConnections
public void (io.netty.bootstrap.Bootstrap, io.netty.channel.pool.ChannelPoolHandler, int, int)
io.netty.bootstrap.Bootstrap bootstrap
io.netty.channel.pool.ChannelPoolHandler handler
int maxConnections
int maxPendingAcquires
public void (io.netty.bootstrap.Bootstrap, io.netty.channel.pool.ChannelPoolHandler, io.netty.channel.pool.ChannelHealthChecker, io.netty.channel.pool.FixedChannelPool$AcquireTimeoutAction, long, int, int)
io.netty.bootstrap.Bootstrap bootstrap
io.netty.channel.pool.ChannelPoolHandler handler
io.netty.channel.pool.ChannelHealthChecker healthCheck
io.netty.channel.pool.FixedChannelPool$AcquireTimeoutAction action
long acquireTimeoutMillis
int maxConnections
int maxPendingAcquires
public void (io.netty.bootstrap.Bootstrap, io.netty.channel.pool.ChannelPoolHandler, io.netty.channel.pool.ChannelHealthChecker, io.netty.channel.pool.FixedChannelPool$AcquireTimeoutAction, long, int, int, boolean)
io.netty.bootstrap.Bootstrap bootstrap
io.netty.channel.pool.ChannelPoolHandler handler
io.netty.channel.pool.ChannelHealthChecker healthCheck
io.netty.channel.pool.FixedChannelPool$AcquireTimeoutAction action
long acquireTimeoutMillis
int maxConnections
int maxPendingAcquires
boolean releaseHealthCheck
public io.netty.util.concurrent.Future acquire (io.netty.util.concurrent.Promise)
Throwable cause
io.netty.util.concurrent.Promise promise
private void acquire0 (io.netty.util.concurrent.Promise)
io.netty.util.concurrent.Promise p
io.netty.channel.pool.FixedChannelPool$AcquireListener l
io.netty.channel.pool.FixedChannelPool$AcquireTask task
io.netty.util.concurrent.Promise promise
public io.netty.util.concurrent.Future release (io.netty.channel.Channel, io.netty.util.concurrent.Promise)
io.netty.channel.Channel channel
io.netty.util.concurrent.Promise promise
io.netty.util.concurrent.Promise p
private void decrementAndRunTaskQueue ()
private void runTaskQueue ()
io.netty.channel.pool.FixedChannelPool$AcquireTask task
java.util.concurrent.ScheduledFuture timeoutFuture
public void close ()
static java.util.concurrent.TimeoutException access$100 ()
static io.netty.util.concurrent.Future access$201 (io.netty.channel.pool.FixedChannelPool, io.netty.util.concurrent.Promise)
io.netty.channel.pool.FixedChannelPool x0
io.netty.util.concurrent.Promise x1
static void access$300 (io.netty.channel.pool.FixedChannelPool, io.netty.util.concurrent.Promise)
io.netty.channel.pool.FixedChannelPool x0
io.netty.util.concurrent.Promise x1
static io.netty.util.concurrent.EventExecutor access$400 (io.netty.channel.pool.FixedChannelPool)
io.netty.channel.pool.FixedChannelPool x0
static boolean access$500 (io.netty.channel.pool.FixedChannelPool)
io.netty.channel.pool.FixedChannelPool x0
static void access$600 (io.netty.channel.pool.FixedChannelPool)
io.netty.channel.pool.FixedChannelPool x0
static long access$700 (io.netty.channel.pool.FixedChannelPool)
io.netty.channel.pool.FixedChannelPool x0
static java.util.Queue access$800 (io.netty.channel.pool.FixedChannelPool)
io.netty.channel.pool.FixedChannelPool x0
static int access$906 (io.netty.channel.pool.FixedChannelPool)
io.netty.channel.pool.FixedChannelPool x0
static void access$1000 (io.netty.channel.pool.FixedChannelPool)
io.netty.channel.pool.FixedChannelPool x0
static int access$1108 (io.netty.channel.pool.FixedChannelPool)
io.netty.channel.pool.FixedChannelPool x0
static boolean access$502 (io.netty.channel.pool.FixedChannelPool, boolean)
io.netty.channel.pool.FixedChannelPool x0
boolean x1
static int access$1102 (io.netty.channel.pool.FixedChannelPool, int)
io.netty.channel.pool.FixedChannelPool x0
int x1
static int access$902 (io.netty.channel.pool.FixedChannelPool, int)
io.netty.channel.pool.FixedChannelPool x0
int x1
static void access$1201 (io.netty.channel.pool.FixedChannelPool)
io.netty.channel.pool.FixedChannelPool x0
static void ()
}
io/netty/channel/pool/FixedChannelPool$6.classFixedChannelPool.java
package io.netty.channel.pool
io.netty.channel.pool.FixedChannelPool$6 extends java.lang.Object {
static final int[] $SwitchMap$io$netty$channel$pool$FixedChannelPool$AcquireTimeoutAction
static void ()
}
io/netty/channel/pool/FixedChannelPool$4.classFixedChannelPool.java
package io.netty.channel.pool
io.netty.channel.pool.FixedChannelPool$4 extends java.lang.Object implements io.netty.util.concurrent.FutureListener {
static final boolean $assertionsDisabled
final io.netty.util.concurrent.Promise val$promise
final io.netty.channel.pool.FixedChannelPool this$0
void (io.netty.channel.pool.FixedChannelPool, io.netty.util.concurrent.Promise)
public void operationComplete (io.netty.util.concurrent.Future) throws java.lang.Exception
Throwable cause
io.netty.util.concurrent.Future future
static void ()
}
io/netty/channel/pool/FixedChannelPool$1.classFixedChannelPool.java
package io.netty.channel.pool
io.netty.channel.pool.FixedChannelPool$1 extends io.netty.channel.pool.FixedChannelPool$TimeoutTask {
final io.netty.channel.pool.FixedChannelPool this$0
void (io.netty.channel.pool.FixedChannelPool)
public void onTimeout (io.netty.channel.pool.FixedChannelPool$AcquireTask)
io.netty.channel.pool.FixedChannelPool$AcquireTask task
}
io/netty/channel/pool/SimpleChannelPool.classSimpleChannelPool.java
package io.netty.channel.pool
public io.netty.channel.pool.SimpleChannelPool extends java.lang.Object implements io.netty.channel.pool.ChannelPool {
private static final io.netty.util.AttributeKey POOL_KEY
private static final IllegalStateException FULL_EXCEPTION
private static final IllegalStateException UNHEALTHY_NON_OFFERED_TO_POOL
private final java.util.Deque deque
private final io.netty.channel.pool.ChannelPoolHandler handler
private final io.netty.channel.pool.ChannelHealthChecker healthCheck
private final io.netty.bootstrap.Bootstrap bootstrap
private final boolean releaseHealthCheck
static final boolean $assertionsDisabled
public void (io.netty.bootstrap.Bootstrap, io.netty.channel.pool.ChannelPoolHandler)
io.netty.bootstrap.Bootstrap bootstrap
io.netty.channel.pool.ChannelPoolHandler handler
public void (io.netty.bootstrap.Bootstrap, io.netty.channel.pool.ChannelPoolHandler, io.netty.channel.pool.ChannelHealthChecker)
io.netty.bootstrap.Bootstrap bootstrap
io.netty.channel.pool.ChannelPoolHandler handler
io.netty.channel.pool.ChannelHealthChecker healthCheck
public void (io.netty.bootstrap.Bootstrap, io.netty.channel.pool.ChannelPoolHandler, io.netty.channel.pool.ChannelHealthChecker, boolean)
io.netty.bootstrap.Bootstrap bootstrap
io.netty.channel.pool.ChannelPoolHandler handler
io.netty.channel.pool.ChannelHealthChecker healthCheck
boolean releaseHealthCheck
public final io.netty.util.concurrent.Future acquire ()
public io.netty.util.concurrent.Future acquire (io.netty.util.concurrent.Promise)
io.netty.util.concurrent.Promise promise
private io.netty.util.concurrent.Future acquireHealthyFromPoolOrNew (io.netty.util.concurrent.Promise)
io.netty.bootstrap.Bootstrap bs
io.netty.channel.ChannelFuture f
io.netty.channel.Channel ch
io.netty.channel.EventLoop loop
Throwable cause
io.netty.util.concurrent.Promise promise
private static void notifyConnect (io.netty.channel.ChannelFuture, io.netty.util.concurrent.Promise)
io.netty.channel.ChannelFuture future
io.netty.util.concurrent.Promise promise
private void doHealthCheck (io.netty.channel.Channel, io.netty.util.concurrent.Promise)
io.netty.channel.Channel ch
io.netty.util.concurrent.Promise promise
io.netty.util.concurrent.Future f
private void notifyHealthCheck (io.netty.util.concurrent.Future, io.netty.channel.Channel, io.netty.util.concurrent.Promise)
Throwable cause
io.netty.util.concurrent.Future future
io.netty.channel.Channel ch
io.netty.util.concurrent.Promise promise
protected io.netty.channel.ChannelFuture connectChannel (io.netty.bootstrap.Bootstrap)
io.netty.bootstrap.Bootstrap bs
public final io.netty.util.concurrent.Future release (io.netty.channel.Channel)
io.netty.channel.Channel channel
public io.netty.util.concurrent.Future release (io.netty.channel.Channel, io.netty.util.concurrent.Promise)
io.netty.channel.EventLoop loop
Throwable cause
io.netty.channel.Channel channel
io.netty.util.concurrent.Promise promise
private void doReleaseChannel (io.netty.channel.Channel, io.netty.util.concurrent.Promise)
Throwable cause
io.netty.channel.Channel channel
io.netty.util.concurrent.Promise promise
private void doHealthCheckOnRelease (io.netty.channel.Channel, io.netty.util.concurrent.Promise) throws java.lang.Exception
io.netty.channel.Channel channel
io.netty.util.concurrent.Promise promise
io.netty.util.concurrent.Future f
private void releaseAndOfferIfHealthy (io.netty.channel.Channel, io.netty.util.concurrent.Promise, io.netty.util.concurrent.Future) throws java.lang.Exception
io.netty.channel.Channel channel
io.netty.util.concurrent.Promise promise
io.netty.util.concurrent.Future future
private void releaseAndOffer (io.netty.channel.Channel, io.netty.util.concurrent.Promise) throws java.lang.Exception
io.netty.channel.Channel channel
io.netty.util.concurrent.Promise promise
private static void closeChannel (io.netty.channel.Channel)
io.netty.channel.Channel channel
private static void closeAndFail (io.netty.channel.Channel, java.lang.Throwable, io.netty.util.concurrent.Promise)
io.netty.channel.Channel channel
Throwable cause
io.netty.util.concurrent.Promise promise
protected io.netty.channel.Channel pollChannel ()
protected boolean offerChannel (io.netty.channel.Channel)
io.netty.channel.Channel channel
public void close ()
io.netty.channel.Channel channel
static void access$000 (io.netty.channel.ChannelFuture, io.netty.util.concurrent.Promise)
io.netty.channel.ChannelFuture x0
io.netty.util.concurrent.Promise x1
static void access$100 (io.netty.channel.pool.SimpleChannelPool, io.netty.channel.Channel, io.netty.util.concurrent.Promise)
io.netty.channel.pool.SimpleChannelPool x0
io.netty.channel.Channel x1
io.netty.util.concurrent.Promise x2
static void access$200 (io.netty.channel.pool.SimpleChannelPool, io.netty.util.concurrent.Future, io.netty.channel.Channel, io.netty.util.concurrent.Promise)
io.netty.channel.pool.SimpleChannelPool x0
io.netty.util.concurrent.Future x1
io.netty.channel.Channel x2
io.netty.util.concurrent.Promise x3
static void access$300 (io.netty.channel.pool.SimpleChannelPool, io.netty.channel.Channel, io.netty.util.concurrent.Promise)
io.netty.channel.pool.SimpleChannelPool x0
io.netty.channel.Channel x1
io.netty.util.concurrent.Promise x2
static void access$400 (io.netty.channel.pool.SimpleChannelPool, io.netty.channel.Channel, io.netty.util.concurrent.Promise, io.netty.util.concurrent.Future) throws java.lang.Exception
io.netty.channel.pool.SimpleChannelPool x0
io.netty.channel.Channel x1
io.netty.util.concurrent.Promise x2
io.netty.util.concurrent.Future x3
static void ()
}
io/netty/channel/pool/FixedChannelPool$AcquireTimeoutAction.classFixedChannelPool.java
package io.netty.channel.pool
public final io.netty.channel.pool.FixedChannelPool$AcquireTimeoutAction extends java.lang.Enum {
public static final io.netty.channel.pool.FixedChannelPool$AcquireTimeoutAction NEW
public static final io.netty.channel.pool.FixedChannelPool$AcquireTimeoutAction FAIL
private static final io.netty.channel.pool.FixedChannelPool$AcquireTimeoutAction[] $VALUES
public static io.netty.channel.pool.FixedChannelPool$AcquireTimeoutAction[] values ()
public static io.netty.channel.pool.FixedChannelPool$AcquireTimeoutAction valueOf (java.lang.String)
String name
private void (java.lang.String, int)
static void ()
}
io/netty/channel/pool/ChannelPoolHandler.classChannelPoolHandler.java
package io.netty.channel.pool
public abstract io.netty.channel.pool.ChannelPoolHandler extends java.lang.Object {
public abstract void channelReleased (io.netty.channel.Channel) throws java.lang.Exception
public abstract void channelAcquired (io.netty.channel.Channel) throws java.lang.Exception
public abstract void channelCreated (io.netty.channel.Channel) throws java.lang.Exception
}
io/netty/channel/pool/SimpleChannelPool$3.classSimpleChannelPool.java
package io.netty.channel.pool
io.netty.channel.pool.SimpleChannelPool$3 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.Channel val$ch
final io.netty.util.concurrent.Promise val$promise
final io.netty.channel.pool.SimpleChannelPool this$0
void (io.netty.channel.pool.SimpleChannelPool, io.netty.channel.Channel, io.netty.util.concurrent.Promise)
public void run ()
}
io/netty/channel/pool/ChannelPool.classChannelPool.java
package io.netty.channel.pool
public abstract io.netty.channel.pool.ChannelPool extends java.lang.Object implements java.io.Closeable {
public abstract io.netty.util.concurrent.Future acquire ()
public abstract io.netty.util.concurrent.Future acquire (io.netty.util.concurrent.Promise)
public abstract io.netty.util.concurrent.Future release (io.netty.channel.Channel)
public abstract io.netty.util.concurrent.Future release (io.netty.channel.Channel, io.netty.util.concurrent.Promise)
public abstract void close ()
}
io/netty/channel/pool/FixedChannelPool$TimeoutTask.classFixedChannelPool.java
package io.netty.channel.pool
abstract io.netty.channel.pool.FixedChannelPool$TimeoutTask extends java.lang.Object implements java.lang.Runnable {
static final boolean $assertionsDisabled
final io.netty.channel.pool.FixedChannelPool this$0
private void (io.netty.channel.pool.FixedChannelPool)
public final void run ()
io.netty.channel.pool.FixedChannelPool$AcquireTask task
long nanoTime
public abstract void onTimeout (io.netty.channel.pool.FixedChannelPool$AcquireTask)
void (io.netty.channel.pool.FixedChannelPool, io.netty.channel.pool.FixedChannelPool$1)
io.netty.channel.pool.FixedChannelPool x0
io.netty.channel.pool.FixedChannelPool$1 x1
static void ()
}
io/netty/channel/pool/FixedChannelPool$5.classFixedChannelPool.java
package io.netty.channel.pool
io.netty.channel.pool.FixedChannelPool$5 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.pool.FixedChannelPool this$0
void (io.netty.channel.pool.FixedChannelPool)
public void run ()
io.netty.channel.pool.FixedChannelPool$AcquireTask task
java.util.concurrent.ScheduledFuture f
}
io/netty/channel/pool/ChannelHealthChecker$1.classChannelHealthChecker.java
package io.netty.channel.pool
final io.netty.channel.pool.ChannelHealthChecker$1 extends java.lang.Object implements io.netty.channel.pool.ChannelHealthChecker {
void ()
public io.netty.util.concurrent.Future isHealthy (io.netty.channel.Channel)
io.netty.channel.Channel channel
io.netty.channel.EventLoop loop
}
io/netty/channel/pool/SimpleChannelPool$1.classSimpleChannelPool.java
package io.netty.channel.pool
io.netty.channel.pool.SimpleChannelPool$1 extends io.netty.channel.ChannelInitializer {
static final boolean $assertionsDisabled
final io.netty.channel.pool.ChannelPoolHandler val$handler
final io.netty.channel.pool.SimpleChannelPool this$0
void (io.netty.channel.pool.SimpleChannelPool, io.netty.channel.pool.ChannelPoolHandler)
protected void initChannel (io.netty.channel.Channel) throws java.lang.Exception
io.netty.channel.Channel ch
static void ()
}
io/netty/channel/pool/FixedChannelPool$2.classFixedChannelPool.java
package io.netty.channel.pool
io.netty.channel.pool.FixedChannelPool$2 extends io.netty.channel.pool.FixedChannelPool$TimeoutTask {
final io.netty.channel.pool.FixedChannelPool this$0
void (io.netty.channel.pool.FixedChannelPool)
public void onTimeout (io.netty.channel.pool.FixedChannelPool$AcquireTask)
io.netty.channel.pool.FixedChannelPool$AcquireTask task
}
io/netty/channel/pool/SimpleChannelPool$6.classSimpleChannelPool.java
package io.netty.channel.pool
io.netty.channel.pool.SimpleChannelPool$6 extends java.lang.Object implements io.netty.util.concurrent.FutureListener {
final io.netty.channel.Channel val$channel
final io.netty.util.concurrent.Promise val$promise
final io.netty.util.concurrent.Future val$f
final io.netty.channel.pool.SimpleChannelPool this$0
void (io.netty.channel.pool.SimpleChannelPool, io.netty.channel.Channel, io.netty.util.concurrent.Promise, io.netty.util.concurrent.Future)
public void operationComplete (io.netty.util.concurrent.Future) throws java.lang.Exception
io.netty.util.concurrent.Future future
}
io/netty/channel/pool/AbstractChannelPoolMap.classAbstractChannelPoolMap.java
package io.netty.channel.pool
public abstract io.netty.channel.pool.AbstractChannelPoolMap extends java.lang.Object implements io.netty.channel.pool.ChannelPoolMap java.lang.Iterable java.io.Closeable {
private final java.util.concurrent.ConcurrentMap map
public void ()
public final io.netty.channel.pool.ChannelPool get (java.lang.Object)
io.netty.channel.pool.ChannelPool old
Object key
io.netty.channel.pool.ChannelPool pool
public final boolean remove (java.lang.Object)
Object key
io.netty.channel.pool.ChannelPool pool
public final java.util.Iterator iterator ()
public final int size ()
public final boolean isEmpty ()
public final boolean contains (java.lang.Object)
Object key
protected abstract io.netty.channel.pool.ChannelPool newPool (java.lang.Object)
public final void close ()
Object key
java.util.Iterator i$
}
io/netty/channel/pool/AbstractChannelPoolHandler.classAbstractChannelPoolHandler.java
package io.netty.channel.pool
public abstract io.netty.channel.pool.AbstractChannelPoolHandler extends java.lang.Object implements io.netty.channel.pool.ChannelPoolHandler {
public void ()
public void channelAcquired (io.netty.channel.Channel) throws java.lang.Exception
io.netty.channel.Channel ch
public void channelReleased (io.netty.channel.Channel) throws java.lang.Exception
io.netty.channel.Channel ch
}
io/netty/channel/pool/SimpleChannelPool$4.classSimpleChannelPool.java
package io.netty.channel.pool
io.netty.channel.pool.SimpleChannelPool$4 extends java.lang.Object implements io.netty.util.concurrent.FutureListener {
final io.netty.channel.Channel val$ch
final io.netty.util.concurrent.Promise val$promise
final io.netty.channel.pool.SimpleChannelPool this$0
void (io.netty.channel.pool.SimpleChannelPool, io.netty.channel.Channel, io.netty.util.concurrent.Promise)
public void operationComplete (io.netty.util.concurrent.Future) throws java.lang.Exception
io.netty.util.concurrent.Future future
}
io/netty/channel/pool/FixedChannelPool$3.classFixedChannelPool.java
package io.netty.channel.pool
io.netty.channel.pool.FixedChannelPool$3 extends io.netty.util.internal.OneTimeTask {
final io.netty.util.concurrent.Promise val$promise
final io.netty.channel.pool.FixedChannelPool this$0
void (io.netty.channel.pool.FixedChannelPool, io.netty.util.concurrent.Promise)
public void run ()
}
io/netty/channel/pool/SimpleChannelPool$5.classSimpleChannelPool.java
package io.netty.channel.pool
io.netty.channel.pool.SimpleChannelPool$5 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.Channel val$channel
final io.netty.util.concurrent.Promise val$promise
final io.netty.channel.pool.SimpleChannelPool this$0
void (io.netty.channel.pool.SimpleChannelPool, io.netty.channel.Channel, io.netty.util.concurrent.Promise)
public void run ()
}
io/netty/channel/pool/FixedChannelPool$AcquireTask.classFixedChannelPool.java
package io.netty.channel.pool
final io.netty.channel.pool.FixedChannelPool$AcquireTask extends io.netty.channel.pool.FixedChannelPool$AcquireListener {
final io.netty.util.concurrent.Promise promise
final long expireNanoTime
java.util.concurrent.ScheduledFuture timeoutFuture
final io.netty.channel.pool.FixedChannelPool this$0
public void (io.netty.channel.pool.FixedChannelPool, io.netty.util.concurrent.Promise)
io.netty.util.concurrent.Promise promise
}
io/netty/channel/DefaultChannelHandlerContext.classDefaultChannelHandlerContext.java
package io.netty.channel
final io.netty.channel.DefaultChannelHandlerContext extends io.netty.channel.AbstractChannelHandlerContext {
private final io.netty.channel.ChannelHandler handler
void (io.netty.channel.DefaultChannelPipeline, io.netty.channel.ChannelHandlerInvoker, java.lang.String, io.netty.channel.ChannelHandler)
io.netty.channel.DefaultChannelPipeline pipeline
io.netty.channel.ChannelHandlerInvoker invoker
String name
io.netty.channel.ChannelHandler handler
public io.netty.channel.ChannelHandler handler ()
private static boolean isInbound (io.netty.channel.ChannelHandler)
io.netty.channel.ChannelHandler handler
private static boolean isOutbound (io.netty.channel.ChannelHandler)
io.netty.channel.ChannelHandler handler
}
io/netty/channel/DefaultAddressedEnvelope.classDefaultAddressedEnvelope.java
package io.netty.channel
public io.netty.channel.DefaultAddressedEnvelope extends java.lang.Object implements io.netty.channel.AddressedEnvelope {
private final Object message
private final java.net.SocketAddress sender
private final java.net.SocketAddress recipient
public void (java.lang.Object, java.net.SocketAddress, java.net.SocketAddress)
Object message
java.net.SocketAddress recipient
java.net.SocketAddress sender
public void (java.lang.Object, java.net.SocketAddress)
Object message
java.net.SocketAddress recipient
public java.lang.Object content ()
public java.net.SocketAddress sender ()
public java.net.SocketAddress recipient ()
public int refCnt ()
public io.netty.channel.AddressedEnvelope retain ()
public io.netty.channel.AddressedEnvelope retain (int)
int increment
public boolean release ()
public boolean release (int)
int decrement
public io.netty.channel.AddressedEnvelope touch ()
public io.netty.channel.AddressedEnvelope touch (java.lang.Object)
Object hint
public java.lang.String toString ()
public volatile io.netty.util.ReferenceCounted touch (java.lang.Object)
public volatile io.netty.util.ReferenceCounted touch ()
public volatile io.netty.util.ReferenceCounted retain (int)
public volatile io.netty.util.ReferenceCounted retain ()
}
io/netty/channel/SingleThreadEventLoop.classSingleThreadEventLoop.java
package io.netty.channel
public abstract io.netty.channel.SingleThreadEventLoop extends io.netty.util.concurrent.SingleThreadEventExecutor implements io.netty.channel.EventLoop {
private final io.netty.channel.ChannelHandlerInvoker invoker
protected void (io.netty.channel.EventLoopGroup, java.util.concurrent.ThreadFactory, boolean)
io.netty.channel.EventLoopGroup parent
java.util.concurrent.ThreadFactory threadFactory
boolean addTaskWakesUp
protected void (io.netty.channel.EventLoopGroup, java.util.concurrent.Executor, boolean)
io.netty.channel.EventLoopGroup parent
java.util.concurrent.Executor executor
boolean addTaskWakesUp
public io.netty.channel.EventLoopGroup parent ()
public io.netty.channel.EventLoop next ()
public io.netty.channel.ChannelHandlerInvoker asInvoker ()
public io.netty.channel.ChannelFuture register (io.netty.channel.Channel)
io.netty.channel.Channel channel
public io.netty.channel.ChannelFuture register (io.netty.channel.Channel, io.netty.channel.ChannelPromise)
io.netty.channel.Channel channel
io.netty.channel.ChannelPromise promise
protected boolean wakesUpForTask (java.lang.Runnable)
Runnable task
public volatile io.netty.util.concurrent.EventExecutor next ()
public volatile io.netty.util.concurrent.EventExecutorGroup parent ()
}
io/netty/channel/AbstractEventLoopGroup.classAbstractEventLoopGroup.java
package io.netty.channel
public abstract io.netty.channel.AbstractEventLoopGroup extends io.netty.util.concurrent.AbstractEventExecutorGroup implements io.netty.channel.EventLoopGroup {
public void ()
public abstract io.netty.channel.EventLoop next ()
public volatile io.netty.util.concurrent.EventExecutor next ()
}
io/netty/channel/DefaultChannelHandlerInvoker$14.classDefaultChannelHandlerInvoker.java
package io.netty.channel
io.netty.channel.DefaultChannelHandlerInvoker$14 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.ChannelHandlerContext val$ctx
final io.netty.channel.ChannelPromise val$promise
final io.netty.channel.DefaultChannelHandlerInvoker this$0
void (io.netty.channel.DefaultChannelHandlerInvoker, io.netty.channel.ChannelHandlerContext, io.netty.channel.ChannelPromise)
public void run ()
}
io/netty/bootstrap/Bootstrap$1.classBootstrap.java
package io.netty.bootstrap
io.netty.bootstrap.Bootstrap$1 extends java.lang.Object implements io.netty.util.concurrent.FutureListener {
final io.netty.channel.Channel val$channel
final io.netty.channel.ChannelPromise val$connectPromise
final java.net.SocketAddress val$localAddress
final io.netty.channel.ChannelFuture val$regFuture
final io.netty.bootstrap.Bootstrap this$0
void (io.netty.bootstrap.Bootstrap, io.netty.channel.Channel, io.netty.channel.ChannelPromise, java.net.SocketAddress, io.netty.channel.ChannelFuture)
public void operationComplete (io.netty.util.concurrent.Future) throws java.lang.Exception
io.netty.util.concurrent.Future future
}
io/netty/bootstrap/ServerBootstrap$ServerBootstrapAcceptor.classServerBootstrap.java
package io.netty.bootstrap
io.netty.bootstrap.ServerBootstrap$ServerBootstrapAcceptor extends io.netty.channel.ChannelInboundHandlerAdapter {
private final io.netty.channel.EventLoopGroup childGroup
private final io.netty.channel.ChannelHandler childHandler
private final java.util.Map$Entry[] childOptions
private final java.util.Map$Entry[] childAttrs
void (io.netty.channel.EventLoopGroup, io.netty.channel.ChannelHandler, java.util.Map$Entry[], java.util.Map$Entry[])
io.netty.channel.EventLoopGroup childGroup
io.netty.channel.ChannelHandler childHandler
java.util.Map$Entry[] childOptions
java.util.Map$Entry[] childAttrs
public void channelRead (io.netty.channel.ChannelHandlerContext, java.lang.Object)
Throwable t
java.util.Map$Entry e
java.util.Map$Entry[] arr$
int len$
int i$
java.util.Map$Entry e
java.util.Map$Entry[] arr$
int len$
int i$
Throwable t
io.netty.channel.ChannelHandlerContext ctx
Object msg
io.netty.channel.Channel child
private static void forceClose (io.netty.channel.Channel, java.lang.Throwable)
io.netty.channel.Channel child
Throwable t
public void exceptionCaught (io.netty.channel.ChannelHandlerContext, java.lang.Throwable) throws java.lang.Exception
io.netty.channel.ChannelHandlerContext ctx
Throwable cause
io.netty.channel.ChannelConfig config
static void access$100 (io.netty.channel.Channel, java.lang.Throwable)
io.netty.channel.Channel x0
Throwable x1
}
io/netty/bootstrap/Bootstrap.classBootstrap.java
package io.netty.bootstrap
public io.netty.bootstrap.Bootstrap extends io.netty.bootstrap.AbstractBootstrap {
private static final io.netty.util.internal.logging.InternalLogger logger
private static final io.netty.resolver.AddressResolverGroup DEFAULT_RESOLVER
private volatile io.netty.resolver.AddressResolverGroup resolver
private volatile java.net.SocketAddress remoteAddress
public void ()
private void (io.netty.bootstrap.Bootstrap)
io.netty.bootstrap.Bootstrap bootstrap
public io.netty.bootstrap.Bootstrap resolver (io.netty.resolver.AddressResolverGroup)
io.netty.resolver.AddressResolverGroup resolver
public io.netty.bootstrap.Bootstrap remoteAddress (java.net.SocketAddress)
java.net.SocketAddress remoteAddress
public io.netty.bootstrap.Bootstrap remoteAddress (java.lang.String, int)
String inetHost
int inetPort
public io.netty.bootstrap.Bootstrap remoteAddress (java.net.InetAddress, int)
java.net.InetAddress inetHost
int inetPort
public io.netty.channel.ChannelFuture connect ()
java.net.SocketAddress remoteAddress
public io.netty.channel.ChannelFuture connect (java.lang.String, int)
String inetHost
int inetPort
public io.netty.channel.ChannelFuture connect (java.net.InetAddress, int)
java.net.InetAddress inetHost
int inetPort
public io.netty.channel.ChannelFuture connect (java.net.SocketAddress)
java.net.SocketAddress remoteAddress
public io.netty.channel.ChannelFuture connect (java.net.SocketAddress, java.net.SocketAddress)
java.net.SocketAddress remoteAddress
java.net.SocketAddress localAddress
private io.netty.channel.ChannelFuture doResolveAndConnect (java.net.SocketAddress, java.net.SocketAddress)
java.net.SocketAddress remoteAddress
java.net.SocketAddress localAddress
io.netty.channel.ChannelFuture regFuture
io.netty.channel.Channel channel
io.netty.channel.EventLoop eventLoop
io.netty.resolver.AddressResolver resolver
io.netty.util.concurrent.Future resolveFuture
Throwable resolveFailureCause
io.netty.channel.ChannelPromise connectPromise
private static io.netty.channel.ChannelFuture doConnect (java.net.SocketAddress, java.net.SocketAddress, io.netty.channel.ChannelFuture, io.netty.channel.ChannelPromise)
java.net.SocketAddress remoteAddress
java.net.SocketAddress localAddress
io.netty.channel.ChannelFuture regFuture
io.netty.channel.ChannelPromise connectPromise
private static void doConnect0 (java.net.SocketAddress, java.net.SocketAddress, io.netty.channel.ChannelFuture, io.netty.channel.ChannelPromise)
java.net.SocketAddress remoteAddress
java.net.SocketAddress localAddress
io.netty.channel.ChannelFuture regFuture
io.netty.channel.ChannelPromise connectPromise
io.netty.channel.Channel channel
void init (io.netty.channel.Channel) throws java.lang.Exception
Throwable t
java.util.Map$Entry e
java.util.Iterator i$
java.util.Map$Entry e
java.util.Iterator i$
io.netty.channel.Channel channel
io.netty.channel.ChannelPipeline p
java.util.Map options
java.util.Map attrs
public io.netty.bootstrap.Bootstrap validate ()
public io.netty.bootstrap.Bootstrap clone ()
public io.netty.bootstrap.Bootstrap clone (io.netty.channel.EventLoopGroup)
io.netty.channel.EventLoopGroup group
io.netty.bootstrap.Bootstrap bs
public java.lang.String toString ()
StringBuilder buf
public volatile io.netty.bootstrap.AbstractBootstrap clone ()
public volatile io.netty.bootstrap.AbstractBootstrap validate ()
public volatile java.lang.Object clone () throws java.lang.CloneNotSupportedException
static io.netty.channel.ChannelFuture access$000 (java.net.SocketAddress, java.net.SocketAddress, io.netty.channel.ChannelFuture, io.netty.channel.ChannelPromise)
java.net.SocketAddress x0
java.net.SocketAddress x1
io.netty.channel.ChannelFuture x2
io.netty.channel.ChannelPromise x3
static void access$100 (java.net.SocketAddress, java.net.SocketAddress, io.netty.channel.ChannelFuture, io.netty.channel.ChannelPromise)
java.net.SocketAddress x0
java.net.SocketAddress x1
io.netty.channel.ChannelFuture x2
io.netty.channel.ChannelPromise x3
static void ()
}
io/netty/bootstrap/Bootstrap$3.classBootstrap.java
package io.netty.bootstrap
final io.netty.bootstrap.Bootstrap$3 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.ChannelFuture val$regFuture
final java.net.SocketAddress val$localAddress
final io.netty.channel.Channel val$channel
final java.net.SocketAddress val$remoteAddress
final io.netty.channel.ChannelPromise val$connectPromise
void (io.netty.channel.ChannelFuture, java.net.SocketAddress, io.netty.channel.Channel, java.net.SocketAddress, io.netty.channel.ChannelPromise)
public void run ()
}
io/netty/bootstrap/AbstractBootstrap$1.classAbstractBootstrap.java
package io.netty.bootstrap
io.netty.bootstrap.AbstractBootstrap$1 extends java.lang.Object implements io.netty.channel.ChannelFutureListener {
final io.netty.bootstrap.AbstractBootstrap$PendingRegistrationPromise val$promise
final io.netty.channel.Channel val$channel
final io.netty.channel.ChannelFuture val$regFuture
final java.net.SocketAddress val$localAddress
final io.netty.bootstrap.AbstractBootstrap this$0
void (io.netty.bootstrap.AbstractBootstrap, io.netty.bootstrap.AbstractBootstrap$PendingRegistrationPromise, io.netty.channel.Channel, io.netty.channel.ChannelFuture, java.net.SocketAddress)
public void operationComplete (io.netty.channel.ChannelFuture) throws java.lang.Exception
io.netty.channel.ChannelFuture future
Throwable cause
public volatile void operationComplete (io.netty.util.concurrent.Future) throws java.lang.Exception
}
io/netty/bootstrap/AbstractBootstrap$PendingRegistrationPromise.classAbstractBootstrap.java
package io.netty.bootstrap
final io.netty.bootstrap.AbstractBootstrap$PendingRegistrationPromise extends io.netty.channel.DefaultChannelPromise {
private volatile io.netty.util.concurrent.EventExecutor executor
private void (io.netty.channel.Channel)
io.netty.channel.Channel channel
protected io.netty.util.concurrent.EventExecutor executor ()
io.netty.util.concurrent.EventExecutor executor
void (io.netty.channel.Channel, io.netty.bootstrap.AbstractBootstrap$1)
io.netty.channel.Channel x0
io.netty.bootstrap.AbstractBootstrap$1 x1
static io.netty.util.concurrent.EventExecutor access$102 (io.netty.bootstrap.AbstractBootstrap$PendingRegistrationPromise, io.netty.util.concurrent.EventExecutor)
io.netty.bootstrap.AbstractBootstrap$PendingRegistrationPromise x0
io.netty.util.concurrent.EventExecutor x1
}
io/netty/bootstrap/AbstractBootstrap$2.classAbstractBootstrap.java
package io.netty.bootstrap
final io.netty.bootstrap.AbstractBootstrap$2 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.ChannelFuture val$regFuture
final io.netty.channel.Channel val$channel
final java.net.SocketAddress val$localAddress
final io.netty.channel.ChannelPromise val$promise
void (io.netty.channel.ChannelFuture, io.netty.channel.Channel, java.net.SocketAddress, io.netty.channel.ChannelPromise)
public void run ()
}
io/netty/bootstrap/ServerBootstrap.classServerBootstrap.java
package io.netty.bootstrap
public io.netty.bootstrap.ServerBootstrap extends io.netty.bootstrap.AbstractBootstrap {
private static final io.netty.util.internal.logging.InternalLogger logger
private final java.util.Map childOptions
private final java.util.Map childAttrs
private volatile io.netty.channel.EventLoopGroup childGroup
private volatile io.netty.channel.ChannelHandler childHandler
public void ()
private void (io.netty.bootstrap.ServerBootstrap)
io.netty.bootstrap.ServerBootstrap bootstrap
public io.netty.bootstrap.ServerBootstrap group (io.netty.channel.EventLoopGroup)
io.netty.channel.EventLoopGroup group
public io.netty.bootstrap.ServerBootstrap group (io.netty.channel.EventLoopGroup, io.netty.channel.EventLoopGroup)
io.netty.channel.EventLoopGroup parentGroup
io.netty.channel.EventLoopGroup childGroup
public io.netty.bootstrap.ServerBootstrap childOption (io.netty.channel.ChannelOption, java.lang.Object)
io.netty.channel.ChannelOption childOption
Object value
public io.netty.bootstrap.ServerBootstrap childAttr (io.netty.util.AttributeKey, java.lang.Object)
io.netty.util.AttributeKey childKey
Object value
public io.netty.bootstrap.ServerBootstrap childHandler (io.netty.channel.ChannelHandler)
io.netty.channel.ChannelHandler childHandler
public io.netty.channel.EventLoopGroup childGroup ()
void init (io.netty.channel.Channel) throws java.lang.Exception
io.netty.util.AttributeKey key
java.util.Map$Entry e
java.util.Iterator i$
java.util.Map$Entry[] currentChildOptions
java.util.Map$Entry[] currentChildAttrs
io.netty.channel.Channel channel
java.util.Map options
java.util.Map attrs
io.netty.channel.ChannelPipeline p
io.netty.channel.EventLoopGroup currentChildGroup
io.netty.channel.ChannelHandler currentChildHandler
java.util.Map$Entry[] currentChildOptions
java.util.Map$Entry[] currentChildAttrs
public io.netty.bootstrap.ServerBootstrap validate ()
private static java.util.Map$Entry[] newOptionArray (int)
int size
private static java.util.Map$Entry[] newAttrArray (int)
int size
public io.netty.bootstrap.ServerBootstrap clone ()
public java.lang.String toString ()
StringBuilder buf
public volatile io.netty.bootstrap.AbstractBootstrap clone ()
public volatile io.netty.bootstrap.AbstractBootstrap validate ()
public volatile io.netty.bootstrap.AbstractBootstrap group (io.netty.channel.EventLoopGroup)
public volatile java.lang.Object clone () throws java.lang.CloneNotSupportedException
static io.netty.util.internal.logging.InternalLogger access$000 ()
static void ()
}
io/netty/bootstrap/AbstractBootstrap.classAbstractBootstrap.java
package io.netty.bootstrap
public abstract io.netty.bootstrap.AbstractBootstrap extends java.lang.Object implements java.lang.Cloneable {
volatile io.netty.channel.EventLoopGroup group
private volatile io.netty.bootstrap.ChannelFactory channelFactory
private volatile java.net.SocketAddress localAddress
private final java.util.Map options
private final java.util.Map attrs
private volatile io.netty.channel.ChannelHandler handler
void ()
void (io.netty.bootstrap.AbstractBootstrap)
io.netty.bootstrap.AbstractBootstrap bootstrap
public io.netty.bootstrap.AbstractBootstrap group (io.netty.channel.EventLoopGroup)
io.netty.channel.EventLoopGroup group
public io.netty.bootstrap.AbstractBootstrap channel (java.lang.Class)
Class channelClass
public io.netty.bootstrap.AbstractBootstrap channelFactory (io.netty.bootstrap.ChannelFactory)
io.netty.bootstrap.ChannelFactory channelFactory
public io.netty.bootstrap.AbstractBootstrap channelFactory (io.netty.channel.ChannelFactory)
io.netty.channel.ChannelFactory channelFactory
public io.netty.bootstrap.AbstractBootstrap localAddress (java.net.SocketAddress)
java.net.SocketAddress localAddress
public io.netty.bootstrap.AbstractBootstrap localAddress (int)
int inetPort
public io.netty.bootstrap.AbstractBootstrap localAddress (java.lang.String, int)
String inetHost
int inetPort
public io.netty.bootstrap.AbstractBootstrap localAddress (java.net.InetAddress, int)
java.net.InetAddress inetHost
int inetPort
public io.netty.bootstrap.AbstractBootstrap option (io.netty.channel.ChannelOption, java.lang.Object)
io.netty.channel.ChannelOption option
Object value
public io.netty.bootstrap.AbstractBootstrap attr (io.netty.util.AttributeKey, java.lang.Object)
io.netty.util.AttributeKey key
Object value
public io.netty.bootstrap.AbstractBootstrap validate ()
public abstract io.netty.bootstrap.AbstractBootstrap clone ()
public io.netty.channel.ChannelFuture register ()
public io.netty.channel.ChannelFuture bind ()
java.net.SocketAddress localAddress
public io.netty.channel.ChannelFuture bind (int)
int inetPort
public io.netty.channel.ChannelFuture bind (java.lang.String, int)
String inetHost
int inetPort
public io.netty.channel.ChannelFuture bind (java.net.InetAddress, int)
java.net.InetAddress inetHost
int inetPort
public io.netty.channel.ChannelFuture bind (java.net.SocketAddress)
java.net.SocketAddress localAddress
private io.netty.channel.ChannelFuture doBind (java.net.SocketAddress)
io.netty.channel.ChannelPromise promise
io.netty.bootstrap.AbstractBootstrap$PendingRegistrationPromise promise
java.net.SocketAddress localAddress
io.netty.channel.ChannelFuture regFuture
io.netty.channel.Channel channel
final io.netty.channel.ChannelFuture initAndRegister ()
Throwable t
io.netty.channel.Channel channel
io.netty.channel.ChannelFuture regFuture
abstract void init (io.netty.channel.Channel) throws java.lang.Exception
private static void doBind0 (io.netty.channel.ChannelFuture, io.netty.channel.Channel, java.net.SocketAddress, io.netty.channel.ChannelPromise)
io.netty.channel.ChannelFuture regFuture
io.netty.channel.Channel channel
java.net.SocketAddress localAddress
io.netty.channel.ChannelPromise promise
public io.netty.bootstrap.AbstractBootstrap handler (io.netty.channel.ChannelHandler)
io.netty.channel.ChannelHandler handler
final java.net.SocketAddress localAddress ()
final io.netty.bootstrap.ChannelFactory channelFactory ()
final io.netty.channel.ChannelHandler handler ()
public io.netty.channel.EventLoopGroup group ()
final java.util.Map options ()
final java.util.Map attrs ()
public java.lang.String toString ()
StringBuilder buf
public volatile java.lang.Object clone () throws java.lang.CloneNotSupportedException
static void access$200 (io.netty.channel.ChannelFuture, io.netty.channel.Channel, java.net.SocketAddress, io.netty.channel.ChannelPromise)
io.netty.channel.ChannelFuture x0
io.netty.channel.Channel x1
java.net.SocketAddress x2
io.netty.channel.ChannelPromise x3
}
io/netty/bootstrap/ServerBootstrap$ServerBootstrapAcceptor$2.classServerBootstrap.java
package io.netty.bootstrap
io.netty.bootstrap.ServerBootstrap$ServerBootstrapAcceptor$2 extends io.netty.util.internal.OneTimeTask {
final io.netty.channel.ChannelConfig val$config
final io.netty.bootstrap.ServerBootstrap$ServerBootstrapAcceptor this$0
void (io.netty.bootstrap.ServerBootstrap$ServerBootstrapAcceptor, io.netty.channel.ChannelConfig)
public void run ()
}
io/netty/bootstrap/Bootstrap$2.classBootstrap.java
package io.netty.bootstrap
final io.netty.bootstrap.Bootstrap$2 extends java.lang.Object implements io.netty.channel.ChannelFutureListener {
final java.net.SocketAddress val$remoteAddress
final java.net.SocketAddress val$localAddress
final io.netty.channel.ChannelFuture val$regFuture
final io.netty.channel.ChannelPromise val$connectPromise
void (java.net.SocketAddress, java.net.SocketAddress, io.netty.channel.ChannelFuture, io.netty.channel.ChannelPromise)
public void operationComplete (io.netty.channel.ChannelFuture) throws java.lang.Exception
io.netty.channel.ChannelFuture future
public volatile void operationComplete (io.netty.util.concurrent.Future) throws java.lang.Exception
}
io/netty/bootstrap/ChannelFactory.classChannelFactory.java
package io.netty.bootstrap
public abstract io.netty.bootstrap.ChannelFactory extends java.lang.Object {
public abstract io.netty.channel.Channel newChannel ()
}
io/netty/bootstrap/ServerBootstrap$1.classServerBootstrap.java
package io.netty.bootstrap
io.netty.bootstrap.ServerBootstrap$1 extends io.netty.channel.ChannelInitializer {
final io.netty.channel.EventLoopGroup val$currentChildGroup
final io.netty.channel.ChannelHandler val$currentChildHandler
final java.util.Map$Entry[] val$currentChildOptions
final java.util.Map$Entry[] val$currentChildAttrs
final io.netty.bootstrap.ServerBootstrap this$0
void (io.netty.bootstrap.ServerBootstrap, io.netty.channel.EventLoopGroup, io.netty.channel.ChannelHandler, java.util.Map$Entry[], java.util.Map$Entry[])
public void initChannel (io.netty.channel.Channel) throws java.lang.Exception
io.netty.channel.Channel ch
io.netty.channel.ChannelPipeline pipeline
io.netty.channel.ChannelHandler handler
}
io/netty/bootstrap/ServerBootstrap$ServerBootstrapAcceptor$1.classServerBootstrap.java
package io.netty.bootstrap
io.netty.bootstrap.ServerBootstrap$ServerBootstrapAcceptor$1 extends java.lang.Object implements io.netty.channel.ChannelFutureListener {
final io.netty.channel.Channel val$child
final io.netty.bootstrap.ServerBootstrap$ServerBootstrapAcceptor this$0
void (io.netty.bootstrap.ServerBootstrap$ServerBootstrapAcceptor, io.netty.channel.Channel)
public void operationComplete (io.netty.channel.ChannelFuture) throws java.lang.Exception
io.netty.channel.ChannelFuture future
public volatile void operationComplete (io.netty.util.concurrent.Future) throws java.lang.Exception
}
META-INF/io.netty.versions.properties
META-INF/maven/
META-INF/maven/io.netty/
META-INF/maven/io.netty/netty-transport/
META-INF/maven/io.netty/netty-transport/pom.xml
META-INF/maven/io.netty/netty-transport/pom.properties
META-INF/INDEX.LIST