- AbstractConstant<T extends AbstractConstant<T>> - Class in io.netty.util
-
- AbstractConstant(int, String) - Constructor for class io.netty.util.AbstractConstant
-
Creates a new instance.
- AbstractEventExecutor - Class in io.netty.util.concurrent
-
- AbstractEventExecutor() - Constructor for class io.netty.util.concurrent.AbstractEventExecutor
-
- AbstractEventExecutor(EventExecutorGroup) - Constructor for class io.netty.util.concurrent.AbstractEventExecutor
-
- AbstractEventExecutorGroup - Class in io.netty.util.concurrent
-
- AbstractEventExecutorGroup() - Constructor for class io.netty.util.concurrent.AbstractEventExecutorGroup
-
- AbstractFuture<V> - Class in io.netty.util.concurrent
-
Abstract
Future
implementation which does not allow for cancellation.
- AbstractFuture() - Constructor for class io.netty.util.concurrent.AbstractFuture
-
- AbstractInternalLogger - Class in io.netty.util.internal.logging
-
- AbstractInternalLogger(String) - Constructor for class io.netty.util.internal.logging.AbstractInternalLogger
-
Creates a new instance.
- AbstractReferenceCounted - Class in io.netty.util
-
- AbstractReferenceCounted() - Constructor for class io.netty.util.AbstractReferenceCounted
-
- AbstractScheduledEventExecutor - Class in io.netty.util.concurrent
-
Abstract base class for
EventExecutor
s that want to support scheduling.
- AbstractScheduledEventExecutor() - Constructor for class io.netty.util.concurrent.AbstractScheduledEventExecutor
-
- AbstractScheduledEventExecutor(EventExecutorGroup) - Constructor for class io.netty.util.concurrent.AbstractScheduledEventExecutor
-
- adapt(Runnable) - Static method in class io.netty.util.internal.chmv8.ForkJoinTask
-
Returns a new
ForkJoinTask
that performs the
run
method of the given
Runnable
as its action, and returns
a null result upon
ForkJoinTask.join()
.
- adapt(Runnable, T) - Static method in class io.netty.util.internal.chmv8.ForkJoinTask
-
Returns a new
ForkJoinTask
that performs the
run
method of the given
Runnable
as its action, and returns
the given result upon
ForkJoinTask.join()
.
- adapt(Callable<? extends T>) - Static method in class io.netty.util.internal.chmv8.ForkJoinTask
-
Returns a new
ForkJoinTask
that performs the
call
method of the given
Callable
as its action, and returns
its result upon
ForkJoinTask.join()
, translating any checked exceptions
encountered into
RuntimeException
.
- add(Promise<V>...) - Method in class io.netty.util.concurrent.PromiseAggregator
-
Add the given
Promise
s to the aggregator.
- add(String, V) - Method in class io.netty.util.DomainMappingBuilder
-
Adds a mapping that maps the specified (optionally wildcard) host name to the specified output value.
- add(String, V) - Method in class io.netty.util.DomainNameMapping
-
- add(K) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8.KeySetView
-
Adds the specified key to this set view by mapping the key to
the default mapped value in the backing map, if defined.
- add(long) - Method in class io.netty.util.internal.chmv8.LongAdderV8
-
Adds the given value.
- add(E) - Method in class io.netty.util.internal.ConcurrentSet
-
- add(long) - Method in interface io.netty.util.internal.LongCounter
-
- add(Object) - Method in class io.netty.util.internal.RecyclableArrayList
-
- add(int, Object) - Method in class io.netty.util.internal.RecyclableArrayList
-
- addAll(Collection<? extends K>) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8.KeySetView
-
- addAll(Collection<?>) - Method in class io.netty.util.internal.RecyclableArrayList
-
- addAll(int, Collection<?>) - Method in class io.netty.util.internal.RecyclableArrayList
-
- addListener(GenericFutureListener<? extends Future<? super V>>) - Method in class io.netty.util.concurrent.CompleteFuture
-
- addListener(GenericFutureListener<? extends Future<? super V>>) - Method in class io.netty.util.concurrent.DefaultProgressivePromise
-
- addListener(GenericFutureListener<? extends Future<? super V>>) - Method in class io.netty.util.concurrent.DefaultPromise
-
- addListener(GenericFutureListener<? extends Future<? super V>>) - Method in interface io.netty.util.concurrent.Future
-
Adds the specified listener to this future.
- addListener(GenericFutureListener<? extends Future<? super V>>) - Method in interface io.netty.util.concurrent.ProgressiveFuture
-
- addListener(GenericFutureListener<? extends Future<? super V>>) - Method in interface io.netty.util.concurrent.ProgressivePromise
-
- addListener(GenericFutureListener<? extends Future<? super V>>) - Method in interface io.netty.util.concurrent.Promise
-
- addListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in class io.netty.util.concurrent.CompleteFuture
-
- addListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in class io.netty.util.concurrent.DefaultProgressivePromise
-
- addListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in class io.netty.util.concurrent.DefaultPromise
-
- addListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in interface io.netty.util.concurrent.Future
-
Adds the specified listeners to this future.
- addListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in interface io.netty.util.concurrent.ProgressiveFuture
-
- addListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in interface io.netty.util.concurrent.ProgressivePromise
-
- addListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in interface io.netty.util.concurrent.Promise
-
- addressSize() - Static method in class io.netty.util.internal.PlatformDependent
-
Return the address size of the OS.
4 (for 32 bits systems ) and 8 (for 64 bits systems).
- addShutdownHook(Runnable) - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
Add a
Runnable
which will be executed on shutdown of this instance
- addTask(Runnable) - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- addToPendingCount(int) - Method in class io.netty.util.internal.chmv8.CountedCompleter
-
Adds (atomically) the given value to the pending count.
- allocateMemory(long) - Static method in class io.netty.util.internal.PlatformDependent
-
- append(char) - Method in class io.netty.util.internal.AppendableCharSequence
-
- append(CharSequence) - Method in class io.netty.util.internal.AppendableCharSequence
-
- append(CharSequence, int, int) - Method in class io.netty.util.internal.AppendableCharSequence
-
- AppendableCharSequence - Class in io.netty.util.internal
-
- AppendableCharSequence(int) - Constructor for class io.netty.util.internal.AppendableCharSequence
-
- appendClassPath(ClassPath) - Static method in class io.netty.util.internal.JavassistTypeParameterMatcherGenerator
-
- appendClassPath(String) - Static method in class io.netty.util.internal.JavassistTypeParameterMatcherGenerator
-
- apply(A) - Method in interface io.netty.util.internal.chmv8.ConcurrentHashMapV8.Action
-
- apply(A, B) - Method in interface io.netty.util.internal.chmv8.ConcurrentHashMapV8.BiAction
-
- apply(A, B) - Method in interface io.netty.util.internal.chmv8.ConcurrentHashMapV8.BiFun
-
- apply(double, double) - Method in interface io.netty.util.internal.chmv8.ConcurrentHashMapV8.DoubleByDoubleToDouble
-
- apply(A) - Method in interface io.netty.util.internal.chmv8.ConcurrentHashMapV8.Fun
-
- apply(int, int) - Method in interface io.netty.util.internal.chmv8.ConcurrentHashMapV8.IntByIntToInt
-
- apply(long, long) - Method in interface io.netty.util.internal.chmv8.ConcurrentHashMapV8.LongByLongToLong
-
- apply(A, B) - Method in interface io.netty.util.internal.chmv8.ConcurrentHashMapV8.ObjectByObjectToDouble
-
- apply(A, B) - Method in interface io.netty.util.internal.chmv8.ConcurrentHashMapV8.ObjectByObjectToInt
-
- apply(A, B) - Method in interface io.netty.util.internal.chmv8.ConcurrentHashMapV8.ObjectByObjectToLong
-
- apply(A) - Method in interface io.netty.util.internal.chmv8.ConcurrentHashMapV8.ObjectToDouble
-
- apply(A) - Method in interface io.netty.util.internal.chmv8.ConcurrentHashMapV8.ObjectToInt
-
- apply(A) - Method in interface io.netty.util.internal.chmv8.ConcurrentHashMapV8.ObjectToLong
-
- array() - Method in class io.netty.util.AsciiString
-
This gives direct access to the underlying storage array.
- arrayChanged() - Method in class io.netty.util.AsciiString
-
During normal use cases the
AsciiString
should be immutable, but if the underlying array is shared,
and changes then this needs to be called.
- arrayList() - Method in class io.netty.util.internal.InternalThreadLocalMap
-
- arrayList(int) - Method in class io.netty.util.internal.InternalThreadLocalMap
-
- arrayOffset() - Method in class io.netty.util.AsciiString
-
- artifactId() - Method in class io.netty.util.Version
-
- artifactVersion() - Method in class io.netty.util.Version
-
- AsciiString - Class in io.netty.util
-
A string which has been encoded into a character encoding whose character always takes a single byte, similarly to
ASCII.
- AsciiString(byte[]) - Constructor for class io.netty.util.AsciiString
-
Initialize this byte string based upon a byte array.
- AsciiString(byte[], boolean) - Constructor for class io.netty.util.AsciiString
-
Initialize this byte string based upon a byte array.
- AsciiString(byte[], int, int, boolean) - Constructor for class io.netty.util.AsciiString
-
Construct a new instance from a byte[]
array.
- AsciiString(ByteBuffer) - Constructor for class io.netty.util.AsciiString
-
Create a copy of the underlying storage from value
.
- AsciiString(ByteBuffer, boolean) - Constructor for class io.netty.util.AsciiString
-
Initialize an instance based upon the underlying storage from value
.
- AsciiString(ByteBuffer, int, int, boolean) - Constructor for class io.netty.util.AsciiString
-
Initialize an
AsciiString
based upon the underlying storage from
value
.
- AsciiString(char[]) - Constructor for class io.netty.util.AsciiString
-
Create a copy of value
into this instance assuming ASCII encoding.
- AsciiString(char[], int, int) - Constructor for class io.netty.util.AsciiString
-
Create a copy of value
into this instance assuming ASCII encoding.
- AsciiString(char[], Charset) - Constructor for class io.netty.util.AsciiString
-
Create a copy of value
into this instance using the encoding type of charset
.
- AsciiString(char[], Charset, int, int) - Constructor for class io.netty.util.AsciiString
-
Create a copy of value
into a this instance using the encoding type of charset
.
- AsciiString(CharSequence) - Constructor for class io.netty.util.AsciiString
-
Create a copy of value
into this instance assuming ASCII encoding.
- AsciiString(CharSequence, int, int) - Constructor for class io.netty.util.AsciiString
-
Create a copy of value
into this instance assuming ASCII encoding.
- AsciiString(CharSequence, Charset) - Constructor for class io.netty.util.AsciiString
-
Create a copy of value
into this instance using the encoding type of charset
.
- AsciiString(CharSequence, Charset, int, int) - Constructor for class io.netty.util.AsciiString
-
Create a copy of value
into this instance using the encoding type of charset
.
- AsyncMapping<IN,OUT> - Interface in io.netty.util
-
- attr(AttributeKey<T>) - Method in interface io.netty.util.AttributeMap
-
- attr(AttributeKey<T>) - Method in class io.netty.util.DefaultAttributeMap
-
- Attribute<T> - Interface in io.netty.util
-
An attribute which allows to store a value reference.
- AttributeKey<T> - Class in io.netty.util
-
- AttributeMap - Interface in io.netty.util
-
- await() - Method in class io.netty.util.concurrent.CompleteFuture
-
- await(long, TimeUnit) - Method in class io.netty.util.concurrent.CompleteFuture
-
- await(long) - Method in class io.netty.util.concurrent.CompleteFuture
-
- await() - Method in class io.netty.util.concurrent.DefaultProgressivePromise
-
- await() - Method in class io.netty.util.concurrent.DefaultPromise
-
- await(long, TimeUnit) - Method in class io.netty.util.concurrent.DefaultPromise
-
- await(long) - Method in class io.netty.util.concurrent.DefaultPromise
-
- await() - Method in interface io.netty.util.concurrent.Future
-
Waits for this future to be completed.
- await(long, TimeUnit) - Method in interface io.netty.util.concurrent.Future
-
Waits for this future to be completed within the
specified time limit.
- await(long) - Method in interface io.netty.util.concurrent.Future
-
Waits for this future to be completed within the
specified time limit.
- await() - Method in interface io.netty.util.concurrent.ProgressiveFuture
-
- await() - Method in interface io.netty.util.concurrent.ProgressivePromise
-
- await() - Method in interface io.netty.util.concurrent.Promise
-
- awaitInactivity(long, TimeUnit) - Method in class io.netty.util.concurrent.GlobalEventExecutor
-
Waits until the worker thread of this executor has no tasks left in its task queue and terminates itself.
- awaitInactivity(long, TimeUnit) - Static method in class io.netty.util.ThreadDeathWatcher
-
Waits until the thread of this watcher has no threads to watch and terminates itself.
- awaitQuiescence(long, TimeUnit) - Method in class io.netty.util.internal.chmv8.ForkJoinPool
-
- awaitTermination(long, TimeUnit) - Method in class io.netty.util.concurrent.GlobalEventExecutor
-
- awaitTermination(long, TimeUnit) - Method in class io.netty.util.concurrent.ImmediateEventExecutor
-
- awaitTermination(long, TimeUnit) - Method in class io.netty.util.concurrent.MultithreadEventExecutorGroup
-
- awaitTermination(long, TimeUnit) - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- awaitTermination(long, TimeUnit) - Method in class io.netty.util.internal.chmv8.ForkJoinPool
-
Blocks until all tasks have completed execution after a
shutdown request, or the timeout occurs, or the current thread
is interrupted, whichever happens first.
- awaitUninterruptibly() - Method in class io.netty.util.concurrent.CompleteFuture
-
- awaitUninterruptibly(long, TimeUnit) - Method in class io.netty.util.concurrent.CompleteFuture
-
- awaitUninterruptibly(long) - Method in class io.netty.util.concurrent.CompleteFuture
-
- awaitUninterruptibly() - Method in class io.netty.util.concurrent.DefaultProgressivePromise
-
- awaitUninterruptibly() - Method in class io.netty.util.concurrent.DefaultPromise
-
- awaitUninterruptibly(long, TimeUnit) - Method in class io.netty.util.concurrent.DefaultPromise
-
- awaitUninterruptibly(long) - Method in class io.netty.util.concurrent.DefaultPromise
-
- awaitUninterruptibly() - Method in interface io.netty.util.concurrent.Future
-
Waits for this future to be completed without
interruption.
- awaitUninterruptibly(long, TimeUnit) - Method in interface io.netty.util.concurrent.Future
-
Waits for this future to be completed within the
specified time limit without interruption.
- awaitUninterruptibly(long) - Method in interface io.netty.util.concurrent.Future
-
Waits for this future to be completed within the
specified time limit without interruption.
- awaitUninterruptibly() - Method in interface io.netty.util.concurrent.ProgressiveFuture
-
- awaitUninterruptibly() - Method in interface io.netty.util.concurrent.ProgressivePromise
-
- awaitUninterruptibly() - Method in interface io.netty.util.concurrent.Promise
-
- c2b(char) - Static method in class io.netty.util.AsciiString
-
- cancel(boolean) - Method in class io.netty.util.concurrent.CompleteFuture
-
- cancel(boolean) - Method in class io.netty.util.concurrent.DefaultPromise
-
- cancel(boolean) - Method in interface io.netty.util.concurrent.Future
-
- cancel(boolean) - Method in class io.netty.util.internal.chmv8.ForkJoinTask
-
Attempts to cancel execution of this task.
- cancel() - Method in interface io.netty.util.Timeout
-
Attempts to cancel the
TimerTask
associated with this handle.
- cancelScheduledTasks() - Method in class io.netty.util.concurrent.AbstractScheduledEventExecutor
-
Cancel all scheduled tasks.
- canEnableTcpNoDelayByDefault() - Static method in class io.netty.util.internal.PlatformDependent
-
Returns true
if and only if it is fine to enable TCP_NODELAY socket option by default.
- CARRIAGE_RETURN - Static variable in class io.netty.util.internal.StringUtil
-
- cascadeTo(Future<X>, Promise<? super X>) - Static method in class io.netty.util.concurrent.UnaryPromiseNotifier
-
- CASE_INSENSITIVE_HASHER - Static variable in class io.netty.util.AsciiString
-
- CASE_SENSITIVE_HASHER - Static variable in class io.netty.util.AsciiString
-
- cause() - Method in class io.netty.util.concurrent.DefaultPromise
-
- cause() - Method in class io.netty.util.concurrent.FailedFuture
-
- cause() - Method in interface io.netty.util.concurrent.Future
-
Returns the cause of the failed I/O operation if the I/O operation has
failed.
- cause() - Method in class io.netty.util.concurrent.SucceededFuture
-
- charAt(int) - Method in class io.netty.util.AsciiString
-
- charAt(int) - Method in class io.netty.util.internal.AppendableCharSequence
-
- charAtUnsafe(int) - Method in class io.netty.util.internal.AppendableCharSequence
-
- CharCollections - Class in io.netty.util.collection
-
Utilities for char-based primitive collections.
- CharObjectHashMap<V> - Class in io.netty.util.collection
-
A hash map implementation of
CharObjectMap
that uses open addressing for keys.
- CharObjectHashMap() - Constructor for class io.netty.util.collection.CharObjectHashMap
-
- CharObjectHashMap(int) - Constructor for class io.netty.util.collection.CharObjectHashMap
-
- CharObjectHashMap(int, float) - Constructor for class io.netty.util.collection.CharObjectHashMap
-
- CharObjectMap<V> - Interface in io.netty.util.collection
-
Interface for a primitive map that uses char
s as keys.
- CharObjectMap.PrimitiveEntry<V> - Interface in io.netty.util.collection
-
- charsetDecoderCache() - Method in class io.netty.util.internal.InternalThreadLocalMap
-
- charsetEncoderCache() - Method in class io.netty.util.internal.InternalThreadLocalMap
-
- CharsetUtil - Class in io.netty.util
-
A utility class that provides various common operations and constants
related with
Charset
and its relevant classes.
- checkDeadLock() - Method in class io.netty.util.concurrent.DefaultPromise
-
Do deadlock checks
- checkNonEmpty(T[], String) - Static method in class io.netty.util.internal.ObjectUtil
-
Checks that the given argument is neither null nor empty.
- checkNotNull(T, String) - Static method in class io.netty.util.internal.ObjectUtil
-
Checks that the given argument is not null.
- checkPositive(int, String) - Static method in class io.netty.util.internal.ObjectUtil
-
Checks that the given argument is strictly positive.
- checkPositive(long, String) - Static method in class io.netty.util.internal.ObjectUtil
-
Checks that the given argument is strictly positive.
- checkPositiveOrZero(int, String) - Static method in class io.netty.util.internal.ObjectUtil
-
Checks that the given argument is positive or zero.
- children() - Method in class io.netty.util.concurrent.AbstractEventExecutor
-
- children() - Method in interface io.netty.util.concurrent.EventExecutor
-
Returns an unmodifiable singleton set which contains itself.
- children() - Method in interface io.netty.util.concurrent.EventExecutorGroup
-
- children() - Method in class io.netty.util.concurrent.MultithreadEventExecutorGroup
-
- classPool() - Static method in class io.netty.util.internal.JavassistTypeParameterMatcherGenerator
-
- cleanup() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
Do nothing, sub-classes may override
- clear() - Method in class io.netty.util.collection.ByteObjectHashMap
-
- clear() - Method in class io.netty.util.collection.CharObjectHashMap
-
- clear() - Method in class io.netty.util.collection.IntObjectHashMap
-
- clear() - Method in class io.netty.util.collection.LongObjectHashMap
-
- clear() - Method in class io.netty.util.collection.ShortObjectHashMap
-
- clear() - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Removes all of the mappings from this map.
- clear() - Method in class io.netty.util.internal.ConcurrentSet
-
- clear() - Method in class io.netty.util.internal.PriorityQueue
-
- clearMaybe() - Method in class io.netty.util.internal.MpscLinkedQueueNode
-
Sets the element this node contains to null
so that the node can be used as a tombstone.
- close() - Method in interface io.netty.util.ResourceLeak
-
- COMMA - Static variable in class io.netty.util.internal.StringUtil
-
- commitTimeMillis() - Method in class io.netty.util.Version
-
- commonPool() - Static method in class io.netty.util.internal.chmv8.ForkJoinPool
-
Returns the common pool instance.
- CommonsLoggerFactory - Class in io.netty.util.internal.logging
-
- CommonsLoggerFactory() - Constructor for class io.netty.util.internal.logging.CommonsLoggerFactory
-
- commonSuffixOfLength(String, String, int) - Static method in class io.netty.util.internal.StringUtil
-
Checks if two strings have the same suffix of specified length
- compare(long, long) - Static method in class io.netty.util.internal.MathUtil
-
Compare to long
values.
- compareAndSet(T, T) - Method in interface io.netty.util.Attribute
-
Atomically sets the value to the given updated value if the current value == the expected value.
- compareAndSetForkJoinTaskTag(short, short) - Method in class io.netty.util.internal.chmv8.ForkJoinTask
-
Atomically conditionally sets the tag value for this task.
- compareAndSetPendingCount(int, int) - Method in class io.netty.util.internal.chmv8.CountedCompleter
-
Sets (atomically) the pending count to the given count only if
it currently holds the given expected value.
- compareTo(T) - Method in class io.netty.util.AbstractConstant
-
- compareTo(CharSequence) - Method in class io.netty.util.AsciiString
-
Compares the specified string to this string using the ASCII values of the characters.
- compareTo(Signal) - Method in error io.netty.util.Signal
-
- complete(T) - Method in class io.netty.util.internal.chmv8.CountedCompleter
-
- complete(V) - Method in class io.netty.util.internal.chmv8.ForkJoinTask
-
Completes this task, and if not already aborted or cancelled,
returning the given value as the result of subsequent
invocations of join
and related operations.
- completeExceptionally(Throwable) - Method in class io.netty.util.internal.chmv8.ForkJoinTask
-
Completes this task abnormally, and if not already aborted or
cancelled, causes it to throw the given exception upon
join
and related operations.
- CompleteFuture<V> - Class in io.netty.util.concurrent
-
A skeletal
Future
implementation which represents a
Future
which has been completed already.
- CompleteFuture(EventExecutor) - Constructor for class io.netty.util.concurrent.CompleteFuture
-
Creates a new instance.
- compute(K, ConcurrentHashMapV8.BiFun<? super K, ? super V, ? extends V>) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Attempts to compute a mapping for the specified key and its
current mapped value (or null
if there is no current
mapping).
- compute() - Method in class io.netty.util.internal.chmv8.CountedCompleter
-
The main computation performed by this task.
- computeIfAbsent(K, ConcurrentHashMapV8.Fun<? super K, ? extends V>) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
If the specified key is not already associated with a value,
attempts to compute its value using the given mapping function
and enters it into this map unless null
.
- computeIfPresent(K, ConcurrentHashMapV8.BiFun<? super K, ? super V, ? extends V>) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
If the value for the specified key is present, attempts to
compute a new mapping given the key and its current mapped
value.
- concat(CharSequence) - Method in class io.netty.util.AsciiString
-
Concatenates this string and the specified string.
- ConcurrentHashMapV8<K,V> - Class in io.netty.util.internal.chmv8
-
A hash table supporting full concurrency of retrievals and
high expected concurrency for updates.
- ConcurrentHashMapV8() - Constructor for class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Creates a new, empty map with the default initial table size (16).
- ConcurrentHashMapV8(int) - Constructor for class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Creates a new, empty map with an initial table size
accommodating the specified number of elements without the need
to dynamically resize.
- ConcurrentHashMapV8(Map<? extends K, ? extends V>) - Constructor for class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Creates a new map with the same mappings as the given map.
- ConcurrentHashMapV8(int, float) - Constructor for class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Creates a new, empty map with an initial table size based on
the given number of elements (initialCapacity
) and
initial table density (loadFactor
).
- ConcurrentHashMapV8(int, float, int) - Constructor for class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Creates a new, empty map with an initial table size based on
the given number of elements (initialCapacity
), table
density (loadFactor
), and number of concurrently
updating threads (concurrencyLevel
).
- ConcurrentHashMapV8.Action<A> - Interface in io.netty.util.internal.chmv8
-
Interface describing a void action of one argument
- ConcurrentHashMapV8.BiAction<A,B> - Interface in io.netty.util.internal.chmv8
-
Interface describing a void action of two arguments
- ConcurrentHashMapV8.BiFun<A,B,T> - Interface in io.netty.util.internal.chmv8
-
Interface describing a function of two arguments
- ConcurrentHashMapV8.ConcurrentHashMapSpliterator<T> - Interface in io.netty.util.internal.chmv8
-
An object for traversing and partitioning elements of a source.
- ConcurrentHashMapV8.DoubleByDoubleToDouble - Interface in io.netty.util.internal.chmv8
-
Interface describing a function mapping two doubles to a double
- ConcurrentHashMapV8.Fun<A,T> - Interface in io.netty.util.internal.chmv8
-
Interface describing a function of one argument
- ConcurrentHashMapV8.IntByIntToInt - Interface in io.netty.util.internal.chmv8
-
Interface describing a function mapping two ints to an int
- ConcurrentHashMapV8.KeySetView<K,V> - Class in io.netty.util.internal.chmv8
-
A view of a ConcurrentHashMapV8 as a
Set
of keys, in
which additions may optionally be enabled by mapping to a
common value.
- ConcurrentHashMapV8.LongByLongToLong - Interface in io.netty.util.internal.chmv8
-
Interface describing a function mapping two longs to a long
- ConcurrentHashMapV8.ObjectByObjectToDouble<A,B> - Interface in io.netty.util.internal.chmv8
-
Interface describing a function mapping two arguments to a double
- ConcurrentHashMapV8.ObjectByObjectToInt<A,B> - Interface in io.netty.util.internal.chmv8
-
Interface describing a function mapping two arguments to an int
- ConcurrentHashMapV8.ObjectByObjectToLong<A,B> - Interface in io.netty.util.internal.chmv8
-
Interface describing a function mapping two arguments to a long
- ConcurrentHashMapV8.ObjectToDouble<A> - Interface in io.netty.util.internal.chmv8
-
Interface describing a function mapping its argument to a double
- ConcurrentHashMapV8.ObjectToInt<A> - Interface in io.netty.util.internal.chmv8
-
Interface describing a function mapping its argument to an int
- ConcurrentHashMapV8.ObjectToLong<A> - Interface in io.netty.util.internal.chmv8
-
Interface describing a function mapping its argument to a long
- ConcurrentSet<E> - Class in io.netty.util.internal
-
- ConcurrentSet() - Constructor for class io.netty.util.internal.ConcurrentSet
-
Creates a new instance which wraps the specified map
.
- confirmShutdown() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
Confirm that the shutdown if the instance should be done now!
- Constant<T extends Constant<T>> - Interface in io.netty.util
-
A singleton which is safe to compare via the ==
operator.
- ConstantPool<T extends Constant<T>> - Class in io.netty.util
-
- ConstantPool() - Constructor for class io.netty.util.ConstantPool
-
- contains(CharSequence) - Method in class io.netty.util.AsciiString
-
Determines if this String
contains the sequence of characters in the CharSequence
passed.
- contains(CharSequence, CharSequence) - Static method in class io.netty.util.AsciiString
-
Determine if a
contains b
in a case sensitive manner.
- contains(Object) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Deprecated.
- contains(Object) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8.KeySetView
- contains(Object) - Method in class io.netty.util.internal.ConcurrentSet
-
- contains(Object) - Method in class io.netty.util.internal.PriorityQueue
-
- contains(String) - Static method in class io.netty.util.internal.SystemPropertyUtil
-
Returns true
if and only if the system property with the specified key
exists.
- containsAllContentEqualsIgnoreCase(Collection<CharSequence>, Collection<CharSequence>) - Static method in class io.netty.util.AsciiString
-
- containsContentEqualsIgnoreCase(Collection<CharSequence>, CharSequence) - Static method in class io.netty.util.AsciiString
-
- containsIgnoreCase(CharSequence, CharSequence) - Static method in class io.netty.util.AsciiString
-
Determine if a
contains b
in a case insensitive manner.
- containsKey(byte) - Method in class io.netty.util.collection.ByteObjectHashMap
-
- containsKey(Object) - Method in class io.netty.util.collection.ByteObjectHashMap
-
- containsKey(byte) - Method in interface io.netty.util.collection.ByteObjectMap
-
Indicates whether or not this map contains a value for the specified key.
- containsKey(char) - Method in class io.netty.util.collection.CharObjectHashMap
-
- containsKey(Object) - Method in class io.netty.util.collection.CharObjectHashMap
-
- containsKey(char) - Method in interface io.netty.util.collection.CharObjectMap
-
Indicates whether or not this map contains a value for the specified key.
- containsKey(int) - Method in class io.netty.util.collection.IntObjectHashMap
-
- containsKey(Object) - Method in class io.netty.util.collection.IntObjectHashMap
-
- containsKey(int) - Method in interface io.netty.util.collection.IntObjectMap
-
Indicates whether or not this map contains a value for the specified key.
- containsKey(long) - Method in class io.netty.util.collection.LongObjectHashMap
-
- containsKey(Object) - Method in class io.netty.util.collection.LongObjectHashMap
-
- containsKey(long) - Method in interface io.netty.util.collection.LongObjectMap
-
Indicates whether or not this map contains a value for the specified key.
- containsKey(short) - Method in class io.netty.util.collection.ShortObjectHashMap
-
- containsKey(Object) - Method in class io.netty.util.collection.ShortObjectHashMap
-
- containsKey(short) - Method in interface io.netty.util.collection.ShortObjectMap
-
Indicates whether or not this map contains a value for the specified key.
- containsKey(Object) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Tests if the specified object is a key in this table.
- containsValue(Object) - Method in class io.netty.util.collection.ByteObjectHashMap
-
- containsValue(Object) - Method in class io.netty.util.collection.CharObjectHashMap
-
- containsValue(Object) - Method in class io.netty.util.collection.IntObjectHashMap
-
- containsValue(Object) - Method in class io.netty.util.collection.LongObjectHashMap
-
- containsValue(Object) - Method in class io.netty.util.collection.ShortObjectHashMap
-
- containsValue(Object) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Returns true
if this map maps one or more keys to the
specified value.
- contentEquals(CharSequence) - Method in class io.netty.util.AsciiString
-
Compares a CharSequence
to this String
to determine if their contents are equal.
- contentEquals(CharSequence, CharSequence) - Static method in class io.netty.util.AsciiString
-
Returns
true
if the content of both
CharSequence
's are equals.
- contentEqualsIgnoreCase(CharSequence) - Method in class io.netty.util.AsciiString
-
Compares the specified string to this string ignoring the case of the characters and returns true if they are
equal.
- contentEqualsIgnoreCase(CharSequence, CharSequence) - Static method in class io.netty.util.AsciiString
-
Returns
true
if both
CharSequence
's are equals when ignore the case.
- copy(int, byte[], int, int) - Method in class io.netty.util.AsciiString
-
Copies the content of this string to a byte array.
- copy(int, char[], int, int) - Method in class io.netty.util.AsciiString
-
Copied the content of this string to a character array.
- copyMemory(long, long, long) - Static method in class io.netty.util.internal.PlatformDependent
-
- copyMemory(byte[], int, long, long) - Static method in class io.netty.util.internal.PlatformDependent
-
- copyMemory(long, byte[], int, long) - Static method in class io.netty.util.internal.PlatformDependent
-
- CountedCompleter<T> - Class in io.netty.util.internal.chmv8
-
A
ForkJoinTask
with a completion action performed when
triggered and there are no remaining pending actions.
- CountedCompleter(CountedCompleter<?>, int) - Constructor for class io.netty.util.internal.chmv8.CountedCompleter
-
Creates a new CountedCompleter with the given completer
and initial pending count.
- CountedCompleter(CountedCompleter<?>) - Constructor for class io.netty.util.internal.chmv8.CountedCompleter
-
Creates a new CountedCompleter with the given completer
and an initial pending count of zero.
- CountedCompleter() - Constructor for class io.netty.util.internal.chmv8.CountedCompleter
-
Creates a new CountedCompleter with no completer
and an initial pending count of zero.
- counterHashCode() - Method in class io.netty.util.internal.InternalThreadLocalMap
-
- createByteArrayFromIpAddressString(String) - Static method in class io.netty.util.NetUtil
-
Creates an byte[] based on an ipAddressString.
- current() - Static method in class io.netty.util.internal.ThreadLocalRandom
-
Returns the current thread's ThreadLocalRandom
.
- deallocate() - Method in class io.netty.util.AbstractReferenceCounted
-
- debug(Throwable) - Method in class io.netty.util.internal.logging.AbstractInternalLogger
-
- debug(String) - Method in interface io.netty.util.internal.logging.InternalLogger
-
Log a message at the DEBUG level.
- debug(String, Object) - Method in interface io.netty.util.internal.logging.InternalLogger
-
Log a message at the DEBUG level according to the specified format
and argument.
- debug(String, Object, Object) - Method in interface io.netty.util.internal.logging.InternalLogger
-
Log a message at the DEBUG level according to the specified format
and arguments.
- debug(String, Object...) - Method in interface io.netty.util.internal.logging.InternalLogger
-
Log a message at the DEBUG level according to the specified format
and arguments.
- debug(String, Throwable) - Method in interface io.netty.util.internal.logging.InternalLogger
-
Log an exception (throwable) at the DEBUG level with an
accompanying message.
- debug(Throwable) - Method in interface io.netty.util.internal.logging.InternalLogger
-
Log an exception (throwable) at the DEBUG level.
- decrement() - Method in class io.netty.util.internal.chmv8.LongAdderV8
-
Equivalent to add(-1)
.
- decrement() - Method in interface io.netty.util.internal.LongCounter
-
- decrementPendingCountUnlessZero() - Method in class io.netty.util.internal.chmv8.CountedCompleter
-
If the pending count is nonzero, (atomically) decrements it.
- DEFAULT_CAPACITY - Static variable in class io.netty.util.collection.ByteObjectHashMap
-
Default initial capacity.
- DEFAULT_CAPACITY - Static variable in class io.netty.util.collection.CharObjectHashMap
-
Default initial capacity.
- DEFAULT_CAPACITY - Static variable in class io.netty.util.collection.IntObjectHashMap
-
Default initial capacity.
- DEFAULT_CAPACITY - Static variable in class io.netty.util.collection.LongObjectHashMap
-
Default initial capacity.
- DEFAULT_CAPACITY - Static variable in class io.netty.util.collection.ShortObjectHashMap
-
Default initial capacity.
- DEFAULT_LOAD_FACTOR - Static variable in class io.netty.util.collection.ByteObjectHashMap
-
Default load factor.
- DEFAULT_LOAD_FACTOR - Static variable in class io.netty.util.collection.CharObjectHashMap
-
Default load factor.
- DEFAULT_LOAD_FACTOR - Static variable in class io.netty.util.collection.IntObjectHashMap
-
Default load factor.
- DEFAULT_LOAD_FACTOR - Static variable in class io.netty.util.collection.LongObjectHashMap
-
Default load factor.
- DEFAULT_LOAD_FACTOR - Static variable in class io.netty.util.collection.ShortObjectHashMap
-
Default load factor.
- DefaultAttributeMap - Class in io.netty.util
-
Default
AttributeMap
implementation which use simple synchronization per bucket to keep the memory overhead
as low as possible.
- DefaultAttributeMap() - Constructor for class io.netty.util.DefaultAttributeMap
-
- DefaultEventExecutor - Class in io.netty.util.concurrent
-
- DefaultEventExecutor() - Constructor for class io.netty.util.concurrent.DefaultEventExecutor
-
- DefaultEventExecutor(ThreadFactory) - Constructor for class io.netty.util.concurrent.DefaultEventExecutor
-
- DefaultEventExecutor(Executor) - Constructor for class io.netty.util.concurrent.DefaultEventExecutor
-
- DefaultEventExecutor(EventExecutorGroup) - Constructor for class io.netty.util.concurrent.DefaultEventExecutor
-
- DefaultEventExecutor(EventExecutorGroup, ThreadFactory) - Constructor for class io.netty.util.concurrent.DefaultEventExecutor
-
- DefaultEventExecutor(EventExecutorGroup, Executor) - Constructor for class io.netty.util.concurrent.DefaultEventExecutor
-
- DefaultEventExecutorGroup - Class in io.netty.util.concurrent
-
- DefaultEventExecutorGroup(int) - Constructor for class io.netty.util.concurrent.DefaultEventExecutorGroup
-
- DefaultEventExecutorGroup(int, ThreadFactory) - Constructor for class io.netty.util.concurrent.DefaultEventExecutorGroup
-
Create a new instance.
- defaultForkJoinWorkerThreadFactory - Static variable in class io.netty.util.internal.chmv8.ForkJoinPool
-
Creates a new ForkJoinWorkerThread.
- DefaultProgressivePromise<V> - Class in io.netty.util.concurrent
-
- DefaultProgressivePromise(EventExecutor) - Constructor for class io.netty.util.concurrent.DefaultProgressivePromise
-
Creates a new instance.
- DefaultProgressivePromise() - Constructor for class io.netty.util.concurrent.DefaultProgressivePromise
-
- DefaultPromise<V> - Class in io.netty.util.concurrent
-
- DefaultPromise(EventExecutor) - Constructor for class io.netty.util.concurrent.DefaultPromise
-
Creates a new instance.
- DefaultPromise() - Constructor for class io.netty.util.concurrent.DefaultPromise
-
- DefaultThreadFactory - Class in io.netty.util.concurrent
-
- DefaultThreadFactory(Class<?>) - Constructor for class io.netty.util.concurrent.DefaultThreadFactory
-
- DefaultThreadFactory(String) - Constructor for class io.netty.util.concurrent.DefaultThreadFactory
-
- DefaultThreadFactory(Class<?>, boolean) - Constructor for class io.netty.util.concurrent.DefaultThreadFactory
-
- DefaultThreadFactory(String, boolean) - Constructor for class io.netty.util.concurrent.DefaultThreadFactory
-
- DefaultThreadFactory(Class<?>, int) - Constructor for class io.netty.util.concurrent.DefaultThreadFactory
-
- DefaultThreadFactory(String, int) - Constructor for class io.netty.util.concurrent.DefaultThreadFactory
-
- DefaultThreadFactory(Class<?>, boolean, int) - Constructor for class io.netty.util.concurrent.DefaultThreadFactory
-
- DefaultThreadFactory(String, boolean, int) - Constructor for class io.netty.util.concurrent.DefaultThreadFactory
-
- delayNanos(long) - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
Returns the amount of time left until the scheduled task with the closest dead line is executed.
- destroy() - Static method in class io.netty.util.concurrent.FastThreadLocal
-
- destroy() - Static method in class io.netty.util.internal.InternalThreadLocalMap
-
- directBufferAddress(ByteBuffer) - Static method in class io.netty.util.internal.PlatformDependent
-
- directBufferPreferred() - Static method in class io.netty.util.internal.PlatformDependent
-
Returns true
if the platform has reliable low-level direct buffer access API and a user has not specified
-Dio.netty.noPreferDirect
option.
- DomainMappingBuilder<V> - Class in io.netty.util
-
- DomainMappingBuilder(V) - Constructor for class io.netty.util.DomainMappingBuilder
-
Constructor with default initial capacity of the map holding the mappings
- DomainMappingBuilder(int, V) - Constructor for class io.netty.util.DomainMappingBuilder
-
Constructor with initial capacity of the map holding the mappings
- DomainNameMapping<V> - Class in io.netty.util
-
Maps a domain name to its associated value object.
- DomainNameMapping(V) - Constructor for class io.netty.util.DomainNameMapping
-
- DomainNameMapping(int, V) - Constructor for class io.netty.util.DomainNameMapping
-
- DOUBLE_QUOTE - Static variable in class io.netty.util.internal.StringUtil
-
- doubleValue() - Method in class io.netty.util.internal.chmv8.LongAdderV8
-
- drainTasksTo(Collection<? super ForkJoinTask<?>>) - Method in class io.netty.util.internal.chmv8.ForkJoinPool
-
Removes all available unexecuted submitted and forked tasks
from scheduling queues and adds them to the given collection,
without altering their execution status.
- elements() - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Returns an enumeration of the values in this table.
- EMPTY_BOOLEANS - Static variable in class io.netty.util.internal.EmptyArrays
-
- EMPTY_BYTE_BUFFERS - Static variable in class io.netty.util.internal.EmptyArrays
-
- EMPTY_BYTES - Static variable in class io.netty.util.internal.EmptyArrays
-
- EMPTY_CERTIFICATES - Static variable in class io.netty.util.internal.EmptyArrays
-
- EMPTY_CHARS - Static variable in class io.netty.util.internal.EmptyArrays
-
- EMPTY_CLASSES - Static variable in class io.netty.util.internal.EmptyArrays
-
- EMPTY_DOUBLES - Static variable in class io.netty.util.internal.EmptyArrays
-
- EMPTY_FLOATS - Static variable in class io.netty.util.internal.EmptyArrays
-
- EMPTY_INTS - Static variable in class io.netty.util.internal.EmptyArrays
-
- EMPTY_JAVAX_X509_CERTIFICATES - Static variable in class io.netty.util.internal.EmptyArrays
-
- EMPTY_LONGS - Static variable in class io.netty.util.internal.EmptyArrays
-
- EMPTY_OBJECTS - Static variable in class io.netty.util.internal.EmptyArrays
-
- EMPTY_SHORTS - Static variable in class io.netty.util.internal.EmptyArrays
-
- EMPTY_STACK_TRACE - Static variable in class io.netty.util.internal.EmptyArrays
-
- EMPTY_STRING - Static variable in class io.netty.util.AsciiString
-
- EMPTY_STRING - Static variable in class io.netty.util.internal.StringUtil
-
- EMPTY_STRINGS - Static variable in class io.netty.util.internal.EmptyArrays
-
- EMPTY_X509_CERTIFICATES - Static variable in class io.netty.util.internal.EmptyArrays
-
- EmptyArrays - Class in io.netty.util.internal
-
- emptyMap() - Static method in class io.netty.util.collection.ByteCollections
-
- emptyMap() - Static method in class io.netty.util.collection.CharCollections
-
- emptyMap() - Static method in class io.netty.util.collection.IntCollections
-
- emptyMap() - Static method in class io.netty.util.collection.LongCollections
-
- emptyMap() - Static method in class io.netty.util.collection.ShortCollections
-
- endsWith(CharSequence) - Method in class io.netty.util.AsciiString
-
Compares the specified string to this string to determine if the specified string is a suffix.
- entries() - Method in class io.netty.util.collection.ByteObjectHashMap
-
- entries() - Method in interface io.netty.util.collection.ByteObjectMap
-
Gets an iterable to traverse over the primitive entries contained in this map.
- entries() - Method in class io.netty.util.collection.CharObjectHashMap
-
- entries() - Method in interface io.netty.util.collection.CharObjectMap
-
Gets an iterable to traverse over the primitive entries contained in this map.
- entries() - Method in class io.netty.util.collection.IntObjectHashMap
-
- entries() - Method in interface io.netty.util.collection.IntObjectMap
-
Gets an iterable to traverse over the primitive entries contained in this map.
- entries() - Method in class io.netty.util.collection.LongObjectHashMap
-
- entries() - Method in interface io.netty.util.collection.LongObjectMap
-
Gets an iterable to traverse over the primitive entries contained in this map.
- entries() - Method in class io.netty.util.collection.ShortObjectHashMap
-
- entries() - Method in interface io.netty.util.collection.ShortObjectMap
-
Gets an iterable to traverse over the primitive entries contained in this map.
- entrySet() - Method in class io.netty.util.collection.ByteObjectHashMap
-
- entrySet() - Method in class io.netty.util.collection.CharObjectHashMap
-
- entrySet() - Method in class io.netty.util.collection.IntObjectHashMap
-
- entrySet() - Method in class io.netty.util.collection.LongObjectHashMap
-
- entrySet() - Method in class io.netty.util.collection.ShortObjectHashMap
-
- entrySet() - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Returns a
Set
view of the mappings contained in this map.
- equals(Object) - Method in class io.netty.util.AbstractConstant
-
- equals(Object) - Method in class io.netty.util.AsciiString
-
- equals(Object) - Method in class io.netty.util.collection.ByteObjectHashMap
-
- equals(Object) - Method in class io.netty.util.collection.CharObjectHashMap
-
- equals(Object) - Method in class io.netty.util.collection.IntObjectHashMap
-
- equals(Object) - Method in class io.netty.util.collection.LongObjectHashMap
-
- equals(Object) - Method in class io.netty.util.collection.ShortObjectHashMap
-
- equals(T, T) - Method in interface io.netty.util.HashingStrategy
-
Returns true
if the arguments are equal to each other and false
otherwise.
- equals(Object) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Compares the specified object with this map for equality.
- equals(Object) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8.KeySetView
-
- equals(byte[], int, byte[], int, int) - Static method in class io.netty.util.internal.PlatformDependent
-
Compare two byte
arrays for equality.
- equals(Object) - Method in exception io.netty.util.ResourceLeakException
-
Deprecated.
- equals(Object) - Method in error io.netty.util.Signal
-
- error(Throwable) - Method in class io.netty.util.internal.logging.AbstractInternalLogger
-
- error(String) - Method in interface io.netty.util.internal.logging.InternalLogger
-
Log a message at the ERROR level.
- error(String, Object) - Method in interface io.netty.util.internal.logging.InternalLogger
-
Log a message at the ERROR level according to the specified format
and argument.
- error(String, Object, Object) - Method in interface io.netty.util.internal.logging.InternalLogger
-
Log a message at the ERROR level according to the specified format
and arguments.
- error(String, Object...) - Method in interface io.netty.util.internal.logging.InternalLogger
-
Log a message at the ERROR level according to the specified format
and arguments.
- error(String, Throwable) - Method in interface io.netty.util.internal.logging.InternalLogger
-
Log an exception (throwable) at the ERROR level with an
accompanying message.
- error(Throwable) - Method in interface io.netty.util.internal.logging.InternalLogger
-
Log an exception (throwable) at the ERROR level.
- escapeCsv(CharSequence) - Static method in class io.netty.util.internal.StringUtil
-
Escapes the specified value, if necessary according to
RFC-4180.
- estimateSize() - Method in interface io.netty.util.internal.chmv8.ConcurrentHashMapV8.ConcurrentHashMapSpliterator
-
Returns an estimate of the number of elements covered by
this Spliterator.
- EventExecutor - Interface in io.netty.util.concurrent
-
- EventExecutorGroup - Interface in io.netty.util.concurrent
-
- exec() - Method in class io.netty.util.internal.chmv8.CountedCompleter
-
Implements execution conventions for CountedCompleters.
- exec() - Method in class io.netty.util.internal.chmv8.ForkJoinTask
-
Immediately performs the base action of this task and returns
true if, upon return from this method, this task is guaranteed
to have completed normally.
- execute(Runnable) - Method in class io.netty.util.concurrent.AbstractEventExecutorGroup
-
- execute(Runnable) - Method in class io.netty.util.concurrent.GlobalEventExecutor
-
- execute(Runnable) - Method in class io.netty.util.concurrent.ImmediateEventExecutor
-
- execute(Runnable) - Method in class io.netty.util.concurrent.ImmediateExecutor
-
- execute(Runnable) - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- execute(Runnable) - Method in class io.netty.util.concurrent.ThreadPerTaskExecutor
-
- execute(ForkJoinTask<?>) - Method in class io.netty.util.internal.chmv8.ForkJoinPool
-
Arranges for (asynchronous) execution of the given task.
- execute(Runnable) - Method in class io.netty.util.internal.chmv8.ForkJoinPool
-
- executor() - Method in class io.netty.util.concurrent.CompleteFuture
-
- executor() - Method in class io.netty.util.concurrent.DefaultPromise
-
- executorCount() - Method in class io.netty.util.concurrent.MultithreadEventExecutorGroup
-
- exists(String) - Static method in class io.netty.util.AttributeKey
-
- exists(String) - Method in class io.netty.util.ConstantPool
-
- expect(Signal) - Method in error io.netty.util.Signal
-
Check if the given
Signal
is the same as this instance.
- failAndRecycle(Throwable) - Method in class io.netty.util.internal.PendingWrite
-
Fails the underlying
Promise
with the given cause and reycle this instance.
- FailedFuture<V> - Class in io.netty.util.concurrent
-
- FailedFuture(EventExecutor, Throwable) - Constructor for class io.netty.util.concurrent.FailedFuture
-
Creates a new instance.
- FastThreadLocal<V> - Class in io.netty.util.concurrent
-
- FastThreadLocal() - Constructor for class io.netty.util.concurrent.FastThreadLocal
-
- FastThreadLocalThread - Class in io.netty.util.concurrent
-
- FastThreadLocalThread() - Constructor for class io.netty.util.concurrent.FastThreadLocalThread
-
- FastThreadLocalThread(Runnable) - Constructor for class io.netty.util.concurrent.FastThreadLocalThread
-
- FastThreadLocalThread(ThreadGroup, Runnable) - Constructor for class io.netty.util.concurrent.FastThreadLocalThread
-
- FastThreadLocalThread(String) - Constructor for class io.netty.util.concurrent.FastThreadLocalThread
-
- FastThreadLocalThread(ThreadGroup, String) - Constructor for class io.netty.util.concurrent.FastThreadLocalThread
-
- FastThreadLocalThread(Runnable, String) - Constructor for class io.netty.util.concurrent.FastThreadLocalThread
-
- FastThreadLocalThread(ThreadGroup, Runnable, String) - Constructor for class io.netty.util.concurrent.FastThreadLocalThread
-
- FastThreadLocalThread(ThreadGroup, Runnable, String, long) - Constructor for class io.netty.util.concurrent.FastThreadLocalThread
-
- fillInStackTrace() - Method in error io.netty.util.Signal
-
- find(Object, Class<?>, String) - Static method in class io.netty.util.internal.TypeParameterMatcher
-
- FIND_CR - Static variable in interface io.netty.util.ByteProcessor
-
Aborts on a CR ('\r')
.
- FIND_CRLF - Static variable in interface io.netty.util.ByteProcessor
-
Aborts on a CR ('\r')
or a LF ('\n')
.
- FIND_LF - Static variable in interface io.netty.util.ByteProcessor
-
Aborts on a LF ('\n')
.
- FIND_LINEAR_WHITESPACE - Static variable in interface io.netty.util.ByteProcessor
-
Aborts on a linear whitespace (a (' '
or a '\t'
).
- FIND_NON_CR - Static variable in interface io.netty.util.ByteProcessor
-
Aborts on a non-CR ('\r')
.
- FIND_NON_CRLF - Static variable in interface io.netty.util.ByteProcessor
-
Aborts on a byte which is neither a CR ('\r')
nor a LF ('\n')
.
- FIND_NON_LF - Static variable in interface io.netty.util.ByteProcessor
-
Aborts on a non-LF ('\n')
.
- FIND_NON_LINEAR_WHITESPACE - Static variable in interface io.netty.util.ByteProcessor
-
Aborts on a byte which is not a linear whitespace (neither ' '
nor '\t'
).
- FIND_NON_NUL - Static variable in interface io.netty.util.ByteProcessor
-
Aborts on a non-NUL (0x00)
.
- FIND_NUL - Static variable in interface io.netty.util.ByteProcessor
-
Aborts on a NUL (0x00)
.
- FIND_SEMI_COLON - Static variable in interface io.netty.util.ByteProcessor
-
Aborts on a CR (';')
.
- findNextPositivePowerOfTwo(int) - Static method in class io.netty.util.internal.MathUtil
-
Fast method of finding the next power of 2 greater than or equal to the supplied value.
- firstComplete() - Method in class io.netty.util.internal.chmv8.CountedCompleter
-
If this task's pending count is zero, returns this task;
otherwise decrements its pending count and returns null
.
- floatValue() - Method in class io.netty.util.internal.chmv8.LongAdderV8
-
- forEach(ConcurrentHashMapV8.BiAction<? super K, ? super V>) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
- forEach(long, ConcurrentHashMapV8.BiAction<? super K, ? super V>) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Performs the given action for each (key, value).
- forEach(long, ConcurrentHashMapV8.BiFun<? super K, ? super V, ? extends U>, ConcurrentHashMapV8.Action<? super U>) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Performs the given action for each non-null transformation
of each (key, value).
- forEach(ConcurrentHashMapV8.Action<? super K>) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8.KeySetView
-
- forEachByte(ByteProcessor) - Method in class io.netty.util.AsciiString
-
Iterates over the readable bytes of this buffer with the specified processor
in ascending order.
- forEachByte(int, int, ByteProcessor) - Method in class io.netty.util.AsciiString
-
Iterates over the specified area of this buffer with the specified processor
in ascending order.
- forEachByteDesc(ByteProcessor) - Method in class io.netty.util.AsciiString
-
Iterates over the readable bytes of this buffer with the specified processor
in descending order.
- forEachByteDesc(int, int, ByteProcessor) - Method in class io.netty.util.AsciiString
-
Iterates over the specified area of this buffer with the specified processor
in descending order.
- forEachEntry(long, ConcurrentHashMapV8.Action<? super Map.Entry<K, V>>) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Performs the given action for each entry.
- forEachEntry(long, ConcurrentHashMapV8.Fun<Map.Entry<K, V>, ? extends U>, ConcurrentHashMapV8.Action<? super U>) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Performs the given action for each non-null transformation
of each entry.
- forEachKey(long, ConcurrentHashMapV8.Action<? super K>) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Performs the given action for each key.
- forEachKey(long, ConcurrentHashMapV8.Fun<? super K, ? extends U>, ConcurrentHashMapV8.Action<? super U>) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Performs the given action for each non-null transformation
of each key.
- forEachRemaining(ConcurrentHashMapV8.Action<? super T>) - Method in interface io.netty.util.internal.chmv8.ConcurrentHashMapV8.ConcurrentHashMapSpliterator
-
Applies the action to each untraversed element
- forEachValue(long, ConcurrentHashMapV8.Action<? super V>) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Performs the given action for each value.
- forEachValue(long, ConcurrentHashMapV8.Fun<? super V, ? extends U>, ConcurrentHashMapV8.Action<? super U>) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Performs the given action for each non-null transformation
of each value.
- fork() - Method in class io.netty.util.internal.chmv8.ForkJoinTask
-
- ForkJoinPool - Class in io.netty.util.internal.chmv8
-
- ForkJoinPool() - Constructor for class io.netty.util.internal.chmv8.ForkJoinPool
-
- ForkJoinPool(int) - Constructor for class io.netty.util.internal.chmv8.ForkJoinPool
-
Creates a
ForkJoinPool
with the indicated parallelism
level, the
default thread factory,
no UncaughtExceptionHandler, and non-async LIFO processing mode.
- ForkJoinPool(int, ForkJoinPool.ForkJoinWorkerThreadFactory, Thread.UncaughtExceptionHandler, boolean) - Constructor for class io.netty.util.internal.chmv8.ForkJoinPool
-
Creates a ForkJoinPool
with the given parameters.
- ForkJoinPool.ForkJoinWorkerThreadFactory - Interface in io.netty.util.internal.chmv8
-
- ForkJoinPool.ManagedBlocker - Interface in io.netty.util.internal.chmv8
-
Interface for extending managed parallelism for tasks running
in
ForkJoinPool
s.
- ForkJoinTask<V> - Class in io.netty.util.internal.chmv8
-
Abstract base class for tasks that run within a
ForkJoinPool
.
- ForkJoinTask() - Constructor for class io.netty.util.internal.chmv8.ForkJoinTask
-
- ForkJoinWorkerThread - Class in io.netty.util.internal.chmv8
-
- ForkJoinWorkerThread(ForkJoinPool) - Constructor for class io.netty.util.internal.chmv8.ForkJoinWorkerThread
-
Creates a ForkJoinWorkerThread operating in the given pool.
- formatAddress(byte[]) - Static method in class io.netty.util.internal.MacAddressUtil
-
- freeDirectBuffer(ByteBuffer) - Static method in class io.netty.util.internal.PlatformDependent
-
Try to deallocate the specified direct
ByteBuffer
.
- freeMemory(long) - Static method in class io.netty.util.internal.PlatformDependent
-
- Future<V> - Interface in io.netty.util.concurrent
-
The result of an asynchronous operation.
- FutureListener<V> - Interface in io.netty.util.concurrent
-
- futureListenerStackDepth() - Method in class io.netty.util.internal.InternalThreadLocalMap
-
- generate(Class<?>) - Static method in class io.netty.util.internal.JavassistTypeParameterMatcherGenerator
-
- generate(Class<?>, ClassLoader) - Static method in class io.netty.util.internal.JavassistTypeParameterMatcherGenerator
-
- GenericFutureListener<F extends Future<?>> - Interface in io.netty.util.concurrent
-
Listens to the result of a
Future
.
- GenericProgressiveFutureListener<F extends ProgressiveFuture<?>> - Interface in io.netty.util.concurrent
-
- get() - Method in interface io.netty.util.Attribute
-
Returns the current value, which may be null
- get(byte) - Method in class io.netty.util.collection.ByteObjectHashMap
-
- get(Object) - Method in class io.netty.util.collection.ByteObjectHashMap
-
- get(byte) - Method in interface io.netty.util.collection.ByteObjectMap
-
Gets the value in the map with the specified key.
- get(char) - Method in class io.netty.util.collection.CharObjectHashMap
-
- get(Object) - Method in class io.netty.util.collection.CharObjectHashMap
-
- get(char) - Method in interface io.netty.util.collection.CharObjectMap
-
Gets the value in the map with the specified key.
- get(int) - Method in class io.netty.util.collection.IntObjectHashMap
-
- get(Object) - Method in class io.netty.util.collection.IntObjectHashMap
-
- get(int) - Method in interface io.netty.util.collection.IntObjectMap
-
Gets the value in the map with the specified key.
- get(long) - Method in class io.netty.util.collection.LongObjectHashMap
-
- get(Object) - Method in class io.netty.util.collection.LongObjectHashMap
-
- get(long) - Method in interface io.netty.util.collection.LongObjectMap
-
Gets the value in the map with the specified key.
- get(short) - Method in class io.netty.util.collection.ShortObjectHashMap
-
- get(Object) - Method in class io.netty.util.collection.ShortObjectHashMap
-
- get(short) - Method in interface io.netty.util.collection.ShortObjectMap
-
Gets the value in the map with the specified key.
- get() - Method in class io.netty.util.concurrent.AbstractFuture
-
- get(long, TimeUnit) - Method in class io.netty.util.concurrent.AbstractFuture
-
- get() - Method in class io.netty.util.concurrent.FastThreadLocal
-
Returns the current value for the current thread
- get(InternalThreadLocalMap) - Method in class io.netty.util.concurrent.FastThreadLocal
-
Returns the current value for the specified thread local map.
- get(Object) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Returns the value to which the specified key is mapped,
or null
if this map contains no mapping for the key.
- get() - Method in class io.netty.util.internal.chmv8.ForkJoinTask
-
Waits if necessary for the computation to complete, and then
retrieves its result.
- get(long, TimeUnit) - Method in class io.netty.util.internal.chmv8.ForkJoinTask
-
Waits if necessary for at most the given time for the computation
to complete, and then retrieves its result, if available.
- get() - Static method in class io.netty.util.internal.InternalThreadLocalMap
-
- get(String) - Static method in class io.netty.util.internal.SystemPropertyUtil
-
Returns the value of the Java system property with the specified
key
, while falling back to null
if the property access fails.
- get(String, String) - Static method in class io.netty.util.internal.SystemPropertyUtil
-
Returns the value of the Java system property with the specified
key
, while falling back to the specified default value if
the property access fails.
- get(Class<?>) - Static method in class io.netty.util.internal.TypeParameterMatcher
-
- get() - Method in class io.netty.util.Recycler
-
- getActiveThreadCount() - Method in class io.netty.util.internal.chmv8.ForkJoinPool
-
Returns an estimate of the number of threads that are currently
stealing or executing tasks.
- getAndRemove() - Method in interface io.netty.util.Attribute
-
Removes this attribute from the
AttributeMap
and returns the old value.
- getAndSet(T) - Method in interface io.netty.util.Attribute
-
Atomically sets to the given value and returns the old value which may be null
if non was set before.
- getAsyncMode() - Method in class io.netty.util.internal.chmv8.ForkJoinPool
-
Returns true
if this pool uses local first-in-first-out
scheduling mode for forked tasks that are never joined.
- getBoolean(String, boolean) - Static method in class io.netty.util.internal.SystemPropertyUtil
-
Returns the value of the Java system property with the specified
key
, while falling back to the specified default value if
the property access fails.
- getByName(CharSequence) - Static method in class io.netty.util.NetUtil
-
- getByName(CharSequence, boolean) - Static method in class io.netty.util.NetUtil
-
- getByte(long) - Static method in class io.netty.util.internal.PlatformDependent
-
- getByte(byte[], int) - Static method in class io.netty.util.internal.PlatformDependent
-
- getClassLoader(Class<?>) - Static method in class io.netty.util.internal.PlatformDependent
-
- getCommonPoolParallelism() - Static method in class io.netty.util.internal.chmv8.ForkJoinPool
-
Returns the targeted parallelism level of the common pool.
- getCompleter() - Method in class io.netty.util.internal.chmv8.CountedCompleter
-
Returns the completer established in this task's constructor,
or null
if none.
- getContextClassLoader() - Static method in class io.netty.util.internal.PlatformDependent
-
- getDecoder(Charset) - Static method in class io.netty.util.CharsetUtil
-
Returns a cached thread-local
CharsetDecoder
for the specified
charset.
- getDefaultFactory() - Static method in class io.netty.util.internal.logging.InternalLoggerFactory
-
Returns the default factory.
- getEncoder(Charset) - Static method in class io.netty.util.CharsetUtil
-
Returns a cached thread-local
CharsetEncoder
for the specified
charset.
- getException() - Method in class io.netty.util.internal.chmv8.ForkJoinTask
-
Returns the exception thrown by the base computation, or a
CancellationException
if cancelled, or null
if
none or if the method has not yet completed.
- getFactory() - Method in class io.netty.util.internal.chmv8.ForkJoinPool
-
Returns the factory used for constructing new workers.
- getForkJoinTaskTag() - Method in class io.netty.util.internal.chmv8.ForkJoinTask
-
Returns the tag for this task.
- getIfSet() - Static method in class io.netty.util.internal.InternalThreadLocalMap
-
- getInitialSeedUniquifier() - Static method in class io.netty.util.internal.ThreadLocalRandom
-
- getInstance(Class<?>) - Static method in class io.netty.util.internal.logging.InternalLoggerFactory
-
Creates a new logger instance with the name of the specified class.
- getInstance(String) - Static method in class io.netty.util.internal.logging.InternalLoggerFactory
-
Creates a new logger instance with the specified name.
- getInt(Object, long) - Static method in class io.netty.util.internal.PlatformDependent
-
- getInt(long) - Static method in class io.netty.util.internal.PlatformDependent
-
- getInt(byte[], int) - Static method in class io.netty.util.internal.PlatformDependent
-
- getInt(String, int) - Static method in class io.netty.util.internal.SystemPropertyUtil
-
Returns the value of the Java system property with the specified
key
, while falling back to the specified default value if
the property access fails.
- getLevel() - Static method in class io.netty.util.ResourceLeakDetector
-
Returns the current resource leak detection level.
- getLong(long) - Static method in class io.netty.util.internal.PlatformDependent
-
- getLong(byte[], int) - Static method in class io.netty.util.internal.PlatformDependent
-
- getLong(String, long) - Static method in class io.netty.util.internal.SystemPropertyUtil
-
Returns the value of the Java system property with the specified
key
, while falling back to the specified default value if
the property access fails.
- getMappedValue() - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8.KeySetView
-
Returns the default mapped value for additions,
or null
if additions are not supported.
- getNow() - Method in class io.netty.util.concurrent.DefaultPromise
-
- getNow() - Method in class io.netty.util.concurrent.FailedFuture
-
- getNow() - Method in interface io.netty.util.concurrent.Future
-
Return the result without blocking.
- getNow() - Method in class io.netty.util.concurrent.SucceededFuture
-
- getObject(Object, long) - Static method in class io.netty.util.internal.PlatformDependent
-
- getObjectVolatile(Object, long) - Static method in class io.netty.util.internal.PlatformDependent
-
- getOrDefault(Object, V) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Returns the value to which the specified key is mapped, or the
given default value if this map contains no mapping for the
key.
- getParallelism() - Method in class io.netty.util.internal.chmv8.ForkJoinPool
-
Returns the targeted parallelism level of this pool.
- getPendingCount() - Method in class io.netty.util.internal.chmv8.CountedCompleter
-
Returns the current pending count.
- getPool() - Static method in class io.netty.util.internal.chmv8.ForkJoinTask
-
Returns the pool hosting the current task execution, or null
if this task is executing outside of any ForkJoinPool.
- getPool() - Method in class io.netty.util.internal.chmv8.ForkJoinWorkerThread
-
Returns the pool hosting this thread.
- getPoolIndex() - Method in class io.netty.util.internal.chmv8.ForkJoinWorkerThread
-
Returns the unique index number of this thread in its pool.
- getPoolSize() - Method in class io.netty.util.internal.chmv8.ForkJoinPool
-
Returns the number of worker threads that have started but not
yet terminated.
- getQueuedSubmissionCount() - Method in class io.netty.util.internal.chmv8.ForkJoinPool
-
Returns an estimate of the number of tasks submitted to this
pool that have not yet begun executing.
- getQueuedTaskCount() - Method in class io.netty.util.internal.chmv8.ForkJoinPool
-
Returns an estimate of the total number of tasks currently held
in queues by worker threads (but not including tasks submitted
to the pool that have not begun executing).
- getQueuedTaskCount() - Static method in class io.netty.util.internal.chmv8.ForkJoinTask
-
Returns an estimate of the number of tasks that have been
forked by the current worker thread but not yet executed.
- getRawResult() - Method in class io.netty.util.internal.chmv8.CountedCompleter
-
Returns the result of the computation.
- getRawResult() - Method in class io.netty.util.internal.chmv8.ForkJoinTask
-
Returns the result that would be returned by
ForkJoinTask.join()
, even
if this task completed abnormally, or
null
if this task
is not known to have been completed.
- getRoot() - Method in class io.netty.util.internal.chmv8.CountedCompleter
-
Returns the root of the current computation; i.e., this
task if it has no completer, else its completer's root.
- getRunningThreadCount() - Method in class io.netty.util.internal.chmv8.ForkJoinPool
-
Returns an estimate of the number of worker threads that are
not blocked waiting to join tasks or for other managed
synchronization.
- getShort(long) - Static method in class io.netty.util.internal.PlatformDependent
-
- getShort(byte[], int) - Static method in class io.netty.util.internal.PlatformDependent
-
- getStealCount() - Method in class io.netty.util.internal.chmv8.ForkJoinPool
-
Returns an estimate of the total number of tasks stolen from
one thread's work queue by another.
- getSurplusQueuedTaskCount() - Static method in class io.netty.util.internal.chmv8.ForkJoinTask
-
Returns an estimate of how many more locally queued tasks are
held by the current worker thread than there are other worker
threads that might steal them, or zero if this thread is not
operating in a ForkJoinPool.
- getSystemClassLoader() - Static method in class io.netty.util.internal.PlatformDependent
-
- getUncaughtExceptionHandler() - Method in class io.netty.util.internal.chmv8.ForkJoinPool
-
Returns the handler for internal worker threads that terminate
due to unrecoverable errors encountered while executing tasks.
- GlobalEventExecutor - Class in io.netty.util.concurrent
-
- id() - Method in class io.netty.util.AbstractConstant
-
- id() - Method in interface io.netty.util.concurrent.ThreadProperties
-
- id() - Method in interface io.netty.util.Constant
-
Returns the unique number assigned to this
Constant
.
- id() - Method in error io.netty.util.Signal
-
- identify() - Static method in class io.netty.util.Version
-
- identify(ClassLoader) - Static method in class io.netty.util.Version
-
Retrieves the version information of Netty artifacts using the specified
ClassLoader
.
- IllegalReferenceCountException - Exception in io.netty.util
-
- IllegalReferenceCountException() - Constructor for exception io.netty.util.IllegalReferenceCountException
-
- IllegalReferenceCountException(int) - Constructor for exception io.netty.util.IllegalReferenceCountException
-
- IllegalReferenceCountException(int, int) - Constructor for exception io.netty.util.IllegalReferenceCountException
-
- IllegalReferenceCountException(String) - Constructor for exception io.netty.util.IllegalReferenceCountException
-
- IllegalReferenceCountException(String, Throwable) - Constructor for exception io.netty.util.IllegalReferenceCountException
-
- IllegalReferenceCountException(Throwable) - Constructor for exception io.netty.util.IllegalReferenceCountException
-
- ImmediateEventExecutor - Class in io.netty.util.concurrent
-
- ImmediateExecutor - Class in io.netty.util.concurrent
-
Executor
which execute tasks in the callers thread.
- increment() - Method in class io.netty.util.internal.chmv8.LongAdderV8
-
Equivalent to add(1)
.
- increment() - Method in interface io.netty.util.internal.LongCounter
-
- INDEX_NOT_FOUND - Static variable in class io.netty.util.AsciiString
-
- INDEX_NOT_IN_QUEUE - Static variable in interface io.netty.util.internal.PriorityQueueNode
-
- indexedVariable(int) - Method in class io.netty.util.internal.InternalThreadLocalMap
-
- indexOf(CharSequence) - Method in class io.netty.util.AsciiString
-
Searches in this string for the first index of the specified string.
- indexOf(CharSequence, int) - Method in class io.netty.util.AsciiString
-
Searches in this string for the index of the specified string.
- indexOfIgnoreCase(CharSequence, CharSequence, int) - Static method in class io.netty.util.AsciiString
-
Case in-sensitive find of the first index within a CharSequence
from the specified position.
- indexOfIgnoreCaseAscii(CharSequence, CharSequence, int) - Static method in class io.netty.util.AsciiString
-
Case in-sensitive find of the first index within a CharSequence
from the specified position.
- inEventLoop() - Method in class io.netty.util.concurrent.AbstractEventExecutor
-
- inEventLoop() - Method in interface io.netty.util.concurrent.EventExecutor
-
- inEventLoop(Thread) - Method in interface io.netty.util.concurrent.EventExecutor
-
Return
true
if the given
Thread
is executed in the event loop,
false
otherwise.
- inEventLoop(Thread) - Method in class io.netty.util.concurrent.GlobalEventExecutor
-
- inEventLoop() - Method in class io.netty.util.concurrent.ImmediateEventExecutor
-
- inEventLoop(Thread) - Method in class io.netty.util.concurrent.ImmediateEventExecutor
-
- inEventLoop(Thread) - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- info(Throwable) - Method in class io.netty.util.internal.logging.AbstractInternalLogger
-
- info(String) - Method in interface io.netty.util.internal.logging.InternalLogger
-
Log a message at the INFO level.
- info(String, Object) - Method in interface io.netty.util.internal.logging.InternalLogger
-
Log a message at the INFO level according to the specified format
and argument.
- info(String, Object, Object) - Method in interface io.netty.util.internal.logging.InternalLogger
-
Log a message at the INFO level according to the specified format
and arguments.
- info(String, Object...) - Method in interface io.netty.util.internal.logging.InternalLogger
-
Log a message at the INFO level according to the specified format
and arguments.
- info(String, Throwable) - Method in interface io.netty.util.internal.logging.InternalLogger
-
Log an exception (throwable) at the INFO level with an
accompanying message.
- info(Throwable) - Method in interface io.netty.util.internal.logging.InternalLogger
-
Log an exception (throwable) at the INFO level.
- inForkJoinPool() - Static method in class io.netty.util.internal.chmv8.ForkJoinTask
-
Returns
true
if the current thread is a
ForkJoinWorkerThread
executing as a ForkJoinPool computation.
- initCause(Throwable) - Method in error io.netty.util.Signal
-
- initialValue() - Method in class io.netty.util.concurrent.FastThreadLocal
-
Returns the initial value for this thread-local variable.
- insertSinceRecycled() - Method in class io.netty.util.internal.RecyclableArrayList
-
Returns true
if any elements where added or set.
- INSTANCE - Static variable in class io.netty.util.concurrent.GlobalEventExecutor
-
- INSTANCE - Static variable in class io.netty.util.concurrent.ImmediateEventExecutor
-
- INSTANCE - Static variable in class io.netty.util.concurrent.ImmediateExecutor
-
- IntCollections - Class in io.netty.util.collection
-
Utilities for int-based primitive collections.
- IntegerHolder - Class in io.netty.util.internal
-
- IntegerHolder() - Constructor for class io.netty.util.internal.IntegerHolder
-
- InternalLogger - Interface in io.netty.util.internal.logging
-
Internal-use-only logger used by Netty.
- InternalLoggerFactory - Class in io.netty.util.internal.logging
-
Creates an
InternalLogger
or changes the default factory
implementation.
- InternalLoggerFactory() - Constructor for class io.netty.util.internal.logging.InternalLoggerFactory
-
- InternalLogLevel - Enum in io.netty.util.internal.logging
-
- InternalThreadLocalMap - Class in io.netty.util.internal
-
The internal data structure that stores the thread-local variables for Netty and all
FastThreadLocal
s.
- interruptThread() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
Interrupt the current running
Thread
.
- IntObjectHashMap<V> - Class in io.netty.util.collection
-
A hash map implementation of
IntObjectMap
that uses open addressing for keys.
- IntObjectHashMap() - Constructor for class io.netty.util.collection.IntObjectHashMap
-
- IntObjectHashMap(int) - Constructor for class io.netty.util.collection.IntObjectHashMap
-
- IntObjectHashMap(int, float) - Constructor for class io.netty.util.collection.IntObjectHashMap
-
- IntObjectMap<V> - Interface in io.netty.util.collection
-
Interface for a primitive map that uses int
s as keys.
- IntObjectMap.PrimitiveEntry<V> - Interface in io.netty.util.collection
-
- intToIpAddress(int) - Static method in class io.netty.util.NetUtil
-
Converts a 32-bit integer into an IPv4 address.
- intValue() - Method in class io.netty.util.internal.chmv8.LongAdderV8
-
- intValue(Integer, int) - Static method in class io.netty.util.internal.ObjectUtil
-
Resolves a possibly null Integer to a primitive int, using a default value.
- invoke(ForkJoinTask<T>) - Method in class io.netty.util.internal.chmv8.ForkJoinPool
-
Performs the given task, returning its result upon completion.
- invoke() - Method in class io.netty.util.internal.chmv8.ForkJoinTask
-
Commences performing this task, awaits its completion if
necessary, and returns its result, or throws an (unchecked)
RuntimeException
or Error
if the underlying
computation did so.
- invokeAll(Collection<? extends Callable<T>>) - Method in class io.netty.util.concurrent.AbstractEventExecutorGroup
-
- invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class io.netty.util.concurrent.AbstractEventExecutorGroup
-
- invokeAll(Collection<? extends Callable<T>>) - Method in class io.netty.util.internal.chmv8.ForkJoinPool
-
- invokeAll(ForkJoinTask<?>, ForkJoinTask<?>) - Static method in class io.netty.util.internal.chmv8.ForkJoinTask
-
Forks the given tasks, returning when isDone
holds for
each task or an (unchecked) exception is encountered, in which
case the exception is rethrown.
- invokeAll(ForkJoinTask<?>...) - Static method in class io.netty.util.internal.chmv8.ForkJoinTask
-
Forks the given tasks, returning when isDone
holds for
each task or an (unchecked) exception is encountered, in which
case the exception is rethrown.
- invokeAll(Collection<T>) - Static method in class io.netty.util.internal.chmv8.ForkJoinTask
-
Forks all tasks in the specified collection, returning when
isDone
holds for each task or an (unchecked) exception
is encountered, in which case the exception is rethrown.
- invokeAny(Collection<? extends Callable<T>>) - Method in class io.netty.util.concurrent.AbstractEventExecutorGroup
-
- invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class io.netty.util.concurrent.AbstractEventExecutorGroup
-
- io.netty.util - package io.netty.util
-
Utility classes used across multiple packages.
- io.netty.util.collection - package io.netty.util.collection
-
- io.netty.util.concurrent - package io.netty.util.concurrent
-
Utility classes for concurrent / async tasks.
- io.netty.util.internal - package io.netty.util.internal
-
Internal-use-only utilities which is not allowed to be used
outside Netty.
- io.netty.util.internal.chmv8 - package io.netty.util.internal.chmv8
-
- io.netty.util.internal.logging - package io.netty.util.internal.logging
-
Internal-use-only logging API which is not allowed to be used outside Netty.
- isAlive() - Method in interface io.netty.util.concurrent.ThreadProperties
-
- isAndroid() - Static method in class io.netty.util.internal.PlatformDependent
-
Returns true
if and only if the current platform is Android
- isCancellable() - Method in class io.netty.util.concurrent.CompleteFuture
-
- isCancellable() - Method in class io.netty.util.concurrent.DefaultPromise
-
- isCancellable() - Method in interface io.netty.util.concurrent.Future
-
- isCancelled() - Method in class io.netty.util.concurrent.CompleteFuture
-
- isCancelled() - Method in class io.netty.util.concurrent.DefaultPromise
-
- isCancelled() - Method in class io.netty.util.internal.chmv8.ForkJoinTask
-
- isCancelled() - Method in interface io.netty.util.Timeout
-
Returns
true
if and only if the
TimerTask
associated
with this handle has been cancelled.
- isCompletedAbnormally() - Method in class io.netty.util.internal.chmv8.ForkJoinTask
-
Returns true
if this task threw an exception or was cancelled.
- isCompletedNormally() - Method in class io.netty.util.internal.chmv8.ForkJoinTask
-
Returns true
if this task completed without throwing an
exception and was not cancelled.
- isDaemon() - Method in interface io.netty.util.concurrent.ThreadProperties
-
- isDebugEnabled() - Method in interface io.netty.util.internal.logging.InternalLogger
-
Is the logger instance enabled for the DEBUG level?
- isDone() - Method in class io.netty.util.concurrent.CompleteFuture
-
- isDone() - Method in class io.netty.util.concurrent.DefaultPromise
-
- isDone() - Method in class io.netty.util.internal.chmv8.ForkJoinTask
-
- isEmpty() - Method in class io.netty.util.AsciiString
-
Determine if this instance has 0 length.
- isEmpty() - Method in class io.netty.util.collection.ByteObjectHashMap
-
- isEmpty() - Method in class io.netty.util.collection.CharObjectHashMap
-
- isEmpty() - Method in class io.netty.util.collection.IntObjectHashMap
-
- isEmpty() - Method in class io.netty.util.collection.LongObjectHashMap
-
- isEmpty() - Method in class io.netty.util.collection.ShortObjectHashMap
-
- isEmpty() - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
- isEmpty() - Method in class io.netty.util.internal.PriorityQueue
-
- isEnabled(InternalLogLevel) - Method in class io.netty.util.internal.logging.AbstractInternalLogger
-
- isEnabled(InternalLogLevel) - Method in interface io.netty.util.internal.logging.InternalLogger
-
Is the logger instance enabled for the specified level
?
- isEnabled() - Static method in class io.netty.util.ResourceLeakDetector
-
Returns true
if resource leak detection is enabled.
- isEntireArrayUsed() - Method in class io.netty.util.AsciiString
-
- isErrorEnabled() - Method in interface io.netty.util.internal.logging.InternalLogger
-
Is the logger instance enabled for the ERROR level?
- isExpired() - Method in interface io.netty.util.Timeout
-
Returns
true
if and only if the
TimerTask
associated
with this handle has been expired.
- isIndexedVariableSet(int) - Method in class io.netty.util.internal.InternalThreadLocalMap
-
- isInfoEnabled() - Method in interface io.netty.util.internal.logging.InternalLogger
-
Is the logger instance enabled for the INFO level?
- isInterrupted() - Method in interface io.netty.util.concurrent.ThreadProperties
-
- isIpV4StackPreferred() - Static method in class io.netty.util.NetUtil
-
Returns true
if ipv4 should be prefered on a system that supports ipv4 and ipv6.
- isNullOrEmpty(String) - Static method in class io.netty.util.internal.StringUtil
-
- ISO_8859_1 - Static variable in class io.netty.util.CharsetUtil
-
ISO Latin Alphabet No. 1, as known as ISO-LATIN-1
- isOutOfBounds(int, int, int) - Static method in class io.netty.util.internal.MathUtil
-
Determine if the requested index
and length
will fit within capacity
.
- isQuiescent() - Method in class io.netty.util.internal.chmv8.ForkJoinPool
-
Returns true
if all worker threads are currently idle.
- isReleasable() - Method in interface io.netty.util.internal.chmv8.ForkJoinPool.ManagedBlocker
-
Returns true
if blocking is unnecessary.
- isRoot() - Static method in class io.netty.util.internal.PlatformDependent
-
Return true
if the current user is root.
- isSet() - Method in class io.netty.util.concurrent.FastThreadLocal
-
Returns true
if and only if this thread-local variable is set.
- isSet(InternalThreadLocalMap) - Method in class io.netty.util.concurrent.FastThreadLocal
-
Returns true
if and only if this thread-local variable is set.
- isShutdown() - Method in class io.netty.util.concurrent.GlobalEventExecutor
-
- isShutdown() - Method in class io.netty.util.concurrent.ImmediateEventExecutor
-
- isShutdown() - Method in class io.netty.util.concurrent.MultithreadEventExecutorGroup
-
- isShutdown() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- isShutdown() - Method in class io.netty.util.internal.chmv8.ForkJoinPool
-
Returns true
if this pool has been shut down.
- isShuttingDown() - Method in interface io.netty.util.concurrent.EventExecutorGroup
-
- isShuttingDown() - Method in class io.netty.util.concurrent.GlobalEventExecutor
-
- isShuttingDown() - Method in class io.netty.util.concurrent.ImmediateEventExecutor
-
- isShuttingDown() - Method in class io.netty.util.concurrent.MultithreadEventExecutorGroup
-
- isShuttingDown() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- isSuccess() - Method in class io.netty.util.concurrent.DefaultPromise
-
- isSuccess() - Method in class io.netty.util.concurrent.FailedFuture
-
- isSuccess() - Method in interface io.netty.util.concurrent.Future
-
Returns true
if and only if the I/O operation was completed
successfully.
- isSuccess() - Method in class io.netty.util.concurrent.SucceededFuture
-
- isSurrogate(char) - Static method in class io.netty.util.internal.StringUtil
-
- isTerminated() - Method in class io.netty.util.concurrent.GlobalEventExecutor
-
- isTerminated() - Method in class io.netty.util.concurrent.ImmediateEventExecutor
-
- isTerminated() - Method in class io.netty.util.concurrent.MultithreadEventExecutorGroup
-
- isTerminated() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- isTerminated() - Method in class io.netty.util.internal.chmv8.ForkJoinPool
-
Returns true
if all tasks have completed following shut down.
- isTerminating() - Method in class io.netty.util.internal.chmv8.ForkJoinPool
-
Returns true
if the process of termination has
commenced but not yet completed.
- isTraceEnabled() - Method in interface io.netty.util.internal.logging.InternalLogger
-
Is the logger instance enabled for the TRACE level?
- isUnaligned() - Static method in class io.netty.util.internal.PlatformDependent
-
true
if and only if the platform supports unaligned access.
- isUpperCase(byte) - Static method in class io.netty.util.AsciiString
-
- isUpperCase(char) - Static method in class io.netty.util.AsciiString
-
- isValidIpV4Address(String) - Static method in class io.netty.util.NetUtil
-
Takes a string and parses it to see if it is a valid IPV4 address.
- isValidIpV6Address(String) - Static method in class io.netty.util.NetUtil
-
- isWarnEnabled() - Method in interface io.netty.util.internal.logging.InternalLogger
-
Is the logger instance enabled for the WARN level?
- isWindows() - Static method in class io.netty.util.internal.PlatformDependent
-
Return true
if the JVM is running on Windows
- iterator() - Method in class io.netty.util.concurrent.AbstractEventExecutor
-
- iterator() - Method in interface io.netty.util.concurrent.EventExecutorGroup
-
- iterator() - Method in class io.netty.util.concurrent.MultithreadEventExecutorGroup
-
- iterator() - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8.KeySetView
-
- iterator() - Method in class io.netty.util.internal.ConcurrentSet
-
- iterator() - Method in class io.netty.util.internal.PriorityQueue
-
This iterator does not return elements in any particular order.
- parent() - Method in class io.netty.util.concurrent.AbstractEventExecutor
-
- parent() - Method in interface io.netty.util.concurrent.EventExecutor
-
- parseBoolean() - Method in class io.netty.util.AsciiString
-
- parseChar() - Method in class io.netty.util.AsciiString
-
- parseChar(int) - Method in class io.netty.util.AsciiString
-
- parseDouble() - Method in class io.netty.util.AsciiString
-
- parseDouble(int, int) - Method in class io.netty.util.AsciiString
-
- parseFloat() - Method in class io.netty.util.AsciiString
-
- parseFloat(int, int) - Method in class io.netty.util.AsciiString
-
- parseInt() - Method in class io.netty.util.AsciiString
-
- parseInt(int) - Method in class io.netty.util.AsciiString
-
- parseInt(int, int) - Method in class io.netty.util.AsciiString
-
- parseInt(int, int, int) - Method in class io.netty.util.AsciiString
-
- parseLong() - Method in class io.netty.util.AsciiString
-
- parseLong(int) - Method in class io.netty.util.AsciiString
-
- parseLong(int, int) - Method in class io.netty.util.AsciiString
-
- parseLong(int, int, int) - Method in class io.netty.util.AsciiString
-
- parseShort() - Method in class io.netty.util.AsciiString
-
- parseShort(int) - Method in class io.netty.util.AsciiString
-
- parseShort(int, int) - Method in class io.netty.util.AsciiString
-
- parseShort(int, int, int) - Method in class io.netty.util.AsciiString
-
- peek() - Method in class io.netty.util.internal.PriorityQueue
-
- peekNextLocalTask() - Static method in class io.netty.util.internal.chmv8.ForkJoinTask
-
Returns, but does not unschedule or execute, a task queued by
the current thread but not yet executed, if one is immediately
available.
- peekTask() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- pendingTasks() - Method in class io.netty.util.concurrent.GlobalEventExecutor
-
Return the number of tasks that are pending for processing.
- pendingTasks() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
Return the number of tasks that are pending for processing.
- PendingWrite - Class in io.netty.util.internal
-
Some pending write which should be picked up later.
- PlatformDependent - Class in io.netty.util.internal
-
Utility that detects various properties specific to the current runtime
environment, such as Java version and the availability of the
sun.misc.Unsafe
object.
- poll() - Method in class io.netty.util.internal.PriorityQueue
-
- pollNextLocalTask() - Static method in class io.netty.util.internal.chmv8.ForkJoinTask
-
Unschedules and returns, without executing, the next task
queued by the current thread but not yet executed, if the
current thread is operating in a ForkJoinPool.
- pollScheduledTask() - Method in class io.netty.util.concurrent.AbstractScheduledEventExecutor
-
- pollScheduledTask(long) - Method in class io.netty.util.concurrent.AbstractScheduledEventExecutor
-
Return the
Runnable
which is ready to be executed with the given
nanoTime
.
- pollSubmission() - Method in class io.netty.util.internal.chmv8.ForkJoinPool
-
Removes and returns the next unexecuted submission if one is
available.
- pollTask() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- pollTask() - Static method in class io.netty.util.internal.chmv8.ForkJoinTask
-
If the current thread is operating in a ForkJoinPool,
unschedules and returns, without executing, the next task
queued by the current thread but not yet executed, if one is
available, or if not available, a task that was forked by some
other thread, if available.
- priority() - Method in interface io.netty.util.concurrent.ThreadProperties
-
- PriorityQueue<T extends PriorityQueueNode<T>> - Class in io.netty.util.internal
-
A priority queue which uses natural ordering of elements.
- PriorityQueue() - Constructor for class io.netty.util.internal.PriorityQueue
-
- PriorityQueue(int) - Constructor for class io.netty.util.internal.PriorityQueue
-
- priorityQueueIndex() - Method in interface io.netty.util.internal.PriorityQueueNode
-
- priorityQueueIndex(int) - Method in interface io.netty.util.internal.PriorityQueueNode
-
Used by
PriorityQueue
to maintain state for an element in the queue.
- PriorityQueueNode<T> - Interface in io.netty.util.internal
-
- process(byte) - Method in class io.netty.util.ByteProcessor.IndexNotOfProcessor
-
- process(byte) - Method in class io.netty.util.ByteProcessor.IndexOfProcessor
-
- process(byte) - Method in interface io.netty.util.ByteProcessor
-
- ProgressiveFuture<V> - Interface in io.netty.util.concurrent
-
A
Future
which is used to indicate the progress of an operation.
- ProgressivePromise<V> - Interface in io.netty.util.concurrent
-
- Promise<V> - Interface in io.netty.util.concurrent
-
Special
Future
which is writable.
- promise() - Method in class io.netty.util.internal.PendingWrite
-
- PromiseAggregator<V,F extends Future<V>> - Class in io.netty.util.concurrent
-
GenericFutureListener
implementation which consolidates multiple
Future
s
into one, by listening to individual
Future
s and producing an aggregated result
(success/failure) when all
Future
s have completed.
- PromiseAggregator(Promise<Void>, boolean) - Constructor for class io.netty.util.concurrent.PromiseAggregator
-
Creates a new instance.
- PromiseAggregator(Promise<Void>) - Constructor for class io.netty.util.concurrent.PromiseAggregator
-
- PromiseNotifier<V,F extends Future<V>> - Class in io.netty.util.concurrent
-
- PromiseNotifier(Promise<? super V>...) - Constructor for class io.netty.util.concurrent.PromiseNotifier
-
Create a new instance.
- propagateCompletion() - Method in class io.netty.util.internal.chmv8.CountedCompleter
-
- put(byte, V) - Method in class io.netty.util.collection.ByteObjectHashMap
-
- put(Byte, V) - Method in class io.netty.util.collection.ByteObjectHashMap
-
- put(byte, V) - Method in interface io.netty.util.collection.ByteObjectMap
-
Puts the given entry into the map.
- put(char, V) - Method in class io.netty.util.collection.CharObjectHashMap
-
- put(Character, V) - Method in class io.netty.util.collection.CharObjectHashMap
-
- put(char, V) - Method in interface io.netty.util.collection.CharObjectMap
-
Puts the given entry into the map.
- put(int, V) - Method in class io.netty.util.collection.IntObjectHashMap
-
- put(Integer, V) - Method in class io.netty.util.collection.IntObjectHashMap
-
- put(int, V) - Method in interface io.netty.util.collection.IntObjectMap
-
Puts the given entry into the map.
- put(long, V) - Method in class io.netty.util.collection.LongObjectHashMap
-
- put(Long, V) - Method in class io.netty.util.collection.LongObjectHashMap
-
- put(long, V) - Method in interface io.netty.util.collection.LongObjectMap
-
Puts the given entry into the map.
- put(short, V) - Method in class io.netty.util.collection.ShortObjectHashMap
-
- put(Short, V) - Method in class io.netty.util.collection.ShortObjectHashMap
-
- put(short, V) - Method in interface io.netty.util.collection.ShortObjectMap
-
Puts the given entry into the map.
- put(K, V) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Maps the specified key to the specified value in this table.
- putAll(Map<? extends Byte, ? extends V>) - Method in class io.netty.util.collection.ByteObjectHashMap
-
- putAll(Map<? extends Character, ? extends V>) - Method in class io.netty.util.collection.CharObjectHashMap
-
- putAll(Map<? extends Integer, ? extends V>) - Method in class io.netty.util.collection.IntObjectHashMap
-
- putAll(Map<? extends Long, ? extends V>) - Method in class io.netty.util.collection.LongObjectHashMap
-
- putAll(Map<? extends Short, ? extends V>) - Method in class io.netty.util.collection.ShortObjectHashMap
-
- putAll(Map<? extends K, ? extends V>) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Copies all of the mappings from the specified map to this one.
- putByte(long, byte) - Static method in class io.netty.util.internal.PlatformDependent
-
- putByte(byte[], int, byte) - Static method in class io.netty.util.internal.PlatformDependent
-
- putIfAbsent(K, V) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
- putInt(long, int) - Static method in class io.netty.util.internal.PlatformDependent
-
- putInt(byte[], int, int) - Static method in class io.netty.util.internal.PlatformDependent
-
- putLong(long, long) - Static method in class io.netty.util.internal.PlatformDependent
-
- putLong(byte[], int, long) - Static method in class io.netty.util.internal.PlatformDependent
-
- putOrderedObject(Object, long, Object) - Static method in class io.netty.util.internal.PlatformDependent
-
- putShort(long, short) - Static method in class io.netty.util.internal.PlatformDependent
-
- putShort(byte[], int, short) - Static method in class io.netty.util.internal.PlatformDependent
-
- random() - Method in class io.netty.util.internal.InternalThreadLocalMap
-
- ReadOnlyIterator<T> - Class in io.netty.util.internal
-
- ReadOnlyIterator(Iterator<? extends T>) - Constructor for class io.netty.util.internal.ReadOnlyIterator
-
- readResolve() - Method in class io.netty.util.internal.logging.AbstractInternalLogger
-
- record() - Method in interface io.netty.util.ResourceLeak
-
Records the caller's current stack trace so that the
ResourceLeakDetector
can tell where the leaked
resource was accessed lastly.
- record(Object) - Method in interface io.netty.util.ResourceLeak
-
Records the caller's current stack trace and the specified additional arbitrary information
so that the
ResourceLeakDetector
can tell where the leaked resource was accessed lastly.
- RecyclableArrayList - Class in io.netty.util.internal
-
A simple list which is recyclable.
- RecyclableMpscLinkedQueueNode<T> - Class in io.netty.util.internal
-
MpscLinkedQueueNode
that will automatically call
Recycler.Handle#recycle(Object)
when the node was
unlinked.
- RecyclableMpscLinkedQueueNode(Recycler.Handle<? extends RecyclableMpscLinkedQueueNode<T>>) - Constructor for class io.netty.util.internal.RecyclableMpscLinkedQueueNode
-
- recycle() - Method in class io.netty.util.internal.PendingWrite
-
Clear and recycle this instance.
- recycle() - Method in class io.netty.util.internal.RecyclableArrayList
-
Clear and recycle this instance.
- recycle(T) - Method in interface io.netty.util.Recycler.Handle
-
- recycle(T, Recycler.Handle<T>) - Method in class io.netty.util.Recycler
-
- recycleAndGet() - Method in class io.netty.util.internal.PendingWrite
-
Recycle this instance and return the
Promise
.
- Recycler<T> - Class in io.netty.util
-
Light-weight object pool based on a thread-local stack.
- Recycler() - Constructor for class io.netty.util.Recycler
-
- Recycler(int) - Constructor for class io.netty.util.Recycler
-
- Recycler.Handle<T> - Interface in io.netty.util
-
- reduce(long, ConcurrentHashMapV8.BiFun<? super K, ? super V, ? extends U>, ConcurrentHashMapV8.BiFun<? super U, ? super U, ? extends U>) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Returns the result of accumulating the given transformation
of all (key, value) pairs using the given reducer to
combine values, or null if none.
- reduceEntries(long, ConcurrentHashMapV8.BiFun<Map.Entry<K, V>, Map.Entry<K, V>, ? extends Map.Entry<K, V>>) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Returns the result of accumulating all entries using the
given reducer to combine values, or null if none.
- reduceEntries(long, ConcurrentHashMapV8.Fun<Map.Entry<K, V>, ? extends U>, ConcurrentHashMapV8.BiFun<? super U, ? super U, ? extends U>) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Returns the result of accumulating the given transformation
of all entries using the given reducer to combine values,
or null if none.
- reduceEntriesToDouble(long, ConcurrentHashMapV8.ObjectToDouble<Map.Entry<K, V>>, double, ConcurrentHashMapV8.DoubleByDoubleToDouble) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Returns the result of accumulating the given transformation
of all entries using the given reducer to combine values,
and the given basis as an identity value.
- reduceEntriesToInt(long, ConcurrentHashMapV8.ObjectToInt<Map.Entry<K, V>>, int, ConcurrentHashMapV8.IntByIntToInt) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Returns the result of accumulating the given transformation
of all entries using the given reducer to combine values,
and the given basis as an identity value.
- reduceEntriesToLong(long, ConcurrentHashMapV8.ObjectToLong<Map.Entry<K, V>>, long, ConcurrentHashMapV8.LongByLongToLong) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Returns the result of accumulating the given transformation
of all entries using the given reducer to combine values,
and the given basis as an identity value.
- reduceKeys(long, ConcurrentHashMapV8.BiFun<? super K, ? super K, ? extends K>) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Returns the result of accumulating all keys using the given
reducer to combine values, or null if none.
- reduceKeys(long, ConcurrentHashMapV8.Fun<? super K, ? extends U>, ConcurrentHashMapV8.BiFun<? super U, ? super U, ? extends U>) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Returns the result of accumulating the given transformation
of all keys using the given reducer to combine values, or
null if none.
- reduceKeysToDouble(long, ConcurrentHashMapV8.ObjectToDouble<? super K>, double, ConcurrentHashMapV8.DoubleByDoubleToDouble) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Returns the result of accumulating the given transformation
of all keys using the given reducer to combine values, and
the given basis as an identity value.
- reduceKeysToInt(long, ConcurrentHashMapV8.ObjectToInt<? super K>, int, ConcurrentHashMapV8.IntByIntToInt) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Returns the result of accumulating the given transformation
of all keys using the given reducer to combine values, and
the given basis as an identity value.
- reduceKeysToLong(long, ConcurrentHashMapV8.ObjectToLong<? super K>, long, ConcurrentHashMapV8.LongByLongToLong) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Returns the result of accumulating the given transformation
of all keys using the given reducer to combine values, and
the given basis as an identity value.
- reduceToDouble(long, ConcurrentHashMapV8.ObjectByObjectToDouble<? super K, ? super V>, double, ConcurrentHashMapV8.DoubleByDoubleToDouble) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Returns the result of accumulating the given transformation
of all (key, value) pairs using the given reducer to
combine values, and the given basis as an identity value.
- reduceToInt(long, ConcurrentHashMapV8.ObjectByObjectToInt<? super K, ? super V>, int, ConcurrentHashMapV8.IntByIntToInt) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Returns the result of accumulating the given transformation
of all (key, value) pairs using the given reducer to
combine values, and the given basis as an identity value.
- reduceToLong(long, ConcurrentHashMapV8.ObjectByObjectToLong<? super K, ? super V>, long, ConcurrentHashMapV8.LongByLongToLong) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Returns the result of accumulating the given transformation
of all (key, value) pairs using the given reducer to
combine values, and the given basis as an identity value.
- reduceValues(long, ConcurrentHashMapV8.BiFun<? super V, ? super V, ? extends V>) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Returns the result of accumulating all values using the
given reducer to combine values, or null if none.
- reduceValues(long, ConcurrentHashMapV8.Fun<? super V, ? extends U>, ConcurrentHashMapV8.BiFun<? super U, ? super U, ? extends U>) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Returns the result of accumulating the given transformation
of all values using the given reducer to combine values, or
null if none.
- reduceValuesToDouble(long, ConcurrentHashMapV8.ObjectToDouble<? super V>, double, ConcurrentHashMapV8.DoubleByDoubleToDouble) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Returns the result of accumulating the given transformation
of all values using the given reducer to combine values,
and the given basis as an identity value.
- reduceValuesToInt(long, ConcurrentHashMapV8.ObjectToInt<? super V>, int, ConcurrentHashMapV8.IntByIntToInt) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Returns the result of accumulating the given transformation
of all values using the given reducer to combine values,
and the given basis as an identity value.
- reduceValuesToLong(long, ConcurrentHashMapV8.ObjectToLong<? super V>, long, ConcurrentHashMapV8.LongByLongToLong) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Returns the result of accumulating the given transformation
of all values using the given reducer to combine values,
and the given basis as an identity value.
- refCnt() - Method in class io.netty.util.AbstractReferenceCounted
-
- refCnt() - Method in interface io.netty.util.ReferenceCounted
-
Returns the reference count of this object.
- ReferenceCounted - Interface in io.netty.util
-
A reference-counted object that requires explicit deallocation.
- ReferenceCountUtil - Class in io.netty.util
-
- regionMatches(int, CharSequence, int, int) - Method in class io.netty.util.AsciiString
-
Compares the specified string to this string and compares the specified range of characters to determine if they
are the same.
- regionMatches(boolean, int, CharSequence, int, int) - Method in class io.netty.util.AsciiString
-
Compares the specified string to this string and compares the specified range of characters to determine if they
are the same.
- regionMatches(CharSequence, boolean, int, CharSequence, int, int) - Static method in class io.netty.util.AsciiString
-
This methods make regionMatches operation correctly for any chars in strings
- regionMatchesAscii(CharSequence, boolean, int, CharSequence, int, int) - Static method in class io.netty.util.AsciiString
-
This is optimized version of regionMatches for string with ASCII chars only
- reinitialize() - Method in class io.netty.util.internal.chmv8.ForkJoinTask
-
Resets the internal bookkeeping state of this task, allowing a
subsequent fork
.
- reject() - Static method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- release() - Method in class io.netty.util.AbstractReferenceCounted
-
- release(int) - Method in class io.netty.util.AbstractReferenceCounted
-
- release() - Method in interface io.netty.util.ReferenceCounted
-
Decreases the reference count by 1
and deallocates this object if the reference count reaches at
0
.
- release(int) - Method in interface io.netty.util.ReferenceCounted
-
Decreases the reference count by the specified decrement
and deallocates this object if the reference
count reaches at 0
.
- release(Object) - Static method in class io.netty.util.ReferenceCountUtil
-
- release(Object, int) - Static method in class io.netty.util.ReferenceCountUtil
-
- releaseLater(T) - Static method in class io.netty.util.ReferenceCountUtil
-
Schedules the specified object to be released when the caller thread terminates.
- releaseLater(T, int) - Static method in class io.netty.util.ReferenceCountUtil
-
Schedules the specified object to be released when the caller thread terminates.
- remove() - Method in interface io.netty.util.Attribute
-
- remove(byte) - Method in class io.netty.util.collection.ByteObjectHashMap
-
- remove(Object) - Method in class io.netty.util.collection.ByteObjectHashMap
-
- remove(byte) - Method in interface io.netty.util.collection.ByteObjectMap
-
Removes the entry with the specified key.
- remove(char) - Method in class io.netty.util.collection.CharObjectHashMap
-
- remove(Object) - Method in class io.netty.util.collection.CharObjectHashMap
-
- remove(char) - Method in interface io.netty.util.collection.CharObjectMap
-
Removes the entry with the specified key.
- remove(int) - Method in class io.netty.util.collection.IntObjectHashMap
-
- remove(Object) - Method in class io.netty.util.collection.IntObjectHashMap
-
- remove(int) - Method in interface io.netty.util.collection.IntObjectMap
-
Removes the entry with the specified key.
- remove(long) - Method in class io.netty.util.collection.LongObjectHashMap
-
- remove(Object) - Method in class io.netty.util.collection.LongObjectHashMap
-
- remove(long) - Method in interface io.netty.util.collection.LongObjectMap
-
Removes the entry with the specified key.
- remove(short) - Method in class io.netty.util.collection.ShortObjectHashMap
-
- remove(Object) - Method in class io.netty.util.collection.ShortObjectHashMap
-
- remove(short) - Method in interface io.netty.util.collection.ShortObjectMap
-
Removes the entry with the specified key.
- remove() - Method in class io.netty.util.concurrent.FastThreadLocal
-
Sets the value to uninitialized; a proceeding call to get() will trigger a call to initialValue().
- remove(InternalThreadLocalMap) - Method in class io.netty.util.concurrent.FastThreadLocal
-
Sets the value to uninitialized for the specified thread local map;
a proceeding call to get() will trigger a call to initialValue().
- remove(Object) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8.KeySetView
-
Removes the key from this map view, by removing the key (and its
corresponding value) from the backing map.
- remove(Object) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Removes the key (and its corresponding value) from this map.
- remove(Object, Object) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
- remove(Object) - Method in class io.netty.util.internal.ConcurrentSet
-
- remove() - Static method in class io.netty.util.internal.InternalThreadLocalMap
-
- remove(Object) - Method in class io.netty.util.internal.PriorityQueue
-
- remove() - Method in class io.netty.util.internal.ReadOnlyIterator
-
- removeAll() - Static method in class io.netty.util.concurrent.FastThreadLocal
-
- removeIndexedVariable(int) - Method in class io.netty.util.internal.InternalThreadLocalMap
-
- removeListener(GenericFutureListener<? extends Future<? super V>>) - Method in class io.netty.util.concurrent.CompleteFuture
-
- removeListener(GenericFutureListener<? extends Future<? super V>>) - Method in class io.netty.util.concurrent.DefaultProgressivePromise
-
- removeListener(GenericFutureListener<? extends Future<? super V>>) - Method in class io.netty.util.concurrent.DefaultPromise
-
- removeListener(GenericFutureListener<? extends Future<? super V>>) - Method in interface io.netty.util.concurrent.Future
-
Removes the specified listener from this future.
- removeListener(GenericFutureListener<? extends Future<? super V>>) - Method in interface io.netty.util.concurrent.ProgressiveFuture
-
- removeListener(GenericFutureListener<? extends Future<? super V>>) - Method in interface io.netty.util.concurrent.ProgressivePromise
-
- removeListener(GenericFutureListener<? extends Future<? super V>>) - Method in interface io.netty.util.concurrent.Promise
-
- removeListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in class io.netty.util.concurrent.CompleteFuture
-
- removeListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in class io.netty.util.concurrent.DefaultProgressivePromise
-
- removeListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in class io.netty.util.concurrent.DefaultPromise
-
- removeListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in interface io.netty.util.concurrent.Future
-
Removes the specified listeners from this future.
- removeListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in interface io.netty.util.concurrent.ProgressiveFuture
-
- removeListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in interface io.netty.util.concurrent.ProgressivePromise
-
- removeListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in interface io.netty.util.concurrent.Promise
-
- removeShutdownHook(Runnable) - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
Remove a previous added
Runnable
as a shutdown hook
- removeTask(Runnable) - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- replace(char, char) - Method in class io.netty.util.AsciiString
-
Copies this string replacing occurrences of the specified character with another character.
- replace(K, V, V) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
- replace(K, V) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
- replaceAll(ConcurrentHashMapV8.BiFun<? super K, ? super V, ? extends V>) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
- repositoryStatus() - Method in class io.netty.util.Version
-
- reset() - Method in class io.netty.util.internal.AppendableCharSequence
-
- reset() - Method in class io.netty.util.internal.chmv8.LongAdderV8
-
Resets variables maintaining the sum to zero.
- ResourceLeak - Interface in io.netty.util
-
- ResourceLeakDetector<T> - Class in io.netty.util
-
- ResourceLeakDetector(Class<?>) - Constructor for class io.netty.util.ResourceLeakDetector
-
- ResourceLeakDetector(String) - Constructor for class io.netty.util.ResourceLeakDetector
-
- ResourceLeakDetector(Class<?>, int, long) - Constructor for class io.netty.util.ResourceLeakDetector
-
- ResourceLeakDetector(String, int, long) - Constructor for class io.netty.util.ResourceLeakDetector
-
- ResourceLeakDetector.Level - Enum in io.netty.util
-
Represents the level of resource leak detection.
- ResourceLeakException - Exception in io.netty.util
-
Deprecated.
This class will be removed in the future version.
- ResourceLeakException() - Constructor for exception io.netty.util.ResourceLeakException
-
Deprecated.
- ResourceLeakException(String) - Constructor for exception io.netty.util.ResourceLeakException
-
Deprecated.
- ResourceLeakException(String, Throwable) - Constructor for exception io.netty.util.ResourceLeakException
-
Deprecated.
- ResourceLeakException(Throwable) - Constructor for exception io.netty.util.ResourceLeakException
-
Deprecated.
- ResourceLeakHint - Interface in io.netty.util
-
A hint object that provides human-readable message for easier resource leak tracking.
- retain() - Method in class io.netty.util.AbstractReferenceCounted
-
- retain(int) - Method in class io.netty.util.AbstractReferenceCounted
-
- retain() - Method in interface io.netty.util.ReferenceCounted
-
Increases the reference count by 1
.
- retain(int) - Method in interface io.netty.util.ReferenceCounted
-
Increases the reference count by the specified increment
.
- retain(T) - Static method in class io.netty.util.ReferenceCountUtil
-
- retain(T, int) - Static method in class io.netty.util.ReferenceCountUtil
-
- rp1 - Variable in class io.netty.util.internal.InternalThreadLocalMap
-
- rp2 - Variable in class io.netty.util.internal.InternalThreadLocalMap
-
- rp3 - Variable in class io.netty.util.internal.InternalThreadLocalMap
-
- rp4 - Variable in class io.netty.util.internal.InternalThreadLocalMap
-
- rp5 - Variable in class io.netty.util.internal.InternalThreadLocalMap
-
- rp6 - Variable in class io.netty.util.internal.InternalThreadLocalMap
-
- rp7 - Variable in class io.netty.util.internal.InternalThreadLocalMap
-
- rp8 - Variable in class io.netty.util.internal.InternalThreadLocalMap
-
- rp9 - Variable in class io.netty.util.internal.InternalThreadLocalMap
-
- run() - Method in class io.netty.util.concurrent.DefaultEventExecutor
-
- run() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- run() - Method in class io.netty.util.internal.chmv8.ForkJoinWorkerThread
-
This method is required to be public, but should never be
called explicitly.
- run(Timeout) - Method in interface io.netty.util.TimerTask
-
- runAllTasks() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
Poll all tasks from the task queue and run them via
Runnable.run()
method.
- runAllTasks(long) - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
Poll all tasks from the task queue and run them via
Runnable.run()
method.
- safeRelease(Object) - Static method in class io.netty.util.ReferenceCountUtil
-
- safeRelease(Object, int) - Static method in class io.netty.util.ReferenceCountUtil
-
- schedule(Runnable, long, TimeUnit) - Method in class io.netty.util.concurrent.AbstractEventExecutor
-
- schedule(Callable<V>, long, TimeUnit) - Method in class io.netty.util.concurrent.AbstractEventExecutor
-
- schedule(Runnable, long, TimeUnit) - Method in class io.netty.util.concurrent.AbstractEventExecutorGroup
-
- schedule(Callable<V>, long, TimeUnit) - Method in class io.netty.util.concurrent.AbstractEventExecutorGroup
-
- schedule(Runnable, long, TimeUnit) - Method in class io.netty.util.concurrent.AbstractScheduledEventExecutor
-
- schedule(Callable<V>, long, TimeUnit) - Method in class io.netty.util.concurrent.AbstractScheduledEventExecutor
-
- schedule(Runnable, long, TimeUnit) - Method in interface io.netty.util.concurrent.EventExecutorGroup
-
- schedule(Callable<V>, long, TimeUnit) - Method in interface io.netty.util.concurrent.EventExecutorGroup
-
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class io.netty.util.concurrent.AbstractEventExecutor
-
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class io.netty.util.concurrent.AbstractEventExecutorGroup
-
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class io.netty.util.concurrent.AbstractScheduledEventExecutor
-
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in interface io.netty.util.concurrent.EventExecutorGroup
-
- ScheduledFuture<V> - Interface in io.netty.util.concurrent
-
The result of an scheduled asynchronous operation.
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class io.netty.util.concurrent.AbstractEventExecutor
-
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class io.netty.util.concurrent.AbstractEventExecutorGroup
-
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class io.netty.util.concurrent.AbstractScheduledEventExecutor
-
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in interface io.netty.util.concurrent.EventExecutorGroup
-
- search(long, ConcurrentHashMapV8.BiFun<? super K, ? super V, ? extends U>) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Returns a non-null result from applying the given search
function on each (key, value), or null if none.
- searchEntries(long, ConcurrentHashMapV8.Fun<Map.Entry<K, V>, ? extends U>) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Returns a non-null result from applying the given search
function on each entry, or null if none.
- searchKeys(long, ConcurrentHashMapV8.Fun<? super K, ? extends U>) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Returns a non-null result from applying the given search
function on each key, or null if none.
- searchValues(long, ConcurrentHashMapV8.Fun<? super V, ? extends U>) - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Returns a non-null result from applying the given search
function on each value, or null if none.
- set(T) - Method in interface io.netty.util.Attribute
-
Sets the value
- set(V) - Method in class io.netty.util.concurrent.FastThreadLocal
-
Set the value for the current thread.
- set(InternalThreadLocalMap, V) - Method in class io.netty.util.concurrent.FastThreadLocal
-
Set the value for the specified thread local map.
- set(int, Object) - Method in class io.netty.util.internal.RecyclableArrayList
-
- setCounterHashCode(IntegerHolder) - Method in class io.netty.util.internal.InternalThreadLocalMap
-
- setDefaultFactory(InternalLoggerFactory) - Static method in class io.netty.util.internal.logging.InternalLoggerFactory
-
Changes the default factory.
- setEnabled(boolean) - Static method in class io.netty.util.ResourceLeakDetector
-
- setFailure(Throwable) - Method in class io.netty.util.concurrent.DefaultProgressivePromise
-
- setFailure(Throwable) - Method in class io.netty.util.concurrent.DefaultPromise
-
- setFailure(Throwable) - Method in interface io.netty.util.concurrent.ProgressivePromise
-
- setFailure(Throwable) - Method in interface io.netty.util.concurrent.Promise
-
Marks this future as a failure and notifies all
listeners.
- setForkJoinTaskTag(short) - Method in class io.netty.util.internal.chmv8.ForkJoinTask
-
Atomically sets the tag value for this task.
- setFutureListenerStackDepth(int) - Method in class io.netty.util.internal.InternalThreadLocalMap
-
- setIfAbsent(T) - Method in interface io.netty.util.Attribute
-
Atomically sets to the given value if this
Attribute
's value is
null
.
- setIndexedVariable(int, Object) - Method in class io.netty.util.internal.InternalThreadLocalMap
-
- setInitialSeedUniquifier(long) - Static method in class io.netty.util.internal.ThreadLocalRandom
-
- setLevel(ResourceLeakDetector.Level) - Static method in class io.netty.util.ResourceLeakDetector
-
Sets the resource leak detection level.
- setLocalChannelReaderStackDepth(int) - Method in class io.netty.util.internal.InternalThreadLocalMap
-
- setPendingCount(int) - Method in class io.netty.util.internal.chmv8.CountedCompleter
-
Sets the pending count to the given value.
- setProgress(long, long) - Method in class io.netty.util.concurrent.DefaultProgressivePromise
-
- setProgress(long, long) - Method in interface io.netty.util.concurrent.ProgressivePromise
-
- setRawResult(T) - Method in class io.netty.util.internal.chmv8.CountedCompleter
-
A method that result-bearing CountedCompleters may optionally
use to help maintain result data.
- setRawResult(V) - Method in class io.netty.util.internal.chmv8.ForkJoinTask
-
Forces the given value to be returned as a result.
- setRefCnt(int) - Method in class io.netty.util.AbstractReferenceCounted
-
An unsafe operation intended for use by a subclass that sets the reference count of the buffer directly
- setSeed(long) - Method in class io.netty.util.internal.ThreadLocalRandom
-
Throws UnsupportedOperationException
.
- setSuccess(V) - Method in class io.netty.util.concurrent.DefaultProgressivePromise
-
- setSuccess(V) - Method in class io.netty.util.concurrent.DefaultPromise
-
- setSuccess(V) - Method in interface io.netty.util.concurrent.ProgressivePromise
-
- setSuccess(V) - Method in interface io.netty.util.concurrent.Promise
-
Marks this future as a success and notifies all
listeners.
- setThreadLocalMap(InternalThreadLocalMap) - Method in class io.netty.util.concurrent.FastThreadLocalThread
-
Sets the internal data structure that keeps the thread-local variables bound to this thread.
- setUncancellable() - Method in class io.netty.util.concurrent.DefaultPromise
-
- setUncancellable() - Method in interface io.netty.util.concurrent.Promise
-
Make this future impossible to cancel.
- setValue(V) - Method in interface io.netty.util.collection.ByteObjectMap.PrimitiveEntry
-
Sets the value for this entry.
- setValue(V) - Method in interface io.netty.util.collection.CharObjectMap.PrimitiveEntry
-
Sets the value for this entry.
- setValue(V) - Method in interface io.netty.util.collection.IntObjectMap.PrimitiveEntry
-
Sets the value for this entry.
- setValue(V) - Method in interface io.netty.util.collection.LongObjectMap.PrimitiveEntry
-
Sets the value for this entry.
- setValue(V) - Method in interface io.netty.util.collection.ShortObjectMap.PrimitiveEntry
-
Sets the value for this entry.
- ShortCollections - Class in io.netty.util.collection
-
Utilities for short-based primitive collections.
- shortCommitHash() - Method in class io.netty.util.Version
-
- ShortObjectHashMap<V> - Class in io.netty.util.collection
-
A hash map implementation of
ShortObjectMap
that uses open addressing for keys.
- ShortObjectHashMap() - Constructor for class io.netty.util.collection.ShortObjectHashMap
-
- ShortObjectHashMap(int) - Constructor for class io.netty.util.collection.ShortObjectHashMap
-
- ShortObjectHashMap(int, float) - Constructor for class io.netty.util.collection.ShortObjectHashMap
-
- ShortObjectMap<V> - Interface in io.netty.util.collection
-
Interface for a primitive map that uses short
s as keys.
- ShortObjectMap.PrimitiveEntry<V> - Interface in io.netty.util.collection
-
- shutdown() - Method in class io.netty.util.concurrent.AbstractEventExecutor
-
- shutdown() - Method in class io.netty.util.concurrent.AbstractEventExecutorGroup
-
- shutdown() - Method in interface io.netty.util.concurrent.EventExecutorGroup
-
- shutdown() - Method in class io.netty.util.concurrent.GlobalEventExecutor
-
Deprecated.
- shutdown() - Method in class io.netty.util.concurrent.ImmediateEventExecutor
-
Deprecated.
- shutdown() - Method in class io.netty.util.concurrent.MultithreadEventExecutorGroup
-
Deprecated.
- shutdown() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
Deprecated.
- shutdown() - Method in class io.netty.util.internal.chmv8.ForkJoinPool
-
Possibly initiates an orderly shutdown in which previously
submitted tasks are executed, but no new tasks will be
accepted.
- shutdownGracefully() - Method in class io.netty.util.concurrent.AbstractEventExecutor
-
- shutdownGracefully() - Method in class io.netty.util.concurrent.AbstractEventExecutorGroup
-
- shutdownGracefully() - Method in interface io.netty.util.concurrent.EventExecutorGroup
-
- shutdownGracefully(long, long, TimeUnit) - Method in interface io.netty.util.concurrent.EventExecutorGroup
-
Signals this executor that the caller wants the executor to be shut down.
- shutdownGracefully(long, long, TimeUnit) - Method in class io.netty.util.concurrent.GlobalEventExecutor
-
- shutdownGracefully(long, long, TimeUnit) - Method in class io.netty.util.concurrent.ImmediateEventExecutor
-
- shutdownGracefully(long, long, TimeUnit) - Method in class io.netty.util.concurrent.MultithreadEventExecutorGroup
-
- shutdownGracefully(long, long, TimeUnit) - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- shutdownNow() - Method in class io.netty.util.concurrent.AbstractEventExecutor
-
- shutdownNow() - Method in class io.netty.util.concurrent.AbstractEventExecutorGroup
-
- shutdownNow() - Method in interface io.netty.util.concurrent.EventExecutorGroup
-
- shutdownNow() - Method in class io.netty.util.internal.chmv8.ForkJoinPool
-
Possibly attempts to cancel and/or stop all tasks, and reject
all subsequently submitted tasks.
- Signal - Error in io.netty.util
-
A special
Error
which is used to signal some state or request by throwing it.
- simpleClassName(Object) - Static method in class io.netty.util.internal.StringUtil
-
- simpleClassName(Class<?>) - Static method in class io.netty.util.internal.StringUtil
-
Generates a simplified name from a
Class
.
- SingleThreadEventExecutor - Class in io.netty.util.concurrent
-
Abstract base class for
EventExecutor
's that execute all its submitted tasks in a single thread.
- SingleThreadEventExecutor(EventExecutorGroup, ThreadFactory, boolean) - Constructor for class io.netty.util.concurrent.SingleThreadEventExecutor
-
Create a new instance
- SingleThreadEventExecutor(EventExecutorGroup, Executor, boolean) - Constructor for class io.netty.util.concurrent.SingleThreadEventExecutor
-
Create a new instance
- size() - Method in class io.netty.util.collection.ByteObjectHashMap
-
- size() - Method in class io.netty.util.collection.CharObjectHashMap
-
- size() - Method in class io.netty.util.collection.IntObjectHashMap
-
- size() - Method in class io.netty.util.collection.LongObjectHashMap
-
- size() - Method in class io.netty.util.collection.ShortObjectHashMap
-
- size() - Static method in class io.netty.util.concurrent.FastThreadLocal
-
Returns the number of thread local variables bound to the current thread.
- size() - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
- size() - Method in class io.netty.util.internal.ConcurrentSet
-
- size() - Method in class io.netty.util.internal.InternalThreadLocalMap
-
- size() - Method in class io.netty.util.internal.PriorityQueue
-
- Slf4JLoggerFactory - Class in io.netty.util.internal.logging
-
Logger factory which creates a
SLF4J
logger.
- Slf4JLoggerFactory() - Constructor for class io.netty.util.internal.logging.Slf4JLoggerFactory
-
- SOMAXCONN - Static variable in class io.netty.util.NetUtil
-
The SOMAXCONN value of the current machine.
- split(String, int) - Method in class io.netty.util.AsciiString
-
Splits this string using the supplied regular expression expr
.
- split(char) - Method in class io.netty.util.AsciiString
-
Splits the specified
String
with the specified delimiter..
- split(String, char) - Static method in class io.netty.util.internal.StringUtil
-
Splits the specified
String
with the specified delimiter.
- split(String, char, int) - Static method in class io.netty.util.internal.StringUtil
-
Splits the specified
String
with the specified delimiter in maxParts maximum parts.
- spliterator166() - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8.KeySetView
-
- stackTrace() - Method in interface io.netty.util.concurrent.ThreadProperties
-
- start() - Method in class io.netty.util.HashedWheelTimer
-
Starts the background thread explicitly.
- startsWith(CharSequence) - Method in class io.netty.util.AsciiString
-
Compares the specified string to this string to determine if the specified string is a prefix.
- startsWith(CharSequence, int) - Method in class io.netty.util.AsciiString
-
Compares the specified string to this string, starting at the specified offset, to determine if the specified
string is a prefix.
- state() - Method in interface io.netty.util.concurrent.ThreadProperties
-
- stop() - Method in class io.netty.util.HashedWheelTimer
-
- stop() - Method in interface io.netty.util.Timer
-
Releases all resources acquired by this
Timer
and cancels all
tasks which were scheduled but not executed yet.
- stringBuilder() - Method in class io.netty.util.internal.InternalThreadLocalMap
-
- StringUtil - Class in io.netty.util.internal
-
String utility class.
- submit(Runnable) - Method in class io.netty.util.concurrent.AbstractEventExecutor
-
- submit(Runnable, T) - Method in class io.netty.util.concurrent.AbstractEventExecutor
-
- submit(Callable<T>) - Method in class io.netty.util.concurrent.AbstractEventExecutor
-
- submit(Runnable) - Method in class io.netty.util.concurrent.AbstractEventExecutorGroup
-
- submit(Runnable, T) - Method in class io.netty.util.concurrent.AbstractEventExecutorGroup
-
- submit(Callable<T>) - Method in class io.netty.util.concurrent.AbstractEventExecutorGroup
-
- submit(Runnable) - Method in interface io.netty.util.concurrent.EventExecutorGroup
-
- submit(Runnable, T) - Method in interface io.netty.util.concurrent.EventExecutorGroup
-
- submit(Callable<T>) - Method in interface io.netty.util.concurrent.EventExecutorGroup
-
- submit(ForkJoinTask<T>) - Method in class io.netty.util.internal.chmv8.ForkJoinPool
-
Submits a ForkJoinTask for execution.
- submit(Callable<T>) - Method in class io.netty.util.internal.chmv8.ForkJoinPool
-
- submit(Runnable, T) - Method in class io.netty.util.internal.chmv8.ForkJoinPool
-
- submit(Runnable) - Method in class io.netty.util.internal.chmv8.ForkJoinPool
-
- subSequence(int) - Method in class io.netty.util.AsciiString
-
Copies a range of characters into a new string.
- subSequence(int, int) - Method in class io.netty.util.AsciiString
-
Copies a range of characters into a new string.
- subSequence(int, int, boolean) - Method in class io.netty.util.AsciiString
-
Either copy or share a subset of underlying sub-sequence of bytes.
- subSequence(int, int) - Method in class io.netty.util.internal.AppendableCharSequence
-
- substring(int, int) - Method in class io.netty.util.internal.AppendableCharSequence
-
Create a new
String
from the given start to end.
- substringAfter(String, char) - Static method in class io.netty.util.internal.StringUtil
-
Get the item after one char delim if the delim is found (else null).
- subStringUnsafe(int, int) - Method in class io.netty.util.internal.AppendableCharSequence
-
Create a new
String
from the given start to end.
- SucceededFuture<V> - Class in io.netty.util.concurrent
-
- SucceededFuture(EventExecutor, V) - Constructor for class io.netty.util.concurrent.SucceededFuture
-
Creates a new instance.
- successAndRecycle() - Method in class io.netty.util.internal.PendingWrite
-
Mark the underlying
Promise
successed and reycle this instance.
- sum() - Method in class io.netty.util.internal.chmv8.LongAdderV8
-
Returns the current sum.
- sumThenReset() - Method in class io.netty.util.internal.chmv8.LongAdderV8
-
- sync() - Method in class io.netty.util.concurrent.CompleteFuture
-
- sync() - Method in class io.netty.util.concurrent.DefaultProgressivePromise
-
- sync() - Method in class io.netty.util.concurrent.DefaultPromise
-
- sync() - Method in class io.netty.util.concurrent.FailedFuture
-
- sync() - Method in interface io.netty.util.concurrent.Future
-
Waits for this future until it is done, and rethrows the cause of the failure if this future
failed.
- sync() - Method in interface io.netty.util.concurrent.ProgressiveFuture
-
- sync() - Method in interface io.netty.util.concurrent.ProgressivePromise
-
- sync() - Method in interface io.netty.util.concurrent.Promise
-
- syncUninterruptibly() - Method in class io.netty.util.concurrent.CompleteFuture
-
- syncUninterruptibly() - Method in class io.netty.util.concurrent.DefaultProgressivePromise
-
- syncUninterruptibly() - Method in class io.netty.util.concurrent.DefaultPromise
-
- syncUninterruptibly() - Method in class io.netty.util.concurrent.FailedFuture
-
- syncUninterruptibly() - Method in interface io.netty.util.concurrent.Future
-
Waits for this future until it is done, and rethrows the cause of the failure if this future
failed.
- syncUninterruptibly() - Method in interface io.netty.util.concurrent.ProgressiveFuture
-
- syncUninterruptibly() - Method in interface io.netty.util.concurrent.ProgressivePromise
-
- syncUninterruptibly() - Method in interface io.netty.util.concurrent.Promise
-
- SystemPropertyUtil - Class in io.netty.util.internal
-
A collection of utility methods to retrieve and parse the values of the Java system properties.
- TAB - Static variable in class io.netty.util.internal.StringUtil
-
- takeTask() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
Take the next
Runnable
from the task queue and so will block if no task is currently present.
- task() - Method in interface io.netty.util.Timeout
-
Returns the
TimerTask
which is associated with this handle.
- terminationFuture() - Method in interface io.netty.util.concurrent.EventExecutorGroup
-
- terminationFuture() - Method in class io.netty.util.concurrent.GlobalEventExecutor
-
- terminationFuture() - Method in class io.netty.util.concurrent.ImmediateEventExecutor
-
- terminationFuture() - Method in class io.netty.util.concurrent.MultithreadEventExecutorGroup
-
- terminationFuture() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- ThreadDeathWatcher - Class in io.netty.util
-
Checks if a thread is alive periodically and runs a task when a thread dies.
- threadLocalMap() - Method in class io.netty.util.concurrent.FastThreadLocalThread
-
Returns the internal data structure that keeps the thread-local variables bound to this thread.
- ThreadLocalRandom - Class in io.netty.util.internal
-
A random number generator isolated to the current thread.
- ThreadPerTaskExecutor - Class in io.netty.util.concurrent
-
- ThreadPerTaskExecutor(ThreadFactory) - Constructor for class io.netty.util.concurrent.ThreadPerTaskExecutor
-
- threadProperties() - Method in class io.netty.util.concurrent.SingleThreadEventExecutor
-
- ThreadProperties - Interface in io.netty.util.concurrent
-
- throwException(Throwable) - Static method in class io.netty.util.internal.PlatformDependent
-
Raises an exception bypassing compiler checks for checked exceptions.
- Timeout - Interface in io.netty.util
-
- timer() - Method in interface io.netty.util.Timeout
-
Returns the
Timer
that created this handle.
- Timer - Interface in io.netty.util
-
Schedules
TimerTask
s for one-time future execution in a background
thread.
- TimerTask - Interface in io.netty.util
-
- tmpdir() - Static method in class io.netty.util.internal.PlatformDependent
-
Returns the temporary directory.
- toAddressString(InetAddress) - Static method in class io.netty.util.NetUtil
-
- toAddressString(InetAddress, boolean) - Static method in class io.netty.util.NetUtil
-
- toArray() - Method in class io.netty.util.internal.PriorityQueue
-
- toArray(X[]) - Method in class io.netty.util.internal.PriorityQueue
-
- toByteArray() - Method in class io.netty.util.AsciiString
-
Converts this string to a byte array.
- toByteArray(int, int) - Method in class io.netty.util.AsciiString
-
Converts a subset of this string to a byte array.
- toCharArray() - Method in class io.netty.util.AsciiString
-
Copies the characters in this string to a character array.
- toCharArray(int, int) - Method in class io.netty.util.AsciiString
-
Copies the characters in this string to a character array.
- toHexString(byte[]) - Static method in class io.netty.util.internal.StringUtil
-
Converts the specified byte array into a hexadecimal value.
- toHexString(byte[], int, int) - Static method in class io.netty.util.internal.StringUtil
-
Converts the specified byte array into a hexadecimal value.
- toHexString(T, byte[]) - Static method in class io.netty.util.internal.StringUtil
-
Converts the specified byte array into a hexadecimal value and appends it to the specified buffer.
- toHexString(T, byte[], int, int) - Static method in class io.netty.util.internal.StringUtil
-
Converts the specified byte array into a hexadecimal value and appends it to the specified buffer.
- toHexStringPadded(byte[]) - Static method in class io.netty.util.internal.StringUtil
-
Converts the specified byte array into a hexadecimal value.
- toHexStringPadded(byte[], int, int) - Static method in class io.netty.util.internal.StringUtil
-
Converts the specified byte array into a hexadecimal value.
- toHexStringPadded(T, byte[]) - Static method in class io.netty.util.internal.StringUtil
-
Converts the specified byte array into a hexadecimal value and appends it to the specified buffer.
- toHexStringPadded(T, byte[], int, int) - Static method in class io.netty.util.internal.StringUtil
-
Converts the specified byte array into a hexadecimal value and appends it to the specified buffer.
- toHintString() - Method in interface io.netty.util.ResourceLeakHint
-
Returns a human-readable message that potentially enables easier resource leak tracking.
- toLowerCase() - Method in class io.netty.util.AsciiString
-
Converts the characters in this string to lowercase, using the default Locale.
- toString() - Method in class io.netty.util.AbstractConstant
-
- toString() - Method in class io.netty.util.AsciiString
-
Translates the entire byte string to a
String
.
- toString(int) - Method in class io.netty.util.AsciiString
-
Translates the entire byte string to a
String
using the
charset
encoding.
- toString(int, int) - Method in class io.netty.util.AsciiString
-
Translates the [
start
,
end
) range of this byte string to a
String
.
- toString() - Method in class io.netty.util.collection.ByteObjectHashMap
-
- toString() - Method in class io.netty.util.collection.CharObjectHashMap
-
- toString() - Method in class io.netty.util.collection.IntObjectHashMap
-
- toString() - Method in class io.netty.util.collection.LongObjectHashMap
-
- toString() - Method in class io.netty.util.collection.ShortObjectHashMap
-
- toString() - Method in class io.netty.util.concurrent.DefaultPromise
-
- toString() - Method in class io.netty.util.DomainNameMapping
-
- toString() - Method in class io.netty.util.internal.AppendableCharSequence
-
- toString() - Method in class io.netty.util.internal.chmv8.ConcurrentHashMapV8
-
Returns a string representation of this map.
- toString() - Method in class io.netty.util.internal.chmv8.ForkJoinPool
-
Returns a string identifying this pool, as well as its state,
including indications of run state, parallelism level, and
worker and task counts.
- toString() - Method in class io.netty.util.internal.chmv8.LongAdderV8
-
- toString() - Method in class io.netty.util.internal.logging.AbstractInternalLogger
-
- toString() - Method in error io.netty.util.Signal
-
- toString() - Method in class io.netty.util.Version
-
- toStringBuilder() - Method in class io.netty.util.concurrent.DefaultPromise
-
- touch() - Method in class io.netty.util.AbstractReferenceCounted
-
- touch() - Method in interface io.netty.util.ReferenceCounted
-
Records the current access location of this object for debugging purposes.
- touch(Object) - Method in interface io.netty.util.ReferenceCounted
-
Records the current access location of this object with an additonal arbitrary information for debugging
purposes.
- touch(T) - Static method in class io.netty.util.ReferenceCountUtil
-
- touch(T, Object) - Static method in class io.netty.util.ReferenceCountUtil
-
- toUpperCase() - Method in class io.netty.util.AsciiString
-
Converts the characters in this string to uppercase, using the default Locale.
- trace(Throwable) - Method in class io.netty.util.internal.logging.AbstractInternalLogger
-
- trace(String) - Method in interface io.netty.util.internal.logging.InternalLogger
-
Log a message at the TRACE level.
- trace(String, Object) - Method in interface io.netty.util.internal.logging.InternalLogger
-
Log a message at the TRACE level according to the specified format
and argument.
- trace(String, Object, Object) - Method in interface io.netty.util.internal.logging.InternalLogger
-
Log a message at the TRACE level according to the specified format
and arguments.
- trace(String, Object...) - Method in interface io.netty.util.internal.logging.InternalLogger
-
Log a message at the TRACE level according to the specified format
and arguments.
- trace(String, Throwable) - Method in interface io.netty.util.internal.logging.InternalLogger
-
Log an exception (throwable) at the TRACE level with an
accompanying message.
- trace(Throwable) - Method in interface io.netty.util.internal.logging.InternalLogger
-
Log an exception (throwable) at the TRACE level.
- trim() - Method in class io.netty.util.AsciiString
-
Copies this string removing white space characters from the beginning and end of the string.
- tryAdvance(ConcurrentHashMapV8.Action<? super T>) - Method in interface io.netty.util.internal.chmv8.ConcurrentHashMapV8.ConcurrentHashMapSpliterator
-
If an element remains, applies the action and returns true.
- tryComplete() - Method in class io.netty.util.internal.chmv8.CountedCompleter
-
- tryFailure(Throwable) - Method in class io.netty.util.concurrent.DefaultPromise
-
- tryFailure(Throwable) - Method in interface io.netty.util.concurrent.Promise
-
Marks this future as a failure and notifies all
listeners.
- tryProgress(long, long) - Method in class io.netty.util.concurrent.DefaultProgressivePromise
-
- tryProgress(long, long) - Method in interface io.netty.util.concurrent.ProgressivePromise
-
- trySplit() - Method in interface io.netty.util.internal.chmv8.ConcurrentHashMapV8.ConcurrentHashMapSpliterator
-
If possible, returns a new spliterator covering
approximately one half of the elements, which will not be
covered by this spliterator.
- trySuccess(V) - Method in class io.netty.util.concurrent.DefaultPromise
-
- trySuccess(V) - Method in interface io.netty.util.concurrent.Promise
-
Marks this future as a success and notifies all
listeners.
- tryUnfork() - Method in class io.netty.util.internal.chmv8.ForkJoinTask
-
Tries to unschedule this task for execution.
- TypeParameterMatcher - Class in io.netty.util.internal
-
- TypeParameterMatcher() - Constructor for class io.netty.util.internal.TypeParameterMatcher
-
- typeParameterMatcherFindCache() - Method in class io.netty.util.internal.InternalThreadLocalMap
-
- typeParameterMatcherGetCache() - Method in class io.netty.util.internal.InternalThreadLocalMap
-