- abortAll() - Method in class com.bluegosling.concurrent.executors.PipeliningExecutor
-
Aborts all pipelines, draining their queues and attempting to interrupt any currently
running tasks.
- abortOnAnyException() - Method in class com.bluegosling.reflect.blaster.Blaster
-
- abortOnNullTarget() - Method in class com.bluegosling.reflect.blaster.Blaster
-
- abortPipeline(K) - Method in class com.bluegosling.concurrent.executors.PipeliningExecutor
-
Aborts the specified pipeline by draining its queue and attempting to interrupt its currently
running task.
- absent() - Method in interface com.bluegosling.possible.Possible.Visitor
-
Visits a possible value where no value is actually present.
- AbstractDeque<E> - Class in com.bluegosling.collections
-
An abstract base class for implementations of the
Deque
interface.
- AbstractDeque() - Constructor for class com.bluegosling.collections.AbstractDeque
-
- AbstractDynamicPossible<T> - Class in com.bluegosling.possible
-
An abstract base class for possible values that are dynamic, meaning whether a value is present
or not can change over the life of the value.
- AbstractDynamicPossible() - Constructor for class com.bluegosling.possible.AbstractDynamicPossible
-
- AbstractFluentFuture<T> - Class in com.bluegosling.concurrent.fluent
-
A
FluentFuture
implementation that is suitable for sub-classing.
- AbstractFluentFuture() - Constructor for class com.bluegosling.concurrent.fluent.AbstractFluentFuture
-
- AbstractImmutableCollection<E> - Class in com.bluegosling.collections.immutable
-
An abstract base class for implementing immutable collections.
- AbstractImmutableCollection() - Constructor for class com.bluegosling.collections.immutable.AbstractImmutableCollection
-
- AbstractImmutableList<E> - Class in com.bluegosling.collections.immutable
-
An abstract base class for implementing immutable lists.
- AbstractImmutableList() - Constructor for class com.bluegosling.collections.immutable.AbstractImmutableList
-
- AbstractImmutableMap<K,V> - Class in com.bluegosling.collections.immutable
-
An abstract base class for implementing ImmutableMap
s.
- AbstractImmutableMap() - Constructor for class com.bluegosling.collections.immutable.AbstractImmutableMap
-
- AbstractImmutableSet<E> - Class in com.bluegosling.collections.immutable
-
An abstract base class for implementing an immutable sets.
- AbstractImmutableSet() - Constructor for class com.bluegosling.collections.immutable.AbstractImmutableSet
-
- AbstractLinkedImmutableList<E> - Class in com.bluegosling.collections.immutable
-
An abstract base class for immutable list implementations that use linked data structures
so that access is sequential.
- AbstractLinkedImmutableList() - Constructor for class com.bluegosling.collections.immutable.AbstractLinkedImmutableList
-
- AbstractLinkedImmutableList.LinkedSubList<E> - Class in com.bluegosling.collections.immutable
-
A sub-list view of an immutable list that is sequential/linked in nature.
- AbstractLockFreeBlockingDeque<E> - Class in com.bluegosling.collections.concurrent
-
An abstract blocking deque, useful for building deque implementations that do not rely on locks
for thread-safey.
- AbstractLockFreeBlockingDeque() - Constructor for class com.bluegosling.collections.concurrent.AbstractLockFreeBlockingDeque
-
- AbstractLockFreeBlockingOrderedDeque<E> - Class in com.bluegosling.collections.concurrent
-
- AbstractLockFreeBlockingOrderedDeque() - Constructor for class com.bluegosling.collections.concurrent.AbstractLockFreeBlockingOrderedDeque
-
- AbstractLockFreeBlockingQueue<E> - Class in com.bluegosling.collections.concurrent
-
An abstract blocking queue, useful for building queue implementations that do not rely on locks
for thread-safety.
- AbstractLockFreeBlockingQueue() - Constructor for class com.bluegosling.collections.concurrent.AbstractLockFreeBlockingQueue
-
- AbstractNavigableMap<K,V> - Class in com.bluegosling.collections
-
- AbstractNavigableMap() - Constructor for class com.bluegosling.collections.AbstractNavigableMap
-
Constructs a new, empty map that orders keys according to their
natural
ordering.
- AbstractNavigableMap(Comparator<? super K>) - Constructor for class com.bluegosling.collections.AbstractNavigableMap
-
Constructs a new, empty map that orders keys using the specified comparator.
- AbstractNavigableMap.BaseIteratorImpl<T> - Class in com.bluegosling.collections
-
An iterator over the mappings in this map.
- AbstractNavigableMap.DescendingKeyIteratorImpl - Class in com.bluegosling.collections
-
An iterator over the keys in this map that goes from highest to lowest key.
- AbstractNavigableMap.EntryIteratorImpl - Class in com.bluegosling.collections
-
An iterator over the map entries in this map.
- AbstractNavigableMap.EntrySet - Class in com.bluegosling.collections
-
- AbstractNavigableMap.KeyIteratorImpl - Class in com.bluegosling.collections
-
An iterator over the keys in this map.
- AbstractNavigableMap.KeySet - Class in com.bluegosling.collections
-
A view of the map's keys as a set.
- AbstractNavigableMap.SubMap - Class in com.bluegosling.collections
-
A sub-map view, with bounds on the range of included keys.
- AbstractNavigableMap.ValueCollection - Class in com.bluegosling.collections
-
A view of the map's values as a collection.
- AbstractNavigableMap.ValueIteratorImpl - Class in com.bluegosling.collections
-
An iterator over the values in this map.
- AbstractPrimitiveList<T,T_CONS,T_ITER extends PrimitiveIterator<T,T_CONS>,T_LISTITER extends PrimitiveListIterator<T,T_CONS>,T_LIST extends PrimitiveList<T,T_CONS,T_ITER,T_LISTITER,T_LIST>> - Class in com.bluegosling.collections.primitive
-
- AbstractPrimitiveList() - Constructor for class com.bluegosling.collections.primitive.AbstractPrimitiveList
-
- AbstractPrimitiveList.OfBoolean - Class in com.bluegosling.collections.primitive
-
A specialization for lists of boolean elements.
- AbstractPrimitiveList.OfByte - Class in com.bluegosling.collections.primitive
-
A specialization for lists of byte elements.
- AbstractPrimitiveList.OfChar - Class in com.bluegosling.collections.primitive
-
A specialization for lists of char elements.
- AbstractPrimitiveList.OfDouble - Class in com.bluegosling.collections.primitive
-
A specialization for lists of double elements.
- AbstractPrimitiveList.OfFloat - Class in com.bluegosling.collections.primitive
-
A specialization for lists of float elements.
- AbstractPrimitiveList.OfInt - Class in com.bluegosling.collections.primitive
-
A specialization for lists of int elements.
- AbstractPrimitiveList.OfLong - Class in com.bluegosling.collections.primitive
-
A specialization for lists of long elements.
- AbstractPrimitiveList.OfShort - Class in com.bluegosling.collections.primitive
-
A specialization for lists of short elements.
- AbstractProcessor - Class in com.bluegosling.apt
-
An abstract annotation processor that may make for a better base class than the standard.
- AbstractProcessor() - Constructor for class com.bluegosling.apt.AbstractProcessor
-
- AbstractQueuedReferenceSynchronizer<S,R> - Class in com.bluegosling.concurrent
-
Provides a framework for implementing blocking locks and related synchronizer that rely on FIFO
wait queues.
- AbstractQueuedReferenceSynchronizer() - Constructor for class com.bluegosling.concurrent.AbstractQueuedReferenceSynchronizer
-
Creates a new instance with initial synchronization state of null
.
- AbstractRandomAccessNavigableMap<K,V> - Class in com.bluegosling.collections.maps
-
- AbstractRandomAccessNavigableMap() - Constructor for class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap
-
Constructs a new, empty map that orders keys according to their
natural
ordering.
- AbstractRandomAccessNavigableMap(Comparator<? super K>) - Constructor for class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap
-
Constructs a new, empty map that orders keys using the specified comparator.
- AbstractRandomAccessNavigableMap.BaseListIteratorImpl<T> - Class in com.bluegosling.collections.maps
-
- AbstractRandomAccessNavigableMap.EntryListIteratorImpl - Class in com.bluegosling.collections.maps
-
- AbstractRandomAccessNavigableMap.KeyListIteratorImpl - Class in com.bluegosling.collections.maps
-
- AbstractRandomAccessNavigableMap.RandomAccessEntrySet - Class in com.bluegosling.collections.maps
-
- AbstractRandomAccessNavigableMap.RandomAccessKeySet - Class in com.bluegosling.collections.maps
-
- AbstractRandomAccessNavigableMap.RandomAccessSubMap - Class in com.bluegosling.collections.maps
-
A sub-map view, with key value bounds, not indices.
- AbstractRandomAccessNavigableMap.SubMapByIndices - Class in com.bluegosling.collections.maps
-
A sub-map view, defined by a range of indices.
- AbstractRandomAccessNavigableMap.SubMapByIndicesAndByValueBounds - Class in com.bluegosling.collections.maps
-
- AbstractRandomAccessNavigableMap.SubMapByIndicesIterator<K,V> - Class in com.bluegosling.collections.maps
-
Implements an iterator over a
sub-map (by indices) of
elements for the various set views of this map.
- AbstractRandomAccessNavigableMap.ValueList - Class in com.bluegosling.collections.maps
-
- AbstractRandomAccessNavigableMap.ValueListIteratorImpl - Class in com.bluegosling.collections.maps
-
- AbstractStreamNode<T,U> - Class in com.bluegosling.streams
-
A useful base class for
StreamNode
implementations.
- AbstractStreamNode() - Constructor for class com.bluegosling.streams.AbstractStreamNode
-
Constructs a new node.
- accept(ArType.Visitor<R, P>, P) - Method in class com.bluegosling.apt.reflect.ArArrayType
-
- accept(ArType.Visitor<R, P>, P) - Method in class com.bluegosling.apt.reflect.ArDeclaredType
-
- accept(ArType.Visitor<R, P>, P) - Method in class com.bluegosling.apt.reflect.ArPrimitiveType
-
- accept(ArType.Visitor<R, P>, P) - Method in class com.bluegosling.apt.reflect.ArType
-
Uses the specified visitor to visit this type.
- accept(ArType.Visitor<R, P>, P) - Method in class com.bluegosling.apt.reflect.ArTypeVariable
-
- accept(ArType.Visitor<R, P>, P) - Method in class com.bluegosling.apt.reflect.ArWildcardType
-
- accept(TaskImplementation.Visitor<R, ? super V>) - Method in class com.bluegosling.concurrent.scheduler.TaskImplementation
-
Visits this task using the specified visitor.
- accept(boolean) - Method in interface com.bluegosling.function.BooleanConsumer
-
- accept(byte) - Method in interface com.bluegosling.function.ByteConsumer
-
- accept(char) - Method in interface com.bluegosling.function.CharConsumer
-
- accept(float) - Method in interface com.bluegosling.function.FloatConsumer
-
- accept(short) - Method in interface com.bluegosling.function.ShortConsumer
-
- accept(T, U, V) - Method in interface com.bluegosling.function.TriConsumer
-
- accumulateAndGet(T, BiFunction<? super T, ? super T, ? extends T>) - Method in class com.bluegosling.concurrent.atoms.AsynchronousAtom
-
Submits a mutation that will combine the atom's value with the given value, using the given
function, and set the atom's value to the result.
- accumulateAndGet(T, BiFunction<? super T, ? super T, ? extends T>) - Method in interface com.bluegosling.concurrent.atoms.SynchronousAtom
-
Combines the atom's value with the given value, using the given function.
- accumulateAndGet(int, IntBinaryOperator) - Method in class com.bluegosling.concurrent.contended.ContendedInteger
-
Atomically updates the current value with the results of applying the given function to the
current and given values, returning the updated value.
- accumulateAndGet(long, LongBinaryOperator) - Method in class com.bluegosling.concurrent.contended.ContendedLong
-
Atomically updates the current value with the results of applying the given function to the
current and given values, returning the updated value.
- accumulateAndGet(V, BinaryOperator<V>) - Method in class com.bluegosling.concurrent.contended.ContendedReference
-
Atomically updates the current value with the results of applying the given function to the
current and given values, returning the updated value.
- accumulateAndGet(T, BinaryOperator<T>) - Method in class com.bluegosling.vars.Variable
-
Accumulates the given value into this variable, using the given function to combine the
current value with the given one.
- accumulateAndGet(boolean, BooleanBinaryOperator) - Method in class com.bluegosling.vars.VariableBoolean
-
Accumulates the given value into the variable using the given function.
- accumulateAndGet(byte, ByteBinaryOperator) - Method in class com.bluegosling.vars.VariableByte
-
Accumulates the given value into the variable using the given function.
- accumulateAndGet(char, CharBinaryOperator) - Method in class com.bluegosling.vars.VariableChar
-
Accumulates the given value into the variable using the given function.
- accumulateAndGet(double, DoubleBinaryOperator) - Method in class com.bluegosling.vars.VariableDouble
-
Accumulates the given value into the variable using the given function.
- accumulateAndGet(float, FloatBinaryOperator) - Method in class com.bluegosling.vars.VariableFloat
-
Accumulates the given value into the variable using the given function.
- accumulateAndGet(int, IntBinaryOperator) - Method in class com.bluegosling.vars.VariableInt
-
Accumulates the given value into the variable using the given function.
- accumulateAndGet(long, LongBinaryOperator) - Method in class com.bluegosling.vars.VariableLong
-
Accumulates the given value into the variable using the given function.
- accumulateAndGet(short, ShortBinaryOperator) - Method in class com.bluegosling.vars.VariableShort
-
Accumulates the given value into the variable using the given function.
- acquire(R) - Method in class com.bluegosling.concurrent.AbstractQueuedReferenceSynchronizer
-
Acquires in exclusive mode, ignoring interrupts.
- acquire() - Method in class com.bluegosling.concurrent.RateLimiter
-
Acquires a permit, blocking if one is not available.
- acquire(long) - Method in class com.bluegosling.concurrent.RateLimiter
-
Acquires the given number of permits, blocking if they are not all immediately available.
- acquireInterruptibly(R) - Method in class com.bluegosling.concurrent.AbstractQueuedReferenceSynchronizer
-
Acquires in exclusive mode, aborting if interrupted.
- acquireInterruptibly() - Method in class com.bluegosling.concurrent.RateLimiter
-
Acquires a permit, blocking interruptibly if one is not available.
- acquireInterruptibly(int) - Method in class com.bluegosling.concurrent.RateLimiter
-
Acquires the given number of permits, blocking interruptibly if they are not all immediately
available.
- acquireShared(R) - Method in class com.bluegosling.concurrent.AbstractQueuedReferenceSynchronizer
-
Acquires in shared mode, ignoring interrupts.
- acquireSharedInterruptibly(R) - Method in class com.bluegosling.concurrent.AbstractQueuedReferenceSynchronizer
-
Acquires in shared mode, aborting if interrupted.
- ActorThreadPool<T> - Class in com.bluegosling.concurrent.executors
-
A thread pool that runs multiple sequential streams.
- ActorThreadPool(int) - Constructor for class com.bluegosling.concurrent.executors.ActorThreadPool
-
Creates a new thread pool with the given size.
- ActorThreadPool(int, int) - Constructor for class com.bluegosling.concurrent.executors.ActorThreadPool
-
Creates a new thread pool with the given size.
- ActorThreadPool(int, int, long, TimeUnit) - Constructor for class com.bluegosling.concurrent.executors.ActorThreadPool
-
Creates a new thread pool with the given size and keep-alive time.
- ActorThreadPool(int, int, ThreadFactory) - Constructor for class com.bluegosling.concurrent.executors.ActorThreadPool
-
Creates a new thread pool with the given size and thread factory.
- ActorThreadPool(int, int, long, TimeUnit, ThreadFactory) - Constructor for class com.bluegosling.concurrent.executors.ActorThreadPool
-
Creates a new thread pool with the given size, keep-alive time, and thread factory.
- ActorThreadPool(int, int, long, TimeUnit, ThreadFactory, int) - Constructor for class com.bluegosling.concurrent.executors.ActorThreadPool
-
Creates a new thread pool with the given size, keep-alive time, thread factory, and maximum
batch size.
- ActorThreadPool(int, int, long, TimeUnit, ThreadFactory, int, long, TimeUnit) - Constructor for class com.bluegosling.concurrent.executors.ActorThreadPool
-
Creates a new thread pool with the given size, keep-alive time, thread factory, and maximum
batch size and duration.
- ActorThreadPool.Builder - Class in com.bluegosling.concurrent.executors
-
- actualStartTimeMillis() - Method in interface com.bluegosling.concurrent.scheduler.ScheduledTask
-
Returns the actual start time of this invocation, in milliseconds.
- add(E) - Method in class com.bluegosling.collections.AbstractDeque
- add(E) - Method in class com.bluegosling.collections.concurrent.ConcurrentSortedArraySet
- add(T) - Method in class com.bluegosling.collections.concurrent.SimpleTreiberStack
-
- add(T) - Method in class com.bluegosling.collections.concurrent.TreiberStack
-
- add(E) - Method in class com.bluegosling.collections.DescendingSet
-
- add(E) - Method in class com.bluegosling.collections.FilteringCollection
-
- add(int, E) - Method in class com.bluegosling.collections.FilteringList
-
- add(E) - Method in class com.bluegosling.collections.FilteringListIterator
-
- add(E) - Method in class com.bluegosling.collections.immutable.AbstractImmutableCollection
-
Deprecated.
- add(E) - Method in class com.bluegosling.collections.immutable.AbstractImmutableList
-
Deprecated.
- add(int, E) - Method in class com.bluegosling.collections.immutable.AbstractImmutableList
-
Deprecated.
- add(E) - Method in class com.bluegosling.collections.immutable.AbstractImmutableSet
-
Deprecated.
- add(E) - Method in interface com.bluegosling.collections.immutable.PersistentCollection
-
Deprecated.
- add(int, E) - Method in interface com.bluegosling.collections.immutable.PersistentList
-
Deprecated.
- add(E) - Method in interface com.bluegosling.collections.immutable.PersistentList
-
Deprecated.
- add(E) - Method in interface com.bluegosling.collections.immutable.PersistentSet
-
Deprecated.
- add(E) - Method in class com.bluegosling.collections.lists.ArrayBackedLinkedList
- add(int, E) - Method in class com.bluegosling.collections.lists.ArrayBackedLinkedList
- add(E, K) - Method in class com.bluegosling.collections.lists.AssociativeArrayList
-
- add(int, E, K) - Method in class com.bluegosling.collections.lists.AssociativeArrayList
-
- add(int, E) - Method in class com.bluegosling.collections.lists.AssociativeArrayList
-
- add(E, K) - Method in interface com.bluegosling.collections.lists.AssociativeList
-
Adds an element with an associative key.
- add(int, E, K) - Method in interface com.bluegosling.collections.lists.AssociativeList
-
Adds an element with an associative key.
- add(E) - Method in class com.bluegosling.collections.lists.TreeList
-
- add(int, E) - Method in class com.bluegosling.collections.lists.TreeList
-
- add(E) - Method in class com.bluegosling.collections.lists.UnrolledLinkedList
-
- add(int, E) - Method in class com.bluegosling.collections.lists.UnrolledLinkedList
-
- add(T) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.BaseListIteratorImpl
-
- add(Map.Entry<K, V>) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.SubMapByIndicesIterator
-
- add(T) - Method in class com.bluegosling.collections.NoCopyGrowableArray
-
- add(Boolean) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfBoolean
-
- add(int, Boolean) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfBoolean
-
- add(Byte) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfByte
-
- add(int, Byte) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfByte
-
- add(Character) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfChar
-
- add(int, Character) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfChar
-
- add(Double) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfDouble
-
- add(int, Double) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfDouble
-
- add(Float) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfFloat
-
- add(int, Float) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfFloat
-
- add(Integer) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfInt
-
- add(int, Integer) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfInt
-
- add(Long) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfLong
-
- add(int, Long) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfLong
-
- add(Short) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfShort
-
- add(int, Short) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfShort
-
- add(E) - Method in class com.bluegosling.collections.queues.FibonacciHeapOrderedQueue
-
- add(E, P) - Method in interface com.bluegosling.collections.queues.PriorityQueue
-
Adds an element to the queue with the specified priority.
- add(P, PriorityQueue<E, P>) - Method in class com.bluegosling.collections.queues.PriorityQueues.AutoEntry
-
Adds this element to the given queue with the given priority.
- add(int, E) - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- add(int, E) - Method in class com.bluegosling.collections.queues.RandomAccessArrayDeque
-
- add(E) - Method in class com.bluegosling.collections.queues.RandomAccessArrayDeque
-
- add(E) - Method in class com.bluegosling.collections.queues.RandomizedQueue
-
- add(E) - Method in class com.bluegosling.collections.sets.RandomAccessSetList
-
- add(int, E) - Method in class com.bluegosling.collections.sets.RandomAccessSetList
-
- add(E) - Method in class com.bluegosling.collections.sets.SortedArraySet
- add(O) - Method in class com.bluegosling.collections.TransformingCollection
-
- add(O) - Method in class com.bluegosling.collections.TransformingCollection.Bidi
-
- add(int, O) - Method in class com.bluegosling.collections.TransformingList
-
- add(O) - Method in class com.bluegosling.collections.TransformingList.Bidi
-
- add(int, O) - Method in class com.bluegosling.collections.TransformingList.Bidi
-
- add(O) - Method in class com.bluegosling.collections.TransformingListIterator
-
- add(O) - Method in class com.bluegosling.collections.TransformingListIterator.Bidi
-
- add(InterceptingExecutor.Interceptor) - Method in class com.bluegosling.concurrent.executors.InterceptingExecutor.Interceptor.ListBuilder
-
Adds an interceptor to the list.
- add(InterceptingExecutor.Decorator) - Method in class com.bluegosling.concurrent.executors.InterceptingExecutor.Interceptor.ListBuilder
-
Adds a decorator to the list.
- add(InterceptingExecutorService.Interceptor) - Method in class com.bluegosling.concurrent.executors.InterceptingExecutorService.Interceptor.ListBuilder
-
Adds an interceptor to the list.
- add(InterceptingExecutorService.Decorator) - Method in class com.bluegosling.concurrent.executors.InterceptingExecutorService.Interceptor.ListBuilder
-
Adds a decorator to the list.
- add(String, T) - Method in class com.bluegosling.reflect.EnumType.Builder
-
Adds an enum value with the given name.
- add(T) - Method in class com.bluegosling.tuples.Empty
-
- add(T) - Method in class com.bluegosling.tuples.NTuple
-
- add(T) - Method in class com.bluegosling.tuples.Pair
-
- add(T) - Method in class com.bluegosling.tuples.Quadruple
-
- add(T) - Method in class com.bluegosling.tuples.Quintuple
-
- add(T) - Method in class com.bluegosling.tuples.Single
-
- add(T) - Method in class com.bluegosling.tuples.Triple
-
- add(T) - Method in interface com.bluegosling.tuples.Tuple
-
Adds a new item to this tuple.
- add(T) - Method in interface com.bluegosling.tuples.Tuple.Ops1
-
- add(T) - Method in interface com.bluegosling.tuples.Tuple.Ops2
-
- add(T) - Method in interface com.bluegosling.tuples.Tuple.Ops3
-
- add(T) - Method in interface com.bluegosling.tuples.Tuple.Ops4
-
- add(T, T) - Method in class com.bluegosling.util.PrimeIterator
-
Adds two values and returns their sum.
- add3rdPartyPackage(String, String) - Method in class com.bluegosling.buildgen.BuildGen.Settings.Builder
-
- addAfter(int, E, E) - Method in interface com.bluegosling.collections.concurrent.ConcurrentList
-
Adds the given value at the given index, after the given value.
- addAll(Collection<? extends E>) - Method in class com.bluegosling.collections.concurrent.ConcurrentSortedArraySet
- addAll(Collection<? extends E>) - Method in class com.bluegosling.collections.DescendingSet
-
- addAll(Collection<? extends E>) - Method in class com.bluegosling.collections.FilteringCollection
-
- addAll(int, Collection<? extends E>) - Method in class com.bluegosling.collections.FilteringList
-
- addAll(Collection<? extends E>) - Method in class com.bluegosling.collections.immutable.AbstractImmutableCollection
-
Deprecated.
- addAll(Collection<? extends E>) - Method in class com.bluegosling.collections.immutable.AbstractImmutableList
-
Deprecated.
- addAll(int, Collection<? extends E>) - Method in class com.bluegosling.collections.immutable.AbstractImmutableList
-
Deprecated.
- addAll(Collection<? extends E>) - Method in class com.bluegosling.collections.immutable.AbstractImmutableSet
-
Deprecated.
- addAll(Collection<? extends E>) - Method in interface com.bluegosling.collections.immutable.PersistentCollection
-
Deprecated.
- addAll(int, Collection<? extends E>) - Method in interface com.bluegosling.collections.immutable.PersistentList
-
Deprecated.
- addAll(Collection<? extends E>) - Method in interface com.bluegosling.collections.immutable.PersistentList
-
Deprecated.
- addAll(Collection<? extends E>) - Method in interface com.bluegosling.collections.immutable.PersistentSet
-
Deprecated.
- addAll(Collection<? extends E>) - Method in class com.bluegosling.collections.lists.ArrayBackedLinkedList
- addAll(int, Collection<? extends E>) - Method in class com.bluegosling.collections.lists.ArrayBackedLinkedList
- addAll(Map<? extends K, ? extends E>) - Method in class com.bluegosling.collections.lists.AssociativeArrayList
-
- addAll(int, Map<? extends K, ? extends E>) - Method in class com.bluegosling.collections.lists.AssociativeArrayList
-
- addAll(AssociativeList<? extends E, ? extends K>) - Method in class com.bluegosling.collections.lists.AssociativeArrayList
-
- addAll(int, AssociativeList<? extends E, ? extends K>) - Method in class com.bluegosling.collections.lists.AssociativeArrayList
-
- addAll(int, Collection<? extends E>) - Method in class com.bluegosling.collections.lists.AssociativeArrayList
-
- addAll(Map<? extends K, ? extends E>) - Method in interface com.bluegosling.collections.lists.AssociativeList
-
Adds a collection of mapped entries from a map.
- addAll(int, Map<? extends K, ? extends E>) - Method in interface com.bluegosling.collections.lists.AssociativeList
-
Adds a collection of mapped entries from a map.
- addAll(AssociativeList<? extends E, ? extends K>) - Method in interface com.bluegosling.collections.lists.AssociativeList
-
- addAll(int, AssociativeList<? extends E, ? extends K>) - Method in interface com.bluegosling.collections.lists.AssociativeList
-
- addAll(Collection<? extends E>) - Method in class com.bluegosling.collections.lists.TreeList
-
- addAll(int, Collection<? extends E>) - Method in class com.bluegosling.collections.lists.TreeList
-
- addAll(Collection<? extends T>) - Method in class com.bluegosling.collections.NoCopyGrowableArray
-
- addAll(PriorityQueue<? extends E, ? extends P>) - Method in interface com.bluegosling.collections.queues.PriorityQueue
-
Adds all of the specified entries to the this queue.
- addAll(Collection<? extends E>) - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- addAll(int, Collection<? extends E>) - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- addAll(Collection<? extends E>) - Method in class com.bluegosling.collections.queues.RandomAccessArrayDeque
-
- addAll(int, Collection<? extends E>) - Method in class com.bluegosling.collections.queues.RandomAccessArrayDeque
-
- addAll(Collection<? extends E>) - Method in class com.bluegosling.collections.queues.RandomizedQueue
-
- addAll(Collection<? extends E>) - Method in class com.bluegosling.collections.sets.RandomAccessSetList
-
- addAll(int, Collection<? extends E>) - Method in class com.bluegosling.collections.sets.RandomAccessSetList
-
- addAll(Collection<? extends E>) - Method in class com.bluegosling.collections.sets.SortedArraySet
- addAll(Collection<? extends O>) - Method in class com.bluegosling.collections.TransformingCollection
-
- addAll(Collection<? extends O>) - Method in class com.bluegosling.collections.TransformingCollection.Bidi
-
- addAll(int, Collection<? extends O>) - Method in class com.bluegosling.collections.TransformingList
-
- addAll(Collection<? extends O>) - Method in class com.bluegosling.collections.TransformingList.Bidi
-
- addAll(int, Collection<? extends O>) - Method in class com.bluegosling.collections.TransformingList.Bidi
-
- addAndGet(int) - Method in class com.bluegosling.concurrent.contended.ContendedInteger
-
Atomically adds the given value to the current value.
- addAndGet(long) - Method in class com.bluegosling.concurrent.contended.ContendedLong
-
Atomically adds the given value to the current value.
- addAndGet(byte) - Method in class com.bluegosling.vars.VariableByte
-
Adds the given amount to the variable.
- addAndGet(int) - Method in class com.bluegosling.vars.VariableInt
-
Adds the given amount to the variable.
- addAndGet(long) - Method in class com.bluegosling.vars.VariableLong
-
Adds the given amount to the variable.
- addAndGet(short) - Method in class com.bluegosling.vars.VariableShort
-
Adds the given amount to the variable.
- addAnnotations(AnnotatedType, Annotation...) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- addAnnotations(AnnotatedType, Collection<? extends Annotation>) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- addAnnotations(AnnotatedParameterizedType, Annotation...) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- addAnnotations(AnnotatedParameterizedType, Collection<? extends Annotation>) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- addAnnotations(AnnotatedArrayType, Annotation...) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- addAnnotations(AnnotatedArrayType, Collection<? extends Annotation>) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- addAnnotations(AnnotatedWildcardType, Annotation...) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- addAnnotations(AnnotatedWildcardType, Collection<? extends Annotation>) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- addAnnotations(AnnotatedTypeVariable, Annotation...) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- addAnnotations(AnnotatedTypeVariable, Collection<? extends Annotation>) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- addBefore(int, E, E) - Method in interface com.bluegosling.collections.concurrent.ConcurrentList
-
Adds the given value at the given index, before the given value.
- addBoolean(boolean) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfBoolean
-
- addBoolean(int, boolean) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfBoolean
-
- addBoolean(boolean) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfBoolean
-
- addBoolean(int, boolean) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfBoolean
-
- addByte(byte) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfByte
-
- addByte(int, byte) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfByte
-
- addByte(byte) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfByte
-
- addByte(int, byte) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfByte
-
- addChar(char) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfChar
-
- addChar(int, char) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfChar
-
- addChar(char) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfChar
-
- addChar(int, char) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfChar
-
- addDecorator(NodeDecorator) - Method in class com.bluegosling.graph.ComputationFactory.Builder
-
- addDecorators(Iterable<NodeDecorator>) - Method in class com.bluegosling.graph.ComputationFactory.Builder
-
- addDouble(double) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfDouble
-
- addDouble(int, double) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfDouble
-
- addDouble(double) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfDouble
-
- addDouble(int, double) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfDouble
-
- addFirst(E) - Method in class com.bluegosling.collections.AbstractDeque
-
- addFirst(E) - Method in class com.bluegosling.collections.CircularBuffer
-
Adds an item to the front of the buffer.
- addFirst(E) - Method in interface com.bluegosling.collections.concurrent.ConcurrentList
-
Adds an element to the beginning of the list.
- addFirst(E) - Method in class com.bluegosling.collections.lists.ArrayBackedLinkedList
- addFirst(E) - Method in class com.bluegosling.collections.lists.UnrolledLinkedList
-
- addFirst(E) - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- addFirst(E) - Method in class com.bluegosling.collections.queues.RandomAccessArrayDeque
-
- addFloat(float) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfFloat
-
- addFloat(int, float) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfFloat
-
- addFloat(float) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfFloat
-
- addFloat(int, float) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfFloat
-
- addIgnorePath(String) - Method in class com.bluegosling.buildgen.BuildGen.Settings.Builder
-
- addIgnorePath(File) - Method in class com.bluegosling.buildgen.BuildGen.Settings.Builder
-
- addImpliedDep(String, String) - Method in class com.bluegosling.buildgen.BuildGen.Settings.Builder
-
- addInt(int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfInt
-
- addInt(int, int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfInt
-
- addInt(int) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfInt
-
- addInt(int, int) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfInt
-
- addJavaBinary(String, String) - Method in class com.bluegosling.buildgen.BuildGen.Settings.Builder
-
- addLast(E) - Method in class com.bluegosling.collections.AbstractDeque
-
- addLast(E) - Method in class com.bluegosling.collections.CircularBuffer
-
Adds an item to the end of the buffer.
- addLast(E) - Method in interface com.bluegosling.collections.concurrent.ConcurrentList
-
Adds an element to the end of the list and returns its index, atomically.
- addLast(E) - Method in class com.bluegosling.collections.lists.ArrayBackedLinkedList
- addLast(E) - Method in class com.bluegosling.collections.lists.UnrolledLinkedList
-
- addLast(E) - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- addLast(E) - Method in class com.bluegosling.collections.queues.RandomAccessArrayDeque
-
- addListener(FutureListener<? super T>, Executor) - Method in class com.bluegosling.concurrent.fluent.AbstractFluentFuture
-
- addListener(FutureListener<? super T>, Executor) - Method in interface com.bluegosling.concurrent.fluent.FluentFuture
-
Adds a listener that will be called when the future completes.
- addListener(Runnable, Executor) - Method in interface com.bluegosling.concurrent.fluent.FluentFuture
-
- addListener(FutureListener<? super T>, Executor) - Method in class com.bluegosling.concurrent.fluent.FluentFutureTask
-
- addListener(ScheduledTaskListener<? super V>) - Method in interface com.bluegosling.concurrent.scheduler.ScheduledTaskDefinition
-
Adds a listener that will be notified when task invocations complete.
- addListenerForEachInstance(FutureListener<? super T>, Executor) - Method in interface com.bluegosling.concurrent.fluent.FluentRepeatingFuture
-
Adds a listener that is invoked after each occurrence of the task.
- addListenerForEachInstance(FutureListener<? super T>, Executor) - Method in class com.bluegosling.concurrent.fluent.FluentRepeatingFutureTask
-
- addLong(long) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfLong
-
- addLong(int, long) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfLong
-
- addLong(long) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfLong
-
- addLong(int, long) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfLong
-
- addShort(short) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfShort
-
- addShort(int, short) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfShort
-
- addShort(short) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfShort
-
- addShort(int, short) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfShort
-
- addTestPath(String) - Method in class com.bluegosling.buildgen.BuildGen.Settings.Builder
-
- addTestPath(File) - Method in class com.bluegosling.buildgen.BuildGen.Settings.Builder
-
- addWatcher(Atom.Watcher<? super T>) - Method in interface com.bluegosling.concurrent.atoms.Atom
-
Registers a watcher, which will receive notifications when the atom's value changes.
- adjustSizeTo(int) - Method in class com.bluegosling.collections.NoCopyGrowableArray
-
- advance(K) - Method in class com.bluegosling.collections.AbstractNavigableMap.BaseIteratorImpl
-
Advances the iterator and returns the next entry to be visited during iteration.
- advance(K) - Method in class com.bluegosling.collections.AbstractNavigableMap.DescendingKeyIteratorImpl
-
Advances the iterator and returns the next entry to be visited during iteration.
- after(TriConsumer<? super Executor, ? super Runnable, ? super Throwable>) - Method in class com.bluegosling.concurrent.executors.InterceptingExecutor.Decorator.Builder
-
Defines the action performed after each task is run.
- after(BiConsumer<? super Executor, ? super Runnable>) - Method in class com.bluegosling.concurrent.executors.InterceptingExecutor.Decorator.Builder
-
Defines the action performed after each task is run.
- after(Consumer<? super Runnable>) - Method in class com.bluegosling.concurrent.executors.InterceptingExecutor.Decorator.Builder
-
Defines the action performed after each task is run.
- after(Runnable) - Method in class com.bluegosling.concurrent.executors.InterceptingExecutor.Decorator.Builder
-
Defines the action performed after each task is run.
- after(BiConsumer<? super ExecutorService, ? super Callable<?>>) - Method in class com.bluegosling.concurrent.executors.InterceptingExecutorService.Decorator.Builder
-
Defines the action performed after each task is run.
- after(Consumer<? super Callable<?>>) - Method in class com.bluegosling.concurrent.executors.InterceptingExecutorService.Decorator.Builder
-
Defines the action performed after each task is run.
- after(Runnable) - Method in class com.bluegosling.concurrent.executors.InterceptingExecutorService.Decorator.Builder
-
Defines the action performed after each task is run.
- afterFailed(Executor, Runnable, Throwable) - Method in interface com.bluegosling.concurrent.executors.InterceptingExecutor.Decorator
-
Performs actions after the given task has failed.
- afterFailed(ExecutorService, Callable<?>, Throwable) - Method in interface com.bluegosling.concurrent.executors.InterceptingExecutorService.Decorator
-
Performs actions after the given task has failed.
- afterFailure(TriConsumer<? super Executor, ? super Runnable, ? super Throwable>) - Method in class com.bluegosling.concurrent.executors.InterceptingExecutor.Decorator.Builder
-
Defines the action performed after each failed task.
- afterFailure(BiConsumer<? super Executor, ? super Runnable>) - Method in class com.bluegosling.concurrent.executors.InterceptingExecutor.Decorator.Builder
-
Defines the action performed after each failed task.
- afterFailure(Consumer<? super Runnable>) - Method in class com.bluegosling.concurrent.executors.InterceptingExecutor.Decorator.Builder
-
Defines the action performed after each failed task.
- afterFailure(Runnable) - Method in class com.bluegosling.concurrent.executors.InterceptingExecutor.Decorator.Builder
-
Defines the action performed after each failed task.
- afterFailure(TriConsumer<? super ExecutorService, ? super Callable<?>, ? super Throwable>) - Method in class com.bluegosling.concurrent.executors.InterceptingExecutorService.Decorator.Builder
-
Defines the action performed after each failed task.
- afterFailure(BiConsumer<? super ExecutorService, ? super Callable<?>>) - Method in class com.bluegosling.concurrent.executors.InterceptingExecutorService.Decorator.Builder
-
Defines the action performed after each failed task.
- afterFailure(Consumer<? super Callable<?>>) - Method in class com.bluegosling.concurrent.executors.InterceptingExecutorService.Decorator.Builder
-
Defines the action performed after each failed task.
- afterFailure(Runnable) - Method in class com.bluegosling.concurrent.executors.InterceptingExecutorService.Decorator.Builder
-
Defines the action performed after each failed task.
- afterFinish(Executor, Runnable) - Method in interface com.bluegosling.concurrent.executors.InterceptingExecutor.Decorator
-
Performs actions after the given task has completed successfully.
- afterFinish(ExecutorService, Callable<T>, T) - Method in interface com.bluegosling.concurrent.executors.InterceptingExecutorService.Decorator
-
Performs actions after the given task has completed successfully.
- afterSuccess(BiConsumer<? super Executor, ? super Runnable>) - Method in class com.bluegosling.concurrent.executors.InterceptingExecutor.Decorator.Builder
-
Defines the action performed after each successful task.
- afterSuccess(Consumer<? super Runnable>) - Method in class com.bluegosling.concurrent.executors.InterceptingExecutor.Decorator.Builder
-
Defines the action performed after each successful task.
- afterSuccess(Runnable) - Method in class com.bluegosling.concurrent.executors.InterceptingExecutor.Decorator.Builder
-
Defines the action performed after each successful task.
- afterSuccess(TriConsumer<? super ExecutorService, ? super Callable<?>, Object>) - Method in class com.bluegosling.concurrent.executors.InterceptingExecutorService.Decorator.Builder
-
Defines the action performed after each successful task.
- afterSuccess(BiConsumer<? super ExecutorService, ? super Callable<?>>) - Method in class com.bluegosling.concurrent.executors.InterceptingExecutorService.Decorator.Builder
-
Defines the action performed after each successful task.
- afterSuccess(Consumer<? super Callable<?>>) - Method in class com.bluegosling.concurrent.executors.InterceptingExecutorService.Decorator.Builder
-
Defines the action performed after each successful task.
- afterSuccess(Runnable) - Method in class com.bluegosling.concurrent.executors.InterceptingExecutorService.Decorator.Builder
-
Defines the action performed after each successful task.
- allClasses() - Method in class com.bluegosling.apt.reflect.ArRoundEnvironment
-
- allClasses(Set<ArClass.Kind>) - Method in class com.bluegosling.apt.reflect.ArRoundEnvironment
-
- allElements() - Method in class com.bluegosling.apt.reflect.ArRoundEnvironment
-
- allMethods() - Method in class com.bluegosling.testing.InterfaceVerifier
-
Returns all methods supported by this interface verifier.
- allMethodSignatures() - Method in class com.bluegosling.testing.InterfaceVerifier
-
Returns all method signatures supported by this interface verifier.
- allOnes(int) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- allowingUnsupportedOperations() - Method in class com.bluegosling.reflect.caster.Caster.Builder
-
Enables unsupported operations.
- allPackages() - Method in class com.bluegosling.apt.reflect.ArRoundEnvironment
-
- allZeros(int) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- always() - Method in enum com.bluegosling.concurrent.atoms.AsynchronousAtom.ErrorAction
-
- alwaysAccept() - Static method in class com.bluegosling.function.Predicates
-
Returns a predicate that always returns true
.
- alwaysAcceptAll() - Static method in class com.bluegosling.function.Predicates
-
Returns a predicate of three arguments that always returns true
.
- alwaysAcceptBoth() - Static method in class com.bluegosling.function.Predicates
-
Returns a predicate of two arguments that always returns true
.
- alwaysReject() - Static method in class com.bluegosling.function.Predicates
-
Returns a predicate that always returns false
.
- alwaysRejectAll() - Static method in class com.bluegosling.function.Predicates
-
Returns a predicate of three arguments that always returns false
.
- alwaysRejectBoth() - Static method in class com.bluegosling.function.Predicates
-
Returns a predicate of two arguments that always returns false
.
- AmbiguousMethodException - Exception in com.bluegosling.reflect.caster
-
- AmtPersistentList<E> - Class in com.bluegosling.collections.immutable
-
A fully persistent list backed by an array-mapped trie.
- analyze(Executor) - Method in class com.bluegosling.buildgen.SourceDependencyAnalyzer
-
Performs the file analysis asynchronously.
- analyze() - Method in class com.bluegosling.buildgen.SourceDependencyAnalyzer
-
Performs the file analysis.
- and(BitSequence, BitSequence) - Static method in class com.bluegosling.collections.bits.BitSequences
-
Computes the bitwise AND for two bit sequences.
- and(BooleanPredicate) - Method in interface com.bluegosling.function.BooleanPredicate
-
Returns a composed predicate that represents a short-circuiting logical AND of this predicate
and another.
- and(BytePredicate) - Method in interface com.bluegosling.function.BytePredicate
-
Returns a composed predicate that represents a short-circuiting logical AND of this predicate
and another.
- and(CharPredicate) - Method in interface com.bluegosling.function.CharPredicate
-
Returns a composed predicate that represents a short-circuiting logical AND of this predicate
and another.
- and(FloatPredicate) - Method in interface com.bluegosling.function.FloatPredicate
-
Returns a composed predicate that represents a short-circuiting logical AND of this predicate
and another.
- and(ShortPredicate) - Method in interface com.bluegosling.function.ShortPredicate
-
Returns a composed predicate that represents a short-circuiting logical AND of this predicate
and another.
- and(TriPredicate<? super T, ? super U, ? super V>) - Method in interface com.bluegosling.function.TriPredicate
-
Returns a composed predicate that represents a short-circuiting logical AND of this predicate
and another.
- and(TypeAnnotationChecker) - Method in interface com.bluegosling.reflect.TypeAnnotationChecker
-
Combines two checkers into one.
- andThen(BooleanConsumer) - Method in interface com.bluegosling.function.BooleanConsumer
-
- andThen(BooleanUnaryOperator) - Method in interface com.bluegosling.function.BooleanUnaryOperator
-
Returns a composed operator that first applies this operator to its input, and then applies
the after
operator to the result.
- andThen(ByteConsumer) - Method in interface com.bluegosling.function.ByteConsumer
-
- andThen(ByteUnaryOperator) - Method in interface com.bluegosling.function.ByteUnaryOperator
-
Returns a composed operator that first applies this operator to its input, and then applies
the after
operator to the result.
- andThen(CharConsumer) - Method in interface com.bluegosling.function.CharConsumer
-
- andThen(CharUnaryOperator) - Method in interface com.bluegosling.function.CharUnaryOperator
-
Returns a composed operator that first applies this operator to its input, and then applies
the after
operator to the result.
- andThen(FloatConsumer) - Method in interface com.bluegosling.function.FloatConsumer
-
- andThen(FloatUnaryOperator) - Method in interface com.bluegosling.function.FloatUnaryOperator
-
Returns a composed operator that first applies this operator to its input, and then applies
the after
operator to the result.
- andThen(ShortConsumer) - Method in interface com.bluegosling.function.ShortConsumer
-
- andThen(ShortUnaryOperator) - Method in interface com.bluegosling.function.ShortUnaryOperator
-
Returns a composed operator that first applies this operator to its input, and then applies
the after
operator to the result.
- andThen(TriConsumer<T, U, V>) - Method in interface com.bluegosling.function.TriConsumer
-
- andThen(Function<? super R, ? extends W>) - Method in interface com.bluegosling.function.TriFunction
-
Returns a composed function that first applies this function to its input, and then applies
the after
function to the result.
- andThen(Function<T, U>) - Method in class com.bluegosling.graph.Node
-
Returns a new node that is the result of applying the given function to the values produced by
this node.
- annotatedClasses(Class<? extends Annotation>) - Method in class com.bluegosling.apt.reflect.ArRoundEnvironment
-
- annotatedClasses(ArClass) - Method in class com.bluegosling.apt.reflect.ArRoundEnvironment
-
- annotatedClasses(Class<? extends Annotation>, Set<ArClass.Kind>) - Method in class com.bluegosling.apt.reflect.ArRoundEnvironment
-
- annotatedClasses(ArClass, Set<ArClass.Kind>) - Method in class com.bluegosling.apt.reflect.ArRoundEnvironment
-
- annotatedConstructors(Class<? extends Annotation>) - Method in class com.bluegosling.apt.reflect.ArRoundEnvironment
-
- annotatedConstructors(ArClass) - Method in class com.bluegosling.apt.reflect.ArRoundEnvironment
-
- annotatedElements(Class<? extends Annotation>) - Method in class com.bluegosling.apt.reflect.ArRoundEnvironment
-
- annotatedElements(ArClass) - Method in class com.bluegosling.apt.reflect.ArRoundEnvironment
-
- annotatedFields(Class<? extends Annotation>) - Method in class com.bluegosling.apt.reflect.ArRoundEnvironment
-
- annotatedFields(ArClass) - Method in class com.bluegosling.apt.reflect.ArRoundEnvironment
-
- annotatedMethods(Class<? extends Annotation>) - Method in class com.bluegosling.apt.reflect.ArRoundEnvironment
-
- annotatedMethods(ArClass) - Method in class com.bluegosling.apt.reflect.ArRoundEnvironment
-
- annotatedPackages(Class<? extends Annotation>) - Method in class com.bluegosling.apt.reflect.ArRoundEnvironment
-
- annotatedPackages(ArClass) - Method in class com.bluegosling.apt.reflect.ArRoundEnvironment
-
- AnnotatedTypeRef<T> - Class in com.bluegosling.reflect
-
A type token that represents an annotated type.
- AnnotatedTypeRef() - Constructor for class com.bluegosling.reflect.AnnotatedTypeRef
-
Constructs a new type reference.
- AnnotatedTypes - Class in com.bluegosling.reflect
-
Numerous utility methods for using, constructing, and inspecting
annotated types.
- AnnotatedTypeVisitor<R,P> - Interface in com.bluegosling.reflect
-
A visitor for annotated types.
- AnnotatedTypeVisitor.Builder<R,P> - Class in com.bluegosling.reflect
-
A builder of visitors, using functional interfaces as the building blocks.
- AnnotationMirrors - Class in com.bluegosling.reflect.model
-
- AnnotationProcessorTestRunner - Class in com.bluegosling.apt.testing
-
A test runner for executing tests inside the context of the annotation processing phase of a Java
compiler.
- AnnotationProcessorTestRunner(Class<?>) - Constructor for class com.bluegosling.apt.testing.AnnotationProcessorTestRunner
-
- Annotations - Class in com.bluegosling.reflect
-
Utility methods for working with instances of
Annotation
.
- annotationType() - Method in class com.bluegosling.apt.reflect.ArAnnotation
-
Returns the annotation's type.
- annotationTypes() - Method in class com.bluegosling.apt.testing.TestEnvironment
-
Gets the set of annotation types for the current round, as
TypeElement
s.
- AnyOfFive<A,B,C,D,E> - Class in com.bluegosling.choice
-
- AnyOfFour<A,B,C,D> - Class in com.bluegosling.choice
-
- AnyOfThree<A,B,C> - Class in com.bluegosling.choice
-
- apply(I) - Method in class com.bluegosling.collections.TransformingIterable
-
Transforms an element.
- apply(I) - Method in class com.bluegosling.collections.TransformingIterator
-
Transforms an element by applying a function.
- apply(T, U, V) - Method in interface com.bluegosling.function.TriFunction
-
Invokes the function with the specified arguments and returns the result.
- apply(Function<? super T, ? extends T>) - Method in class com.bluegosling.possible.Holder
-
Applies the specified function to the held value, if present.
- applyAsBoolean(boolean, boolean) - Method in interface com.bluegosling.function.BooleanBinaryOperator
-
Applies this operator to the given operands.
- applyAsBoolean(boolean) - Method in interface com.bluegosling.function.BooleanPredicate
-
- applyAsBoolean(boolean) - Method in interface com.bluegosling.function.BooleanUnaryOperator
-
Applies this operator to the given operand.
- applyAsByte(byte, byte) - Method in interface com.bluegosling.function.ByteBinaryOperator
-
Applies this operator to the given operands.
- applyAsByte(byte) - Method in interface com.bluegosling.function.ByteUnaryOperator
-
Applies this operator to the given operand.
- applyAsChar(char, char) - Method in interface com.bluegosling.function.CharBinaryOperator
-
Applies this operator to the given operands.
- applyAsChar(char) - Method in interface com.bluegosling.function.CharUnaryOperator
-
Applies this operator to the given operand.
- applyAsFloat(float, float) - Method in interface com.bluegosling.function.FloatBinaryOperator
-
Applies this operator to the given operands.
- applyAsFloat(float) - Method in interface com.bluegosling.function.FloatUnaryOperator
-
Applies this operator to the given operand.
- applyAsShort(short, short) - Method in interface com.bluegosling.function.ShortBinaryOperator
-
Applies this operator to the given operands.
- applyAsShort(short) - Method in interface com.bluegosling.function.ShortUnaryOperator
-
Applies this operator to the given operand.
- applyFilter(Predicate<? super T>) - Method in class com.bluegosling.possible.Holder
-
Applies the specified predicate to the held value, if present.
- ArAnnotatedConstruct - Interface in com.bluegosling.apt.reflect
-
Anything that can have annotations.
- ArAnnotatedElement - Interface in com.bluegosling.apt.reflect
-
An element that can have annotations.
- ArAnnotation - Class in com.bluegosling.apt.reflect
-
An annotation in Java source code.
- ArAnnotationBridge - Class in com.bluegosling.apt.reflect
-
Bridges an annotation mirror into an actual annotation interface.
- ArArrayType - Class in com.bluegosling.apt.reflect
-
An array type.
- ArClass - Class in com.bluegosling.apt.reflect
-
A class (or interface, enum, or annotation type).
- ArClass.Kind - Enum in com.bluegosling.apt.reflect
-
An enumeration of the various kinds of classes.
- ArConstructor - Class in com.bluegosling.apt.reflect
-
A constructor.
- ArDeclaredType - Class in com.bluegosling.apt.reflect
-
A declared type.
- areSameObject() - Static method in class com.bluegosling.function.Predicates
-
- ArExecutableMember - Interface in com.bluegosling.apt.reflect
-
An interface that represents a member that has executable code -- a constructor or a method.
- ArField - Class in com.bluegosling.apt.reflect
-
A field.
- ArGenericDeclaration - Interface in com.bluegosling.apt.reflect
-
An element that may include the declaration of generic type variables.
- ArGenericMethodSignature - Class in com.bluegosling.apt.reflect
-
Represents a generic method signature, composed of a method name and sequence of generic
parameter types.
- ArGenericMethodSignature(ArMethod) - Constructor for class com.bluegosling.apt.reflect.ArGenericMethodSignature
-
Constructs a new signature for the specified method.
- ArGenericMethodSignature(String, ArType...) - Constructor for class com.bluegosling.apt.reflect.ArGenericMethodSignature
-
Constructs a new signature based on the given name and list of arguments.
- ArGenericMethodSignature(String, List<ArType>) - Constructor for class com.bluegosling.apt.reflect.ArGenericMethodSignature
-
Constructs a new signature based on the given name and list of arguments.
- ArMember - Interface in com.bluegosling.apt.reflect
-
A member of a Java class or interface.
- ArMethod - Class in com.bluegosling.apt.reflect
-
A method.
- ArMethodSignature - Class in com.bluegosling.apt.reflect
-
Represents a method signature, composed of a method name and sequence of parameter types.
- ArMethodSignature(ArMethod) - Constructor for class com.bluegosling.apt.reflect.ArMethodSignature
-
Constructs a new signature for the specified method.
- ArMethodSignature(String, ArClass...) - Constructor for class com.bluegosling.apt.reflect.ArMethodSignature
-
Constructs a new signature based on the given name and list of arguments.
- ArMethodSignature(String, List<ArClass>) - Constructor for class com.bluegosling.apt.reflect.ArMethodSignature
-
Constructs a new signature based on the given name and list of arguments.
- ArModifier - Enum in com.bluegosling.apt.reflect
-
Represents a modifier used in Java source code.
- ArPackage - Class in com.bluegosling.apt.reflect
-
A package.
- ArParameter<M extends ArExecutableMember> - Class in com.bluegosling.apt.reflect
-
A representation of a parameter to an executable member, like a constructor or method.
- ArPrimitiveType - Class in com.bluegosling.apt.reflect
-
A primitive type.
- ArProcessor - Class in com.bluegosling.apt.reflect
-
An abstract annotation processor whose methods is defined in terms of the reflection-like API in
this package instead of the standard element and type mirror APIs.
- ArProcessor() - Constructor for class com.bluegosling.apt.reflect.ArProcessor
-
- ArrayBackedLinkedList<E> - Class in com.bluegosling.collections.lists
-
A list implementation that attempts to achieve some of the benefits of a linked list without
sacrificing the overwhelming performance advantages and memory efficiency of arrays.
- ArrayBackedLinkedList() - Constructor for class com.bluegosling.collections.lists.ArrayBackedLinkedList
-
Constructs a new empty list.
- ArrayBackedLinkedList(Collection<? extends E>) - Constructor for class com.bluegosling.collections.lists.ArrayBackedLinkedList
-
Constructs a new list with the specified contents.
- ArrayBackedLinkedList(int) - Constructor for class com.bluegosling.collections.lists.ArrayBackedLinkedList
-
Constructs a new empty list with buffers sized as specified.
- ArrayBlockingDeque<E> - Class in com.bluegosling.collections.concurrent
-
A double-ended blocking queue backed by an array.
- ArrayBlockingDeque(int) - Constructor for class com.bluegosling.collections.concurrent.ArrayBlockingDeque
-
- ArrayMappedBitwiseTrie<K,V> - Class in com.bluegosling.collections.tries
-
- ArrayMappedBitwiseTrie(BitConverter<? super K>) - Constructor for class com.bluegosling.collections.tries.ArrayMappedBitwiseTrie
-
- ArrayMappedBitwiseTrie(BitConverter<? super K>, Comparator<? super K>) - Constructor for class com.bluegosling.collections.tries.ArrayMappedBitwiseTrie
-
- ArrayMappedStringTrie<V> - Class in com.bluegosling.collections.tries
-
- ArrayMappedStringTrie() - Constructor for class com.bluegosling.collections.tries.ArrayMappedStringTrie
-
- ArrayMappedStringTrie(Locale) - Constructor for class com.bluegosling.collections.tries.ArrayMappedStringTrie
-
- ArrayMappedStringTrie(Collator) - Constructor for class com.bluegosling.collections.tries.ArrayMappedStringTrie
-
- ArrayMappedStringTrie(Map<? extends CharSequence, ? extends V>) - Constructor for class com.bluegosling.collections.tries.ArrayMappedStringTrie
-
- ArrayMappedStringTrie(Locale, Map<? extends CharSequence, ? extends V>) - Constructor for class com.bluegosling.collections.tries.ArrayMappedStringTrie
-
- ArrayMappedStringTrie(Collator, Map<? extends CharSequence, ? extends V>) - Constructor for class com.bluegosling.collections.tries.ArrayMappedStringTrie
-
- arrayTypeRef(AnnotatedTypeRef<T>, Annotation...) - Static method in class com.bluegosling.reflect.AnnotatedTypeRef
-
Creates a
TypeRef
for an array type with the given component type.
- arrayTypeRef(TypeRef<T>) - Static method in class com.bluegosling.reflect.TypeRef
-
Creates a
TypeRef
for an array type with the given component type.
- ArrayUtils - Class in com.bluegosling.collections
-
Utility methods for working with arrays that back collection implementations.
- ArrayUtils - Class in com.bluegosling.reflect
-
Utility methods for dealing with arrays, including primitive arrays.
- ArRoundEnvironment - Class in com.bluegosling.apt.reflect
-
The environment for a single round of annotation processing.
- ArRoundEnvironment(RoundEnvironment) - Constructor for class com.bluegosling.apt.reflect.ArRoundEnvironment
-
Wraps a standard round environment.
- ArType - Class in com.bluegosling.apt.reflect
-
A interface that represents a generic type.
- ArTypeParameter<D extends ArGenericDeclaration> - Class in com.bluegosling.apt.reflect
-
A type parameter declaration.
- ArTypes - Class in com.bluegosling.apt.reflect
-
Container of helper methods for working with
ArType
s.
- ArTypeVariable - Class in com.bluegosling.apt.reflect
-
A type variable, or a use of a type parameter.
- ArWildcardType - Class in com.bluegosling.apt.reflect
-
A wildcard type.
- asClass() - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns a
Class
token for this class.
- asClass(ClassLoader) - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns a
Class
token for this class.
- asClass(ArType) - Static method in class com.bluegosling.apt.reflect.ArTypes
-
- asClass() - Method in class com.bluegosling.reflect.scanner.PackageScanner.ClassInfo
-
TODO: document me!
- asClass() - Method in class com.bluegosling.reflect.TypeRef
-
Returns a Class
representation of this type.
- asCollection(Iterable<E>) - Static method in class com.bluegosling.collections.MoreIterables
-
Returns a view of the given iterable as a collection.
- asCompletionStage() - Method in interface com.bluegosling.concurrent.fluent.FluentFuture
-
- asDeclaredType(ArType) - Static method in class com.bluegosling.apt.reflect.ArTypes
-
- asElement() - Method in interface com.bluegosling.apt.reflect.ArAnnotatedElement
-
Returns the underlying
Element
for this object.
- asElement() - Method in class com.bluegosling.apt.reflect.ArClass
-
- asElementModifier() - Method in enum com.bluegosling.apt.reflect.ArModifier
-
- asEnum() - Method in class com.bluegosling.apt.reflect.ArField
-
Returns the actual enum instance represented by this enum constant field.
- asEnum(ClassLoader) - Method in class com.bluegosling.apt.reflect.ArField
-
Returns the actual enum instance represented by this enum constant field.
- asFuture() - Method in class com.bluegosling.result.Result
-
Returns a future that represents the same value or failure as this result.
- asGenericArrayType(ArType) - Static method in class com.bluegosling.apt.reflect.ArTypes
-
- asInt() - Method in enum com.bluegosling.apt.reflect.ArModifier
-
Returns the corresponding bit mask for this modifier.
- asInterceptor(List<? extends InterceptingExecutor.Decorator>) - Static method in interface com.bluegosling.concurrent.executors.InterceptingExecutor.Decorator
-
Converts a list of decorators into a single interceptor.
- asInterceptor(List<? extends InterceptingExecutorService.Decorator>) - Static method in interface com.bluegosling.concurrent.executors.InterceptingExecutorService.Decorator
-
Converts a list of decorators into a single interceptor.
- asIntStream() - Method in interface com.bluegosling.collections.bits.BitStream
-
Provides a view of this bit stream as an
IntStream
.
- asIterable() - Method in class com.bluegosling.generator.Generator
-
Returns a view of this generator as an
Iterable
.
- asIterator() - Method in interface com.bluegosling.generator.Sequence
-
Returns a view of this sequence as an
Iterator
.
- asIteratorOfDouble() - Method in interface com.bluegosling.collections.primitive.FloatIterator
-
- asIteratorOfInt() - Method in interface com.bluegosling.collections.primitive.BooleanIterator
-
- asIteratorOfInt() - Method in interface com.bluegosling.collections.primitive.ByteIterator
-
- asIteratorOfInt() - Method in interface com.bluegosling.collections.primitive.CharIterator
-
- asIteratorOfInt() - Method in interface com.bluegosling.collections.primitive.ShortIterator
-
- asJavaPackage() - Method in class com.bluegosling.buildgen.PackageDirectory
-
- asList(BitSequence) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- asList() - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.RandomAccessEntrySet
-
- asList() - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.RandomAccessKeySet
-
- asList() - Method in class com.bluegosling.collections.sets.DescendingRandomAccessSet
-
- asList() - Method in interface com.bluegosling.collections.sets.RandomAccessSet
-
Returns a view of this set as a list.
- asList() - Method in class com.bluegosling.collections.sets.TransformingRandomAccessSet
-
- asList() - Method in class com.bluegosling.collections.sets.TransformingRandomAccessSet.Bidi
-
- asList() - Method in class com.bluegosling.collections.sets.TransformingRandomAccessSet.ReadOnly
-
- asList(Object) - Static method in class com.bluegosling.reflect.ArrayUtils
-
Returns a view of the given array as a list.
- asList(boolean...) - Static method in class com.bluegosling.reflect.ArrayUtils
-
- asList(byte...) - Static method in class com.bluegosling.reflect.ArrayUtils
-
- asList(char...) - Static method in class com.bluegosling.reflect.ArrayUtils
-
- asList(short...) - Static method in class com.bluegosling.reflect.ArrayUtils
-
- asList(int...) - Static method in class com.bluegosling.reflect.ArrayUtils
-
- asList(long...) - Static method in class com.bluegosling.reflect.ArrayUtils
-
- asList(float...) - Static method in class com.bluegosling.reflect.ArrayUtils
-
- asList(double...) - Static method in class com.bluegosling.reflect.ArrayUtils
-
- asList() - Method in class com.bluegosling.tuples.Empty
-
- asList() - Method in class com.bluegosling.tuples.NTuple
-
- asList() - Method in class com.bluegosling.tuples.Pair
-
- asList() - Method in class com.bluegosling.tuples.Quadruple
-
- asList() - Method in class com.bluegosling.tuples.Quintuple
-
- asList() - Method in class com.bluegosling.tuples.Single
-
Returns a view of this tuple as a list.
- asList() - Method in class com.bluegosling.tuples.Triple
-
- asList() - Method in interface com.bluegosling.tuples.Tuple
-
Returns a view of this tuple as a list.
- asListOfBitTuples(BitSequence, int) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- asListOfBitTuples(BitSequence, int, BitSequence.BitOrder) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- asListOfBytes(BitSequence) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- asListOfBytes(BitSequence, BitSequence.BitOrder) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- asListOfInts(BitSequence) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- asListOfInts(BitSequence, BitSequence.BitOrder) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- asListOfLongs(BitSequence) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- asListOfLongs(BitSequence, BitSequence.BitOrder) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- asListOfShorts(BitSequence) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- asListOfShorts(BitSequence, BitSequence.BitOrder) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- asMap() - Method in class com.bluegosling.collections.lists.AssociativeArrayList
-
- asMap() - Method in interface com.bluegosling.collections.lists.AssociativeList
-
Returns a view of the associative mappings in this list.
- asMap() - Method in interface com.bluegosling.collections.tables.Table2D
-
- asMap() - Method in interface com.bluegosling.collections.tables.Table3D
-
- asMap() - Method in interface com.bluegosling.collections.tables.Table4D
-
- asMap() - Method in interface com.bluegosling.collections.tables.Table5D
-
- asNTuple(FluentFuture<? extends T>, FluentFuture<? extends U>, FluentFuture<? extends V>, FluentFuture<? extends W>, FluentFuture<? extends X>, FluentFuture<?>, FluentFuture<?>...) - Static method in class com.bluegosling.concurrent.extras.FutureTuples
-
- asOptional() - Method in class com.bluegosling.result.Result
-
Returns the result's value, as an optional.
- asPair(FluentFuture<? extends T>, FluentFuture<? extends U>) - Static method in class com.bluegosling.concurrent.extras.FutureTuples
-
- asPossible() - Method in class com.bluegosling.result.Result
-
Returns the result's value, as a possible.
- asPrimitiveType(ArType) - Static method in class com.bluegosling.apt.reflect.ArTypes
-
- asQuadruple(FluentFuture<? extends T>, FluentFuture<? extends U>, FluentFuture<? extends V>, FluentFuture<? extends W>) - Static method in class com.bluegosling.concurrent.extras.FutureTuples
-
- asQueue(PriorityQueue<E, E>) - Static method in class com.bluegosling.collections.queues.PriorityQueues
-
- asQueue(Q) - Static method in class com.bluegosling.collections.queues.PriorityQueues
-
- asQuintuple(FluentFuture<? extends T>, FluentFuture<? extends U>, FluentFuture<? extends V>, FluentFuture<? extends W>, FluentFuture<? extends X>) - Static method in class com.bluegosling.concurrent.extras.FutureTuples
-
- asRandomAccess(boolean) - Method in class com.bluegosling.collections.lists.ArrayBackedLinkedList
-
Returns the current list as an instance of RandomAccess
.
- asReference(Possible<? extends T>) - Static method in class com.bluegosling.possible.Reference
-
Converts a possible value to a reference.
- asRunnableFuture(Runnable) - Method in class com.bluegosling.concurrent.fluent.SettableFluentFuture
-
- asRunnableFuture(Runnable, T) - Method in class com.bluegosling.concurrent.fluent.SettableFluentFuture
-
- asRunnableFuture(Callable<T>) - Method in class com.bluegosling.concurrent.fluent.SettableFluentFuture
-
Returns a view of this future as a
RunnableFluentFuture
that performs the given
computation when run.
- assertNotEquals(T, T) - Static method in class com.bluegosling.testing.MoreAsserts
-
Asserts that the given two values are not equal.
- assertNotEquals(String, T, T) - Static method in class com.bluegosling.testing.MoreAsserts
-
Asserts that the given two values are not equal.
- assertThrows(Class<T>, MoreAsserts.Block) - Static method in class com.bluegosling.testing.MoreAsserts
-
Assert that the given block throws.
- asSet() - Method in class com.bluegosling.possible.AbstractDynamicPossible
-
Returns a view of this possible as a set.
- asSet() - Method in class com.bluegosling.possible.Holder
-
Returns a view of this possible as a set.
- asSet() - Method in interface com.bluegosling.possible.Possible
-
Returns a view of this possible value as a set.
- asSet() - Method in class com.bluegosling.possible.Reference
-
- asSet() - Method in class com.bluegosling.reflect.EnumType
-
Returns a view of the enum elements' values as a set.
- assignable(Class<? extends Annotation>, Class<? extends Annotation>) - Method in class com.bluegosling.reflect.TypeAnnotationHierarchy.Builder
-
Defines an assignability relationship (or subtype relationship) between the given two type
annotations.
- assignable(Class<? extends Annotation>, Class<? extends Annotation>, Map<String, String>) - Method in class com.bluegosling.reflect.TypeAnnotationHierarchy.Builder
-
Defines an assignability relationship (or subtype relationship) between the given two type
annotations.
- asSingle(FluentFuture<? extends T>) - Static method in class com.bluegosling.concurrent.extras.FutureTuples
-
- AssociativeArrayList<E,K> - Class in com.bluegosling.collections.lists
-
- AssociativeArrayList() - Constructor for class com.bluegosling.collections.lists.AssociativeArrayList
-
- AssociativeArrayList(int) - Constructor for class com.bluegosling.collections.lists.AssociativeArrayList
-
- AssociativeArrayList(Collection<? extends E>) - Constructor for class com.bluegosling.collections.lists.AssociativeArrayList
-
- AssociativeArrayList(Map<? extends K, ? extends E>) - Constructor for class com.bluegosling.collections.lists.AssociativeArrayList
-
- AssociativeArrayList(AssociativeList<? extends E, ? extends K>) - Constructor for class com.bluegosling.collections.lists.AssociativeArrayList
-
- AssociativeList<E,K> - Interface in com.bluegosling.collections.lists
-
A
List
that can have associative keys and can be viewed as a
Map
.
- asTriple(FluentFuture<? extends T>, FluentFuture<? extends U>, FluentFuture<? extends V>) - Static method in class com.bluegosling.concurrent.extras.FutureTuples
-
- asType() - Method in class com.bluegosling.apt.reflect.ArClass
-
- asType() - Method in class com.bluegosling.apt.reflect.ArTypeParameter
-
- asType() - Method in class com.bluegosling.reflect.AnnotatedTypeRef
-
- asType() - Method in class com.bluegosling.reflect.TypeRef
-
Returns the
Type
representation of this type token.
- asTypedList(Pair<? extends T, ? extends T>) - Static method in class com.bluegosling.tuples.Pair
-
- asTypedList(Quadruple<? extends T, ? extends T, ? extends T, ? extends T>) - Static method in class com.bluegosling.tuples.Quadruple
-
- asTypedList(Quintuple<? extends T, ? extends T, ? extends T, ? extends T, ? extends T>) - Static method in class com.bluegosling.tuples.Quintuple
-
- asTypedList(Triple<? extends T, ? extends T, ? extends T>) - Static method in class com.bluegosling.tuples.Triple
-
- asTypeMirror() - Method in class com.bluegosling.apt.reflect.ArArrayType
-
- asTypeMirror() - Method in class com.bluegosling.apt.reflect.ArClass
-
- asTypeMirror() - Method in class com.bluegosling.apt.reflect.ArDeclaredType
-
- asTypeMirror() - Method in class com.bluegosling.apt.reflect.ArType
-
Returns the underlying
TypeMirror
represented by this type.
- asTypeMirror() - Method in class com.bluegosling.apt.reflect.ArTypeParameter
-
- asTypeMirror() - Method in class com.bluegosling.apt.reflect.ArTypeVariable
-
- asTypeMirror() - Method in class com.bluegosling.apt.reflect.ArWildcardType
-
- asTypeParameter() - Method in class com.bluegosling.apt.reflect.ArTypeVariable
-
- asTypeRef() - Method in class com.bluegosling.reflect.AnnotatedTypeRef
-
- asTypeVariable(ArType) - Static method in class com.bluegosling.apt.reflect.ArTypes
-
- asWildcardType(ArType) - Static method in class com.bluegosling.apt.reflect.ArTypes
-
- AsynchronousAtom<T> - Class in com.bluegosling.concurrent.atoms
-
An atom that is mutated asynchronously using a thread pool.
- AsynchronousAtom() - Constructor for class com.bluegosling.concurrent.atoms.AsynchronousAtom
-
Constructs a new asynchronous atom with a null
value and no validator.
- AsynchronousAtom(T) - Constructor for class com.bluegosling.concurrent.atoms.AsynchronousAtom
-
Constructs a new asynchronous atom with the specified value and no validator.
- AsynchronousAtom(T, Predicate<? super T>) - Constructor for class com.bluegosling.concurrent.atoms.AsynchronousAtom
-
Constructs a new asynchronous atom with the specified value and the specified validator.
- AsynchronousAtom.ErrorAction - Enum in com.bluegosling.concurrent.atoms
-
One of the possible actions taken when an error occurs during a mutation operation.
- AsynchronousAtom.ErrorHandler<T> - Interface in com.bluegosling.concurrent.atoms
-
Handles errors that occur during a mutation operation on an atom.
- atFixedRate(long, TimeUnit) - Static method in interface com.bluegosling.concurrent.fluent.Rescheduler
-
Creates a rescheduler that schedules tasks at a fixed rate.
- atFixedRateSkippingMissedOccurrences(long, TimeUnit) - Static method in interface com.bluegosling.concurrent.fluent.Rescheduler
-
Creates a rescheduler that schedules tasks at a fixed rate.
- Atom<T> - Interface in com.bluegosling.concurrent.atoms
-
A thread-safe reference type.
- Atom.Watcher<T> - Interface in com.bluegosling.concurrent.atoms
-
Watches an atom for changes to its value.
- AutoEntry() - Constructor for class com.bluegosling.collections.queues.PriorityQueues.AutoEntry
-
- await() - Method in interface com.bluegosling.concurrent.Awaitable
-
Awaits the future event, blocking the current thread until the event occurs.
- await(long, TimeUnit) - Method in interface com.bluegosling.concurrent.Awaitable
-
Awaits the future event, blocking up to the specified amount of time until the event occurs.
- await() - Method in class com.bluegosling.concurrent.fluent.AbstractFluentFuture
-
- await(long, TimeUnit) - Method in class com.bluegosling.concurrent.fluent.AbstractFluentFuture
-
- await() - Method in class com.bluegosling.concurrent.fluent.FluentFutureTask
-
- await(long, TimeUnit) - Method in class com.bluegosling.concurrent.fluent.FluentFutureTask
-
- await() - Method in class com.bluegosling.concurrent.UpAndDownLatch
-
Waits for the number of references to reach zero.
- await(long, TimeUnit) - Method in class com.bluegosling.concurrent.UpAndDownLatch
-
Waits up to specified amount of time for the number of references to reach zero.
- await() - Method in class com.bluegosling.reflect.scanner.PackageScanner.ScanResult
-
- await(long, TimeUnit) - Method in class com.bluegosling.reflect.scanner.PackageScanner.ScanResult
-
- Awaitable - Interface in com.bluegosling.concurrent
-
An object that represents a future event.
- awaitPipelineQuiescence(K) - Method in class com.bluegosling.concurrent.executors.PipeliningExecutor
-
Waits for the specified pipeline to reach a point where no tasks are running or queued.
- awaitPipelineQuiescence(K, long, TimeUnit) - Method in class com.bluegosling.concurrent.executors.PipeliningExecutor
-
Waits up to the specified amount of time for the specified pipeline to reach a point where no
tasks are running or queued.
- awaitQuiescence() - Method in class com.bluegosling.concurrent.executors.PipeliningExecutor
-
Waits for this executor to reach a point where no tasks are running or queued.
- awaitQuiescence(long, TimeUnit) - Method in class com.bluegosling.concurrent.executors.PipeliningExecutor
-
Waits up to the specified amount of time for this executor to reach a point where no tasks are
running or queued.
- awaitTermination(long, TimeUnit) - Method in class com.bluegosling.concurrent.executors.ActorThreadPool
-
Blocks until this executor has finished terminating.
- awaitTermination(long, TimeUnit) - Method in class com.bluegosling.concurrent.executors.ThreadLimitingExecutorService
-
- awaitTermination(long, TimeUnit) - Method in class com.bluegosling.concurrent.executors.WorkSharingThreadPool
-
- awaitTermination(long, TimeUnit) - Method in class com.bluegosling.concurrent.executors.WrappingExecutorService
-
- awaitTermination(long, TimeUnit) - Method in class com.bluegosling.concurrent.scheduler.ScheduledTaskManager
-
- awaitUninterruptibly() - Method in interface com.bluegosling.concurrent.Awaitable
-
Awaits the future event, blocking the current thread in a manner that cannot be interrupted
until the event occurs.
- awaitUninterruptibly(long, TimeUnit) - Method in interface com.bluegosling.concurrent.Awaitable
-
Awaits the future event, blocking in a manner that cannot be interrupted up to the specified
amount of time until the event occurs.
- awakeOneWorker(ActorThreadPool.Worker<T>) - Method in class com.bluegosling.concurrent.executors.ActorThreadPool
-
Awakens a single worker.
- callAsync(Callable<T>) - Static method in class com.bluegosling.concurrent.futures.CompletableFutures
-
Calls the given task asynchronously, returning a future that represents its completion.
- callAsync(Callable<T>, Executor) - Static method in class com.bluegosling.concurrent.futures.CompletableFutures
-
Calls the given task asynchronously, returning a future that represents its completion.
- CallingClass - Class in com.bluegosling.reflect
-
- CallingClass.StackFrame - Class in com.bluegosling.reflect
-
- callInterruptiblyAsync(Callable<T>) - Static method in class com.bluegosling.concurrent.futures.CompletableFutures
-
Calls the given task asynchronously, returning a future that represents its completion.
- callInterruptiblyAsync(Callable<T>, Executor) - Static method in class com.bluegosling.concurrent.futures.CompletableFutures
-
Calls the given task asynchronously, returning a future that represents its completion.
- callWithExclusiveLock(Callable<T>) - Method in class com.bluegosling.concurrent.locks.HierarchicalLock
-
Invokes the specified callable while holding this lock in exclusive mode.
- callWithLock(Callable<T>) - Method in interface com.bluegosling.concurrent.locks.Locking
-
Invokes the given action while holding a lock.
- callWithOptimisticReadLock(Callable<T>) - Method in interface com.bluegosling.concurrent.locks.Locking.StampedLocking
-
Invokes the given action without acquiring a lock, relying on optimistic concurrency.
- callWithReadLock(Callable<T>) - Method in interface com.bluegosling.concurrent.locks.Locking.ReadWriteLocking
-
Invokes the given action while holding a read (e.g.
- callWithSharedLock(Callable<T>) - Method in class com.bluegosling.concurrent.locks.HierarchicalLock
-
Invokes the specified callable while holding this lock in shared mode.
- callWithWriteLock(Callable<T>) - Method in interface com.bluegosling.concurrent.locks.Locking.ReadWriteLocking
-
Invokes the given action while holding a write (e.g.
- cancel(boolean) - Method in interface com.bluegosling.concurrent.Cancellable
-
Cancels the activity.
- cancel(boolean) - Method in class com.bluegosling.concurrent.fluent.AbstractFluentFuture
-
- cancel(boolean) - Method in class com.bluegosling.concurrent.fluent.CombiningFluentFuture
-
- cancel(boolean) - Method in class com.bluegosling.concurrent.futures.InterruptibleCompletableFuture
-
- cancel(boolean) - Method in interface com.bluegosling.concurrent.scheduler.ScheduledTaskDefinition
-
Cancels this task definition.
- Cancellable - Interface in com.bluegosling.concurrent
-
Represents an activity that can be cancelled.
- cancelled() - Method in interface com.bluegosling.concurrent.fluent.FutureVisitor
-
Invoked when the visited future was cancelled.
- cancelled() - Method in class com.bluegosling.concurrent.fluent.SimpleFutureVisitor
-
Invoked when the visited future was cancelled.
- cancelledFuture() - Static method in interface com.bluegosling.concurrent.fluent.FluentFuture
-
Returns a future that has already been cancelled.
- cancelledFuture() - Static method in class com.bluegosling.concurrent.futures.CompletableFutures
-
- canonicalize(Object) - Method in interface com.bluegosling.collections.sets.CanonicalSet
-
Returns the canonical representation for the given value or null
if the value is
not present in this set.
- CanonicalSet<E> - Interface in com.bluegosling.collections.sets
-
A set that can also provide the canonical instance for a given value.
- capacity() - Method in class com.bluegosling.collections.CircularBuffer
-
Returns the maximum capacity of the buffer, as specified during construction.
- capture() - Method in interface com.bluegosling.concurrent.executors.ContextPropagator
-
Captures the context from the current thread.
- capture() - Method in class com.bluegosling.reflect.MethodCapturer
-
Returns a proxy for the interfaces whose methods are captured.
- car() - Method in interface com.bluegosling.collections.immutable.ConsList
-
Returns the first of the list.
- cast(S) - Static method in class com.bluegosling.collections.immutable.Immutables
-
Safely upcasts the element type of an immutable collection.
- cast(S) - Static method in class com.bluegosling.collections.immutable.Immutables
-
Safely upcasts the key and/or value types of an immutable map.
- cast(S) - Static method in class com.bluegosling.collections.immutable.Immutables
-
Safely upcasts the element type of an immutable collection.
- cast(S) - Static method in class com.bluegosling.collections.immutable.Immutables
-
Safely upcasts the key and/or value types of an immutable map.
- cast(Iterable<? extends E>) - Static method in class com.bluegosling.collections.MoreIterables
-
Casts the given iterable to one whose elements are a super-type.
- cast(Iterator<? extends E>) - Static method in class com.bluegosling.collections.MoreIterators
-
Casts the given iterator to one whose elements are a super-type.
- cast(Spliterator<? extends T>) - Static method in class com.bluegosling.collections.MoreSpliterators
-
Casts the given spliterator to emitting a supertype.
- cast(FluentFuture<U>) - Static method in interface com.bluegosling.concurrent.fluent.FluentFuture
-
Casts a future to a super-type.
- cast(Optional<T>) - Static method in class com.bluegosling.possible.Optionals
-
Upcasts an optional value to a super-type.
- cast(Reference<S>, Class<T>) - Static method in class com.bluegosling.possible.Reference
-
Casts a reference to a different type.
- cast(Object) - Method in class com.bluegosling.reflect.caster.Caster
-
Casts the specified object to this caster's target interface.
- cast(Result<U, F>) - Static method in class com.bluegosling.result.Result
-
Casts an immediate value to a super-type.
- Caster<T> - Class in com.bluegosling.reflect.caster
-
An object that can cast objects to arbitrary interfaces.
- Caster.Builder<T> - Class in com.bluegosling.reflect.caster
-
- castingArguments() - Method in class com.bluegosling.reflect.caster.Caster.Builder
-
Enables casting of arguments.
- castingReturnTypes() - Method in class com.bluegosling.reflect.caster.Caster.Builder
-
Enables casting of return values.
- castToInterface(Object, Class<T>) - Static method in class com.bluegosling.reflect.caster.Caster
-
Casts an object to an interface that it may not necessarily implement.
- castToInterface(Object, Class<T>, boolean) - Static method in class com.bluegosling.reflect.caster.Caster
-
Casts an object to interface that it may not necessarily implement.
- CategorizingDiagnosticCollector - Class in com.bluegosling.apt.testing
-
A collector of diagnostic messages emitted by the compiler.
- CategorizingDiagnosticCollector() - Constructor for class com.bluegosling.apt.testing.CategorizingDiagnosticCollector
-
Constructs a new collector.
- cdr() - Method in interface com.bluegosling.collections.immutable.ConsList
-
Returns the rest of the list.
- ceiling(K) - Method in class com.bluegosling.collections.AbstractNavigableMap.KeySet
-
- ceiling(E) - Method in class com.bluegosling.collections.concurrent.ConcurrentSortedArraySet
- ceiling(E) - Method in class com.bluegosling.collections.DescendingSet
-
- ceiling(E) - Method in class com.bluegosling.collections.FilteringNavigableSet
-
- ceiling(E) - Method in class com.bluegosling.collections.sets.SortedArraySet
- ceilingEntry(K) - Method in class com.bluegosling.collections.AbstractNavigableMap
- ceilingEntry(K) - Method in class com.bluegosling.collections.AbstractNavigableMap.SubMap
-
Finds the entry in this sub-map with the smallest key that is greater than or equal to the
specified key.
- ceilingEntry(K) - Method in class com.bluegosling.collections.concurrent.DoubleInstanceLockedTreeMap
-
- ceilingEntry(K) - Method in class com.bluegosling.collections.DescendingMap
-
- ceilingEntry(K) - Method in class com.bluegosling.collections.FilteringNavigableMap
-
- ceilingEntry(K) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.RandomAccessSubMap
-
Finds the entry in this sub-map with the smallest key that is greater than or equal to the
specified key.
- ceilingEntry(K) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.SubMapByIndices
-
- ceilingEntry(K) - Method in class com.bluegosling.collections.maps.SortedArrayMap
-
- ceilingEntry(K) - Method in class com.bluegosling.collections.maps.WeightBalancedTreeMap
-
- ceilingEntry(K) - Method in class com.bluegosling.collections.tries.ArrayMappedBitwiseTrie
-
- ceilingEntry(K) - Method in class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- ceilingEntry(Iterable<K>) - Method in class com.bluegosling.collections.tries.DescendingSequenceTrie
-
- ceilingEntry(Iterable<K>) - Method in interface com.bluegosling.collections.tries.NavigableSequenceTrie
-
- ceilingEntry(K) - Method in class com.bluegosling.collections.tries.SimpleBitwiseTrie
-
- ceilingKey(K) - Method in class com.bluegosling.collections.AbstractNavigableMap
- ceilingKey(K) - Method in class com.bluegosling.collections.concurrent.DoubleInstanceLockedTreeMap
-
- ceilingKey(K) - Method in class com.bluegosling.collections.DescendingMap
-
- ceilingKey(K) - Method in class com.bluegosling.collections.FilteringNavigableMap
-
- ceilingKey(K) - Method in class com.bluegosling.collections.maps.WeightBalancedTreeMap
-
- ceilingKey(K) - Method in class com.bluegosling.collections.tries.ArrayMappedBitwiseTrie
-
- ceilingKey(K) - Method in class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- ceilingKey(Iterable<K>) - Method in class com.bluegosling.collections.tries.DescendingSequenceTrie
-
- ceilingKey(Iterable<K>) - Method in interface com.bluegosling.collections.tries.NavigableSequenceTrie
-
- ceilingKey(K) - Method in class com.bluegosling.collections.tries.SimpleBitwiseTrie
-
- cellSet() - Method in interface com.bluegosling.collections.tables.Table2D
-
- cellSet() - Method in interface com.bluegosling.collections.tables.Table3D
-
- cellSet() - Method in interface com.bluegosling.collections.tables.Table4D
-
- cellSet() - Method in interface com.bluegosling.collections.tables.Table5D
-
- chain(PartialFunction<? super I, ? extends O>, PartialFunction<? super I, ? extends O>) - Static method in class com.bluegosling.function.PartialFunctions
-
Returns a partial function that chains two partial functions together.
- chain(PartialBiFunction<? super I1, ? super I2, ? extends O>, PartialBiFunction<? super I1, ? super I2, ? extends O>) - Static method in class com.bluegosling.function.PartialFunctions
-
Returns a bivariate partial function that chains two bivariate partial functions together.
- chain(PartialTriFunction<? super I1, ? super I2, ? super I3, ? extends O>, PartialTriFunction<? super I1, ? super I2, ? super I3, ? extends O>) - Static method in class com.bluegosling.function.PartialFunctions
-
Returns a bivariate partial function that chains two bivariate partial functions together.
- chainTo(Callable<U>, Executor) - Method in interface com.bluegosling.concurrent.fluent.FluentFuture
-
Chains the specified task to the completion of this future.
- chainTo(Runnable, U, Executor) - Method in interface com.bluegosling.concurrent.fluent.FluentFuture
-
Chains the specified task to the completion of this future.
- chainTo(Runnable, Executor) - Method in interface com.bluegosling.concurrent.fluent.FluentFuture
-
Chains the specified task to the completion of this future.
- chainTo(Function<? super T, ? extends U>, Executor) - Method in interface com.bluegosling.concurrent.fluent.FluentFuture
-
Chains the specified task to the completion of this future.
- changeCapacity(int) - Method in class com.bluegosling.collections.CircularBuffer
-
Creates a new buffer with the same elements as the current buffer but with a different
capacity.
- changed(Atom<? extends T>, T, T) - Method in interface com.bluegosling.concurrent.atoms.Atom.Watcher
-
Handles changes to the specified atom.
- CharBinaryOperator - Interface in com.bluegosling.function
-
Represents an operation upon two char
-valued operands and producing a
char
-valued result.
- CharConsumer - Interface in com.bluegosling.function
-
- CharIterator - Interface in com.bluegosling.collections.primitive
-
An
Iterator
that can provide primitive (un-boxed) characters.
- CharPredicate - Interface in com.bluegosling.function
-
Represents a predicate (boolean-valued function) of one char
-valued
argument.
- CharUnaryOperator - Interface in com.bluegosling.function
-
Represents an operation on a single char
-valued operand that produces a
char
-valued result.
- checkClone(Object, Object) - Static method in class com.bluegosling.util.Cloners
-
Checks that the clone is valid.
- checkedGet() - Method in class com.bluegosling.reflect.blaster.Blaster.Result
-
Gets the result value.
- checkedGet(Result<? extends T, ? extends E>) - Static method in class com.bluegosling.result.Result
-
Gets the value of the given result or throws the cause of failure.
- CheckedProcessingTask<T,X extends Throwable> - Interface in com.bluegosling.apt.testing
-
A task that can be run from the context of the annotation processing phase of a compiler.
- checkInstance(T) - Static method in class com.bluegosling.testing.ObjectVerifiers
-
Returns an object that verifies that the test object is the same as a specified instance.
- checkModCount() - Method in class com.bluegosling.collections.AbstractNavigableMap.BaseIteratorImpl
-
Checks for concurrent modification by examining the underlying map's
modCount
.
- checkModCount() - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.SubMapByIndicesIterator
-
Checks for concurrent modification by examining the underlying map's
modCount
.
- checkPackageAccess(Class<?>) - Static method in class com.bluegosling.reflect.SecureUtils
-
Checks package access on the given class.
- checkPackageAccess(String) - Static method in class com.bluegosling.reflect.SecureUtils
-
Checks package access on the given classname.
- Choice<A,B> - Interface in com.bluegosling.choice
-
An object that represents a choice between one of a few options.
- Choice.OfFive<A,B,C,D,E> - Interface in com.bluegosling.choice
-
- Choice.OfFour<A,B,C,D> - Interface in com.bluegosling.choice
-
- Choice.OfThree<A,B,C> - Interface in com.bluegosling.choice
-
- Choice.OfTwo<A,B> - Interface in com.bluegosling.choice
-
Operations for a
Choice
that has exactly two options.
- Choice.Ops3<A,B,C> - Interface in com.bluegosling.choice
-
Extends the
Choice
interface with operations for choices with at least three options.
- Choice.Ops4<A,B,C,D> - Interface in com.bluegosling.choice
-
Extends the
Choice
interface with operations for choices with at least four options.
- Choice.Ops5<A,B,C,D,E> - Interface in com.bluegosling.choice
-
Extends the
Choice
interface with operations for choices with at least five options.
- Choice.VisitorOfFive<A,B,C,D,E,R> - Interface in com.bluegosling.choice
-
A visitor for a choice with five options.
- Choice.VisitorOfFour<A,B,C,D,R> - Interface in com.bluegosling.choice
-
A visitor for a choice with four options.
- Choice.VisitorOfThree<A,B,C,R> - Interface in com.bluegosling.choice
-
A visitor for a choice with three options.
- Choice.VisitorOfTwo<A,B,R> - Interface in com.bluegosling.choice
-
A visitor for a choice with two options.
- Choices - Class in com.bluegosling.choice
-
Utility methods and interfaces for working with
Choice
s.
- Choices() - Constructor for class com.bluegosling.choice.Choices
-
- CircularBuffer<E> - Class in com.bluegosling.collections
-
A simple fixed-capacity buffer of object references.
- CircularBuffer(int) - Constructor for class com.bluegosling.collections.CircularBuffer
-
Constructs a new buffer with the specified capacity.
- ClassesToProcess - Annotation Type in com.bluegosling.apt.testing
-
An annotation on a test class or method that defines the classes to process.
- ClassHierarchyScanner<R,P> - Class in com.bluegosling.reflect
-
An object that scans an entire type hierarchy.
- ClassHierarchyScanner.Builder<R,P> - Class in com.bluegosling.reflect
-
- ClassLoaders - Class in com.bluegosling.reflect
-
- clear() - Method in class com.bluegosling.collections.AbstractNavigableMap
- clear() - Method in class com.bluegosling.collections.AbstractNavigableMap.EntrySet
-
- clear() - Method in class com.bluegosling.collections.AbstractNavigableMap.KeySet
-
- clear() - Method in class com.bluegosling.collections.AbstractNavigableMap.SubMap
-
Removes all elements within the sub-map's bounds.
- clear() - Method in class com.bluegosling.collections.AbstractNavigableMap.ValueCollection
-
- clear() - Method in class com.bluegosling.collections.CircularBuffer
-
Clears all elements from this buffer.
- clear() - Method in class com.bluegosling.collections.concurrent.ConcurrentSortedArraySet
- clear() - Method in class com.bluegosling.collections.concurrent.DoubleInstanceLockedTreeMap
-
- clear() - Method in class com.bluegosling.collections.concurrent.PersistentMapBackedConcurrentMap
-
- clear() - Method in class com.bluegosling.collections.concurrent.SimpleTreiberStack
-
- clear() - Method in class com.bluegosling.collections.concurrent.TreiberStack
-
- clear() - Method in class com.bluegosling.collections.DescendingMap
-
- clear() - Method in class com.bluegosling.collections.DescendingSet
-
- clear() - Method in class com.bluegosling.collections.FilteringCollection
-
- clear() - Method in class com.bluegosling.collections.FilteringMap
-
- clear() - Method in class com.bluegosling.collections.immutable.AbstractImmutableCollection
-
Deprecated.
- clear() - Method in class com.bluegosling.collections.immutable.AbstractImmutableList
-
Deprecated.
- clear() - Method in class com.bluegosling.collections.immutable.AbstractImmutableMap
-
Deprecated.
- clear() - Method in class com.bluegosling.collections.immutable.AbstractImmutableSet
-
Deprecated.
- clear() - Method in interface com.bluegosling.collections.immutable.PersistentCollection
-
Deprecated.
- clear() - Method in interface com.bluegosling.collections.immutable.PersistentList
-
Deprecated.
- clear() - Method in interface com.bluegosling.collections.immutable.PersistentMap
-
Deprecated.
- clear() - Method in interface com.bluegosling.collections.immutable.PersistentSet
-
Deprecated.
- clear() - Method in class com.bluegosling.collections.lists.ArrayBackedLinkedList
- clear() - Method in class com.bluegosling.collections.lists.TreeList
-
- clear() - Method in class com.bluegosling.collections.lists.UnrolledLinkedList
-
- clear() - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.RandomAccessSubMap
-
Removes all elements within the sub-map's bounds.
- clear() - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.SubMapByIndices
-
- clear() - Method in class com.bluegosling.collections.maps.HamtMap
-
- clear() - Method in class com.bluegosling.collections.maps.LinearHashingMap
-
- clear() - Method in class com.bluegosling.collections.maps.WeightBalancedTreeMap
-
- clear() - Method in class com.bluegosling.collections.NoCopyGrowableArray
-
- clear() - Method in class com.bluegosling.collections.queues.FibonacciHeapOrderedQueue
-
- clear() - Method in interface com.bluegosling.collections.queues.PriorityQueue
-
Removes all entries from this queue.
- clear() - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- clear() - Method in class com.bluegosling.collections.queues.RandomAccessArrayDeque
-
- clear() - Method in class com.bluegosling.collections.queues.RandomizedQueue
-
- clear() - Method in class com.bluegosling.collections.queues.SkewHeapOrderedQueue
-
- clear() - Method in class com.bluegosling.collections.sets.RandomAccessSetList
-
- clear() - Method in class com.bluegosling.collections.sets.SortedArraySet
- clear() - Method in interface com.bluegosling.collections.tables.Table2D
-
- clear() - Method in interface com.bluegosling.collections.tables.Table3D
-
- clear() - Method in interface com.bluegosling.collections.tables.Table4D
-
- clear() - Method in interface com.bluegosling.collections.tables.Table5D
-
- clear() - Method in class com.bluegosling.collections.TransformingCollection
-
- clear() - Method in class com.bluegosling.collections.TransformingCollection.ReadOnly
-
- clear() - Method in class com.bluegosling.collections.TransformingMap
-
- clear() - Method in class com.bluegosling.collections.TransformingMap.ReadOnly
-
- clear() - Method in class com.bluegosling.collections.tries.ArrayMappedBitwiseTrie
-
- clear() - Method in class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- clear() - Method in class com.bluegosling.collections.tries.SimpleBitwiseTrie
-
- clear() - Method in class com.bluegosling.concurrent.RateLimitedBlockingQueue
-
- clear() - Method in class com.bluegosling.possible.Holder
-
Clears the held value.
- clear() - Method in class com.bluegosling.vars.Variable
-
Clears this variable's value, setting it to null
.
- clearKey(int) - Method in class com.bluegosling.collections.lists.AssociativeArrayList
-
- clearKey(int) - Method in interface com.bluegosling.collections.lists.AssociativeList
-
Clears an associative key from a given list index.
- Clock - Interface in com.bluegosling.util
-
- clone() - Method in class com.bluegosling.collections.lists.ArrayBackedLinkedList
- clone() - Method in class com.bluegosling.collections.lists.AssociativeArrayList
-
- clone() - Method in class com.bluegosling.collections.lists.TreeList
-
- clone() - Method in class com.bluegosling.collections.lists.UnrolledLinkedList
-
- clone() - Method in class com.bluegosling.collections.maps.HamtMap
-
- clone() - Method in class com.bluegosling.collections.queues.FibonacciHeapOrderedQueue
-
- clone() - Method in class com.bluegosling.collections.queues.SkewHeapOrderedQueue
-
- clone() - Method in class com.bluegosling.collections.sets.SortedArraySet
-
- clone(T) - Static method in class com.bluegosling.reflect.ArrayUtils
-
Clones the given array object.
- clone(T) - Method in interface com.bluegosling.util.Cloner
-
Clones an object.
- clone() - Method in class com.bluegosling.vars.Variable
-
Creates a shallow copy of this variable.
- clone() - Method in class com.bluegosling.vars.VariableBoolean
-
Creates a copy of this variable.
- clone() - Method in class com.bluegosling.vars.VariableByte
-
Creates a copy of this variable.
- clone() - Method in class com.bluegosling.vars.VariableChar
-
Creates a copy of this variable.
- clone() - Method in class com.bluegosling.vars.VariableDouble
-
Creates a copy of this variable.
- clone() - Method in class com.bluegosling.vars.VariableFloat
-
Creates a copy of this variable.
- clone() - Method in class com.bluegosling.vars.VariableInt
-
Creates a copy of this variable.
- clone() - Method in class com.bluegosling.vars.VariableLong
-
Creates a copy of this variable.
- clone() - Method in class com.bluegosling.vars.VariableShort
-
Creates a copy of this variable.
- cloneAllArgumentsWith(Cloner<?>) - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfiguration
-
Indicates that the arguments should be cloned prior to method execution.
- cloneAllArgumentsWith(Cloner<?>) - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfigurator
-
Indicates that the arguments should be cloned prior to method execution.
- cloneAndVerifyArguments() - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfiguration
-
Indicates that arguments should be cloned prior to method execution and then verified.
- cloneAndVerifyArguments() - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfigurator
-
Indicates that arguments should be cloned prior to method execution and then verified.
- cloneArguments() - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfiguration
-
Indicates that the arguments should be cloned prior to method execution.
- cloneArguments() - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfigurator
-
Indicates that the arguments should be cloned prior to method execution.
- cloneArgumentsWith(Cloner<?>...) - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfiguration
-
Indicates that the arguments should be cloned prior to method execution.
- cloneArgumentsWith(List<Cloner<?>>) - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfiguration
-
Indicates that the arguments should be cloned prior to method execution.
- cloneArgumentsWith(Cloner<?>...) - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfigurator
-
Indicates that the arguments should be cloned prior to method execution.
- cloneArgumentsWith(List<Cloner<?>>) - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfigurator
-
Indicates that the arguments should be cloned prior to method execution.
- Cloner<T> - Interface in com.bluegosling.util
-
An object that can clone other objects.
- Cloners - Class in com.bluegosling.util
-
Utility methods and constants for using and creating Cloner
instances.
- CloningException - Exception in com.bluegosling.util
-
An exception that occurs during a cloning operation.
- CloningException(String) - Constructor for exception com.bluegosling.util.CloningException
-
Constructs a new exception with a message.
- CloningException(Throwable) - Constructor for exception com.bluegosling.util.CloningException
-
Constructs a new exception chained to another.
- CloningException(String, Throwable) - Constructor for exception com.bluegosling.util.CloningException
-
Constructs a new exception with a message that is chained to another.
- close() - Method in class com.bluegosling.apt.testing.TestJavaFileManager
-
- close() - Method in interface com.bluegosling.collections.concurrent.SharedCapacityDequeFactory.CloseableQueue
-
Closes the queue, releasing its capacity, and rendering it inoperable.
- close() - Method in interface com.bluegosling.streams.StreamOperator
-
Performs clean-up needed after processing of the stream completes.
- coalesce(Choice.OfTwo<? extends T, ? extends T>) - Static method in class com.bluegosling.choice.Choices
-
Coalesces two options into a single result.
- coalesce(Choice.OfThree<? extends T, ? extends T, ? extends T>) - Static method in class com.bluegosling.choice.Choices
-
Coalesces three options into a single result.
- coalesce(Choice.OfFour<? extends T, ? extends T, ? extends T, ? extends T>) - Static method in class com.bluegosling.choice.Choices
-
Coalesces four options into a single result.
- coalesce(Choice.OfFive<? extends T, ? extends T, ? extends T, ? extends T, ? extends T>) - Static method in class com.bluegosling.choice.Choices
-
Coalesces five options into a single result.
- collator() - Method in class com.bluegosling.collections.tries.ArrayMappedStringTrie
-
- collator() - Method in class com.bluegosling.collections.tries.SimpleStringTrie
-
- CollectionUtils - Class in com.bluegosling.collections
-
Utility functions for implementing standard collection interfaces.
- columnIndex() - Method in interface com.bluegosling.collections.tables.Table2D
-
- columnIndex() - Method in interface com.bluegosling.collections.tables.Table3D
-
- columnIndex() - Method in interface com.bluegosling.collections.tables.Table4D
-
- columnIndex() - Method in interface com.bluegosling.collections.tables.Table5D
-
- columnKeySet() - Method in interface com.bluegosling.collections.tables.Table2D
-
- columnKeySet() - Method in interface com.bluegosling.collections.tables.Table3D
-
- columnKeySet() - Method in interface com.bluegosling.collections.tables.Table4D
-
- columnKeySet() - Method in interface com.bluegosling.collections.tables.Table5D
-
- com.bluegosling.apt - package com.bluegosling.apt
-
APIs to simplify implementation of annotation processors and annotation processing tools.
- com.bluegosling.apt.reflect - package com.bluegosling.apt.reflect
-
This package provides an alternate set of APIs for interacting with annotations and types from an
annotation processor.
- com.bluegosling.apt.testing - package com.bluegosling.apt.testing
-
Tools for unit testing annotation processors using JUnit4.
- com.bluegosling.buildgen - package com.bluegosling.buildgen
-
Tools for analyzing file and package dependencies in Java source code and generating Pants
BUILD
files based on those dependencies.
- com.bluegosling.choice - package com.bluegosling.choice
-
APIs for tagged union types.
- com.bluegosling.collections - package com.bluegosling.collections
-
Various utilities that extend the Java Collections Framework (JCF).
- com.bluegosling.collections.bits - package com.bluegosling.collections.bits
-
This package contains an alternative to the standard
BitSet
that provides an
immutable view of a sequence of bits and includes mechanisms to navigate the sequence in
arbitrarily-sized chunks of bits.
- com.bluegosling.collections.concurrent - package com.bluegosling.collections.concurrent
-
New implementations of concurrent data structures.
- com.bluegosling.collections.immutable - package com.bluegosling.collections.immutable
-
Immutable and persistent collections.
- com.bluegosling.collections.lists - package com.bluegosling.collections.lists
-
New interfaces and implementations related to the standard Java
List
interface.
- com.bluegosling.collections.maps - package com.bluegosling.collections.maps
-
New interfaces and implementations related to the standard Java
Map
interface.
- com.bluegosling.collections.primitive - package com.bluegosling.collections.primitive
-
Primitive specializations of collections.
- com.bluegosling.collections.queues - package com.bluegosling.collections.queues
-
New interfaces and implementations related to the standard Java
Queue
interface.
- com.bluegosling.collections.sets - package com.bluegosling.collections.sets
-
New interfaces and implementations related to the standard Java
Set
interface.
- com.bluegosling.collections.sorting - package com.bluegosling.collections.sorting
-
Implementations of sorting algorithms.
- com.bluegosling.collections.tables - package com.bluegosling.collections.tables
-
Multi-dimensional tables and nested maps.
- com.bluegosling.collections.tries - package com.bluegosling.collections.tries
-
General trie container types for Java.
- com.bluegosling.concurrent - package com.bluegosling.concurrent
-
Classes that extend and enhance the API provided by the java.util.concurrent
package.
- com.bluegosling.concurrent.atoms - package com.bluegosling.concurrent.atoms
-
A set of classes for managing mutable thread-safe references.
- com.bluegosling.concurrent.contended - package com.bluegosling.concurrent.contended
-
Classes that provide similar functionality to com java.util.concurrent.atomic
, except
using padded values to prevent cache contention (false sharing).
- com.bluegosling.concurrent.executors - package com.bluegosling.concurrent.executors
-
Implementations and variations of
Executor
s.
- com.bluegosling.concurrent.extras - package com.bluegosling.concurrent.extras
-
Additional concurrency-related APIs.
- com.bluegosling.concurrent.fluent - package com.bluegosling.concurrent.fluent
-
This package contains the über-Future.
- com.bluegosling.concurrent.futures - package com.bluegosling.concurrent.futures
-
- com.bluegosling.concurrent.locks - package com.bluegosling.concurrent.locks
-
New types of locks and synchronizers.
- com.bluegosling.concurrent.scheduler - package com.bluegosling.concurrent.scheduler
-
- com.bluegosling.derivations - package com.bluegosling.derivations
-
A simple tool for analyzing derivations and computing indirect/transitive derivation
relationships.
- com.bluegosling.function - package com.bluegosling.function
-
Interfaces and classes that complement the standard java.util.function
package.
- com.bluegosling.generator - package com.bluegosling.generator
-
Utilities for simulating generators in Java.
- com.bluegosling.graph - package com.bluegosling.graph
-
APIs for representing complex processes as a dependency graph.
- com.bluegosling.possible - package com.bluegosling.possible
-
Objects that may or may not have a value.
- com.bluegosling.processors - package com.bluegosling.processors
-
Annotation processors.
- com.bluegosling.reflect - package com.bluegosling.reflect
-
Utilities to aid in runtime type reflection code, including the use of proxies.
- com.bluegosling.reflect.blaster - package com.bluegosling.reflect.blaster
-
An API that allows a single proxy to be used as a broadcasting proxy -- to "blast" method
invocations out to multiple delegates.
- com.bluegosling.reflect.caster - package com.bluegosling.reflect.caster
-
An API that leverages reflection to dynamically cast an object to an arbitrary interface.
- com.bluegosling.reflect.model - package com.bluegosling.reflect.model
-
Extensions of elements and type mirrors for use with core reflection.
- com.bluegosling.reflect.scanner - package com.bluegosling.reflect.scanner
-
A package scanner that uses reflection to enumerate the contents of a package.
- com.bluegosling.result - package com.bluegosling.result
-
A simple value type that can represent either the value of a successful operation or the cause of
failure for an unsuccessful one.
- com.bluegosling.streams - package com.bluegosling.streams
-
An alternate
stream implementation that includes additional
operations, including simple mechanisms to define new operators.
- com.bluegosling.testing - package com.bluegosling.testing
-
Tools for testing implementations of interfaces.
- com.bluegosling.tuples - package com.bluegosling.tuples
-
APIs for type-safe tuples.
- com.bluegosling.util - package com.bluegosling.util
-
Miscellaneous utility classes.
- com.bluegosling.vars - package com.bluegosling.vars
-
This package contains simple, mutable "holders" for reference types and primitives.
- combine(Pair<? extends Collection<T>, ? extends Collection<U>>) - Static method in class com.bluegosling.tuples.Pair
-
Combines a pair of collections into a collection of pairs.
- combine(Collection<T>, Collection<U>) - Static method in class com.bluegosling.tuples.Pair
-
Combines two collections into a collection of pairs.
- combine(BiFunction<? super A, ? super B, ? extends C>) - Method in class com.bluegosling.tuples.Pair
-
Combines the two values in this pair into a single result using the specified function.
- combine(Quadruple<? extends Collection<T>, ? extends Collection<U>, ? extends Collection<V>, ? extends Collection<W>>) - Static method in class com.bluegosling.tuples.Quadruple
-
Combines a quartet of collections into a collection of quartets.
- combine(Collection<T>, Collection<U>, Collection<V>, Collection<W>) - Static method in class com.bluegosling.tuples.Quadruple
-
Combines four collections into a collection of quartets.
- combine(Quintuple<? extends Collection<T>, ? extends Collection<U>, ? extends Collection<V>, ? extends Collection<W>, ? extends Collection<X>>) - Static method in class com.bluegosling.tuples.Quintuple
-
Combines a quintet of collections into a collection of quintets.
- combine(Collection<T>, Collection<U>, Collection<V>, Collection<W>, Collection<X>) - Static method in class com.bluegosling.tuples.Quintuple
-
Combines five collections into a collection of quintets.
- combine(Triple<? extends Collection<T>, ? extends Collection<U>, ? extends Collection<V>>) - Static method in class com.bluegosling.tuples.Triple
-
Combines a trio of collections into a collection of trios.
- combine(Collection<T>, Collection<U>, Collection<V>) - Static method in class com.bluegosling.tuples.Triple
-
Combines three collections into a collection of trios.
- combine(TriFunction<? super A, ? super B, ? super C, ? extends D>) - Method in class com.bluegosling.tuples.Triple
-
Combines the three values in this trio into a single result using the specified function.
- combinedSize() - Method in class com.bluegosling.collections.concurrent.SharedCapacityDequeFactory
-
Returns the combined size of all queues.
- combineWith(FluentFuture<U>, BiFunction<? super T, ? super U, ? extends V>) - Method in interface com.bluegosling.concurrent.fluent.FluentFuture
-
Combines this future with another by applying a function.
- combineWith(FluentFuture<U>, FluentFuture<V>, TriFunction<? super T, ? super U, ? super V, ? extends W>) - Method in interface com.bluegosling.concurrent.fluent.FluentFuture
-
Combines this future with two other futures by applying a function.
- combineWith(Result<U, E>, BiFunction<? super T, ? super U, ? extends V>) - Method in class com.bluegosling.result.Result
-
Combines this result with another.
- combineWith(Result<U, E>, Result<V, E>, TriFunction<? super T, ? super U, ? super V, ? extends W>) - Method in class com.bluegosling.result.Result
-
Combines this result with two others.
- CombiningFluentFuture<T> - Class in com.bluegosling.concurrent.fluent
-
An abstract future that combines the results from other futures.
- CombiningFluentFuture(Collection<FluentFuture<?>>) - Constructor for class com.bluegosling.concurrent.fluent.CombiningFluentFuture
-
Constructs a new combining future.
- commute(Function<? super T, ? extends T>) - Method in class com.bluegosling.concurrent.atoms.TransactionalAtom
-
Enqueues a commutative transform operation.
- compact() - Method in class com.bluegosling.collections.lists.ArrayBackedLinkedList
-
Compacts the internal buffers for the list.
- CompactBitwiseTrie<K,V> - Class in com.bluegosling.collections.tries
-
- CompactBitwiseTrie(BitConverter<? super K>) - Constructor for class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- CompactBitwiseTrie(BitConverter<? super K>, Comparator<? super K>) - Constructor for class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- CompactBitwiseTrie(BitConverter<? super K>, Map<? extends K, ? extends V>) - Constructor for class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- CompactBitwiseTrie(BitConverter<? super K>, Comparator<? super K>, Map<? extends K, ? extends V>) - Constructor for class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- CompactStringTrie<V> - Class in com.bluegosling.collections.tries
-
- CompactStringTrie() - Constructor for class com.bluegosling.collections.tries.CompactStringTrie
-
- comparator - Variable in class com.bluegosling.collections.AbstractNavigableMap
-
The map's current comparator.
- comparator() - Method in class com.bluegosling.collections.AbstractNavigableMap
- comparator() - Method in class com.bluegosling.collections.AbstractNavigableMap.KeySet
-
- comparator() - Method in class com.bluegosling.collections.concurrent.ConcurrentSkipListOrderedQueue
-
- comparator(Comparator<? super E>) - Method in class com.bluegosling.collections.concurrent.ConcurrentSortedArraySet.Builder
-
Sets the comparator used to sort items in the set.
- comparator() - Method in class com.bluegosling.collections.concurrent.ConcurrentSortedArraySet
- comparator() - Method in class com.bluegosling.collections.concurrent.DoubleInstanceLockedTreeMap
-
- comparator() - Method in class com.bluegosling.collections.concurrent.LockFreeSkipListBlockingQueue
-
- comparator() - Method in class com.bluegosling.collections.DescendingMap
-
- comparator() - Method in class com.bluegosling.collections.DescendingSet
-
- comparator() - Method in class com.bluegosling.collections.FilteringSortedMap
-
- comparator() - Method in class com.bluegosling.collections.FilteringSortedSet
-
- comparator() - Method in class com.bluegosling.collections.maps.WeightBalancedTreeMap
-
- comparator(Comparator<? super E>) - Static method in class com.bluegosling.collections.MoreIterables
-
Returns a comparator of iterables based on the given comparator of elements.
- comparator() - Method in class com.bluegosling.collections.queues.FibonacciHeapOrderedQueue
-
Returns the comparator used to sort elements in the queue.
- comparator() - Method in interface com.bluegosling.collections.queues.OrderedQueue
-
The comparator used to compare elements and determine their order.
- comparator() - Method in interface com.bluegosling.collections.queues.PriorityQueue
-
Gets the comparator for this queue.
- comparator() - Method in class com.bluegosling.collections.queues.SetBackedOrderedQueue
-
- comparator() - Method in class com.bluegosling.collections.queues.SkewHeapOrderedQueue
-
- comparator() - Method in class com.bluegosling.collections.sets.SortedArraySet
- comparator() - Method in class com.bluegosling.collections.tries.ArrayMappedBitwiseTrie
-
- comparator() - Method in class com.bluegosling.collections.tries.ArrayMappedStringTrie
-
- comparator() - Method in class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- comparator() - Method in class com.bluegosling.collections.tries.SimpleBitwiseTrie
-
- comparator() - Method in class com.bluegosling.collections.tries.SimpleStringTrie
-
- COMPARATOR - Static variable in interface com.bluegosling.concurrent.Scheduled
-
An accurate and precise comparator of
Delayed
objects that will compare the scheduled
nano-time if both objects are instances of
Scheduled
.
- compareAndSet(boolean, boolean) - Method in class com.bluegosling.concurrent.contended.ContendedBoolean
-
Atomically sets the value to the given updated value if the current value ==
the
expected value.
- compareAndSet(int, int) - Method in class com.bluegosling.concurrent.contended.ContendedInteger
-
Atomically sets the value to the given updated value if the current value ==
the
expected value.
- compareAndSet(long, long) - Method in class com.bluegosling.concurrent.contended.ContendedLong
-
Atomically sets the value to the given updated value if the current value ==
the
expected value.
- compareAndSet(V, V) - Method in class com.bluegosling.concurrent.contended.ContendedReference
-
Atomically sets the value to the given updated value if the current value ==
the
expected value.
- compareAndSetState(S, S) - Method in class com.bluegosling.concurrent.AbstractQueuedReferenceSynchronizer
-
Atomically sets synchronization state to the given updated value if the current state value
equals the expected value.
- compareTo(JavaClass) - Method in class com.bluegosling.buildgen.JavaClass
-
- compareTo(JavaPackage) - Method in class com.bluegosling.buildgen.JavaPackage
-
- compareTo(Duration) - Method in class com.bluegosling.concurrent.Duration
-
Returns a value less than zero, equal to zero, or greater than zero as this duration is
shorter than, equal to, or longer than the specified duration.
- compareTo(Delayed) - Method in class com.bluegosling.concurrent.fluent.FluentScheduledFutureTask
-
- compareTo(EnumType.EnumElement<T>) - Method in interface com.bluegosling.reflect.EnumType.EnumElement
-
Compares this element to another.
- CompilationContext - Class in com.bluegosling.apt.testing
-
The context for invoking a compiler and running annotation processors.
- CompilationContext() - Constructor for class com.bluegosling.apt.testing.CompilationContext
-
Constructs a new context
- CompilationContext.TaskBuilder - Interface in com.bluegosling.apt.testing
-
Builds a task to run in this compilation context.
- CompilationContext.TaskBuilderWithProcessor - Interface in com.bluegosling.apt.testing
-
Builds a task to run in this compilation context.
- CompilationFailedException - Exception in com.bluegosling.apt.testing
-
An exception thrown if compilation fails.
- CompilationFailedException(String, Collection<Diagnostic<JavaFileObject>>) - Constructor for exception com.bluegosling.apt.testing.CompilationFailedException
-
Creates a new exception with the specified message and set of error diagnostics.
- CompilationFailedException(String, Throwable, Collection<Diagnostic<JavaFileObject>>) - Constructor for exception com.bluegosling.apt.testing.CompilationFailedException
-
Creates a new exception with the specified message, cause, and set of error diagnostics.
- CompilationFailedException(Throwable, Collection<Diagnostic<JavaFileObject>>) - Constructor for exception com.bluegosling.apt.testing.CompilationFailedException
-
Creates a new exception with the specified cause and set of error diagnostics.
- CompilationUnit - Class in com.bluegosling.buildgen
-
- CompletableExecutorService - Interface in com.bluegosling.concurrent.executors
-
- CompletableFutures - Class in com.bluegosling.concurrent.futures
-
- complete(T) - Method in class com.bluegosling.concurrent.futures.ReadOnlyCompletableFuture
-
- completedFuture(T) - Static method in interface com.bluegosling.concurrent.fluent.FluentFuture
-
Returns a future that has already successfully completed with the specified value.
- completeExceptionally(Throwable) - Method in class com.bluegosling.concurrent.futures.ReadOnlyCompletableFuture
-
- CompletionStageFuture<T> - Interface in com.bluegosling.concurrent.futures
-
- componentComparator() - Method in class com.bluegosling.collections.tries.ArrayMappedBitwiseTrie
-
- componentComparator() - Method in class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- componentComparator() - Method in class com.bluegosling.collections.tries.DescendingCompositeTrie
-
- componentComparator() - Method in class com.bluegosling.collections.tries.DescendingSequenceTrie
-
- componentComparator() - Method in interface com.bluegosling.collections.tries.NavigableCompositeTrie
-
- componentComparator() - Method in interface com.bluegosling.collections.tries.NavigableSequenceTrie
-
- componentComparator() - Method in class com.bluegosling.collections.tries.SimpleBitwiseTrie
-
- componentizer() - Method in class com.bluegosling.collections.tries.ArrayMappedBitwiseTrie
-
- componentizer() - Method in class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- Componentizer<T,U> - Interface in com.bluegosling.collections.tries
-
An interface used to break a composite object up into its constituent components.
- componentizer() - Method in interface com.bluegosling.collections.tries.CompositeTrie
-
The object used to break up single key values into a sequence of components.
- componentizer() - Method in class com.bluegosling.collections.tries.DescendingCompositeTrie
-
- componentizer() - Method in class com.bluegosling.collections.tries.SimpleBitwiseTrie
-
- componentizer() - Method in class com.bluegosling.collections.tries.SimpleStringTrie
-
- compose(BooleanUnaryOperator) - Method in interface com.bluegosling.function.BooleanUnaryOperator
-
Returns a composed operator that first applies the before
operator to its input, and
then applies this operator to the result.
- compose(ByteUnaryOperator) - Method in interface com.bluegosling.function.ByteUnaryOperator
-
Returns a composed operator that first applies the before
operator to its input, and
then applies this operator to the result.
- compose(CharUnaryOperator) - Method in interface com.bluegosling.function.CharUnaryOperator
-
Returns a composed operator that first applies the before
operator to its input, and
then applies this operator to the result.
- compose(FloatUnaryOperator) - Method in interface com.bluegosling.function.FloatUnaryOperator
-
Returns a composed operator that first applies the before
operator to its input, and
then applies this operator to the result.
- compose(Function<? super A, ? extends B>, Function<? super B, ? extends C>) - Static method in class com.bluegosling.function.Functions
-
Returns a function that composes two other functions.
- compose(BiFunction<? super A1, ? super A2, ? extends B>, Function<? super B, ? extends C>) - Static method in class com.bluegosling.function.Functions
-
Returns a function that composes a two-argument and single-argument function.
- compose(Function<? super A1, ? extends B1>, Function<? super A2, ? extends B2>, BiFunction<? super B1, ? super B2, ? extends C>) - Static method in class com.bluegosling.function.Functions
-
Returns a function that composes one two-argument and two single-argument functions.
- compose(TriFunction<? super A1, ? super A2, ? super A3, ? extends B>, Function<? super B, ? extends C>) - Static method in class com.bluegosling.function.Functions
-
Returns a function that composes a three-argument and single-argument function.
- compose(Function<? super A1, ? extends B1>, Function<? super A2, ? extends B2>, Function<? super A3, ? extends B3>, TriFunction<? super B1, ? super B2, ? super B3, ? extends C>) - Static method in class com.bluegosling.function.Functions
-
Returns a function that composes one three-argument and three single-argument functions.
- compose(Function<? super V, ? extends T>) - Method in interface com.bluegosling.function.PartialFunction
-
Returns a composed function that first applies the before
function to its input, and then applies this function to the result.
- compose(ShortUnaryOperator) - Method in interface com.bluegosling.function.ShortUnaryOperator
-
Returns a composed operator that first applies the before
operator to its input, and
then applies this operator to the result.
- CompositeTrie<K,C,V> - Interface in com.bluegosling.collections.tries
-
A
trie whose keys are composite objects.
- compositeVerifier(List<ObjectVerifier<T>>) - Static method in class com.bluegosling.testing.ObjectVerifiers
-
Returns an object that performs all specified verifications.
- compositeVerifier(ObjectVerifier<T>...) - Static method in class com.bluegosling.testing.ObjectVerifiers
-
Returns an object that performs all specified verifications.
- Computation<T> - Class in com.bluegosling.graph
-
A single instance of the computation graph.
- ComputationFactory - Class in com.bluegosling.graph
-
- ComputationFactory.Builder - Class in com.bluegosling.graph
-
- compute(Map.Entry<K, V>) - Method in class com.bluegosling.collections.AbstractNavigableMap.BaseIteratorImpl
-
Computes the value fetched from this iterator based on the given map entry.
- compute(Map.Entry<K, V>) - Method in class com.bluegosling.collections.AbstractNavigableMap.DescendingKeyIteratorImpl
-
Computes the value fetched from this iterator based on the given map entry.
- compute(Map.Entry<K, V>) - Method in class com.bluegosling.collections.AbstractNavigableMap.EntryIteratorImpl
-
Computes the value fetched from this iterator based on the given map entry.
- compute(Map.Entry<K, V>) - Method in class com.bluegosling.collections.AbstractNavigableMap.KeyIteratorImpl
-
Computes the value fetched from this iterator based on the given map entry.
- compute(Map.Entry<K, V>) - Method in class com.bluegosling.collections.AbstractNavigableMap.ValueIteratorImpl
-
Computes the value fetched from this iterator based on the given map entry.
- compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class com.bluegosling.collections.concurrent.DoubleInstanceLockedTreeMap
-
- compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class com.bluegosling.collections.immutable.AbstractImmutableMap
-
Deprecated.
- compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in interface com.bluegosling.collections.immutable.PersistentMap
-
Deprecated.
- compute(Map.Entry<K, V>) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.EntryListIteratorImpl
-
- compute(Map.Entry<K, V>) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.KeyListIteratorImpl
-
- compute(Map.Entry<K, V>) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.ValueListIteratorImpl
-
- compute(Transaction) - Method in interface com.bluegosling.concurrent.atoms.Transaction.Computation
-
Executes the computation in the specified transaction.
- compute(Transaction.Computation<T, X>) - Static method in class com.bluegosling.concurrent.atoms.Transaction
-
Runs the specified computation in a transaction and returns the result.
- compute(Transaction.Computation<T, X>) - Method in class com.bluegosling.concurrent.atoms.Transaction.Runner
-
Performs the specified computation in a transaction and returns its result.
- compute() - Method in class com.bluegosling.graph.Computation
-
Executes the computation.
- computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class com.bluegosling.collections.concurrent.DoubleInstanceLockedTreeMap
-
- computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class com.bluegosling.collections.immutable.AbstractImmutableMap
-
Deprecated.
- computeIfAbsent(K, Function<? super K, ? extends V>) - Method in interface com.bluegosling.collections.immutable.PersistentMap
-
Deprecated.
- computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class com.bluegosling.collections.concurrent.DoubleInstanceLockedTreeMap
-
- computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class com.bluegosling.collections.immutable.AbstractImmutableMap
-
Deprecated.
- computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in interface com.bluegosling.collections.immutable.PersistentMap
-
Deprecated.
- computeNextStartTime(FluentRepeatingFuture<? extends T>, long) - Method in interface com.bluegosling.concurrent.fluent.Rescheduler
-
Computes the next scheduled execution time for a repeating task, in system nano-time.
- computeNonIdempotent(Transaction.Computation<T, X>) - Static method in class com.bluegosling.concurrent.atoms.Transaction
-
Runs the specified computation in a transaction and returns the result.
- computeNonIdempotent(Transaction.Computation<T, X>) - Method in class com.bluegosling.concurrent.atoms.Transaction.Runner
-
Performs the specified computation in a transaction and returns its result.
- computeValue() - Method in class com.bluegosling.concurrent.fluent.CombiningFluentFuture
-
Computes the combined value of this future once all components have completed.
- concat(BitSequence...) - Static method in class com.bluegosling.collections.bits.BitSequences
-
Concatenates multiple sequences together.
- concat(Spliterator<? extends T>, Spliterator<? extends T>) - Static method in class com.bluegosling.collections.MoreSpliterators
-
Returns a spliterator that emits the elements of one spliterator concatenated with the
elements of another.
- concat(Spliterator<? extends T>...) - Static method in class com.bluegosling.collections.MoreSpliterators
-
Returns a spliterator that emits the elements of the given spliterators, concatenated all
together.
- concat(Iterable<? extends Spliterator<? extends T>>) - Static method in class com.bluegosling.collections.MoreSpliterators
-
Returns a spliterator that emits the elements of the given spliterators, concatenated all
together.
- concat(Stream<? extends T>) - Method in interface com.bluegosling.streams.FluentStream
-
Returns a stream that is the concatenation of this stream and then given stream.
- concat(Iterable<? extends Stream<? extends T>>) - Method in interface com.bluegosling.streams.FluentStream
-
Returns a stream that is the concatenation of this stream, followed by all of the given
streams.
- concatArray() - Static method in class com.bluegosling.function.Operators
-
- concatArray(Class<T>) - Static method in class com.bluegosling.function.Operators
-
- concatBooleanArray() - Static method in class com.bluegosling.function.Operators
-
- concatByteArray() - Static method in class com.bluegosling.function.Operators
-
- concatCharArray() - Static method in class com.bluegosling.function.Operators
-
- concatDoubleArray() - Static method in class com.bluegosling.function.Operators
-
- concatFloatArray() - Static method in class com.bluegosling.function.Operators
-
- concatIntArray() - Static method in class com.bluegosling.function.Operators
-
- concatList() - Static method in class com.bluegosling.function.Operators
-
- concatLongArray() - Static method in class com.bluegosling.function.Operators
-
- concatShortArray() - Static method in class com.bluegosling.function.Operators
-
- concurrency(int) - Method in class com.bluegosling.collections.concurrent.ConcurrentSortedArraySet.Builder
-
Sets the concurrency level for the set.
- concurrency(int) - Method in class com.bluegosling.collections.concurrent.ShardedConcurrentSets.Builder
-
Sets the concurrency level for the set that will be created.
- ConcurrentList<E> - Interface in com.bluegosling.collections.concurrent
-
A list that is thread-safe and supports concurrent mutations.
- ConcurrentSkipListOrderedQueue<E> - Class in com.bluegosling.collections.concurrent
-
- ConcurrentSkipListOrderedQueue() - Constructor for class com.bluegosling.collections.concurrent.ConcurrentSkipListOrderedQueue
-
- ConcurrentSkipListOrderedQueue(Comparator<? super E>) - Constructor for class com.bluegosling.collections.concurrent.ConcurrentSkipListOrderedQueue
-
- ConcurrentSortedArraySet<E> - Class in com.bluegosling.collections.concurrent
-
- ConcurrentSortedArraySet() - Constructor for class com.bluegosling.collections.concurrent.ConcurrentSortedArraySet
-
Constructs a new empty set.
- ConcurrentSortedArraySet(Comparator<? super E>) - Constructor for class com.bluegosling.collections.concurrent.ConcurrentSortedArraySet
-
Constructs a new set that will use the specified comparator to sort elements.
- ConcurrentSortedArraySet(Collection<? extends E>) - Constructor for class com.bluegosling.collections.concurrent.ConcurrentSortedArraySet
-
Constructs a new set with the specified contents.
- ConcurrentSortedArraySet(SortedSet<E>) - Constructor for class com.bluegosling.collections.concurrent.ConcurrentSortedArraySet
-
Constructs a new set that will have the same contents and comparator as the specified set.
- ConcurrentSortedArraySet.Builder<E> - Class in com.bluegosling.collections.concurrent
-
A builder class for constructing instances of ConcurrentSortedArraySet
.
- ConcurrentStack<E> - Interface in com.bluegosling.collections.concurrent
-
- configureMethod(MethodSignature) - Method in class com.bluegosling.testing.InterfaceVerifier
-
Returns the configuration for the specified method.
- configureMethods(MethodSignature...) - Method in class com.bluegosling.testing.InterfaceVerifier
-
Returns a configurator for configuring multiple methods at the same time.
- ConsList<E> - Interface in com.bluegosling.collections.immutable
-
- contains(Object) - Method in class com.bluegosling.collections.AbstractNavigableMap.EntrySet
-
- contains(Object) - Method in class com.bluegosling.collections.AbstractNavigableMap.KeySet
-
- contains(Iterator<?>, Object) - Static method in class com.bluegosling.collections.CollectionUtils
-
- contains(Object) - Method in class com.bluegosling.collections.concurrent.ConcurrentSortedArraySet
- contains(Object) - Method in class com.bluegosling.collections.concurrent.PersistentListBackedConcurrentList
-
- contains(Object) - Method in class com.bluegosling.collections.DescendingSet
-
- contains(Object) - Method in class com.bluegosling.collections.FilteringCollection
-
- contains(Object) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfBoolean
-
- contains(Object) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfByte
-
- contains(Object) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfChar
-
- contains(Object) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfDouble
-
- contains(Object) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfFloat
-
- contains(Object) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfInt
-
- contains(Object) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfLong
-
- contains(Object) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfShort
-
- contains(Object) - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- contains(Object) - Method in class com.bluegosling.collections.sets.RandomAccessSetList
-
- contains(Object) - Method in class com.bluegosling.collections.sets.SortedArraySet
- contains(Object) - Method in class com.bluegosling.collections.TransformingCollection.Bidi
-
- contains(Object) - Method in class com.bluegosling.collections.TransformingCollection
-
- contains(Object) - Method in class com.bluegosling.collections.TransformingList.Bidi
-
- contains(Object) - Method in class com.bluegosling.tuples.Empty
-
- contains(Object) - Method in class com.bluegosling.tuples.NTuple
-
- contains(Object) - Method in class com.bluegosling.tuples.Pair
-
- contains(Object) - Method in class com.bluegosling.tuples.Quadruple
-
- contains(Object) - Method in class com.bluegosling.tuples.Quintuple
-
- contains(Object) - Method in class com.bluegosling.tuples.Single
-
- contains(Object) - Method in class com.bluegosling.tuples.Triple
-
- contains(Object) - Method in interface com.bluegosling.tuples.Tuple
-
Determines if this tuple contains the specified object.
- containsAll(Collection<?>, Collection<?>) - Static method in class com.bluegosling.collections.CollectionUtils
-
- containsAll(Collection<?>) - Method in class com.bluegosling.collections.concurrent.ConcurrentSortedArraySet
- containsAll(Collection<?>) - Method in class com.bluegosling.collections.concurrent.PersistentListBackedConcurrentList
-
- containsAll(Collection<?>) - Method in class com.bluegosling.collections.DescendingSet
-
- containsAll(Collection<?>) - Method in class com.bluegosling.collections.FilteringCollection
-
- containsAll(Collection<?>) - Method in class com.bluegosling.collections.sets.RandomAccessSetList
-
- containsAll(Collection<?>) - Method in class com.bluegosling.collections.sets.SortedArraySet
- containsAll(Collection<?>) - Method in class com.bluegosling.collections.TransformingCollection.Bidi
-
- containsAll(Collection<?>) - Method in class com.bluegosling.collections.TransformingCollection
-
- containsAll(Collection<?>) - Method in class com.bluegosling.collections.TransformingList.Bidi
-
- containsBoolean(boolean) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfBoolean
-
- containsBoolean(boolean) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfBoolean
-
- containsByte(byte) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfByte
-
- containsByte(byte) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfByte
-
- containsCell(Object, Object) - Method in interface com.bluegosling.collections.tables.Table2D
-
- containsCell(Object, Object, Object) - Method in interface com.bluegosling.collections.tables.Table3D
-
- containsCell(Object, Object, Object, Object) - Method in interface com.bluegosling.collections.tables.Table4D
-
- containsCell(Object, Object, Object, Object, Object) - Method in interface com.bluegosling.collections.tables.Table5D
-
- containsChar(char) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfChar
-
- containsChar(char) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfChar
-
- containsColumn(Object) - Method in interface com.bluegosling.collections.tables.Table2D
-
- containsColumn(Object, Object) - Method in interface com.bluegosling.collections.tables.Table3D
-
- containsColumn(Object, Object, Object) - Method in interface com.bluegosling.collections.tables.Table4D
-
- containsColumn(Object, Object, Object, Object) - Method in interface com.bluegosling.collections.tables.Table5D
-
- containsColumnKey(Object) - Method in interface com.bluegosling.collections.tables.Table3D
-
- containsColumnKey(Object) - Method in interface com.bluegosling.collections.tables.Table4D
-
- containsColumnKey(Object) - Method in interface com.bluegosling.collections.tables.Table5D
-
- containsDouble(double) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfDouble
-
- containsDouble(double) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfDouble
-
- containsElement(Object) - Method in interface com.bluegosling.collections.queues.PriorityQueue
-
Determines if the specified object is an element in this queue.
- containsFloat(float) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfFloat
-
- containsFloat(float) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfFloat
-
- containsInt(int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfInt
-
- containsInt(int) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfInt
-
- containsKey(Object) - Method in class com.bluegosling.collections.AbstractNavigableMap
- containsKey(Object) - Method in class com.bluegosling.collections.concurrent.DoubleInstanceLockedTreeMap
-
- containsKey(Object) - Method in class com.bluegosling.collections.concurrent.PersistentMapBackedConcurrentMap
-
- containsKey(Object) - Method in class com.bluegosling.collections.DescendingMap
-
- containsKey(Object) - Method in class com.bluegosling.collections.FilteringMap
-
- containsKey(Object) - Method in class com.bluegosling.collections.immutable.HamtPersistentMap
-
- containsKey(K) - Method in class com.bluegosling.collections.lists.AssociativeArrayList
-
- containsKey(K) - Method in interface com.bluegosling.collections.lists.AssociativeList
-
Determines if the specified key is associated with an element in the list.
- containsKey(Object) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.SubMapByIndices
-
- containsKey(Object) - Method in class com.bluegosling.collections.maps.HamtMap
-
- containsKey(Object) - Method in class com.bluegosling.collections.maps.LinearHashingMap
-
- containsKey(Object) - Method in class com.bluegosling.collections.maps.WeightBalancedTreeMap
-
- containsKey(Object) - Method in class com.bluegosling.collections.TransformingMap.Bidi
-
- containsKey(Object) - Method in class com.bluegosling.collections.TransformingMap
-
- containsKey(Object) - Method in class com.bluegosling.collections.TransformingMap.ReadOnly.ValuesOnly
-
- containsKey(Object) - Method in class com.bluegosling.collections.TransformingMap.ValuesOnly
-
- containsKey(Object) - Method in class com.bluegosling.collections.tries.ArrayMappedBitwiseTrie
-
- containsKey(Object) - Method in class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- containsKey(Object) - Method in class com.bluegosling.collections.tries.SimpleBitwiseTrie
-
- containsLong(long) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfLong
-
- containsLong(long) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfLong
-
- containsPage(Object) - Method in interface com.bluegosling.collections.tables.Table3D
-
- containsPage(Object, Object) - Method in interface com.bluegosling.collections.tables.Table4D
-
- containsPage(Object, Object, Object) - Method in interface com.bluegosling.collections.tables.Table5D
-
- containsPageKey(Object) - Method in interface com.bluegosling.collections.tables.Table4D
-
- containsPageKey(Object) - Method in interface com.bluegosling.collections.tables.Table5D
-
- containsPriority(Object) - Method in interface com.bluegosling.collections.queues.PriorityQueue
-
Determines if the specified object matches the priority of any element in this queue.
- containsRow(Object) - Method in interface com.bluegosling.collections.tables.Table2D
-
- containsRow(Object, Object) - Method in interface com.bluegosling.collections.tables.Table3D
-
- containsRow(Object, Object, Object) - Method in interface com.bluegosling.collections.tables.Table4D
-
- containsRow(Object, Object, Object, Object) - Method in interface com.bluegosling.collections.tables.Table5D
-
- containsRowKey(Object) - Method in interface com.bluegosling.collections.tables.Table3D
-
- containsRowKey(Object) - Method in interface com.bluegosling.collections.tables.Table4D
-
- containsRowKey(Object) - Method in interface com.bluegosling.collections.tables.Table5D
-
- containsSection(Object) - Method in interface com.bluegosling.collections.tables.Table4D
-
- containsSection(Object, Object) - Method in interface com.bluegosling.collections.tables.Table5D
-
- containsSectionKey(Object) - Method in interface com.bluegosling.collections.tables.Table5D
-
- containsShort(short) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfShort
-
- containsShort(short) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfShort
-
- containsValue(Object) - Method in class com.bluegosling.collections.AbstractNavigableMap
- containsValue(Object) - Method in class com.bluegosling.collections.concurrent.DoubleInstanceLockedTreeMap
-
- containsValue(Object) - Method in class com.bluegosling.collections.concurrent.PersistentMapBackedConcurrentMap
-
- containsValue(Object) - Method in class com.bluegosling.collections.DescendingMap
-
- containsValue(Object) - Method in class com.bluegosling.collections.FilteringMap
-
- containsValue(Object) - Method in class com.bluegosling.collections.immutable.HamtPersistentMap
-
- containsValue(Object) - Method in class com.bluegosling.collections.maps.HamtMap
-
- containsValue(Object) - Method in class com.bluegosling.collections.maps.WeightBalancedTreeMap
-
- containsValue(Object) - Method in class com.bluegosling.collections.TransformingMap
-
- containsValue(Object) - Method in class com.bluegosling.collections.tries.ArrayMappedBitwiseTrie
-
- containsValue(Object) - Method in class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- containsVolume(Object) - Method in interface com.bluegosling.collections.tables.Table5D
-
- ContendedBoolean - Class in com.bluegosling.concurrent.contended
-
Like an
AtomicBoolean
, except uses padding to reduce cache contention (aka false-sharing)
with writes to nearby memory locations.
- ContendedBoolean(boolean) - Constructor for class com.bluegosling.concurrent.contended.ContendedBoolean
-
- ContendedBoolean() - Constructor for class com.bluegosling.concurrent.contended.ContendedBoolean
-
- ContendedInteger - Class in com.bluegosling.concurrent.contended
-
Like an
AtomicInteger
, except uses padding to reduce cache contention (aka false-sharing)
with writes to nearby memory locations.
- ContendedInteger(int) - Constructor for class com.bluegosling.concurrent.contended.ContendedInteger
-
- ContendedInteger() - Constructor for class com.bluegosling.concurrent.contended.ContendedInteger
-
- ContendedLong - Class in com.bluegosling.concurrent.contended
-
Like an
AtomicLong
, except uses padding to reduce cache contention (aka false-sharing)
with writes to nearby memory locations.
- ContendedLong(long) - Constructor for class com.bluegosling.concurrent.contended.ContendedLong
-
- ContendedLong() - Constructor for class com.bluegosling.concurrent.contended.ContendedLong
-
- ContendedReference<V> - Class in com.bluegosling.concurrent.contended
-
Like an
AtomicReference
, except uses padding to reduce cache contention (aka
false-sharing) with writes to nearby memory locations.
- ContendedReference(V) - Constructor for class com.bluegosling.concurrent.contended.ContendedReference
-
- ContendedReference() - Constructor for class com.bluegosling.concurrent.contended.ContendedReference
-
- ContextPropagatingExecutor - Class in com.bluegosling.concurrent.executors
-
An executor that allows for propagation of context from submitting threads to worker threads.
- ContextPropagatingExecutor(Executor, Iterable<? extends ContextPropagator<?>>) - Constructor for class com.bluegosling.concurrent.executors.ContextPropagatingExecutor
-
Constructs a new context propagating executor.
- ContextPropagatingExecutorService - Class in com.bluegosling.concurrent.executors
-
An executor service that allows for propagation of context from submitting threads to worker
threads.
- ContextPropagatingExecutorService(ExecutorService, Iterable<ContextPropagator<?>>) - Constructor for class com.bluegosling.concurrent.executors.ContextPropagatingExecutorService
-
Constructs a new context propagating executor service.
- ContextPropagatingScheduledExecutorService - Class in com.bluegosling.concurrent.executors
-
A scheduled executor service that allows for propagation of context from submitting threads to
worker threads.
- ContextPropagatingScheduledExecutorService(ScheduledExecutorService, Iterable<ContextPropagator<?>>) - Constructor for class com.bluegosling.concurrent.executors.ContextPropagatingScheduledExecutorService
-
Constructs a new context propagating scheduled executor service.
- ContextPropagator<T> - Interface in com.bluegosling.concurrent.executors
-
An object that helps propagate context from one thread to another.
- contractFifth(Function<? super E, AnyOfFour<A, B, C, D>>) - Method in class com.bluegosling.choice.AnyOfFive
-
- contractFifth(Function<? super E, Union4<A, B, C, D>>) - Method in class com.bluegosling.choice.Union5
-
- contractFirst(Function<? super A, AnyOfFour<B, C, D, E>>) - Method in class com.bluegosling.choice.AnyOfFive
-
- contractFirst(Function<? super A, AnyOfThree<B, C, D>>) - Method in class com.bluegosling.choice.AnyOfFour
-
- contractFirst(Function<? super A, Either<B, C>>) - Method in class com.bluegosling.choice.AnyOfThree
-
- contractFirst(Function<? super A, ? extends B>) - Method in class com.bluegosling.choice.Either
-
Contracts this choice from two options to one by removing the first option.
- contractFirst(Function<? super A, ? extends B>) - Method in class com.bluegosling.choice.Union2
-
- contractFirst(Function<? super A, Union2<B, C>>) - Method in class com.bluegosling.choice.Union3
-
- contractFirst(Function<? super A, Union3<B, C, D>>) - Method in class com.bluegosling.choice.Union4
-
- contractFirst(Function<? super A, Union4<B, C, D, E>>) - Method in class com.bluegosling.choice.Union5
-
- contractFourth(Function<? super D, AnyOfFour<A, B, C, E>>) - Method in class com.bluegosling.choice.AnyOfFive
-
- contractFourth(Function<? super D, AnyOfThree<A, B, C>>) - Method in class com.bluegosling.choice.AnyOfFour
-
- contractFourth(Function<? super D, Union3<A, B, C>>) - Method in class com.bluegosling.choice.Union4
-
- contractFourth(Function<? super D, Union4<A, B, C, E>>) - Method in class com.bluegosling.choice.Union5
-
- contractSecond(Function<? super B, AnyOfFour<A, C, D, E>>) - Method in class com.bluegosling.choice.AnyOfFive
-
- contractSecond(Function<? super B, AnyOfThree<A, C, D>>) - Method in class com.bluegosling.choice.AnyOfFour
-
- contractSecond(Function<? super B, Either<A, C>>) - Method in class com.bluegosling.choice.AnyOfThree
-
- contractSecond(Function<? super B, ? extends A>) - Method in class com.bluegosling.choice.Either
-
Contracts this choice from two options to one by removing the second option.
- contractSecond(Function<? super B, ? extends A>) - Method in class com.bluegosling.choice.Union2
-
- contractSecond(Function<? super B, Union2<A, C>>) - Method in class com.bluegosling.choice.Union3
-
- contractSecond(Function<? super B, Union3<A, C, D>>) - Method in class com.bluegosling.choice.Union4
-
- contractSecond(Function<? super B, Union4<A, C, D, E>>) - Method in class com.bluegosling.choice.Union5
-
- contractThird(Function<? super C, AnyOfFour<A, B, D, E>>) - Method in class com.bluegosling.choice.AnyOfFive
-
- contractThird(Function<? super C, AnyOfThree<A, B, D>>) - Method in class com.bluegosling.choice.AnyOfFour
-
- contractThird(Function<? super C, Either<A, B>>) - Method in class com.bluegosling.choice.AnyOfThree
-
- contractThird(Function<? super C, Union2<A, B>>) - Method in class com.bluegosling.choice.Union3
-
- contractThird(Function<? super C, Union3<A, B, D>>) - Method in class com.bluegosling.choice.Union4
-
- contractThird(Function<? super C, Union4<A, B, D, E>>) - Method in class com.bluegosling.choice.Union5
-
- convert(I, Caster<?>) - Method in interface com.bluegosling.reflect.caster.Converter
-
Converts an object.
- Converter<I,O> - Interface in com.bluegosling.reflect.caster
-
Converts a value from one form to another, possibly with the aid of a
Caster
.
- copyFrom(InterfaceVerifier<T>) - Method in class com.bluegosling.testing.InterfaceVerifier
-
Copies the configuration from another verifier.
- copyOf(SortedSet<E>) - Method in class com.bluegosling.collections.concurrent.ConcurrentSortedArraySet.Builder
-
Sets both the initial contents of the set and the comparator used to sort
elements to those of the specified
SortedSet
.
- copyToArray(Iterable<?>, Object[]) - Static method in class com.bluegosling.collections.CollectionUtils
-
Fills the specified array using the contents of the specified collection.
- count() - Method in class com.bluegosling.collections.CircularBuffer
-
Returns the number of items in the buffer.
- countDown() - Method in class com.bluegosling.concurrent.UpAndDownLatch
-
Removes a single reference from the latch.
- countDown(int) - Method in class com.bluegosling.concurrent.UpAndDownLatch
-
Removes the given number of single references from the latch.
- countUp() - Method in class com.bluegosling.concurrent.UpAndDownLatch
-
Adds a single reference to the latch.
- countUp(int) - Method in class com.bluegosling.concurrent.UpAndDownLatch
-
Adds the given number of references to the latch.
- create() - Method in class com.bluegosling.collections.concurrent.ShardedConcurrentSets.Builder
-
Creates a set.
- create() - Static method in class com.bluegosling.collections.immutable.AmtPersistentList
-
- create(Iterable<? extends E>) - Static method in class com.bluegosling.collections.immutable.AmtPersistentList
-
- create() - Static method in class com.bluegosling.collections.immutable.HamtPersistentMap
-
- create(Map<? extends K, ? extends V>) - Static method in class com.bluegosling.collections.immutable.HamtPersistentMap
-
- create() - Static method in class com.bluegosling.collections.immutable.LinkedPersistentList
-
- create(Iterable<? extends E>) - Static method in class com.bluegosling.collections.immutable.LinkedPersistentList
-
- create(SetBackedOrderedQueue.SetFactory) - Static method in class com.bluegosling.collections.queues.SetBackedOrderedQueue
-
- create(SetBackedOrderedQueue.SetFactory, Comparator<? super E>) - Static method in class com.bluegosling.collections.queues.SetBackedOrderedQueue
-
- create(Supplier<? extends T>, Function<? super T, ? extends T>, Consumer<? super T>) - Static method in interface com.bluegosling.concurrent.executors.ContextPropagator
-
- create(Supplier<? extends T>, Consumer<? super T>) - Static method in interface com.bluegosling.concurrent.executors.ContextPropagator
-
- create(Supplier<? extends T>, Function<? super T, ? extends T>) - Static method in interface com.bluegosling.concurrent.executors.ContextPropagator
-
- create() - Static method in class com.bluegosling.concurrent.locks.HierarchicalLock
-
Constructs a new lock that is unfair.
- create(boolean) - Static method in class com.bluegosling.concurrent.locks.HierarchicalLock
-
Constructs a new lock with the specified fairness.
- create(BiConsumer<U, Generator.Output<T, U>>) - Static method in class com.bluegosling.generator.Generator
-
Creates a new generator whose generation logic is performed by a
BiConsumer
that
accepts the initial value provided to the generator as well as the generator's output.
- create(Consumer<Generator.Output<T, Void>>) - Static method in class com.bluegosling.generator.Generator
-
Creates a new generator whose generation logic is performed by a
Consumer
that accepts
the generator's output.
- create(BiConsumer<U, Generator.Output<T, U>>, Executor) - Static method in class com.bluegosling.generator.Generator
-
Creates a new generator whose generation logic is performed by a
BiConsumer
that
accepts the initial value provided to the generator as well as the generator's output.
- create(Consumer<Generator.Output<T, Void>>, Executor) - Static method in class com.bluegosling.generator.Generator
-
Creates a new generator whose generation logic is performed by a
Consumer
that accepts
the generator's output.
- create() - Static method in interface com.bluegosling.possible.Fulfillable
-
Creates a new fulfillable value.
- create() - Static method in class com.bluegosling.possible.Holder
-
Creates a new instance whose value is initially absent.
- create(T) - Static method in class com.bluegosling.possible.Holder
-
Creates a new instance that holds the specified value.
- create(Class<T>, Map<String, ?>) - Static method in class com.bluegosling.reflect.Annotations
-
Creates an annotation instance.
- create(A, B, C, D, E, Object, Object...) - Static method in class com.bluegosling.tuples.NTuple
-
Creates a new tuple.
- createBridge(ArAnnotation, Class<T>) - Static method in class com.bluegosling.apt.reflect.ArAnnotationBridge
-
Creates an annotation bridge.
- createBridge(ArAnnotatedElement, Class<T>) - Static method in class com.bluegosling.apt.reflect.ArAnnotationBridge
-
Queries for an annotation and creates a bridge for it.
- createBridge(ArAnnotation) - Static method in class com.bluegosling.apt.reflect.ArAnnotationBridge
-
Creates an annotation bridge.
- createBridge(ArAnnotation, ClassLoader) - Static method in class com.bluegosling.apt.reflect.ArAnnotationBridge
-
Creates an annotation bridge.
- createDeque() - Method in class com.bluegosling.collections.concurrent.SharedCapacityDequeFactory
-
- createFileObject(JavaFileManager.Location, String, String, String, Charset) - Method in class com.bluegosling.apt.testing.TestJavaFileManager
-
Creates a new text file in the in-memory file system.
- createFileObject(JavaFileManager.Location, String, String, String) - Method in class com.bluegosling.apt.testing.TestJavaFileManager
-
Creates a new text file (UTF-8 encoded) in the in-memory file system.
- createFileObject(JavaFileManager.Location, String, String, byte[]) - Method in class com.bluegosling.apt.testing.TestJavaFileManager
-
Creates a new binary file in the in-memory file system.
- createJavaFileObject(JavaFileManager.Location, String, JavaFileObject.Kind, String, Charset) - Method in class com.bluegosling.apt.testing.TestJavaFileManager
-
Creates a new java file that has text contents in the in-memory file system.
- createJavaFileObject(JavaFileManager.Location, String, JavaFileObject.Kind, String) - Method in class com.bluegosling.apt.testing.TestJavaFileManager
-
Creates a new java file that has text contents (UTF-8 encoded) in the in-memory file system.
- createJavaFileObject(JavaFileManager.Location, String, JavaFileObject.Kind, byte[]) - Method in class com.bluegosling.apt.testing.TestJavaFileManager
-
Creates a new java file that has binary contents in the in-memory file system.
- createKey(K, int) - Method in class com.bluegosling.collections.lists.AssociativeArrayList
-
- createKey(K, int) - Method in interface com.bluegosling.collections.lists.AssociativeList
-
Adds a key for an existing list element.
- createNode() - Method in interface com.bluegosling.streams.StreamOperator
-
Constructs a node that will process data in the stream.
- createProxy(T, T) - Method in class com.bluegosling.testing.InterfaceVerifier
-
Creates a proxy object.
- createProxy(T, T, ClassLoader) - Method in class com.bluegosling.testing.InterfaceVerifier
-
Creates a proxy object.
- current() - Method in interface com.bluegosling.concurrent.scheduler.ScheduledTaskDefinition
-
Returns details for the currently scheduled invocation, which might be
executing currently.
- currentIndex() - Method in interface com.bluegosling.collections.bits.BitStream
-
Returns the current index of the stream.
- currentTimeMillis() - Method in interface com.bluegosling.util.Clock
-
- currentTimeMillis() - Method in class com.bluegosling.util.FakeClock
-
- currentTimeMillis() - Method in enum com.bluegosling.util.SystemClock
-
- curry(Function<? super I, ? extends O>, I) - Static method in class com.bluegosling.function.Functions
-
- curry(BiFunction<? super I1, ? super I2, ? extends O>, I1, I2) - Static method in class com.bluegosling.function.Functions
-
- curry(BiFunction<? super I1, ? super I2, ? extends O>, I1) - Static method in class com.bluegosling.function.Functions
-
- curry(TriFunction<? super I1, ? super I2, ? super I3, ? extends O>, I1, I2, I3) - Static method in class com.bluegosling.function.Functions
-
- curry(TriFunction<? super I1, ? super I2, ? super I3, ? extends O>, I1, I2) - Static method in class com.bluegosling.function.Functions
-
- curry(TriFunction<? super I1, ? super I2, ? super I3, ? extends O>, I1) - Static method in class com.bluegosling.function.Functions
-
- curry(PartialFunction<? super I, ? extends O>, I) - Static method in class com.bluegosling.function.PartialFunctions
-
- curry(PartialBiFunction<? super I1, ? super I2, ? extends O>, I1, I2) - Static method in class com.bluegosling.function.PartialFunctions
-
- curry(PartialBiFunction<? super I1, ? super I2, ? extends O>, I1) - Static method in class com.bluegosling.function.PartialFunctions
-
- curry(PartialTriFunction<? super I1, ? super I2, ? super I3, ? extends O>, I1, I2, I3) - Static method in class com.bluegosling.function.PartialFunctions
-
- curry(PartialTriFunction<? super I1, ? super I2, ? super I3, ? extends O>, I1, I2) - Static method in class com.bluegosling.function.PartialFunctions
-
- curry(PartialTriFunction<? super I1, ? super I2, ? super I3, ? extends O>, I1) - Static method in class com.bluegosling.function.PartialFunctions
-
- curry(Predicate<? super I>, I) - Static method in class com.bluegosling.function.Predicates
-
- curry(BiPredicate<? super I1, ? super I2>, I1, I2) - Static method in class com.bluegosling.function.Predicates
-
- curry(BiPredicate<? super I1, ? super I2>, I1) - Static method in class com.bluegosling.function.Predicates
-
- curry(TriPredicate<? super I1, ? super I2, ? super I3>, I1, I2, I3) - Static method in class com.bluegosling.function.Predicates
-
- curry(TriPredicate<? super I1, ? super I2, ? super I3>, I1, I2) - Static method in class com.bluegosling.function.Predicates
-
- curry(TriPredicate<? super I1, ? super I2, ? super I3>, I1) - Static method in class com.bluegosling.function.Predicates
-
- failed(Throwable) - Method in interface com.bluegosling.concurrent.fluent.FutureVisitor
-
Invoked when the visited future failed.
- failed(Throwable) - Method in class com.bluegosling.concurrent.fluent.SimpleFutureVisitor
-
Invoked when the visited future failed.
- failed() - Method in class com.bluegosling.reflect.blaster.Blaster.Result
-
Returns true if the method invocation failed (e.g.
- failedFuture(Throwable) - Static method in interface com.bluegosling.concurrent.fluent.FluentFuture
-
Returns a future that has already failed due to the specified cause.
- failedFuture(Throwable) - Static method in class com.bluegosling.concurrent.futures.CompletableFutures
-
- failedOnly(Collection<? extends Result<?, ? extends E>>) - Static method in class com.bluegosling.result.Result
-
Returns a list of the given results' errors, omitting errors for any successful results.
- FailedResultException - Exception in com.bluegosling.result
-
An exception used to wrap the error in a
Result
, for result objects whose cause of
failure is not a sub-type of
Throwable
.
- failureCount() - Method in interface com.bluegosling.concurrent.scheduler.ScheduledTaskDefinition
-
Returns the number of times that tasks have failed (completed abnormally) for this task
definition.
- fair(boolean) - Method in class com.bluegosling.collections.concurrent.ConcurrentSortedArraySet.Builder
-
Sets whether read-write locks used will be fair or not.
- fair(boolean) - Method in class com.bluegosling.collections.concurrent.ShardedConcurrentSets.Builder
-
Sets whether or not access to the set uses fair read-write locks.
- FakeClock - Class in com.bluegosling.util
-
- FakeClock() - Constructor for class com.bluegosling.util.FakeClock
-
- FibonacciHeapOrderedQueue<E> - Class in com.bluegosling.collections.queues
-
A priority queue that supports merging of two queues and is backed by a Fibonacci heap.
- FibonacciHeapOrderedQueue() - Constructor for class com.bluegosling.collections.queues.FibonacciHeapOrderedQueue
-
Constructs a new empty queue.
- FibonacciHeapOrderedQueue(Comparator<? super E>) - Constructor for class com.bluegosling.collections.queues.FibonacciHeapOrderedQueue
-
Constructs a new empty queue.
- FibonacciHeapOrderedQueue(Collection<? extends E>) - Constructor for class com.bluegosling.collections.queues.FibonacciHeapOrderedQueue
-
Constructs a new queue whose contents are initialized to the elements in the specified
collection.
- FibonacciHeapOrderedQueue(Collection<? extends E>, Comparator<? super E>) - Constructor for class com.bluegosling.collections.queues.FibonacciHeapOrderedQueue
-
- FibonacciHeapOrderedQueue(FibonacciHeapOrderedQueue<? extends E>) - Constructor for class com.bluegosling.collections.queues.FibonacciHeapOrderedQueue
-
Constructs a new queue whose contents and comparator are initialized to those of the specified
queue.
- FibonacciHeapOrderedQueue(PriorityQueue<? extends E>) - Constructor for class com.bluegosling.collections.queues.FibonacciHeapOrderedQueue
-
Constructs a new queue whose contents and comparator are initialized to those of the specified
queue.
- FibonacciHeapOrderedQueue(SortedSet<? extends E>) - Constructor for class com.bluegosling.collections.queues.FibonacciHeapOrderedQueue
-
Constructs a new queue whose contents and comparator are initialized to those of the specified
set.
- fileManager() - Method in class com.bluegosling.apt.testing.TestEnvironment
-
- FilesToProcess - Annotation Type in com.bluegosling.apt.testing
-
An annotation on a test class or method that defines the files to process.
- filter(Collection<?>, Iterator<?>, boolean) - Static method in class com.bluegosling.collections.CollectionUtils
-
Filters all objects in the list against a specified collection.
- filter(Spliterator<T>, Predicate<? super T>) - Static method in class com.bluegosling.collections.MoreSpliterators
-
Returns a spliterator that filters the data emitted by the given spliterator.
- filter(Predicate<? super T>) - Method in class com.bluegosling.possible.AbstractDynamicPossible
-
Returns a possible that reflects the result of applying the given predicate to this possible
value, if present.
- filter(Predicate<? super T>) - Method in interface com.bluegosling.possible.Possible
-
Filters the current value per the specified predicate.
- filter(Predicate<? super T>) - Method in class com.bluegosling.possible.Reference
-
Filters the current value per the specified predicate.
- filter(Predicate<? super T>) - Method in interface com.bluegosling.streams.FluentStream
- filterAnnotationTypesFor(Processor) - Method in class com.bluegosling.apt.testing.TestEnvironment
-
Filters the current set of annotation types to only those supported by the specified
processor.
- FilteringCollection<E> - Class in com.bluegosling.collections
-
A filtered view of another collection.
- FilteringCollection(Collection<E>, Predicate<? super E>) - Constructor for class com.bluegosling.collections.FilteringCollection
-
Constructs a new filtering collection.
- FilteringIterable<E> - Class in com.bluegosling.collections
-
A filtered view of another iterable.
- FilteringIterable(Iterable<E>, Predicate<? super E>) - Constructor for class com.bluegosling.collections.FilteringIterable
-
Constructs a new filtering iterable.
- FilteringIterator<E> - Class in com.bluegosling.collections
-
A filtered view of another iterator.
- FilteringIterator(Iterator<E>, Predicate<? super E>) - Constructor for class com.bluegosling.collections.FilteringIterator
-
Constructs a new filtering iterator.
- filteringKeys(Map<K, V>, Predicate<? super K>) - Static method in class com.bluegosling.collections.FilteringMap
-
- FilteringList<E> - Class in com.bluegosling.collections
-
A filtered view of another list.
- FilteringList(List<E>, Predicate<? super E>) - Constructor for class com.bluegosling.collections.FilteringList
-
Constructs a new filtering list.
- FilteringListIterator<E> - Class in com.bluegosling.collections
-
A filtered view of another list iterator.
- FilteringListIterator(ListIterator<E>, Predicate<? super E>) - Constructor for class com.bluegosling.collections.FilteringListIterator
-
Constructs a new filtering list iterator.
- FilteringMap<K,V> - Class in com.bluegosling.collections
-
- FilteringMap(Map<K, V>, BiPredicate<? super K, ? super V>) - Constructor for class com.bluegosling.collections.FilteringMap
-
- FilteringNavigableMap<K,V> - Class in com.bluegosling.collections
-
- FilteringNavigableMap(NavigableMap<K, V>, BiPredicate<? super K, ? super V>) - Constructor for class com.bluegosling.collections.FilteringNavigableMap
-
- FilteringNavigableSet<E> - Class in com.bluegosling.collections
-
- FilteringNavigableSet(NavigableSet<E>, Predicate<? super E>) - Constructor for class com.bluegosling.collections.FilteringNavigableSet
-
- FilteringSet<E> - Class in com.bluegosling.collections
-
A filtered view of another set.
- FilteringSet(Set<E>, Predicate<? super E>) - Constructor for class com.bluegosling.collections.FilteringSet
-
Constructs a new filtering set.
- FilteringSortedMap<K,V> - Class in com.bluegosling.collections
-
- FilteringSortedMap(SortedMap<K, V>, BiPredicate<? super K, ? super V>) - Constructor for class com.bluegosling.collections.FilteringSortedMap
-
- FilteringSortedSet<E> - Class in com.bluegosling.collections
-
- FilteringSortedSet(SortedSet<E>, Predicate<? super E>) - Constructor for class com.bluegosling.collections.FilteringSortedSet
-
- filteringValues(Map<K, V>, Predicate<? super V>) - Static method in class com.bluegosling.collections.FilteringMap
-
- findAnnotation(Class<?>, Class<A>) - Static method in class com.bluegosling.reflect.Annotations
-
Returns an annotation, possibly searching for the annotation on super-types if not declared
on the specified type.
- findCopyConstructor(Class<T>) - Static method in class com.bluegosling.util.Cloners
-
Finds a copy constructor for the specified class.
- findField(Class<?>, String) - Static method in class com.bluegosling.reflect.Members
-
Finds an instance field on the specified class with the specified name.
- findFields(Class<?>, String) - Static method in class com.bluegosling.reflect.Members
-
Finds all instance fields with the specified name.
- findMethod(Class<?>, String, Class<?>...) - Static method in class com.bluegosling.reflect.Members
-
Finds an instance method on the specified class with the specified signature.
- findMethod(Class<?>, String, List<Class<?>>) - Static method in class com.bluegosling.reflect.Members
-
Finds an instance method on the specified class with the specified signature.
- findMethod(String) - Method in class com.bluegosling.testing.InterfaceVerifier
-
Finds a method whose name matches the specified search string.
- findMethods(Class<?>, String) - Static method in class com.bluegosling.reflect.Members
-
Finds all instance methods with the specified name.
- findMethods(String) - Method in class com.bluegosling.testing.InterfaceVerifier
-
Finds all methods whose names match the specified search string.
- findObject(Object, ListIterator<?>) - Static method in class com.bluegosling.collections.CollectionUtils
-
Finds an item by iterating through the specified iterator.
- findStaticCopyMethod(Class<T>, String) - Static method in class com.bluegosling.util.Cloners
-
Finds a static copy method for the specified class with the specified name.
- finishTimeMillis() - Method in interface com.bluegosling.concurrent.scheduler.ScheduledTask
-
Returns the actual end time of this invocation, in milliseconds.
- first() - Method in class com.bluegosling.collections.AbstractNavigableMap.KeySet
-
- first() - Method in class com.bluegosling.collections.concurrent.ConcurrentSortedArraySet
- first() - Method in class com.bluegosling.collections.DescendingSet
-
- first() - Method in class com.bluegosling.collections.FilteringSortedSet
-
- first() - Method in class com.bluegosling.collections.immutable.AbstractLinkedImmutableList.LinkedSubList
-
- first() - Method in interface com.bluegosling.collections.immutable.ConsList
-
Returns the first element in the list.
- first() - Method in class com.bluegosling.collections.immutable.LinkedPersistentList
-
- first() - Method in class com.bluegosling.collections.NoCopyGrowableArray
-
- first() - Method in class com.bluegosling.collections.sets.SortedArraySet
- firstEntry() - Method in class com.bluegosling.collections.AbstractNavigableMap.SubMap
-
Finds the entry in the map with the smallest key or null
if the sub-map is empty.
- firstEntry() - Method in class com.bluegosling.collections.concurrent.DoubleInstanceLockedTreeMap
-
- firstEntry() - Method in class com.bluegosling.collections.DescendingMap
-
- firstEntry() - Method in class com.bluegosling.collections.FilteringNavigableMap
-
- firstEntry() - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap
-
- firstEntry() - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.RandomAccessSubMap
-
Finds the entry in the map with the smallest key or null
if the sub-map is empty.
- firstEntry() - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.SubMapByIndices
-
- firstEntry() - Method in class com.bluegosling.collections.maps.SortedArrayMap
-
- firstEntry() - Method in class com.bluegosling.collections.maps.WeightBalancedTreeMap
-
- firstEntry() - Method in interface com.bluegosling.collections.queues.PriorityQueue
-
Returns the minimum entry in the queue.
- firstEntry() - Method in class com.bluegosling.collections.tries.ArrayMappedBitwiseTrie
-
- firstEntry() - Method in class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- firstEntry() - Method in class com.bluegosling.collections.tries.SimpleBitwiseTrie
-
- firstKey() - Method in class com.bluegosling.collections.AbstractNavigableMap
- firstKey() - Method in class com.bluegosling.collections.concurrent.DoubleInstanceLockedTreeMap
-
- firstKey() - Method in class com.bluegosling.collections.DescendingMap
-
- firstKey() - Method in class com.bluegosling.collections.FilteringNavigableMap
-
- firstKey() - Method in class com.bluegosling.collections.FilteringSortedMap
-
- firstKey() - Method in class com.bluegosling.collections.maps.WeightBalancedTreeMap
-
- firstKey() - Method in class com.bluegosling.collections.tries.ArrayMappedBitwiseTrie
-
- firstKey() - Method in class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- firstKey() - Method in class com.bluegosling.collections.tries.SimpleBitwiseTrie
-
- firstOf(A, B, C, D, E) - Static method in class com.bluegosling.choice.AnyOfFive
-
- firstOf(A, B, C, D) - Static method in class com.bluegosling.choice.AnyOfFour
-
- firstOf(A, B, C) - Static method in class com.bluegosling.choice.AnyOfThree
-
- firstOf(A, B) - Static method in class com.bluegosling.choice.Either
-
Constructs an object using the first of the given values that is non-null.
- firstOf(A, B) - Static method in class com.bluegosling.choice.Union2
-
- firstOf(A, B, C) - Static method in class com.bluegosling.choice.Union3
-
- firstOf(A, B, C, D) - Static method in class com.bluegosling.choice.Union4
-
- firstOf(A, B, C, D, E) - Static method in class com.bluegosling.choice.Union5
-
- firstOf(FluentFuture<? extends T>...) - Static method in interface com.bluegosling.concurrent.fluent.FluentFuture
-
Returns a future that represents the first future to complete out of the given futures.
- firstOf(Iterable<FluentFuture<? extends T>>) - Static method in interface com.bluegosling.concurrent.fluent.FluentFuture
-
Returns a future that represents the first future to complete out of the given collection of
futures.
- firstSuccessfulOf(FluentFuture<? extends T>...) - Static method in interface com.bluegosling.concurrent.fluent.FluentFuture
-
Returns a future that represents the first future to successfully complete out of the given
futures.
- firstSuccessfulOf(Iterable<FluentFuture<? extends T>>) - Static method in interface com.bluegosling.concurrent.fluent.FluentFuture
-
Returns a future that represents the first future to successfully complete out of the given
collection of futures.
- firstSuccessfulOf(Result<? extends T, ? extends E>...) - Static method in class com.bluegosling.result.Result
-
Returns the first successful result from the given array.
- firstSuccessfulOf(Iterable<? extends Result<? extends T, ? extends E>>) - Static method in class com.bluegosling.result.Result
-
Returns the first successful result from the given collection.
- flatMap(Iterable<T>, Function<? super T, ? extends Iterator<? extends U>>) - Static method in class com.bluegosling.collections.MoreIterables
-
Expands the given sequence using the given function.
- flatMap(Iterator<T>, Function<? super T, ? extends Iterator<? extends U>>) - Static method in class com.bluegosling.collections.MoreIterators
-
Expands the given sequence using the given function.
- flatMap(Spliterator<T>, Function<? super T, ? extends Spliterator<? extends U>>) - Static method in class com.bluegosling.collections.MoreSpliterators
-
Returns a spliterator that applies the given function to values emitted by the given
spliterator and then flattens the results.
- flatMap(Function<? super T, ? extends FluentFuture<? extends U>>) - Method in interface com.bluegosling.concurrent.fluent.FluentFuture
-
Transforms the result of this future using the specified function.
- flatMap(Function<? super T, ? extends Possible<U>>) - Method in class com.bluegosling.possible.AbstractDynamicPossible
-
Returns a possible that reflects the result of applying the given function to this possible
value, if present.
- flatMap(Function<? super T, ? extends Possible<U>>) - Method in interface com.bluegosling.possible.Possible
-
- flatMap(Function<? super T, ? extends Possible<U>>) - Method in class com.bluegosling.possible.Reference
- flatMap(Function<? super T, Result<? extends U, ? extends E>>) - Method in class com.bluegosling.result.Result
-
Returns a new result that is the result of mapping this result's value using the given
function.
- flatMap(Function<? super T, ? extends Stream<? extends R>>) - Method in interface com.bluegosling.streams.FluentStream
- flatMapFifth(Function<? super E, AnyOfFive<A, B, C, D, E>>) - Method in class com.bluegosling.choice.AnyOfFive
-
- flatMapFifth(Function<? super E, Union5<A, B, C, D, E>>) - Method in class com.bluegosling.choice.Union5
-
- flatMapFirst(Function<? super A, AnyOfFive<A, B, C, D, E>>) - Method in class com.bluegosling.choice.AnyOfFive
-
- flatMapFirst(Function<? super A, AnyOfFour<A, B, C, D>>) - Method in class com.bluegosling.choice.AnyOfFour
-
- flatMapFirst(Function<? super A, AnyOfThree<A, B, C>>) - Method in class com.bluegosling.choice.AnyOfThree
-
- flatMapFirst(Function<? super A, Either<A, B>>) - Method in class com.bluegosling.choice.Either
-
Maps the value of the first option, if present, to a new choice.
- flatMapFirst(Function<? super A, Union2<A, B>>) - Method in class com.bluegosling.choice.Union2
-
- flatMapFirst(Function<? super A, Union3<A, B, C>>) - Method in class com.bluegosling.choice.Union3
-
- flatMapFirst(Function<? super A, Union4<A, B, C, D>>) - Method in class com.bluegosling.choice.Union4
-
- flatMapFirst(Function<? super A, Union5<A, B, C, D, E>>) - Method in class com.bluegosling.choice.Union5
-
- flatMapFourth(Function<? super D, AnyOfFive<A, B, C, D, E>>) - Method in class com.bluegosling.choice.AnyOfFive
-
- flatMapFourth(Function<? super D, AnyOfFour<A, B, C, D>>) - Method in class com.bluegosling.choice.AnyOfFour
-
- flatMapFourth(Function<? super D, Union4<A, B, C, D>>) - Method in class com.bluegosling.choice.Union4
-
- flatMapFourth(Function<? super D, Union5<A, B, C, D, E>>) - Method in class com.bluegosling.choice.Union5
-
- flatMapSecond(Function<? super B, AnyOfFive<A, B, C, D, E>>) - Method in class com.bluegosling.choice.AnyOfFive
-
- flatMapSecond(Function<? super B, AnyOfFour<A, B, C, D>>) - Method in class com.bluegosling.choice.AnyOfFour
-
- flatMapSecond(Function<? super B, AnyOfThree<A, B, C>>) - Method in class com.bluegosling.choice.AnyOfThree
-
- flatMapSecond(Function<? super B, Either<A, B>>) - Method in class com.bluegosling.choice.Either
-
Maps the value of the second option, if present, to a new choice.
- flatMapSecond(Function<? super B, Union2<A, B>>) - Method in class com.bluegosling.choice.Union2
-
- flatMapSecond(Function<? super B, Union3<A, B, C>>) - Method in class com.bluegosling.choice.Union3
-
- flatMapSecond(Function<? super B, Union4<A, B, C, D>>) - Method in class com.bluegosling.choice.Union4
-
- flatMapSecond(Function<? super B, Union5<A, B, C, D, E>>) - Method in class com.bluegosling.choice.Union5
-
- flatMapThird(Function<? super C, AnyOfFive<A, B, C, D, E>>) - Method in class com.bluegosling.choice.AnyOfFive
-
- flatMapThird(Function<? super C, AnyOfFour<A, B, C, D>>) - Method in class com.bluegosling.choice.AnyOfFour
-
- flatMapThird(Function<? super C, AnyOfThree<A, B, C>>) - Method in class com.bluegosling.choice.AnyOfThree
-
- flatMapThird(Function<? super C, Union3<A, B, C>>) - Method in class com.bluegosling.choice.Union3
-
- flatMapThird(Function<? super C, Union4<A, B, C, D>>) - Method in class com.bluegosling.choice.Union4
-
- flatMapThird(Function<? super C, Union5<A, B, C, D, E>>) - Method in class com.bluegosling.choice.Union5
-
- flatten(Iterator<? extends Spliterator<? extends T>>) - Static method in class com.bluegosling.collections.MoreSpliterators
-
Flattens the given iterator so that all elements from its constituent spliterators are
concatenated together.
- flatten(Spliterator<? extends Spliterator<? extends T>>) - Static method in class com.bluegosling.collections.MoreSpliterators
-
Flattens the given spliterator so that all elements from its constituent spliterators are
concatenated together.
- FloatBinaryOperator - Interface in com.bluegosling.function
-
Represents an operation upon two float
-valued operands and producing a
float
-valued result.
- FloatConsumer - Interface in com.bluegosling.function
-
- FloatIterator - Interface in com.bluegosling.collections.primitive
-
An
Iterator
that can provide primitive (un-boxed) floats.
- FloatPredicate - Interface in com.bluegosling.function
-
Represents a predicate (boolean-valued function) of one float
-valued
argument.
- FloatUnaryOperator - Interface in com.bluegosling.function
-
Represents an operation on a single float
-valued operand that produces a
float
-valued result.
- floatValue() - Method in class com.bluegosling.vars.VariableByte
-
- floatValue() - Method in class com.bluegosling.vars.VariableDouble
-
- floatValue() - Method in class com.bluegosling.vars.VariableFloat
-
- floatValue() - Method in class com.bluegosling.vars.VariableInt
-
- floatValue() - Method in class com.bluegosling.vars.VariableLong
-
- floatValue() - Method in class com.bluegosling.vars.VariableShort
-
- floor(K) - Method in class com.bluegosling.collections.AbstractNavigableMap.KeySet
-
- floor(E) - Method in class com.bluegosling.collections.concurrent.ConcurrentSortedArraySet
- floor(E) - Method in class com.bluegosling.collections.DescendingSet
-
- floor(E) - Method in class com.bluegosling.collections.FilteringNavigableSet
-
- floor(E) - Method in class com.bluegosling.collections.sets.SortedArraySet
- floorEntry(K) - Method in class com.bluegosling.collections.AbstractNavigableMap
- floorEntry(K) - Method in class com.bluegosling.collections.AbstractNavigableMap.SubMap
-
Finds the entry in this sub-map with the greatest key that is less than or equal to the
specified key.
- floorEntry(K) - Method in class com.bluegosling.collections.concurrent.DoubleInstanceLockedTreeMap
-
- floorEntry(K) - Method in class com.bluegosling.collections.DescendingMap
-
- floorEntry(K) - Method in class com.bluegosling.collections.FilteringNavigableMap
-
- floorEntry(K) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.RandomAccessSubMap
-
Finds the entry in this sub-map with the greatest key that is less than or equal to the
specified key.
- floorEntry(K) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.SubMapByIndices
-
- floorEntry(K) - Method in class com.bluegosling.collections.maps.SortedArrayMap
-
- floorEntry(K) - Method in class com.bluegosling.collections.maps.WeightBalancedTreeMap
-
- floorEntry(K) - Method in class com.bluegosling.collections.tries.ArrayMappedBitwiseTrie
-
- floorEntry(K) - Method in class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- floorEntry(Iterable<K>) - Method in class com.bluegosling.collections.tries.DescendingSequenceTrie
-
- floorEntry(Iterable<K>) - Method in interface com.bluegosling.collections.tries.NavigableSequenceTrie
-
- floorEntry(K) - Method in class com.bluegosling.collections.tries.SimpleBitwiseTrie
-
- floorKey(K) - Method in class com.bluegosling.collections.AbstractNavigableMap
- floorKey(K) - Method in class com.bluegosling.collections.concurrent.DoubleInstanceLockedTreeMap
-
- floorKey(K) - Method in class com.bluegosling.collections.DescendingMap
-
- floorKey(K) - Method in class com.bluegosling.collections.FilteringNavigableMap
-
- floorKey(K) - Method in class com.bluegosling.collections.maps.WeightBalancedTreeMap
-
- floorKey(K) - Method in class com.bluegosling.collections.tries.ArrayMappedBitwiseTrie
-
- floorKey(K) - Method in class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- floorKey(Iterable<K>) - Method in class com.bluegosling.collections.tries.DescendingSequenceTrie
-
- floorKey(Iterable<K>) - Method in interface com.bluegosling.collections.tries.NavigableSequenceTrie
-
- floorKey(K) - Method in class com.bluegosling.collections.tries.SimpleBitwiseTrie
-
- FluentExecutorService - Interface in com.bluegosling.concurrent.fluent
-
- FluentFuture<T> - Interface in com.bluegosling.concurrent.fluent
-
The future to end all futures.
- FluentFutureTask<T> - Class in com.bluegosling.concurrent.fluent
-
- FluentFutureTask(Callable<T>) - Constructor for class com.bluegosling.concurrent.fluent.FluentFutureTask
-
Constructs a new task for the specified callable.
- FluentFutureTask(Runnable, T) - Constructor for class com.bluegosling.concurrent.fluent.FluentFutureTask
-
Constructs a new task for the specified command and result.
- FluentRepeatingFuture<T> - Interface in com.bluegosling.concurrent.fluent
-
- FluentRepeatingFutureTask<T> - Class in com.bluegosling.concurrent.fluent
-
- FluentRepeatingFutureTask(Callable<T>, long, Rescheduler<? super T>) - Constructor for class com.bluegosling.concurrent.fluent.FluentRepeatingFutureTask
-
- FluentRepeatingFutureTask(Runnable, T, long, Rescheduler<? super T>) - Constructor for class com.bluegosling.concurrent.fluent.FluentRepeatingFutureTask
-
- FluentScheduledExecutorService - Interface in com.bluegosling.concurrent.fluent
-
- FluentScheduledFuture<T> - Interface in com.bluegosling.concurrent.fluent
-
- FluentScheduledFutureTask<T> - Class in com.bluegosling.concurrent.fluent
-
- FluentScheduledFutureTask(Callable<T>, long) - Constructor for class com.bluegosling.concurrent.fluent.FluentScheduledFutureTask
-
- FluentScheduledFutureTask(Runnable, T, long) - Constructor for class com.bluegosling.concurrent.fluent.FluentScheduledFutureTask
-
- FluentStream<T> - Interface in com.bluegosling.streams
-
- flush() - Method in class com.bluegosling.apt.testing.TestJavaFileManager
-
- foldLeft(Iterable<I>, BiFunction<? super O, ? super I, ? extends O>, O) - Static method in class com.bluegosling.function.Functions
-
Performs a fold-left operation over the specified values and returns the result.
- foldLeft(Iterator<I>, BiFunction<? super O, ? super I, ? extends O>, O) - Static method in class com.bluegosling.function.Functions
-
- foldRight(Iterable<I>, BiFunction<? super I, ? super O, ? extends O>, O) - Static method in class com.bluegosling.function.Functions
-
Performs a fold-right operation over the specified values and returns the result.
- foldRight(Iterator<I>, BiFunction<? super I, ? super O, ? extends O>, O) - Static method in class com.bluegosling.function.Functions
-
- forAnnotationMirror(AnnotationMirror) - Static method in class com.bluegosling.apt.reflect.ArAnnotation
-
Constructs a new annotation based on the specified mirror.
- forArray(ArClass) - Static method in class com.bluegosling.apt.reflect.ArClass
-
Returns a class that represents an array with the specified component type.
- forArray(Class<O>, Converter<? super I, ? extends O>) - Static method in interface com.bluegosling.reflect.caster.Converter
-
Returns a converter that converts an array by using a given converter to convert each element
in the array.
- forArray(Cloner<T>) - Static method in class com.bluegosling.util.Cloners
-
Creates a cloner for arrays that performs a deep copy by using the specified cloner to clone
elements.
- forBigDecimal() - Static method in class com.bluegosling.collections.tries.BitConverters
-
Returns a converter that converts big decimals into streams of bits.
- forBigInteger() - Static method in class com.bluegosling.collections.tries.BitConverters
-
Returns a converter that converts big integers into streams of bits.
- forByte() - Static method in class com.bluegosling.collections.tries.BitConverters
-
Returns a converter that converts bytes into streams of eight bits.
- forCallable(Callable<V>) - Static method in interface com.bluegosling.concurrent.scheduler.TaskDefinition
-
Returns a new builder for a task definition whose underlying task is a
Callable
.
- forCallable(Callable<V>) - Static method in class com.bluegosling.concurrent.scheduler.TaskImplementation
-
Returns a task for the specified callable implementation.
- forceTake(long) - Method in class com.bluegosling.concurrent.RateLimiter
-
Forcibly takes permits without waiting to acquire them.
- forCharacter() - Static method in class com.bluegosling.collections.tries.BitConverters
-
Returns a converter that converts characters into streams of bits.
- forCharacter(Charset) - Static method in class com.bluegosling.collections.tries.BitConverters
-
Returns a converter that converts characters into stream of bits using the specified character
encoding.
- forCharSequence() - Static method in interface com.bluegosling.collections.tries.Componentizer
-
Returns a componentizer that breaks any
CharSequence
(for example, a
String
)
into its component characters.
- forClass(Class<?>) - Static method in class com.bluegosling.apt.reflect.ArClass
-
Returns a
ArClass
object that corresponds to the specified
Class
token.
- forClass(Class<T>) - Static method in class com.bluegosling.reflect.TypeRef
-
Constructs a type token that represents a specified class.
- forCloneable() - Static method in class com.bluegosling.util.Cloners
-
Returns a cloner for cloning instances of Cloneable
.
- forCodePointSequence() - Static method in interface com.bluegosling.collections.tries.Componentizer
-
Returns a componentizer that breaks any
CharSequence
(for example, a
String
)
into its component unicode code points.
- forComparable() - Static method in class com.bluegosling.testing.ObjectVerifiers
-
- forConcurrentHashMap() - Static method in interface com.bluegosling.collections.maps.MapBuilder
-
- forConcurrentSkipListMap() - Static method in interface com.bluegosling.collections.maps.MapBuilder
-
- forConcurrentSkipListMap(Comparator<? super K>) - Static method in interface com.bluegosling.collections.maps.MapBuilder
-
Returns a map builder that constructs
ConcurrentSkipListMap
instances that orders
elements per the given comparator.
- forConstructorParameterElement(VariableElement) - Static method in class com.bluegosling.apt.reflect.ArParameter
-
Returns a constructor parameter based on the specified element.
- forConsumer(Consumer<? super FluentFuture<T>>) - Static method in interface com.bluegosling.concurrent.fluent.FutureListener
-
- forDouble() - Static method in class com.bluegosling.collections.tries.BitConverters
-
Returns a converter that converts doubles into streams of 64 bits.
- forEach(BiConsumer<? super K, ? super V>) - Method in class com.bluegosling.collections.concurrent.DoubleInstanceLockedTreeMap
-
- forEach(BiConsumer<? super K, ? super V>) - Method in class com.bluegosling.collections.immutable.HamtPersistentMap
-
- forEach(BiConsumer<? super K, ? super V>) - Method in class com.bluegosling.collections.maps.HamtMap
-
- forEach(BiConsumer<? super K, ? super V>) - Method in class com.bluegosling.collections.maps.LinearHashingMap
-
- forEach(T_CONS) - Method in interface com.bluegosling.collections.primitive.PrimitiveList
-
- forEachClass(BiFunction<Class<?>, P, R>) - Method in class com.bluegosling.reflect.ClassHierarchyScanner.Builder
-
An action that is invoked for each class in the hierarchy.
- forEachRemaining(BooleanConsumer) - Method in interface com.bluegosling.collections.primitive.BooleanIterator
-
- forEachRemaining(ByteConsumer) - Method in interface com.bluegosling.collections.primitive.ByteIterator
-
- forEachRemaining(CharConsumer) - Method in interface com.bluegosling.collections.primitive.CharIterator
-
- forEachRemaining(FloatConsumer) - Method in interface com.bluegosling.collections.primitive.FloatIterator
-
- forEachRemaining(ShortConsumer) - Method in interface com.bluegosling.collections.primitive.ShortIterator
-
- forElement(TypeElement) - Static method in class com.bluegosling.apt.reflect.ArClass
-
Creates a class corresponding to the specified
TypeElement
.
- forElement(ExecutableElement) - Static method in class com.bluegosling.apt.reflect.ArConstructor
-
Returns a constructor based on the specified element.
- forElement(VariableElement) - Static method in class com.bluegosling.apt.reflect.ArField
-
Returns a field based on the specified element.
- forElement(ExecutableElement) - Static method in class com.bluegosling.apt.reflect.ArMethod
-
Returns a method based on the specified element.
- forElement(PackageElement) - Static method in class com.bluegosling.apt.reflect.ArPackage
-
Returns a package based on the specified element.
- forElement(VariableElement) - Static method in class com.bluegosling.apt.reflect.ArParameter
-
Returns a parameter based on the specified element.
- forElement(TypeParameterElement) - Static method in class com.bluegosling.apt.reflect.ArTypeParameter
-
Creates a type variable from the specified element.
- forEnum(Class<T>) - Static method in class com.bluegosling.reflect.EnumType
-
- forFields(Function<? super T, ?>...) - Static method in interface com.bluegosling.util.Hasher
-
Returns a hasher that uses the given functions to extract field values.
- forFields(List<? extends Function<? super T, ?>>) - Static method in interface com.bluegosling.util.Hasher
-
Returns a hasher that uses the given functions to extract field values.
- forFloat() - Static method in class com.bluegosling.collections.tries.BitConverters
-
Returns a converter that converts floats into streams of 32 bits.
- forgetKey(K) - Method in class com.bluegosling.collections.lists.AssociativeArrayList
-
- forgetKey(K) - Method in interface com.bluegosling.collections.lists.AssociativeList
-
Removes an associative key but leaves the list and associated element in tact.
- forHamtMap() - Static method in interface com.bluegosling.collections.maps.MapBuilder
-
Returns a map builder that constructs
HamtMap
instances.
- forHashMap() - Static method in interface com.bluegosling.collections.maps.MapBuilder
-
Returns a map builder that constructs
HashMap
instances.
- forInteger() - Static method in class com.bluegosling.collections.tries.BitConverters
-
Returns a converter that converts integers into streams of 32 bits.
- forInterface(Class<T>) - Static method in class com.bluegosling.reflect.blaster.Blaster
-
Constructs a blaster that implements the specified interface.
- fork(Spliterator<? extends T>, int) - Static method in class com.bluegosling.collections.MoreSpliterators
-
Forks the given source of data into multiple sources.
- fork(int) - Method in interface com.bluegosling.streams.FluentStream
-
Forks this stream into the given number of result streams, each with the same data as this
stream.
- fork() - Method in interface com.bluegosling.streams.FluentStream
-
Forks this stream into two.
- forLinearHashingMap() - Static method in interface com.bluegosling.collections.maps.MapBuilder
-
- forLinkedHashMap() - Static method in interface com.bluegosling.collections.maps.MapBuilder
-
- forLock(Lock) - Static method in interface com.bluegosling.concurrent.locks.Locking
-
Returns a locking interface for the given lock.
- forLong() - Static method in class com.bluegosling.collections.tries.BitConverters
-
Returns a converter that converts longs into streams of 64 bits.
- forMethodParameterElement(VariableElement) - Static method in class com.bluegosling.apt.reflect.ArParameter
-
Returns a method parameter based on the specified element.
- forName(String) - Static method in class com.bluegosling.apt.reflect.ArClass
-
Returns the
ArClass
for the given fully-qualified class name.
- forName(String) - Static method in class com.bluegosling.apt.reflect.ArPackage
-
Returns the package of the specified name.
- forNestedArray(Class<T[]>, Cloner<?>) - Static method in class com.bluegosling.util.Cloners
-
Creates a cloner for arrays that performs a deep copy by cloning all array elements.
- forObject() - Static method in class com.bluegosling.apt.reflect.ArClass
-
Returns the class for Object
.
- forObject() - Static method in class com.bluegosling.apt.reflect.ArDeclaredType
-
- forReadLock() - Method in interface com.bluegosling.concurrent.locks.Locking.ReadWriteLocking
-
Returns a locking interface that corresponds to the read (e.g.
- forReadWriteLock(ReadWriteLock) - Static method in interface com.bluegosling.concurrent.locks.Locking
-
Returns a locking interface for the given read-write lock.
- forRunnable(Runnable) - Static method in interface com.bluegosling.concurrent.fluent.FutureListener
-
Creates a listener that will execute the specified task when the future completes.
- forRunnable(Runnable) - Static method in interface com.bluegosling.concurrent.scheduler.TaskDefinition
-
Returns a new builder for a task definition whose underlying task is a
Runnable
.
- forRunnable(Runnable, V) - Static method in interface com.bluegosling.concurrent.scheduler.TaskDefinition
-
Returns a new builder for a task definition whose underlying task is a
Runnable
that has an associated result value.
- forRunnable(Runnable) - Static method in class com.bluegosling.concurrent.scheduler.TaskImplementation
-
Returns a task for the specified runnable implementation.
- forRunnable(Runnable, V) - Static method in class com.bluegosling.concurrent.scheduler.TaskImplementation
-
Returns a task for the specified runnable implementation.
- forSerializable() - Static method in class com.bluegosling.collections.tries.BitConverters
-
Returns a converter that will serialize a given object.
- forSerializable() - Static method in class com.bluegosling.util.Cloners
-
Returns a cloner for cloning instances of Serializable
.
- forShort() - Static method in class com.bluegosling.collections.tries.BitConverters
-
Returns a converter that converts shorts into streams of sixteen bits.
- forStampedLock(StampedLock) - Static method in interface com.bluegosling.concurrent.locks.Locking
-
Returns a locking interface for the given stamped lock.
- forString() - Static method in class com.bluegosling.collections.tries.BitConverters
-
Returns a converter that converts strings into streams of bits.
- forString(Charset) - Static method in class com.bluegosling.collections.tries.BitConverters
-
Returns a converter that converts strings into streams of bits using the specifed character
encoding.
- forSupplier(Supplier<V>) - Static method in interface com.bluegosling.concurrent.scheduler.TaskDefinition
-
Returns a new builder for a task definition whose underlying task is a
Supplier
.
- forSupplier(Supplier<V>) - Static method in class com.bluegosling.concurrent.scheduler.TaskImplementation
-
Returns a task for the specified source implementation.
- forTesting(Class<T>) - Static method in class com.bluegosling.testing.ObjectVerifiers
-
Returns a special object verifier that returns a testing proxy.
- forTesting(Class<T>, ClassLoader) - Static method in class com.bluegosling.testing.ObjectVerifiers
-
Returns a special object verifier that returns a testing proxy.
- forThreadLocal(ThreadLocal<T>) - Static method in interface com.bluegosling.concurrent.executors.ContextPropagator
-
Creates a
ContextPropagator
that propagates the value of the given thread-local
variable.
- forThreadLocalClearAfterTask(ThreadLocal<T>) - Static method in interface com.bluegosling.concurrent.executors.ContextPropagator
-
Creates a
ContextPropagator
that propagates the value of the given thread-local
variable, clearing thread-local state after each task.
- forTreeMap() - Static method in interface com.bluegosling.collections.maps.MapBuilder
-
Returns a map builder that constructs
TreeMap
instances.
- forTreeMap(Comparator<? super K>) - Static method in interface com.bluegosling.collections.maps.MapBuilder
-
Returns a map builder that constructs
TreeMap
instances that orders elements per the
given comparator.
- forType(ArType) - Static method in class com.bluegosling.apt.reflect.ArClass
-
- forType(Type) - Static method in class com.bluegosling.apt.reflect.ArTypes
-
- forType(Type, Elements, Types) - Static method in class com.bluegosling.apt.reflect.ArTypes
-
- forType(AnnotatedType) - Static method in class com.bluegosling.reflect.AnnotatedTypeRef
-
Constructs a type token that represents a specified java.lang.reflect.Type
.
- forType(Type) - Static method in class com.bluegosling.reflect.TypeRef
-
Constructs a type token that represents a specified java.lang.reflect.Type
.
- forTypeMirror(ArrayType) - Static method in class com.bluegosling.apt.reflect.ArArrayType
-
Creates an array type from the specified type mirror.
- forTypeMirror(TypeMirror) - Static method in class com.bluegosling.apt.reflect.ArClass
-
Creates a class corresponding to the specified type mirror.
- forTypeMirror(DeclaredType) - Static method in class com.bluegosling.apt.reflect.ArDeclaredType
-
- forTypeMirror(TypeMirror) - Static method in class com.bluegosling.apt.reflect.ArPrimitiveType
-
- forTypeMirror(TypeMirror) - Static method in class com.bluegosling.apt.reflect.ArTypes
-
Returns a type that corresponds to the specified type mirror.
- forTypeMirror(TypeVariable) - Static method in class com.bluegosling.apt.reflect.ArTypeVariable
-
Creates a type variable from the specified type mirror.
- forTypeMirror(WildcardType) - Static method in class com.bluegosling.apt.reflect.ArWildcardType
-
Creates a wildcard type from the specified type mirror.
- forUnmodifiableMap() - Static method in interface com.bluegosling.collections.maps.MapBuilder
-
Returns a map builder that constructs unmodifiable maps.
- forUnmodifiableMap(MapBuilder<K, V, ?, ?>) - Static method in interface com.bluegosling.collections.maps.MapBuilder
-
Returns a map builder that constructs unmodifiable maps.
- forVisitor(FutureVisitor<T>) - Static method in interface com.bluegosling.concurrent.fluent.FutureListener
-
Creates a listener that will visit the completed future.
- forWriteLock() - Method in interface com.bluegosling.concurrent.locks.Locking.ReadWriteLocking
-
Returns a locking interface that corresponds to the write (e.g.
- from(CharSequence) - Static method in interface com.bluegosling.collections.primitive.CharIterator
-
- fromArray(Object...) - Static method in class com.bluegosling.tuples.Tuples
-
Creates a new tuple with the same items as the specified array.
- fromBitfield(int) - Static method in enum com.bluegosling.apt.reflect.ArModifier
-
Returns a set of modifiers represented by the specified bitfield.
- fromBitFieldWithVisibility(int) - Static method in enum com.bluegosling.apt.reflect.ArModifier
-
- fromBits(Boolean[]) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- fromBits(Iterable<Boolean>) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- fromBits(boolean[]) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- fromBitSet(BitSet) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- fromBitTuple(long, int) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- fromBitTuple(long, int, BitSequence.BitOrder) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- fromByteBuffer(ByteBuffer) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- fromByteBuffer(ByteBuffer, BitSequence.BitOrder) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- fromBytes(byte[]) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- fromBytes(byte[], BitSequence.BitOrder) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- fromCallable(Callable<? extends T>) - Static method in class com.bluegosling.function.Suppliers
-
- fromCallable(Callable<T>) - Static method in class com.bluegosling.util.Cloners
-
Creates a cloner that gets the clone from the specified object.
- fromCharBuffer(CharBuffer) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- fromCharBuffer(CharBuffer, Charset) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- fromCharBuffer(CharBuffer, BitSequence.BitOrder) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- fromCharBuffer(CharBuffer, Charset, BitSequence.BitOrder) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- fromChars(char[]) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- fromChars(char[], Charset) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- fromChars(char[], BitSequence.BitOrder) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- fromChars(char[], Charset, BitSequence.BitOrder) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- fromCollection(Collection<T>) - Static method in class com.bluegosling.collections.MoreMaps
-
Returns a view of the given collection as an identity map.
- fromCollection(Collection<E>) - Static method in class com.bluegosling.collections.MoreSets
-
Returns a view of the given collection as a set.
- fromCollection(Collection<?>) - Static method in class com.bluegosling.tuples.Tuples
-
Creates a new tuple with the same items as the specified collection.
- fromComparator(Comparator<T>) - Static method in class com.bluegosling.testing.ObjectVerifiers
-
Returns an object that verifies that the test object matches the reference object by using the
specified Comparator
.
- fromCompletableFuture(CompletableFuture<T>) - Static method in interface com.bluegosling.concurrent.futures.CompletionStageFuture
-
- fromCompletedFuture(Future<T>) - Static method in class com.bluegosling.result.Result
-
Returns a result with the same disposition as the given completed future.
- fromCompletionStage(CompletionStage<T>) - Static method in interface com.bluegosling.concurrent.fluent.FluentFuture
-
- fromCompletionStage(CompletionStage<T>) - Static method in interface com.bluegosling.concurrent.futures.CompletionStageFuture
-
- fromCondition(Condition, Lock, BooleanSupplier) - Static method in interface com.bluegosling.concurrent.Awaitable
-
- fromCoreReflection() - Static method in class com.bluegosling.reflect.model.AnnotationMirrors
-
- fromCoreReflection() - Static method in interface com.bluegosling.reflect.model.Elements
-
Returns an
Elements
utility class that is backed by core reflection.
- fromCoreReflection() - Static method in interface com.bluegosling.reflect.model.Types
-
Returns a
Types
utility class that is backed by core reflection.
- fromDeque(Deque<T>) - Static method in interface com.bluegosling.collections.Stack
-
Adapts the
Deque
interface to this interface.
- fromElementModifier(Modifier) - Static method in enum com.bluegosling.apt.reflect.ArModifier
-
- fromElementModifiers(Set<Modifier>) - Static method in enum com.bluegosling.apt.reflect.ArModifier
-
Converts a set of
Modifier
s to a set of modifiers.
- fromElementModifiersWithVisibility(Set<Modifier>) - Static method in enum com.bluegosling.apt.reflect.ArModifier
-
- fromFunction(Function<? super I, Optional<? extends O>>) - Static method in class com.bluegosling.function.PartialFunctions
-
- fromFunction(BiFunction<? super I1, ? super I2, Optional<? extends O>>) - Static method in class com.bluegosling.function.PartialFunctions
-
- fromFunction(TriFunction<? super I1, ? super I2, ? super I3, Optional<? extends O>>) - Static method in class com.bluegosling.function.PartialFunctions
-
- fromFunction(Function<T, Boolean>) - Static method in class com.bluegosling.function.Predicates
-
Converts a function into a predicate.
- fromFunction(BiFunction<T1, T2, Boolean>) - Static method in class com.bluegosling.function.Predicates
-
Converts a bivariate function into a bivariate predicate.
- fromFunction(TriFunction<T1, T2, T3, Boolean>) - Static method in class com.bluegosling.function.Predicates
-
Converts a three-argument function into a three-argument predicate.
- fromFunction(Function<I, O>) - Static method in interface com.bluegosling.reflect.caster.Converter
-
Returns a converter that applies the given function on the object to convert and returns its
result.
- fromFuture(Future<?>) - Static method in interface com.bluegosling.concurrent.Awaitable
-
- fromFuture(Future<?>) - Static method in interface com.bluegosling.concurrent.Cancellable
-
- fromFutures(Future<?>...) - Static method in interface com.bluegosling.concurrent.Cancellable
-
- fromFutures(Iterable<? extends Future<?>>) - Static method in interface com.bluegosling.concurrent.Cancellable
-
- fromInstance(T) - Static method in class com.bluegosling.util.Cloners
-
Creates a cloner that just returns the specified object.
- fromInstances(Object...) - Static method in class com.bluegosling.util.Cloners
-
Creates a list of cloners that just return the specified objects.
- fromInstances(List<?>) - Static method in class com.bluegosling.util.Cloners
-
Creates a list of cloners that just return the specified objects.
- fromInt(int) - Static method in enum com.bluegosling.collections.SpliteratorCharacteristics
-
Returns the set of characteristics represented by the given int bitmask.
- fromIntBuffer(IntBuffer) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- fromIntBuffer(IntBuffer, BitSequence.BitOrder) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- fromIntrinsic(Object, BooleanSupplier) - Static method in interface com.bluegosling.concurrent.Awaitable
-
- fromInts(int[]) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- fromInts(int[], BitSequence.BitOrder) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- fromIterator(Iterator<Boolean>) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- fromJrePriorityQueue(PriorityQueue<E>) - Static method in interface com.bluegosling.collections.queues.OrderedQueue
-
- fromLatch(CountDownLatch) - Static method in interface com.bluegosling.concurrent.Awaitable
-
- fromList(List<T>) - Static method in interface com.bluegosling.collections.Stack
-
Adapts the
List
interface to this interface.
- fromLongBuffer(LongBuffer) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- fromLongBuffer(LongBuffer, BitSequence.BitOrder) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- fromLongs(long[]) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- fromLongs(long[], BitSequence.BitOrder) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- fromMap(Map<? super K, ? extends V>) - Static method in class com.bluegosling.function.PartialFunctions
-
Returns a partial function that is backed by a map.
- fromMinMaxPriorityQueue(MinMaxPriorityQueue<E>) - Static method in interface com.bluegosling.collections.queues.OrderedDeque
-
- fromPossible(Possible<T>) - Static method in class com.bluegosling.possible.Optionals
-
- fromProcessingEnvironment(ProcessingEnvironment) - Static method in class com.bluegosling.reflect.model.AnnotationMirrors
-
Returns an
AnnotationMirrors
utility class that is backed by an annotation processing
environment.
- fromProcessingEnvironment(ProcessingEnvironment) - Static method in interface com.bluegosling.reflect.model.Elements
-
Returns an
Elements
utility class that is backed by an annotation processing
environment.
- fromProcessingEnvironment(ProcessingEnvironment) - Static method in interface com.bluegosling.reflect.model.Types
-
Returns a
Types
utility class that is backed by an annotation processing
environment.
- fromShortBuffer(ShortBuffer) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- fromShortBuffer(ShortBuffer, BitSequence.BitOrder) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- fromShorts(short[]) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- fromShorts(short[], BitSequence.BitOrder) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- fromSpliterator(Spliterator<? extends T>) - Static method in interface com.bluegosling.streams.FluentStream
-
Creates a fluent stream from the given spliterator.
- fromSpliterator(Supplier<? extends Spliterator<? extends T>>, int) - Static method in interface com.bluegosling.streams.FluentStream
-
Creates a fluent stream from the given spliterator source, with the given characteristics.
- fromSpliterator(Supplier<? extends Spliterator<? extends T>>, int, Comparator<? super T>) - Static method in interface com.bluegosling.streams.FluentStream
-
Creates a fluent stream from the given spliterator source, with the given characteristics and
the given comparator if the source of data is sorted.
- fromString(CharSequence) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- fromString(CharSequence, Charset) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- fromString(CharSequence, BitSequence.BitOrder) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- fromString(CharSequence, Charset, BitSequence.BitOrder) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- fromTerminatingExecutor(ExecutorService) - Static method in interface com.bluegosling.concurrent.Awaitable
-
Creates an awaitable that waits for the given
ExecutorService
to terminate.
- fulfill(T) - Method in interface com.bluegosling.possible.Fulfillable
-
Fulfills the value.
- Fulfillable<T> - Interface in com.bluegosling.possible
-
A possible value that can be set exactly once.
- fulfillableFromFuture(SettableFuture<T>) - Static method in class com.bluegosling.concurrent.extras.FuturePossibles
-
- fulfillableFromFuture(SettableFluentFuture<T>) - Static method in class com.bluegosling.concurrent.extras.FuturePossibles
-
- fulfillableFromFuture(CompletableFuture<T>) - Static method in class com.bluegosling.concurrent.extras.FuturePossibles
-
- fulfilled(T) - Static method in interface com.bluegosling.possible.Fulfillable
-
Creates a value that is already fulfilled.
- function() - Method in class com.bluegosling.collections.TransformingIterable
-
Gets the function used to transform elements.
- Functions - Class in com.bluegosling.function
-
Numerous utility methods for using
Function
s.
- FutureListener<T> - Interface in com.bluegosling.concurrent.fluent
-
A listener for the completion of a future.
- FuturePossibles - Class in com.bluegosling.concurrent.extras
-
- FutureTuples - Class in com.bluegosling.concurrent.extras
-
- FutureTuples() - Constructor for class com.bluegosling.concurrent.extras.FutureTuples
-
- FutureVisitor<T> - Interface in com.bluegosling.concurrent.fluent
-
Interface for the visitor pattern with
Future
s.
- generateModel() - Method in class com.bluegosling.buildgen.BuildGen
-
- Generator<T,U,X extends Throwable> - Class in com.bluegosling.generator
-
Provides generator functionality in Java.
- Generator() - Constructor for class com.bluegosling.generator.Generator
-
Constructs a new generator that uses a default, shared thread pool to run generation logic.
- Generator(Executor) - Constructor for class com.bluegosling.generator.Generator
-
Constructs a new generator that uses the given executor to run generation logic.
- Generator.Output<T,U> - Interface in com.bluegosling.generator
-
Represents the output of a generated sequence.
- GENERIC_CLONER - Static variable in class com.bluegosling.util.Cloners
-
A generic cloner that will try to clone any type of object.
- GenericMethodSignature - Class in com.bluegosling.reflect
-
Represents a generic method signature, composed of a method name and sequence of parameter types.
- GenericMethodSignature(Method) - Constructor for class com.bluegosling.reflect.GenericMethodSignature
-
Constructs a new signature for the specified method.
- GenericMethodSignature(String, Type...) - Constructor for class com.bluegosling.reflect.GenericMethodSignature
-
Constructs a new signature based on the given name and list of arguments.
- GenericMethodSignature(String, List<Type>) - Constructor for class com.bluegosling.reflect.GenericMethodSignature
-
Constructs a new signature based on the given name and list of arguments.
- get() - Static method in class com.bluegosling.apt.ProcessingEnvironments
-
Gets the environment for the current thread.
- get() - Method in class com.bluegosling.choice.AnyOfFive
-
- get() - Method in class com.bluegosling.choice.AnyOfFour
-
- get() - Method in class com.bluegosling.choice.AnyOfThree
-
- get() - Method in interface com.bluegosling.choice.Choice
-
Retrieves the value of whichever option is present.
- get() - Method in class com.bluegosling.choice.Either
-
- get() - Method in class com.bluegosling.choice.Union2
-
- get() - Method in class com.bluegosling.choice.Union3
-
- get() - Method in class com.bluegosling.choice.Union4
-
- get() - Method in class com.bluegosling.choice.Union5
-
- get(Object) - Method in class com.bluegosling.collections.AbstractNavigableMap
- get(Object) - Method in class com.bluegosling.collections.concurrent.DoubleInstanceLockedTreeMap
-
- get(int) - Method in class com.bluegosling.collections.concurrent.PersistentListBackedConcurrentList
-
- get(Object) - Method in class com.bluegosling.collections.concurrent.PersistentMapBackedConcurrentMap
-
- get(Object) - Method in class com.bluegosling.collections.DescendingMap
-
- get(int) - Method in class com.bluegosling.collections.FilteringList
-
- get(Object) - Method in class com.bluegosling.collections.FilteringMap
-
- get(int) - Method in class com.bluegosling.collections.immutable.AbstractLinkedImmutableList
-
- get(int) - Method in class com.bluegosling.collections.immutable.AmtPersistentList
-
- get(Object) - Method in class com.bluegosling.collections.immutable.HamtPersistentMap
-
- get(int) - Method in class com.bluegosling.collections.lists.ArrayBackedLinkedList
- get(int) - Method in class com.bluegosling.collections.lists.TreeList
-
- get(int) - Method in class com.bluegosling.collections.lists.UnrolledLinkedList
-
- get(int) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.RandomAccessEntrySet
-
- get(int) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.RandomAccessKeySet
-
- get(Object) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.SubMapByIndices
-
- get(int) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.ValueList
-
- get(Object) - Method in class com.bluegosling.collections.maps.HamtMap
-
- get(Object) - Method in class com.bluegosling.collections.maps.LinearHashingMap
-
- get(Object) - Method in class com.bluegosling.collections.maps.WeightBalancedTreeMap
-
- get(int) - Method in class com.bluegosling.collections.NoCopyGrowableArray
-
- get(int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfBoolean
-
- get(int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfByte
-
- get(int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfChar
-
- get(int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfDouble
-
- get(int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfFloat
-
- get(int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfInt
-
- get(int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfLong
-
- get(int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfShort
-
- get(int) - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- get(int) - Method in class com.bluegosling.collections.queues.RandomAccessArrayDeque
-
- get(int) - Method in class com.bluegosling.collections.sets.DescendingRandomAccessSet
-
- get(int) - Method in interface com.bluegosling.collections.sets.RandomAccessSet
-
Retrieves the item at the specified index.
- get(int) - Method in class com.bluegosling.collections.sets.RandomAccessSetList
-
- get(int) - Method in class com.bluegosling.collections.sets.TransformingRandomAccessSet.Bidi
-
- get(int) - Method in class com.bluegosling.collections.sets.TransformingRandomAccessSet
-
- get(int) - Method in class com.bluegosling.collections.sets.TransformingRandomAccessSet.ReadOnly
-
- get(Object, Object) - Method in interface com.bluegosling.collections.tables.Table2D
-
- get(Object, Object, Object) - Method in interface com.bluegosling.collections.tables.Table3D
-
- get(Object, Object, Object, Object) - Method in interface com.bluegosling.collections.tables.Table4D
-
- get(Object, Object, Object, Object, Object) - Method in interface com.bluegosling.collections.tables.Table5D
-
- get(Object) - Method in interface com.bluegosling.collections.tables.TableMapView
-
Returns the value mapped to the given key.
- get(int) - Method in class com.bluegosling.collections.TransformingList
-
- get(Object) - Method in class com.bluegosling.collections.TransformingMap.Bidi
-
- get(Object) - Method in class com.bluegosling.collections.TransformingMap
-
- get(Object) - Method in class com.bluegosling.collections.TransformingMap.ReadOnly.ValuesOnly
-
- get(Object) - Method in class com.bluegosling.collections.TransformingMap.ValuesOnly
-
- get(Object) - Method in class com.bluegosling.collections.tries.ArrayMappedBitwiseTrie
-
- get(Object) - Method in class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- get(long) - Method in class com.bluegosling.collections.tries.RadixTrieMap
-
Gets the value at the specified key.
- get(Object) - Method in class com.bluegosling.collections.tries.RadixTrieMap
-
- get(Object) - Method in class com.bluegosling.collections.tries.SimpleBitwiseTrie
-
- get() - Method in class com.bluegosling.concurrent.atoms.AsynchronousAtom
-
Retrieves the current value for this atom.
- get() - Method in interface com.bluegosling.concurrent.atoms.Atom
-
Retrieves the current value for this atom.
- get() - Method in class com.bluegosling.concurrent.atoms.SimpleAtom
-
- get() - Method in class com.bluegosling.concurrent.atoms.ThreadLocalAtom
-
- get() - Method in class com.bluegosling.concurrent.atoms.TransactionalAtom
-
Retrieves the current value for this atom.
- get() - Method in class com.bluegosling.concurrent.contended.ContendedBoolean
-
Returns the current value.
- get() - Method in class com.bluegosling.concurrent.contended.ContendedInteger
-
Gets the current value.
- get() - Method in class com.bluegosling.concurrent.contended.ContendedLong
-
Gets the current value.
- get() - Method in class com.bluegosling.concurrent.contended.ContendedReference
-
Gets the current value.
- get() - Method in class com.bluegosling.concurrent.fluent.AbstractFluentFuture
-
- get(long, TimeUnit) - Method in class com.bluegosling.concurrent.fluent.AbstractFluentFuture
-
- get() - Method in class com.bluegosling.concurrent.fluent.FluentFutureTask
-
- get(long, TimeUnit) - Method in class com.bluegosling.concurrent.fluent.FluentFutureTask
-
- get() - Method in interface com.bluegosling.concurrent.ManagedBlockers.InterruptibleSupplier
-
- get(long) - Method in interface com.bluegosling.concurrent.ManagedBlockers.TimedInterruptibleSupplier
-
- get(long) - Method in interface com.bluegosling.concurrent.ManagedBlockers.TimedInterruptibleWait
-
- get() - Static method in class com.bluegosling.concurrent.SameThreadExecutor
-
- get() - Method in class com.bluegosling.possible.Holder
-
- get() - Method in interface com.bluegosling.possible.Possible
-
Gets the contained value if present.
- get() - Method in class com.bluegosling.possible.Reference
-
- get() - Method in class com.bluegosling.reflect.blaster.Blaster.Result
-
Gets the result value.
- get() - Method in interface com.bluegosling.reflect.EnumType.EnumElement
-
Returns the actual value of the enum element.
- get() - Method in class com.bluegosling.result.Result
-
Gets the value of this result.
- get(int) - Method in class com.bluegosling.tuples.NTuple
-
Retrieves an item from the tuple using its index.
- get() - Method in class com.bluegosling.vars.Variable
-
Gets this variable's current value.
- get() - Method in class com.bluegosling.vars.VariableBoolean
-
Gets this variable's current value.
- get() - Method in class com.bluegosling.vars.VariableByte
-
Gets this variable's current value.
- get() - Method in class com.bluegosling.vars.VariableChar
-
Gets this variable's current value.
- get() - Method in class com.bluegosling.vars.VariableDouble
-
Gets this variable's current value.
- get() - Method in class com.bluegosling.vars.VariableFloat
-
Gets this variable's current value.
- get() - Method in class com.bluegosling.vars.VariableInt
-
Gets this variable's current value.
- get() - Method in class com.bluegosling.vars.VariableLong
-
Gets this variable's current value.
- get() - Method in class com.bluegosling.vars.VariableShort
-
Gets this variable's current value.
- get3rdPartyTargetForPackage(String) - Method in class com.bluegosling.buildgen.BuildGen.Settings
-
- getActiveCount() - Method in class com.bluegosling.concurrent.executors.ActorThreadPool
-
Returns the count of active worker threads.
- getActualTypeArguments() - Method in class com.bluegosling.apt.reflect.ArDeclaredType
-
Returns a list of the actual values supplied for the type variables.
- getActualTypeArguments(AnnotatedType) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
Returns the actual type arguments if the given type is a parameterized type.
- getActualTypeArguments(Type) - Static method in class com.bluegosling.reflect.Types
-
Returns the actual type arguments if the given type is a parameterized type.
- getAllAnnotatedSupertypes(AnnotatedType) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
Returns the set of all supertypes for the given annotated type.
- getAllDerivationSources(Class<?>) - Static method in class com.bluegosling.derivations.Derivations
-
Gets all sources, both direct and indirect, from which the specified type is derived.
- getAllDiagnostics() - Method in class com.bluegosling.apt.testing.CategorizingDiagnosticCollector
-
Gets a view of all diagnostics collected so far.
- getAllExceptions() - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfiguration
-
Determine the set of all exceptions thrown from the method signature configured by
this object.
- getAllScanExceptions() - Method in class com.bluegosling.reflect.scanner.PackageScanner.PathResult
-
Returns all exceptions encountered while trying to scan and resolve classes.
- getAllSupertypes(Type) - Static method in class com.bluegosling.reflect.Types
-
Returns the set of all supertypes for the given type.
- getAmbiguousDispatchMethods() - Method in exception com.bluegosling.reflect.caster.AmbiguousMethodException
-
- getAndAccumulate(T, BiFunction<? super T, ? super T, ? extends T>) - Method in class com.bluegosling.concurrent.atoms.AsynchronousAtom
-
- getAndAccumulate(T, BiFunction<? super T, ? super T, ? extends T>) - Method in interface com.bluegosling.concurrent.atoms.SynchronousAtom
-
Combines the atom's value with the given value, using the given function.
- getAndAccumulate(int, IntBinaryOperator) - Method in class com.bluegosling.concurrent.contended.ContendedInteger
-
Atomically updates the current value with the results of applying the given function to the
current and given values, returning the previous value.
- getAndAccumulate(long, LongBinaryOperator) - Method in class com.bluegosling.concurrent.contended.ContendedLong
-
Atomically updates the current value with the results of applying the given function to the
current and given values, returning the previous value.
- getAndAccumulate(V, BinaryOperator<V>) - Method in class com.bluegosling.concurrent.contended.ContendedReference
-
Atomically updates the current value with the results of applying the given function to the
current and given values, returning the previous value.
- getAndAccumulate(T, BinaryOperator<T>) - Method in class com.bluegosling.vars.Variable
-
Accumulates the given value into this variable, using the given function to combine the
current value with the given one.
- getAndAccumulate(boolean, BooleanBinaryOperator) - Method in class com.bluegosling.vars.VariableBoolean
-
Accumulates the given value into the variable using the given function.
- getAndAccumulate(byte, ByteBinaryOperator) - Method in class com.bluegosling.vars.VariableByte
-
Accumulates the given value into the variable using the given function.
- getAndAccumulate(char, CharBinaryOperator) - Method in class com.bluegosling.vars.VariableChar
-
Accumulates the given value into the variable using the given function.
- getAndAccumulate(double, DoubleBinaryOperator) - Method in class com.bluegosling.vars.VariableDouble
-
Accumulates the given value into the variable using the given function.
- getAndAccumulate(float, FloatBinaryOperator) - Method in class com.bluegosling.vars.VariableFloat
-
Accumulates the given value into the variable using the given function.
- getAndAccumulate(int, IntBinaryOperator) - Method in class com.bluegosling.vars.VariableInt
-
Accumulates the given value into the variable using the given function.
- getAndAccumulate(long, LongBinaryOperator) - Method in class com.bluegosling.vars.VariableLong
-
Accumulates the given value into the variable using the given function.
- getAndAccumulate(short, ShortBinaryOperator) - Method in class com.bluegosling.vars.VariableShort
-
Accumulates the given value into the variable using the given function.
- getAndAdd(int) - Method in class com.bluegosling.concurrent.contended.ContendedInteger
-
Atomically adds the given value to the current value.
- getAndAdd(long) - Method in class com.bluegosling.concurrent.contended.ContendedLong
-
Atomically adds the given value to the current value.
- getAndAdd(byte) - Method in class com.bluegosling.vars.VariableByte
-
Adds the given amount to the variable.
- getAndAdd(int) - Method in class com.bluegosling.vars.VariableInt
-
Adds the given amount to the variable.
- getAndAdd(long) - Method in class com.bluegosling.vars.VariableLong
-
Adds the given amount to the variable.
- getAndAdd(short) - Method in class com.bluegosling.vars.VariableShort
-
Adds the given amount to the variable.
- getAndDecrement() - Method in class com.bluegosling.concurrent.contended.ContendedInteger
-
Atomically decrements by one the current value.
- getAndDecrement() - Method in class com.bluegosling.concurrent.contended.ContendedLong
-
Atomically decrements by one the current value.
- getAndDecrement() - Method in class com.bluegosling.vars.VariableByte
-
Decrements the variable by one.
- getAndDecrement() - Method in class com.bluegosling.vars.VariableInt
-
Decrements the variable by one.
- getAndDecrement() - Method in class com.bluegosling.vars.VariableLong
-
Decrements the variable by one.
- getAndDecrement() - Method in class com.bluegosling.vars.VariableShort
-
Decrements the variable by one.
- getAndIncrement() - Method in class com.bluegosling.concurrent.contended.ContendedInteger
-
Atomically increments by one the current value.
- getAndIncrement() - Method in class com.bluegosling.concurrent.contended.ContendedLong
-
Atomically increments by one the current value.
- getAndIncrement() - Method in class com.bluegosling.vars.VariableByte
-
Increments the variable by one.
- getAndIncrement() - Method in class com.bluegosling.vars.VariableInt
-
Increments the variable by one.
- getAndIncrement() - Method in class com.bluegosling.vars.VariableLong
-
Increments the variable by one.
- getAndIncrement() - Method in class com.bluegosling.vars.VariableShort
-
Increments the variable by one.
- getAndSet(boolean) - Method in class com.bluegosling.concurrent.contended.ContendedBoolean
-
Atomically sets to the given value and returns the previous value.
- getAndSet(int) - Method in class com.bluegosling.concurrent.contended.ContendedInteger
-
Atomically sets to the given value and returns the old value.
- getAndSet(long) - Method in class com.bluegosling.concurrent.contended.ContendedLong
-
Atomically sets to the given value and returns the old value.
- getAndSet(V) - Method in class com.bluegosling.concurrent.contended.ContendedReference
-
Atomically sets to the given value and returns the old value.
- getAndSet(T) - Method in class com.bluegosling.vars.Variable
-
Sets this variable's value, returning the previously held value.
- getAndSet(boolean) - Method in class com.bluegosling.vars.VariableBoolean
-
Sets this variable's value, returning the previously held value.
- getAndSet(byte) - Method in class com.bluegosling.vars.VariableByte
-
Sets this variable's value, returning the previously held value.
- getAndSet(char) - Method in class com.bluegosling.vars.VariableChar
-
Sets this variable's value, returning the previously held value.
- getAndSet(double) - Method in class com.bluegosling.vars.VariableDouble
-
Sets this variable's value, returning the previously held value.
- getAndSet(float) - Method in class com.bluegosling.vars.VariableFloat
-
Sets this variable's value, returning the previously held value.
- getAndSet(int) - Method in class com.bluegosling.vars.VariableInt
-
Sets this variable's value, returning the previously held value.
- getAndSet(long) - Method in class com.bluegosling.vars.VariableLong
-
Sets this variable's value, returning the previously held value.
- getAndSet(short) - Method in class com.bluegosling.vars.VariableShort
-
Sets this variable's value, returning the previously held value.
- getAndUpdate(Function<? super T, ? extends T>) - Method in class com.bluegosling.concurrent.atoms.AsynchronousAtom
-
Applies a function to the atom's value.
- getAndUpdate(Function<? super T, ? extends T>) - Method in interface com.bluegosling.concurrent.atoms.SynchronousAtom
-
Applies a function to the atom's value.
- getAndUpdate(Function<? super T, ? extends T>) - Method in class com.bluegosling.concurrent.atoms.TransactionalAtom
-
Applies a function to the atom's value.
- getAndUpdate(IntUnaryOperator) - Method in class com.bluegosling.concurrent.contended.ContendedInteger
-
Atomically updates the current value with the results of applying the given function,
returning the previous value.
- getAndUpdate(LongUnaryOperator) - Method in class com.bluegosling.concurrent.contended.ContendedLong
-
Atomically updates the current value with the results of applying the given function,
returning the previous value.
- getAndUpdate(UnaryOperator<V>) - Method in class com.bluegosling.concurrent.contended.ContendedReference
-
Atomically updates the current value with the results of applying the given function,
returning the previous value.
- getAndUpdate(UnaryOperator<T>) - Method in class com.bluegosling.vars.Variable
-
Updates the variable's current value using the given function.
- getAndUpdate(BooleanUnaryOperator) - Method in class com.bluegosling.vars.VariableBoolean
-
Updates the variable using the given function.
- getAndUpdate(ByteUnaryOperator) - Method in class com.bluegosling.vars.VariableByte
-
Updates the variable using the given function.
- getAndUpdate(CharUnaryOperator) - Method in class com.bluegosling.vars.VariableChar
-
Updates the variable using the given function.
- getAndUpdate(DoubleUnaryOperator) - Method in class com.bluegosling.vars.VariableDouble
-
Updates the variable using the given function.
- getAndUpdate(FloatUnaryOperator) - Method in class com.bluegosling.vars.VariableFloat
-
Updates the variable using the given function.
- getAndUpdate(IntUnaryOperator) - Method in class com.bluegosling.vars.VariableInt
-
Updates the variable using the given function.
- getAndUpdate(LongUnaryOperator) - Method in class com.bluegosling.vars.VariableLong
-
Updates the variable using the given function.
- getAndUpdate(ShortUnaryOperator) - Method in class com.bluegosling.vars.VariableShort
-
Updates the variable using the given function.
- getAnnotatedDirectSupertypes(AnnotatedType) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
Returns the set of annotated direct supertypes for the given type.
- getAnnotatedInterfaces(AnnotatedType) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
Returns the annotated interfaces implemented by the given type.
- getAnnotatedLeastUpperBounds(AnnotatedType...) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
Computes least upper bounds for the given array of types.
- getAnnotatedLeastUpperBounds(Iterable<? extends AnnotatedType>) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
Computes least upper bounds for the given annotated types.
- getAnnotatedSuperclass(AnnotatedType) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
Returns the generic superclass of the given type.
- getAnnotation(ArClass) - Method in interface com.bluegosling.apt.reflect.ArAnnotatedConstruct
-
Gets the annotation from the object that corresponds to the specified annotation type.
- getAnnotation(Class<? extends Annotation>) - Method in interface com.bluegosling.apt.reflect.ArAnnotatedConstruct
-
Gets the annotation from the object that corresponds to the specified annotation type.
- getAnnotation(ArClass) - Method in class com.bluegosling.apt.reflect.ArClass
-
- getAnnotation(Class<? extends Annotation>) - Method in class com.bluegosling.apt.reflect.ArClass
-
- getAnnotation(Class<A>) - Method in class com.bluegosling.reflect.AnnotatedTypeRef
-
- getAnnotation(Class<A>) - Method in class com.bluegosling.reflect.TypeRef
-
- getAnnotation(Type, Class<A>) - Static method in class com.bluegosling.reflect.Types
-
Finds the given annotation on the given type.
- getAnnotationAsMirror(Annotation) - Method in class com.bluegosling.reflect.model.AnnotationMirrors
-
Returns an annotation mirror that represents the given annotation.
- getAnnotationAsValue(Annotation) - Method in class com.bluegosling.reflect.model.AnnotationMirrors
-
Returns an annotation value for the given annotation.
- getAnnotationAttributes() - Method in class com.bluegosling.apt.reflect.ArAnnotation
-
Returns the annotation's attributes and values, including undeclared
attributes with their corresponding default value.
- getAnnotationBridge(Class<T>) - Method in interface com.bluegosling.apt.reflect.ArAnnotatedConstruct
-
Gets an annotation bridge for the specified annotation type.
- getAnnotationBridge(Class<T>) - Method in class com.bluegosling.apt.reflect.ArClass
-
- getAnnotations() - Method in interface com.bluegosling.apt.reflect.ArAnnotatedConstruct
-
Gets all annotations for this object.
- getAnnotations() - Method in class com.bluegosling.apt.reflect.ArClass
-
- getAnnotations() - Method in class com.bluegosling.reflect.AnnotatedTypeRef
-
- getAnnotations() - Method in class com.bluegosling.reflect.TypeRef
-
- getAnnotations(Type) - Static method in class com.bluegosling.reflect.Types
-
Finds all annotations on the given type.
- getAnnotationValue(Object) - Method in class com.bluegosling.reflect.model.AnnotationMirrors
-
Returns an annotation value for the given object.
- getArgumentCloners() - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfiguration
-
Returns the list of argument cloners.
- getArgumentVerifiers() - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfiguration
-
Returns the list of argument verifiers.
- getArrayAnnotationValue(Object) - Method in class com.bluegosling.reflect.model.AnnotationMirrors
-
Returns an annotation value for the given array or list.
- getArrayAnnotationValue(List<?>) - Method in class com.bluegosling.reflect.model.AnnotationMirrors
-
Returns an annotation value for the given list.
- getArrayAnnotationValue(Object[]) - Method in class com.bluegosling.reflect.model.AnnotationMirrors
-
Returns an annotation value for the given array.
- getArrayType(Class<T>) - Static method in class com.bluegosling.reflect.Types
-
Gets the class token that represents an array of the given component type.
- getArrayType(Type) - Static method in class com.bluegosling.reflect.Types
-
Returns an array type with the given component type.
- getArrayTypeMirror(Class<?>) - Method in interface com.bluegosling.reflect.model.Types
-
Returns a type mirror that represents the same type as the given array type.
- getArrayTypeMirror(AnnotatedArrayType) - Method in interface com.bluegosling.reflect.model.Types
-
Returns an array type mirror that represents the same type and has the same annotations as
given.
- getArrayTypeMirror(GenericArrayType) - Method in interface com.bluegosling.reflect.model.Types
-
Returns an array type mirror that represents the same type as given.
- getBatchCount() - Method in class com.bluegosling.concurrent.executors.ActorThreadPool
-
Returns the total number of batches executed by this executor.
- getBoolean(int) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfBoolean
-
- getBooleanAnnotationValue(boolean) - Method in class com.bluegosling.reflect.model.AnnotationMirrors
-
Returns an annotation value for the given boolean.
- getBounds() - Method in class com.bluegosling.apt.reflect.ArTypeParameter
-
Returns the upper bounds (aka "extends" bounds) for this type variable.
- getByKey(K) - Method in class com.bluegosling.collections.lists.AssociativeArrayList
-
- getByKey(K) - Method in interface com.bluegosling.collections.lists.AssociativeList
-
Retrieves a list element via its associative key.
- getByte(int) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfByte
-
- getByteAnnotationValue(byte) - Method in class com.bluegosling.reflect.model.AnnotationMirrors
-
Returns an annotation value for the given byte.
- getByteContents() - Method in class com.bluegosling.apt.testing.TestJavaFileObject
-
Gets the binary contents of the file.
- getCaller() - Static method in class com.bluegosling.reflect.CallingClass
-
- getCaller(Iterable<? extends ClassLoader>) - Static method in class com.bluegosling.reflect.CallingClass
-
- getCaller(int) - Static method in class com.bluegosling.reflect.CallingClass
-
- getCaller(int, Iterable<? extends ClassLoader>) - Static method in class com.bluegosling.reflect.CallingClass
-
- getCallerStackFrame() - Static method in class com.bluegosling.reflect.CallingClass
-
- getCallerStackFrame(Iterable<? extends ClassLoader>) - Static method in class com.bluegosling.reflect.CallingClass
-
- getCallerStackFrame(int) - Static method in class com.bluegosling.reflect.CallingClass
-
- getCallerStackFrame(int, Iterable<? extends ClassLoader>) - Static method in class com.bluegosling.reflect.CallingClass
-
- getCanonicalName() - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns the canonical name of this class.
- getCause() - Method in class com.bluegosling.reflect.blaster.BlasterException.BlasterExceptionCause
-
- getCauses() - Method in exception com.bluegosling.reflect.blaster.BlasterException
-
- getChar(int) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfChar
-
- getCharAnnotationValue(char) - Method in class com.bluegosling.reflect.model.AnnotationMirrors
-
Returns an annotation value for the given character.
- getCharContent(boolean) - Method in class com.bluegosling.apt.testing.TestJavaFileObject
-
- getCheckedExceptions() - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfiguration
-
Determines the set of checked exceptions thrown from the method signature configured by
this object.
- getClasses() - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns a set of all public member types for this class, including those that may have been
inherited from ancestor classes.
- getClassesFound(String) - Method in class com.bluegosling.reflect.scanner.PackageScanner.PathResult
-
Returns the set of classes found in this path that are in the given package.
- getClassesFound(String) - Method in class com.bluegosling.reflect.scanner.PackageScanner.ScanResult
-
- getClassKind() - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns the kind of this class object.
- getClassLoader(JavaFileManager.Location) - Method in class com.bluegosling.apt.testing.TestJavaFileManager
-
- getClassName() - Method in class com.bluegosling.buildgen.JavaClass
-
- getColumn(C) - Method in interface com.bluegosling.collections.tables.Table2D
-
- getColumn(P, C) - Method in interface com.bluegosling.collections.tables.Table3D
-
- getColumn(S, P, C) - Method in interface com.bluegosling.collections.tables.Table4D
-
- getColumn(L, S, P, C) - Method in interface com.bluegosling.collections.tables.Table5D
-
- getColumnKey() - Method in interface com.bluegosling.collections.tables.Table2D.Cell2D
-
- getColumnKey() - Method in interface com.bluegosling.collections.tables.Table3D.Cell3D
-
- getColumnKey() - Method in interface com.bluegosling.collections.tables.Table4D.Cell4D
-
- getColumnKey() - Method in interface com.bluegosling.collections.tables.Table5D.Cell5D
-
- getColumns(C) - Method in interface com.bluegosling.collections.tables.Table3D
-
- getColumns(C) - Method in interface com.bluegosling.collections.tables.Table4D
-
- getColumns(C) - Method in interface com.bluegosling.collections.tables.Table5D
-
- getCompilationUnits() - Method in class com.bluegosling.buildgen.SourceDependencyAnalyzer.Results
-
Returns all compilation units analyzed.
- getCompilationUnitsForPackage(File) - Method in class com.bluegosling.buildgen.SourceDependencyAnalyzer.Results
-
Returns the compilation units found in the given package directory
- getCompiler() - Method in class com.bluegosling.apt.testing.CompilationContext
-
Returns the system compiler that will be invoked when tasks are run in this context.
- getCompletedTaskCount() - Method in class com.bluegosling.concurrent.executors.ActorThreadPool
-
Returns the total number of tasks completed by this executor.
- getComponents(T) - Method in interface com.bluegosling.collections.tries.BitConverter
-
Breaks the specified object into a sequence of components.
- getComponents(T) - Method in interface com.bluegosling.collections.tries.Componentizer
-
Breaks the specified object into a sequence of components.
- getComponentType() - Method in class com.bluegosling.apt.reflect.ArArrayType
-
Gets the component type of the array.
- getComponentType() - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns an array class's component type.
- getComponentType(AnnotatedType) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
Returns the component type of the given array type.
- getComponentType(Type) - Static method in class com.bluegosling.reflect.Types
-
Returns the component type of the given array type.
- getComponentTypeRef() - Method in class com.bluegosling.reflect.AnnotatedTypeRef
-
Returns the component type, as a
TypeRef
, if this represents an array type.
- getComponentTypeRef() - Method in class com.bluegosling.reflect.TypeRef
-
Returns the component type, as a
TypeRef
, if this represents an array type.
- getConstructor(ArClass...) - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns the public constructor with the specified argument types.
- getConstructor(List<ArClass>) - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns the public constructor with the specified argument types.
- getConstructors() - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns the list of public constructors for this class.
- getContainedClasses() - Method in class com.bluegosling.buildgen.CompilationUnit
-
- getCorePoolSize() - Method in class com.bluegosling.concurrent.executors.ActorThreadPool
-
Returns the size of the core pool of worker threads.
- getCount() - Method in class com.bluegosling.concurrent.UpAndDownLatch
-
Returns the current number of references.
- getCurrentPoolSize() - Method in class com.bluegosling.concurrent.executors.ActorThreadPool
-
Returns the current size of the thread pool.
- getDeclaredAnnotationAttributes() - Method in class com.bluegosling.apt.reflect.ArAnnotation
-
Returns the annotation's attributes and values.
- getDeclaredAnnotations() - Method in interface com.bluegosling.apt.reflect.ArAnnotatedConstruct
-
Gets the annotations declared on this object.
- getDeclaredAnnotations() - Method in class com.bluegosling.apt.reflect.ArClass
-
- getDeclaredAnnotations() - Method in class com.bluegosling.reflect.AnnotatedTypeRef
-
- getDeclaredAnnotations() - Method in class com.bluegosling.reflect.TypeRef
-
- getDeclaredAnnotations(Type) - Static method in class com.bluegosling.reflect.Types
-
Finds all annotations declared on the given type.
- getDeclaredClasses() - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns a list of declared member types for this class.
- getDeclaredConstructor(ArClass...) - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns the constructor with the specified argument types.
- getDeclaredConstructor(List<ArClass>) - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns the constructor with the specified argument types.
- getDeclaredConstructors() - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns the list of declared constructors for this class.
- getDeclaredField(String) - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns the declared field with the specified name.
- getDeclaredFields() - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns the list of declared fields for this class.
- getDeclaredMethod(String, ArClass...) - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns the declared method with the specified signature.
- getDeclaredMethod(String, List<ArClass>) - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns the declared method with the specified signature.
- getDeclaredMethods() - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns the list of declared methods for this class.
- getDeclaredTypeMirror(Class<?>) - Method in interface com.bluegosling.reflect.model.Types
-
Returns a type mirror that represents the same type as the given declared type.
- getDeclaringClass() - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns the enclosing class of which this class is a member.
- getDeclaringClass() - Method in interface com.bluegosling.apt.reflect.ArMember
-
Returns the class which declared this member.
- getDefaultExceptionVerifier() - Method in class com.bluegosling.testing.InterfaceVerifier
-
Returns the default verifier used to verify exceptions thrown by methods.
- getDefaultMutatorVerifier() - Method in class com.bluegosling.testing.InterfaceVerifier
-
Returns the default verifier used to verify the implementations of mutator methods.
- getDefaultValue() - Method in class com.bluegosling.apt.reflect.ArMethod
-
Returns the default value for an annotation method.
- getDelay(TimeUnit) - Method in class com.bluegosling.concurrent.fluent.FluentScheduledFutureTask
-
- getDependencies(File) - Method in class com.bluegosling.buildgen.SourceDependencyAnalyzer.Results
-
Gets all compilation units on which the given file or directory depends.
- getDependencyPath(File, File) - Method in class com.bluegosling.buildgen.SourceDependencyAnalyzer.Results
-
Finds the dependency path from one given file or directory to another.
- getDependents(File) - Method in class com.bluegosling.buildgen.SourceDependencyAnalyzer.Results
-
Gets all compilation units that depend on the given source file or package directory.
- getDiagnosticCollector() - Method in class com.bluegosling.apt.testing.CompilationContext
-
Returns the diagnostic collector used to collect output from compiler invocations.
- getDiagnostics(Diagnostic.Kind) - Method in class com.bluegosling.apt.testing.CategorizingDiagnosticCollector
-
Gets a view of diagnostics of a given kind collected so far.
- getDiagnostics() - Method in exception com.bluegosling.apt.testing.CompilationFailedException
-
Retrieves the error diagnostics associated with this compilation failure.
- getDirectDerivationSources(Class<?>) - Static method in class com.bluegosling.derivations.Derivations
-
Gets the sources from which the specified type is directly derived.
- getDirectSupertypeAnnotations(Annotation) - Method in interface com.bluegosling.reflect.TypeAnnotationHierarchy
-
Returns the set of type annotations that qualify supertypes of types with the given
annotation.
- getDirectSupertypes(AnnotatedType) - Method in interface com.bluegosling.reflect.TypeAnnotationHierarchy
-
Returns the set of supertypes of the given annotated type.
- getDirectSupertypes(Type) - Static method in class com.bluegosling.reflect.Types
-
Returns the set of direct supertypes for the given type.
- getDirectSupertypeTypeRefs() - Method in class com.bluegosling.reflect.AnnotatedTypeRef
-
- getDirectSupertypeTypeRefs() - Method in class com.bluegosling.reflect.TypeRef
-
- getDispatchSettings() - Method in class com.bluegosling.reflect.caster.Caster
-
- getDouble(int) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfDouble
-
- getDoubleAnnotationValue(double) - Method in class com.bluegosling.reflect.model.AnnotationMirrors
-
Returns an annotation value for the given double.
- getElement() - Method in interface com.bluegosling.collections.queues.PriorityQueue.Entry
-
Gets the element in this entry.
- getEnclosingClass() - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns the enclosing class that contains this class.
- getEnclosingConstructor() - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns the constructor in which this class was declared.
- getEnclosingMember() - Method in class com.bluegosling.apt.reflect.ArParameter
-
Returns the constructor or method to which this parameter belongs.
- getEnclosingMethod() - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns the method in which this class was declared.
- getEntry(Object) - Method in class com.bluegosling.collections.AbstractNavigableMap
-
Finds an entry for a specified key.
- getEntry(Object) - Method in class com.bluegosling.collections.AbstractNavigableMap.SubMap
-
Finds an entry for a specified key.
- getEntry(Object) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.RandomAccessSubMap
-
Finds an entry for a specified key.
- getEntry(int) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.RandomAccessSubMap
-
- getEntry(Object) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.SubMapByIndices
-
- getEntry(int) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.SubMapByIndices
-
- getEntry(int) - Method in class com.bluegosling.collections.maps.DescendingRandomAccessMap
-
- getEntry(int) - Method in interface com.bluegosling.collections.maps.RandomAccessNavigableMap
-
Gets an entry from the map by random access index.
- getEntry(Object) - Method in class com.bluegosling.collections.maps.SortedArrayMap
-
- getEntry(int) - Method in class com.bluegosling.collections.maps.WeightBalancedTreeMap
-
- getEntry() - Method in class com.bluegosling.collections.queues.PriorityQueues.AutoEntry
-
Gets the element's associated queue entry.
- getEnumAnnotationValue(Enum<?>) - Method in class com.bluegosling.reflect.model.AnnotationMirrors
-
Returns an annotation value for the given enum.
- getEnumConstantElement(Enum<?>) - Method in interface com.bluegosling.reflect.model.Elements
-
Returns a variable element for the given enum constant.
- getEnumConstants() - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns the list of enum constants for this class.
- getErasure(AnnotatedType) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- getErasure(Type) - Static method in class com.bluegosling.reflect.Types
-
Determines the erasure for the given type.
- getErrorHandler() - Method in class com.bluegosling.concurrent.atoms.AsynchronousAtom
-
Returns the atom's error handler.
- getExceptionTypes() - Method in interface com.bluegosling.apt.reflect.ArExecutableMember
-
Returns the list of declared exception types that can be thrown by this executable member.
- getExceptionVerifier() - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfiguration
-
Returns the verifier used to check exceptions thrown from method calls.
- getExclusiveHolder() - Method in class com.bluegosling.concurrent.locks.HierarchicalLock
-
Gets the thread that holds this lock in exclusive mode.
- getExclusiveQueuedThreads() - Method in class com.bluegosling.concurrent.AbstractQueuedReferenceSynchronizer
-
Returns a collection containing threads that may be waiting to acquire in exclusive mode.
- getExecutableElement(Executable) - Method in interface com.bluegosling.reflect.model.Elements
-
Returns an executable element for the given executable.
- getExtendsBound() - Method in class com.bluegosling.apt.reflect.ArWildcardType
-
Returns a bound that the wildcard type must extend.
- getExternalClasses() - Method in class com.bluegosling.buildgen.SourceDependencyAnalyzer.Results
-
- getExternalDependencies(File) - Method in class com.bluegosling.buildgen.SourceDependencyAnalyzer.Results
-
- getExternalPackageContents(JavaPackage) - Method in class com.bluegosling.buildgen.SourceDependencyAnalyzer.Results
-
- getExternalPackageDependencies(File) - Method in class com.bluegosling.buildgen.SourceDependencyAnalyzer.Results
-
- getExternalPackages() - Method in class com.bluegosling.buildgen.SourceDependencyAnalyzer.Results
-
- getFailure() - Method in class com.bluegosling.concurrent.fluent.AbstractFluentFuture
-
- getFailure() - Method in interface com.bluegosling.concurrent.fluent.FluentFuture
-
Gets the cause of failure for a future.
- getFailure() - Method in class com.bluegosling.concurrent.fluent.FluentFutureTask
-
- getFailure() - Method in class com.bluegosling.reflect.blaster.Blaster.Result
-
Gets the throwable that caused the method invocation to fail.
- getFailure() - Method in exception com.bluegosling.result.FailedResultException
-
- getFailure() - Method in class com.bluegosling.result.Result
-
Gets the result's cause of failure.
- getField(String) - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns the public field with the specified name.
- getFieldElement(Field) - Method in interface com.bluegosling.reflect.model.Elements
-
Returns a variable element for the given field.
- getFields() - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns the list of all public fields for this class, including those inherited from ancestor
classes.
- getFifth() - Method in class com.bluegosling.choice.AnyOfFive
-
- getFifth() - Method in interface com.bluegosling.choice.Choice.Ops5
-
Retrieves the value of the fifth option, if it is present.
- getFifth() - Method in class com.bluegosling.choice.Union5
-
- getFifth() - Method in class com.bluegosling.tuples.NTuple
-
- getFifth() - Method in class com.bluegosling.tuples.Quintuple
-
- getFifth() - Method in interface com.bluegosling.tuples.Tuple.Ops5
-
Retrieves the fifth item in the tuple.
- getFileDependencyDetails(File, File) - Method in class com.bluegosling.buildgen.SourceDependencyAnalyzer.Results
-
Gets all file-level dependencies between the given two packages.
- getFileForInput(JavaFileManager.Location, String, String) - Method in class com.bluegosling.apt.testing.TestJavaFileManager
-
- getFileForOutput(JavaFileManager.Location, String, String, FileObject) - Method in class com.bluegosling.apt.testing.TestJavaFileManager
-
- getFileManager() - Method in class com.bluegosling.apt.testing.CompilationContext
-
Returns the file manager for this compilation context, used to seed input files or examine
output files.
- getFirst() - Method in class com.bluegosling.choice.AnyOfFive
-
- getFirst() - Method in class com.bluegosling.choice.AnyOfFour
-
- getFirst() - Method in class com.bluegosling.choice.AnyOfThree
-
- getFirst() - Method in interface com.bluegosling.choice.Choice
-
Retrieves the value of the first option, if it is present.
- getFirst() - Method in class com.bluegosling.choice.Either
-
- getFirst() - Method in class com.bluegosling.choice.Union2
-
- getFirst() - Method in class com.bluegosling.choice.Union3
-
- getFirst() - Method in class com.bluegosling.choice.Union4
-
- getFirst() - Method in class com.bluegosling.choice.Union5
-
- getFirst() - Method in class com.bluegosling.collections.AbstractDeque
-
- getFirst() - Method in class com.bluegosling.collections.lists.ArrayBackedLinkedList
- getFirst() - Method in class com.bluegosling.collections.lists.UnrolledLinkedList
-
- getFirst() - Method in interface com.bluegosling.collections.queues.OrderedDeque
-
- getFirst() - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- getFirst() - Method in class com.bluegosling.collections.queues.RandomAccessArrayDeque
-
- getFirst() - Method in class com.bluegosling.tuples.NTuple
-
- getFirst() - Method in class com.bluegosling.tuples.Pair
-
- getFirst() - Method in class com.bluegosling.tuples.Quadruple
-
- getFirst() - Method in class com.bluegosling.tuples.Quintuple
-
- getFirst() - Method in class com.bluegosling.tuples.Single
-
- getFirst() - Method in class com.bluegosling.tuples.Triple
-
- getFirst() - Method in interface com.bluegosling.tuples.Tuple.Ops1
-
Retrieves the first item in the tuple.
- getFirstQueuedThread() - Method in class com.bluegosling.concurrent.AbstractQueuedReferenceSynchronizer
-
Returns the first (longest-waiting) thread in the queue, or null
if no threads are
currently queued.
- getFirstQueuedThread() - Method in class com.bluegosling.concurrent.locks.HierarchicalLock
-
Gets the first queued thread.
- getFixedDelayNanos(Rescheduler<?>) - Static method in interface com.bluegosling.concurrent.fluent.Rescheduler
-
Returns the fixed delay, in nanoseconds, used by the given rescheduler.
- getFixedRatePeriodNanos(Rescheduler<?>) - Static method in interface com.bluegosling.concurrent.fluent.Rescheduler
-
Returns the fixed period, in nanoseconds, used by the given rescheduler.
- getFloat(int) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfFloat
-
- getFloatAnnotationValue(float) - Method in class com.bluegosling.reflect.model.AnnotationMirrors
-
Returns an annotation value for the given float.
- getFourth() - Method in class com.bluegosling.choice.AnyOfFive
-
- getFourth() - Method in class com.bluegosling.choice.AnyOfFour
-
- getFourth() - Method in interface com.bluegosling.choice.Choice.Ops4
-
Retrieves the value of the fourth option, if it is present.
- getFourth() - Method in class com.bluegosling.choice.Union4
-
- getFourth() - Method in class com.bluegosling.choice.Union5
-
- getFourth() - Method in class com.bluegosling.tuples.NTuple
-
- getFourth() - Method in class com.bluegosling.tuples.Quadruple
-
- getFourth() - Method in class com.bluegosling.tuples.Quintuple
-
- getFourth() - Method in interface com.bluegosling.tuples.Tuple.Ops4
-
Retrieves the fourth item in the tuple.
- getGenericDeclaration() - Method in class com.bluegosling.apt.reflect.ArTypeParameter
-
Returns the declaration for this type variable.
- getGenericExceptionTypes() - Method in interface com.bluegosling.apt.reflect.ArExecutableMember
-
Returns the list of declared exception types that can be thrown by this executable memebr.
- getGenericInterfaces() - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns the list of interfaces directly implemented by this class.
- getGenericInterfaces(Type) - Static method in class com.bluegosling.reflect.Types
-
Returns the generic interfaces implemented by the given type.
- getGenericParameterTypes() - Method in interface com.bluegosling.apt.reflect.ArExecutableMember
-
Returns the list of parameter types.
- getGenericReturnType() - Method in class com.bluegosling.apt.reflect.ArMethod
-
Returns the method's return type.
- getGenericSuperclass() - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns this class's super-class with generic type information.
- getGenericSuperclass(Type) - Static method in class com.bluegosling.reflect.Types
-
Returns the generic superclass of the given type.
- getGenericType() - Method in class com.bluegosling.apt.reflect.ArField
-
Returns the type of this field.
- getGenericType() - Method in class com.bluegosling.apt.reflect.ArParameter
-
Returns the type of this parameter.
- getImpliedExtraDepsFor(String) - Method in class com.bluegosling.buildgen.BuildGen.Settings
-
- getIndentLevel() - Method in class com.bluegosling.util.IndentingPrintWriter
-
Gets the current level of indentation.
- getInt(int) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfInt
-
- getIntAnnotationValue(int) - Method in class com.bluegosling.reflect.model.AnnotationMirrors
-
Returns an annotation value for the given integer.
- getInterfaces() - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns the list of interfaces directly implemented by this class.
- getInterfaces() - Method in class com.bluegosling.reflect.MethodCapturer
-
Returns the set of interfaces whose methods can be captured.
- getInterfaces(Type) - Static method in class com.bluegosling.reflect.Types
-
Returns the interfaces implemented by the given type.
- getInterfaces() - Method in class com.bluegosling.testing.InterfaceVerifier
-
Returns the set of interfaces supported by this verifier.
- getInterfaceTypeRefs() - Method in class com.bluegosling.reflect.AnnotatedTypeRef
-
Returns the interfaces implemented by the current type, as TypeRef
s.
- getInterfaceTypeRefs() - Method in class com.bluegosling.reflect.TypeRef
-
Returns the interfaces implemented by the current type, as TypeRef
s.
- getJavaFileForInput(JavaFileManager.Location, String, JavaFileObject.Kind) - Method in class com.bluegosling.apt.testing.TestJavaFileManager
-
- getJavaFileForOutput(JavaFileManager.Location, String, JavaFileObject.Kind, FileObject) - Method in class com.bluegosling.apt.testing.TestJavaFileManager
-
- getJitter() - Method in class com.bluegosling.concurrent.RateLimiter
-
Gets the current jitter amount.
- getKeepAliveTime(TimeUnit) - Method in class com.bluegosling.concurrent.executors.ActorThreadPool
-
Returns the duration for which idle (non-core) worker threads are kept alive.
- getKey() - Method in class com.bluegosling.collections.TransformingMapEntry
-
- getKeyIndex(K) - Method in class com.bluegosling.collections.lists.AssociativeArrayList
-
- getKeyIndex(K) - Method in interface com.bluegosling.collections.lists.AssociativeList
-
Finds the list index associated with a given key.
- getLargestPoolSize() - Method in class com.bluegosling.concurrent.executors.ActorThreadPool
-
Returns the largest observed size of the thread pool.
- getLast() - Method in class com.bluegosling.collections.AbstractDeque
-
- getLast() - Method in class com.bluegosling.collections.lists.ArrayBackedLinkedList
- getLast() - Method in class com.bluegosling.collections.lists.UnrolledLinkedList
-
- getLast() - Method in interface com.bluegosling.collections.queues.OrderedDeque
-
- getLast() - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- getLast() - Method in class com.bluegosling.collections.queues.RandomAccessArrayDeque
-
- getLastException() - Method in class com.bluegosling.testing.InterfaceVerifier
-
Returns the exception thrown during the most recent method invocation or null
if the
most recent invocation did not throw an exception.
- getLastModified() - Method in class com.bluegosling.apt.testing.TestJavaFileObject
-
- getLeastUpperBounds(Type...) - Static method in class com.bluegosling.reflect.Types
-
Computes least upper bounds for the given array of types.
- getLeastUpperBounds(Iterable<Type>) - Static method in class com.bluegosling.reflect.Types
-
Computes least upper bounds for the given types.
- getLocationClass() - Method in class com.bluegosling.reflect.CallingClass.StackFrame
-
- getLocationClassName() - Method in class com.bluegosling.reflect.CallingClass.StackFrame
-
- getLocationMethod() - Method in class com.bluegosling.reflect.CallingClass.StackFrame
-
- getLocationMethodName() - Method in class com.bluegosling.reflect.CallingClass.StackFrame
-
- getLong(int) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfLong
-
- getLongAnnotationValue(long) - Method in class com.bluegosling.reflect.model.AnnotationMirrors
-
Returns an annotation value for the given long.
- getMainClassFor(String) - Method in class com.bluegosling.buildgen.BuildGen.Settings
-
- getMaximumPoolSize() - Method in class com.bluegosling.concurrent.executors.ActorThreadPool
-
Returns the maximum size for the pool of worker threads.
- getMaxPermits() - Method in class com.bluegosling.concurrent.RateLimiter
-
Gets the current maximum capacity of permits, for bursts.
- getMethod(String, ArClass...) - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns the public method with the specified signature.
- getMethod(String, List<ArClass>) - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns the public method with the specified signature.
- getMethod() - Method in class com.bluegosling.reflect.MethodCapturer
-
Returns the last method captured.
- getMethod(Object) - Method in class com.bluegosling.reflect.MethodCapturer
-
Returns the last method captured.
- getMethod(String, Class<?>...) - Method in class com.bluegosling.testing.InterfaceVerifier
-
Gets the method with the specified signature.
- getMethodNamed(String) - Method in class com.bluegosling.testing.InterfaceVerifier
-
Gets the method with the specified name that is supported by this interface verifier.
- getMethods() - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns the list of all public methods for this class, including those inherited from ancestor
classes.
- getMethods() - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfiguration
-
Returns the set of methods configured by this object.
- getMethodsNamed(String) - Method in class com.bluegosling.testing.InterfaceVerifier
-
Gets all methods with the specified name that are supported by this interface verifier.
- getModCount() - Method in class com.bluegosling.collections.AbstractNavigableMap
-
Returns the map's modification count.
- getModCount() - Method in class com.bluegosling.collections.AbstractNavigableMap.SubMap
-
Returns the main map's modification count.
- getModCount() - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.RandomAccessSubMap
-
Returns the main map's modification count.
- getModCount() - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.SubMapByIndices
-
Returns the main map's modification count.
- getModifiers() - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns all modifiers that were on the declaration of this class.
- getModifiers() - Method in interface com.bluegosling.apt.reflect.ArMember
-
Returns the modifiers that apply to this member.
- getModifiers() - Method in class com.bluegosling.apt.reflect.ArParameter
-
Returns the modifiers that apply to this member.
- getMostRecentResult() - Method in interface com.bluegosling.concurrent.fluent.FluentRepeatingFuture
-
Returns the result returned by the most recent completed occurrence.
- getMostRecentResult() - Method in class com.bluegosling.concurrent.fluent.FluentRepeatingFutureTask
-
- getMutatorVerifier() - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfiguration
-
Returns the verifier for mutations or null
if this is not a mutator method.
- getName() - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns the name of this class.
- getName() - Method in class com.bluegosling.apt.reflect.ArConstructor
-
Returns the simple name of the declaring class, since that is how
constructors are "named" in Java source code.
- getName() - Method in class com.bluegosling.apt.reflect.ArGenericMethodSignature
-
Returns the name of the method that this signature represents.
- getName() - Method in interface com.bluegosling.apt.reflect.ArMember
-
Returns the member's name.
- getName() - Method in class com.bluegosling.apt.reflect.ArMethodSignature
-
Returns the name of the method that this signature represents.
- getName() - Method in class com.bluegosling.apt.reflect.ArPackage
-
Returns the fully-qualified package name.
- getName() - Method in class com.bluegosling.apt.reflect.ArParameter
-
Returns the parameter name.
- getName() - Method in class com.bluegosling.apt.reflect.ArTypeParameter
-
Returns the name of the type variable.
- getName() - Method in class com.bluegosling.apt.testing.TestJavaFileObject
-
- getName() - Method in class com.bluegosling.reflect.GenericMethodSignature
-
Returns the name of the method that this signature represents.
- getName() - Method in class com.bluegosling.reflect.MethodSignature
-
Returns the name of the method that this signature represents.
- getName() - Method in class com.bluegosling.reflect.scanner.PackageScanner.ClassInfo
-
- getNext(StreamNode.Upstream<U>, Consumer<? super T>) - Method in interface com.bluegosling.streams.StreamNode
-
Called by a downstream consumer to pull an element from this node.
- getNow(T) - Method in class com.bluegosling.concurrent.fluent.AbstractFluentFuture
-
- getNow(T) - Method in interface com.bluegosling.concurrent.fluent.FluentFuture
-
Gets the value of the future or a given default value if the future is not yet complete.
- getOrDefault(Object, V) - Method in class com.bluegosling.collections.concurrent.DoubleInstanceLockedTreeMap
-
- getOrDefault(Object, V) - Method in class com.bluegosling.collections.maps.LinearHashingMap
-
- getOwnerType() - Method in class com.bluegosling.apt.reflect.ArDeclaredType
-
Returns the enclosing type.
- getOwnerType(AnnotatedType) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
Returns the owner of the given type.
- getOwnerType(Type) - Static method in class com.bluegosling.reflect.Types
-
Returns the owner of the given type.
- getOwnerTypeRef() - Method in class com.bluegosling.reflect.AnnotatedTypeRef
-
- getOwnerTypeRef() - Method in class com.bluegosling.reflect.TypeRef
-
- getPackage() - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns the package in which this class is declared.
- getPackage() - Method in class com.bluegosling.buildgen.JavaClass
-
- getPackage(String) - Method in class com.bluegosling.reflect.scanner.PackageScanner.ScanResult
-
TODO: document me!
- getPackageCycles() - Method in class com.bluegosling.buildgen.SourceDependencyAnalyzer.Results
-
Gets all package cycles.
- getPackageDependencies(File) - Method in class com.bluegosling.buildgen.SourceDependencyAnalyzer.Results
-
Gets all package directories on which the given source file or package directory depends.
- getPackageDependents(File) - Method in class com.bluegosling.buildgen.SourceDependencyAnalyzer.Results
-
Gets all package directories that depend on the given source file or package directory.
- getPackageDirectories() - Method in class com.bluegosling.buildgen.JavaPackage
-
- getPackageElement(Package) - Method in interface com.bluegosling.reflect.model.Elements
-
Returns a package element for the given package.
- getPackageName() - Method in class com.bluegosling.buildgen.JavaPackage
-
- getPackageName() - Method in class com.bluegosling.reflect.scanner.PackageScanner.ClassInfo
-
- getPackages() - Method in class com.bluegosling.buildgen.SourceDependencyAnalyzer.Results
-
Returns all package directories analyzed.
- getPackagesFound() - Method in class com.bluegosling.reflect.scanner.PackageScanner.PathResult
-
Returns the set of package names found in this path.
- getPackagesFound() - Method in class com.bluegosling.reflect.scanner.PackageScanner.ScanResult
-
- getPage(P) - Method in interface com.bluegosling.collections.tables.Table3D
-
- getPage(S, P) - Method in interface com.bluegosling.collections.tables.Table4D
-
- getPage(L, S, P) - Method in interface com.bluegosling.collections.tables.Table5D
-
- getPageKey() - Method in interface com.bluegosling.collections.tables.Table3D.Cell3D
-
- getPageKey() - Method in interface com.bluegosling.collections.tables.Table4D.Cell4D
-
- getPageKey() - Method in interface com.bluegosling.collections.tables.Table5D.Cell5D
-
- getPages(P) - Method in interface com.bluegosling.collections.tables.Table4D
-
- getPages(P) - Method in interface com.bluegosling.collections.tables.Table5D
-
- getParameterAnnotations() - Method in interface com.bluegosling.apt.reflect.ArExecutableMember
-
Returns lists of parameter annotations, one list for each parameter.
- getParameterElement(Parameter) - Method in interface com.bluegosling.reflect.model.Elements
-
Returns a variable element for the given parameter.
- getParameterizedTypeMirror(AnnotatedParameterizedType) - Method in interface com.bluegosling.reflect.model.Types
-
Returns a declared type mirror that represents the same type and has the same annotations as
given.
- getParameterizedTypeMirror(ParameterizedType) - Method in interface com.bluegosling.reflect.model.Types
-
Returns a declared type mirror that represents the same type as given.
- getParameters() - Method in class com.bluegosling.apt.reflect.ArConstructor
-
Returns the constructor's list of parameters.
- getParameters() - Method in interface com.bluegosling.apt.reflect.ArExecutableMember
-
Returns the list of parameters declared for the method or constructor.
- getParameters() - Method in class com.bluegosling.apt.reflect.ArMethod
-
Returns the method's list of parameters.
- getParameterTypes() - Method in interface com.bluegosling.apt.reflect.ArExecutableMember
-
Returns the list of parameter types.
- getParameterTypes() - Method in class com.bluegosling.apt.reflect.ArGenericMethodSignature
-
Returns the parameter types for the method that this signature represents.
- getParameterTypes() - Method in class com.bluegosling.apt.reflect.ArMethodSignature
-
Returns the parameter types for the method that this signature represents.
- getParameterTypes() - Method in class com.bluegosling.reflect.GenericMethodSignature
-
Returns the parameter types for the method that this signature represents.
- getParameterTypes() - Method in class com.bluegosling.reflect.MethodSignature
-
Returns the parameter types for the method that this signature represents.
- getParent() - Method in class com.bluegosling.concurrent.locks.HierarchicalLock
-
Gets the lock's parent.
- getParentFile() - Method in class com.bluegosling.buildgen.CompilationUnit
-
- getPathResult(String) - Method in class com.bluegosling.reflect.scanner.PackageScanner.ScanResult
-
Returns the result of scanning the given path.
- getPathScanned() - Method in class com.bluegosling.reflect.scanner.PackageScanner.PathResult
-
Returns the path that was scanned.
- getPathsScanned() - Method in class com.bluegosling.reflect.scanner.PackageScanner.ScanResult
-
Returns the set of paths scanned.
- getPending() - Method in class com.bluegosling.concurrent.atoms.AsynchronousAtom
-
Returns a future that completes with the atom's value once all currently pending operations
complete.
- getPrimitiveTypeMirror(Class<?>) - Method in interface com.bluegosling.reflect.model.Types
-
Returns a type mirror that represents the same type as the given primitive type.
- getPriority() - Method in interface com.bluegosling.collections.queues.PriorityQueue.Entry
-
Gets the priority associated with the element in this entry.
- getPriority() - Method in class com.bluegosling.collections.queues.PriorityQueues.AutoEntry
-
Gets the priority associated with this object.
- getQueuedThreads() - Method in class com.bluegosling.concurrent.AbstractQueuedReferenceSynchronizer
-
Returns a collection containing threads that may be waiting to acquire.
- getQueuedThreads() - Method in class com.bluegosling.concurrent.locks.HierarchicalLock
-
Gets the collection of all queued threads.
- getQueueLength() - Method in class com.bluegosling.concurrent.AbstractQueuedReferenceSynchronizer
-
Returns an estimate of the number of threads waiting to acquire.
- getQueueLength() - Method in class com.bluegosling.concurrent.atoms.AsynchronousAtom
-
Returns the number of queued mutation operations.
- getRate() - Method in class com.bluegosling.concurrent.RateLimiter
-
Gets the current allowed rate of permit acquisition, in permits per second.
- getRawType() - Method in class com.bluegosling.reflect.TypeRef
-
Returns the raw type that corresponds to this generic type.
- getReceiverType() - Method in class com.bluegosling.apt.reflect.ArConstructor
-
Returns the constructor's implicit receiver type or null
if the constructor is for a
static or top-level type.
- getReceiverType() - Method in class com.bluegosling.apt.reflect.ArMethod
-
Returns the method's receiver type or null
if the method is static.
- getReferenceTypeMirror(Class<?>) - Method in interface com.bluegosling.reflect.model.Types
-
Returns a type mirror that represents the same type as the given reference type.
- getResult() - Method in class com.bluegosling.concurrent.fluent.AbstractFluentFuture
-
- getResult() - Method in interface com.bluegosling.concurrent.fluent.FluentFuture
-
Gets the result of a successful future.
- getResult() - Method in class com.bluegosling.concurrent.fluent.FluentFutureTask
-
- getReturnType() - Method in class com.bluegosling.apt.reflect.ArMethod
-
Returns the method's return type.
- getReturnType() - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfiguration
-
Determines the appropriate return type for the method signature configured by this object.
- getReturnVerifier() - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfiguration
-
Returns the verifier used to check values returned from method calls.
- getRootValue() - Method in class com.bluegosling.concurrent.atoms.ThreadLocalAtom
-
Returns the atom's root value, used to seed the thread-local value for new threads.
- getRow(R) - Method in interface com.bluegosling.collections.tables.Table2D
-
- getRow(P, R) - Method in interface com.bluegosling.collections.tables.Table3D
-
- getRow(S, P, R) - Method in interface com.bluegosling.collections.tables.Table4D
-
- getRow(L, S, P, R) - Method in interface com.bluegosling.collections.tables.Table5D
-
- getRowKey() - Method in interface com.bluegosling.collections.tables.Table2D.Cell2D
-
- getRowKey() - Method in interface com.bluegosling.collections.tables.Table3D.Cell3D
-
- getRowKey() - Method in interface com.bluegosling.collections.tables.Table4D.Cell4D
-
- getRowKey() - Method in interface com.bluegosling.collections.tables.Table5D.Cell5D
-
- getRows(R) - Method in interface com.bluegosling.collections.tables.Table3D
-
- getRows(R) - Method in interface com.bluegosling.collections.tables.Table4D
-
- getRows(R) - Method in interface com.bluegosling.collections.tables.Table5D
-
- getScanDuration(TimeUnit) - Method in class com.bluegosling.reflect.scanner.PackageScanner.PathResult
-
Returns the amount of time elapsed during the scan of this path, in the given unit.
- getScanDuration(TimeUnit) - Method in class com.bluegosling.reflect.scanner.PackageScanner.ScanResult
-
Returns the amount of time elapsed during this scan, in the given unit.
- getScanException(String) - Method in class com.bluegosling.reflect.scanner.PackageScanner.PathResult
-
Returns the exception associated with given searched path.
- getScanExceptionSources() - Method in class com.bluegosling.reflect.scanner.PackageScanner.PathResult
-
Returns the set of paths that were found in this path but could not be scanned or resolved.
- getScheduledNanoTime() - Method in class com.bluegosling.concurrent.fluent.FluentScheduledFutureTask
-
- getScheduledNanoTime() - Method in interface com.bluegosling.concurrent.Scheduled
-
Returns the time at which this instance is scheduled, in
system
nanos.
- getSecond() - Method in class com.bluegosling.choice.AnyOfFive
-
- getSecond() - Method in class com.bluegosling.choice.AnyOfFour
-
- getSecond() - Method in class com.bluegosling.choice.AnyOfThree
-
- getSecond() - Method in interface com.bluegosling.choice.Choice
-
Retrieves the value of the second option, if it is present.
- getSecond() - Method in class com.bluegosling.choice.Either
-
- getSecond() - Method in class com.bluegosling.choice.Union2
-
- getSecond() - Method in class com.bluegosling.choice.Union3
-
- getSecond() - Method in class com.bluegosling.choice.Union4
-
- getSecond() - Method in class com.bluegosling.choice.Union5
-
- getSecond() - Method in class com.bluegosling.tuples.NTuple
-
- getSecond() - Method in class com.bluegosling.tuples.Pair
-
- getSecond() - Method in class com.bluegosling.tuples.Quadruple
-
- getSecond() - Method in class com.bluegosling.tuples.Quintuple
-
- getSecond() - Method in class com.bluegosling.tuples.Triple
-
- getSecond() - Method in interface com.bluegosling.tuples.Tuple.Ops2
-
Retrieves the second item in the tuple.
- getSection(S) - Method in interface com.bluegosling.collections.tables.Table4D
-
- getSection(L, S) - Method in interface com.bluegosling.collections.tables.Table5D
-
- getSectionKey() - Method in interface com.bluegosling.collections.tables.Table4D.Cell4D
-
- getSectionKey() - Method in interface com.bluegosling.collections.tables.Table5D.Cell5D
-
- getSections(S) - Method in interface com.bluegosling.collections.tables.Table5D
-
- getSharedHolders() - Method in class com.bluegosling.concurrent.locks.HierarchicalLock
-
Gets the set of threads that hold this lock in shared mode.
- getSharedQueuedThreads() - Method in class com.bluegosling.concurrent.AbstractQueuedReferenceSynchronizer
-
Returns a collection containing threads that may be waiting to acquire in shared mode.
- getShort(int) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfShort
-
- getShortAnnotationValue(short) - Method in class com.bluegosling.reflect.model.AnnotationMirrors
-
Returns an annotation value for the given short.
- getSignature() - Method in class com.bluegosling.reflect.MethodCapturer
-
Returns the signature of the last method captured.
- getSignature(Object) - Method in class com.bluegosling.reflect.MethodCapturer
-
Returns the last method captured.
- getSignature() - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfiguration
-
Returns the method signature configured by this object.
- getSimpleName() - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns the simple name of this class.
- getSourceFile() - Method in class com.bluegosling.buildgen.JavaClass
-
- getSourceFileName() - Method in class com.bluegosling.reflect.CallingClass.StackFrame
-
- getSourceLineNumber() - Method in class com.bluegosling.reflect.CallingClass.StackFrame
-
- getSourceRoot() - Method in class com.bluegosling.buildgen.JavaClass
-
- getState() - Method in class com.bluegosling.concurrent.AbstractQueuedReferenceSynchronizer
-
Returns the current value of synchronization state.
- getStealCount() - Method in class com.bluegosling.concurrent.executors.ActorThreadPool
-
Returns the total number of times that an idle worker has stolen an actor from another busy
worker.
- getStringAnnotationValue(String) - Method in class com.bluegosling.reflect.model.AnnotationMirrors
-
Returns an annotation value for the given string.
- getSuperBound() - Method in class com.bluegosling.apt.reflect.ArWildcardType
-
Returns a bound of which the wildcard type must be a super-type.
- getSuperclass() - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns this class's super-class.
- getSuperclass(Type) - Static method in class com.bluegosling.reflect.Types
-
Returns the superclass of the given type.
- getSuperclassTypeRef() - Method in class com.bluegosling.reflect.AnnotatedTypeRef
-
Returns superclass of the current type, as a TypeRef
.
- getSuperclassTypeRef() - Method in class com.bluegosling.reflect.TypeRef
-
Returns superclass of the current type, as a TypeRef
.
- getSupportedAnnotationTypes() - Method in class com.bluegosling.apt.AbstractProcessor
-
Returns the set of annotations supported by this processor.
- getSupportedSourceVersion() - Method in class com.bluegosling.processors.ValueTypeProcessor
-
- getTarget() - Method in class com.bluegosling.reflect.blaster.BlasterException.BlasterExceptionCause
-
- getTargetMethod() - Method in exception com.bluegosling.reflect.caster.AmbiguousMethodException
-
- getTaskCount() - Method in class com.bluegosling.concurrent.executors.ActorThreadPool
-
Returns the total number of tasks submitted to this executor.
- getThird() - Method in class com.bluegosling.choice.AnyOfFive
-
- getThird() - Method in class com.bluegosling.choice.AnyOfFour
-
- getThird() - Method in class com.bluegosling.choice.AnyOfThree
-
- getThird() - Method in interface com.bluegosling.choice.Choice.Ops3
-
Retrieves the value of the third option, if it is present.
- getThird() - Method in class com.bluegosling.choice.Union3
-
- getThird() - Method in class com.bluegosling.choice.Union4
-
- getThird() - Method in class com.bluegosling.choice.Union5
-
- getThird() - Method in class com.bluegosling.tuples.NTuple
-
- getThird() - Method in class com.bluegosling.tuples.Quadruple
-
- getThird() - Method in class com.bluegosling.tuples.Quintuple
-
- getThird() - Method in class com.bluegosling.tuples.Triple
-
- getThird() - Method in interface com.bluegosling.tuples.Tuple.Ops3
-
Retrieves the third item in the tuple.
- getThreadFactory() - Method in class com.bluegosling.concurrent.executors.ActorThreadPool
-
Returns the factory used to create worker threads.
- getType() - Method in class com.bluegosling.apt.reflect.ArField
-
Returns the type of this field.
- getType() - Method in class com.bluegosling.apt.reflect.ArParameter
-
Returns the type of this parameter.
- getTypeAnnotationValue(Class<?>) - Method in class com.bluegosling.reflect.model.AnnotationMirrors
-
Returns an annotation value for the given class token.
- getTypeElement(Class<?>) - Method in interface com.bluegosling.reflect.model.Elements
-
Returns a type element for the given class token.
- getTypeKind() - Method in class com.bluegosling.apt.reflect.ArArrayType
-
- getTypeKind() - Method in class com.bluegosling.apt.reflect.ArDeclaredType
-
- getTypeKind() - Method in class com.bluegosling.apt.reflect.ArPrimitiveType
-
- getTypeKind() - Method in class com.bluegosling.apt.reflect.ArType
-
Gets the kind of this type.
- getTypeKind() - Method in class com.bluegosling.apt.reflect.ArTypeVariable
-
- getTypeKind() - Method in class com.bluegosling.apt.reflect.ArWildcardType
-
- getTypeMirror(AnnotatedType) - Method in interface com.bluegosling.reflect.model.Types
-
Returns a type mirror that represents the same type and has the same annotations as given.
- getTypeMirror(Type) - Method in interface com.bluegosling.reflect.model.Types
-
Returns a type mirror that represents the same type as given.
- getTypeParameterElement(TypeVariable<?>) - Method in interface com.bluegosling.reflect.model.Elements
-
Returns a type parameter for the given type variable.
- getTypeParameterNamed(String) - Method in class com.bluegosling.reflect.AnnotatedTypeRef
-
Returns the TypeVariable
for the specified type parameter name.
- getTypeParameterNamed(String) - Method in class com.bluegosling.reflect.TypeRef
-
Returns the TypeVariable
for the specified type parameter name.
- getTypeParameterNames() - Method in class com.bluegosling.reflect.AnnotatedTypeRef
-
Returns the names of this type's generic type variables (as declared in code).
- getTypeParameterNames() - Method in class com.bluegosling.reflect.TypeRef
-
Returns the names of this type's generic type variables (as declared in code).
- getTypeParameters() - Method in class com.bluegosling.apt.reflect.ArClass
-
- getTypeParameters() - Method in class com.bluegosling.apt.reflect.ArConstructor
-
Returns the constructor's list of type variables.
- getTypeParameters() - Method in interface com.bluegosling.apt.reflect.ArGenericDeclaration
-
Returns the list of type parameters for the declaring method, constructor, or class.
- getTypeParameters() - Method in class com.bluegosling.apt.reflect.ArMethod
-
Returns the method's list of type variables.
- getTypeParameters() - Method in class com.bluegosling.reflect.AnnotatedTypeRef
-
Returns this type's type variables if it has any.
- getTypeParameters() - Method in class com.bluegosling.reflect.TypeRef
-
Returns this type's type variables if it has any.
- getTypeParameters(Type) - Static method in class com.bluegosling.reflect.Types
-
Returns the type parameters for the given type or an empty array if it has none.
- getTypeVariable(String, D) - Static method in class com.bluegosling.reflect.Types
-
Gets the
TypeVariable
from the given declaration site (class, method, or constructor)
for the given name.
- getTypeVariableMirror(AnnotatedTypeVariable) - Method in interface com.bluegosling.reflect.model.Types
-
Returns a type variable mirror that represents the same type and has the same annotations as
given.
- getTypeVariableMirror(TypeVariable<?>) - Method in interface com.bluegosling.reflect.model.Types
-
Returns a type variable mirror that represents the same type as given.
- getTypeVariablesAsMap(D) - Static method in class com.bluegosling.reflect.Types
-
Retrieves the type variables of the given declaration site as a map of type parameter names to
TypeVariable
s.
- getUncheckedExceptions() - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfiguration
-
- getUnqualifiedName() - Method in class com.bluegosling.reflect.scanner.PackageScanner.ClassInfo
-
- getUpstream(Consumer<? super T>) - Method in interface com.bluegosling.streams.StreamNode.Upstream
-
Gets the next element from the upstream producer.
- getValue() - Method in interface com.bluegosling.collections.tables.Table2D.Cell2D
-
- getValue() - Method in interface com.bluegosling.collections.tables.Table3D.Cell3D
-
- getValue() - Method in interface com.bluegosling.collections.tables.Table4D.Cell4D
-
- getValue() - Method in interface com.bluegosling.collections.tables.Table5D.Cell5D
-
- getValue() - Method in class com.bluegosling.collections.TransformingMapEntry
-
- getViewForKey(K) - Method in interface com.bluegosling.collections.tables.TableMapView
-
Returns a view of the value for a given key.
- getVolume(L) - Method in interface com.bluegosling.collections.tables.Table5D
-
- getVolumeKey() - Method in interface com.bluegosling.collections.tables.Table5D.Cell5D
-
- getWildcardTypeMirror(AnnotatedWildcardType) - Method in interface com.bluegosling.reflect.model.Types
-
Returns a wildcard type mirror that represents the same type and has the same annotations as
given.
- getWildcardTypeMirror(WildcardType) - Method in interface com.bluegosling.reflect.model.Types
-
Returns a wildcard type mirror that represents the same type as given.
- getZeroValue(Type) - Static method in class com.bluegosling.reflect.Types
-
Determines the zero, of default, value for a given type.
- graph() - Method in class com.bluegosling.graph.Computation
-
Returns the graph that defines the structure of this computation.
- Graph<T> - Class in com.bluegosling.graph
-
A computation graph.
- greaterOf(Duration, Duration) - Static method in class com.bluegosling.concurrent.Duration
-
Returns the greater of two given durations.
- greatestOf(Duration...) - Static method in class com.bluegosling.concurrent.Duration
-
Returns the greatest of the given durations.
- greatestOf(Iterable<Duration>) - Static method in class com.bluegosling.concurrent.Duration
-
Returns the greatest of the given durations.
- group(Cancellable...) - Static method in interface com.bluegosling.concurrent.Cancellable
-
- group(Iterable<? extends Cancellable>) - Static method in interface com.bluegosling.concurrent.Cancellable
-
- groupBy(Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Method in interface com.bluegosling.streams.FluentStream
-
Returns a stream that groups elements in this stream by keys computed by the given function.
- groupBy(Function<? super T, ? extends K>) - Method in interface com.bluegosling.streams.FluentStream
-
Returns a stream that groups elements in this stream by keys computed by the given function.
- growBy(int) - Method in class com.bluegosling.collections.NoCopyGrowableArray
-
- identity() - Static method in interface com.bluegosling.function.BooleanUnaryOperator
-
Returns a unary operator that always returns its input argument.
- identity() - Static method in interface com.bluegosling.function.ByteUnaryOperator
-
Returns a unary operator that always returns its input argument.
- identity() - Static method in interface com.bluegosling.function.CharUnaryOperator
-
Returns a unary operator that always returns its input argument.
- identity() - Static method in interface com.bluegosling.function.FloatUnaryOperator
-
Returns a unary operator that always returns its input argument.
- identity() - Static method in interface com.bluegosling.function.ShortUnaryOperator
-
Returns a unary operator that always returns its input argument.
- ifFailed(Consumer<? super E>) - Method in class com.bluegosling.result.Result
-
Invokes the given action if this result is a failure.
- ifPresent(Consumer<? super T>) - Method in class com.bluegosling.possible.AbstractDynamicPossible
-
- ifPresent(Consumer<? super T>) - Method in interface com.bluegosling.possible.Possible
-
- ifPresent(Consumer<? super T>) - Method in class com.bluegosling.possible.Reference
-
- ifSuccessful(Consumer<? super T>) - Method in class com.bluegosling.result.Result
-
Invokes the given action if this result is a success.
- ignoringAmbiguities() - Method in class com.bluegosling.reflect.caster.Caster.Builder
-
- Immutables - Class in com.bluegosling.collections.immutable
-
Utility methods related to immutable collections.
- inc(T) - Method in class com.bluegosling.util.PrimeIterator
-
Returns the specified value, incremented by one.
- includeAllDefaults() - Method in class com.bluegosling.reflect.scanner.PackageScanner
-
Includes all several default locations that correspond to paths from which the JVM can load
classes.
- includeBootClasspaths() - Method in class com.bluegosling.reflect.scanner.PackageScanner
-
Includes JVM boot paths in the scan.
- includeClasspath() - Method in class com.bluegosling.reflect.scanner.PackageScanner
-
Includes this JVM's class path in the scan.
- includeDefaultClassLoaders() - Method in class com.bluegosling.reflect.scanner.PackageScanner
-
Includes a few default class loaders in the scan.
- includeJarsFromDirectory(String) - Method in class com.bluegosling.reflect.scanner.PackageScanner
-
Includes any JAR files found in the given directory.
- includePath(String) - Method in class com.bluegosling.reflect.scanner.PackageScanner
-
Includes the given path in the scan.
- includesPackage(String) - Method in class com.bluegosling.reflect.scanner.PackageScanner.PathResult
-
TODO: document me!
- includesPackage(String) - Method in class com.bluegosling.reflect.scanner.PackageScanner.ScanResult
-
Determines whether the given package was encountered in this scan.
- includeURLClassLoader(URLClassLoader) - Method in class com.bluegosling.reflect.scanner.PackageScanner
-
Includes the given class loader in the scan.
- includeURLClassLoaders(URLClassLoader...) - Method in class com.bluegosling.reflect.scanner.PackageScanner
-
Includes the given class loaders in the scan.
- includeURLClassLoaders(Iterable<URLClassLoader>) - Method in class com.bluegosling.reflect.scanner.PackageScanner
-
Includes the given class loaders in the scan.
- includingInterfaces() - Method in class com.bluegosling.reflect.ClassHierarchyScanner.Builder
-
Indicates that all interfaces implemented by a type will be included in the scan.
- incrementAndGet() - Method in class com.bluegosling.concurrent.contended.ContendedInteger
-
Atomically increments by one the current value.
- incrementAndGet() - Method in class com.bluegosling.concurrent.contended.ContendedLong
-
Atomically increments by one the current value.
- incrementAndGet() - Method in class com.bluegosling.vars.VariableByte
-
Increments the variable by one.
- incrementAndGet() - Method in class com.bluegosling.vars.VariableInt
-
Increments the variable by one.
- incrementAndGet() - Method in class com.bluegosling.vars.VariableLong
-
Increments the variable by one.
- incrementAndGet() - Method in class com.bluegosling.vars.VariableShort
-
Increments the variable by one.
- indent() - Method in class com.bluegosling.util.IndentingPrintWriter
-
Increases the current level of indentation by one.
- IndentingPrintWriter - Class in com.bluegosling.util
-
A utility for printing indented content.
- IndentingPrintWriter(Writer, int) - Constructor for class com.bluegosling.util.IndentingPrintWriter
-
Creates a new printer that sends all output to the specified writer.
- IndentingPrintWriter(OutputStream, int) - Constructor for class com.bluegosling.util.IndentingPrintWriter
-
Creates a new printer that sends all output to the specified stream.
- IndentingPrintWriter(OutputStream, Charset, int) - Constructor for class com.bluegosling.util.IndentingPrintWriter
-
Creates a new printer that sends all output to the specified stream.
- indexOf(Object) - Method in class com.bluegosling.collections.concurrent.PersistentListBackedConcurrentList
-
- indexOf(Object) - Method in class com.bluegosling.collections.FilteringList
-
- indexOf(Object) - Method in class com.bluegosling.collections.immutable.AbstractLinkedImmutableList
-
- indexOf(Object) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.RandomAccessEntrySet
-
- indexOf(Object) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.RandomAccessKeySet
-
- indexOf(Object) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfBoolean
-
- indexOf(Object) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfByte
-
- indexOf(Object) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfChar
-
- indexOf(Object) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfDouble
-
- indexOf(Object) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfFloat
-
- indexOf(Object) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfInt
-
- indexOf(Object) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfLong
-
- indexOf(Object) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfShort
-
- indexOf(Object) - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- indexOf(Object) - Method in class com.bluegosling.collections.sets.DescendingRandomAccessSet
-
- indexOf(Object) - Method in interface com.bluegosling.collections.sets.RandomAccessSet
-
Retrieves the index of the specified element in the set.
- indexOf(Object) - Method in class com.bluegosling.collections.sets.RandomAccessSetList
-
- indexOf(Object) - Method in class com.bluegosling.collections.sets.TransformingRandomAccessSet.Bidi
-
- indexOf(Object) - Method in class com.bluegosling.collections.sets.TransformingRandomAccessSet
-
- indexOf(Object) - Method in class com.bluegosling.collections.sets.TransformingRandomAccessSet.ReadOnly
-
- indexOf(Object) - Method in class com.bluegosling.collections.TransformingList
-
- indexOfBoolean(boolean) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfBoolean
-
- indexOfBoolean(boolean) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfBoolean
-
- indexOfByte(byte) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfByte
-
- indexOfByte(byte) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfByte
-
- indexOfChar(char) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfChar
-
- indexOfChar(char) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfChar
-
- indexOfDouble(double) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfDouble
-
- indexOfDouble(double) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfDouble
-
- indexOfFloat(float) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfFloat
-
- indexOfFloat(float) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfFloat
-
- indexOfInt(int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfInt
-
- indexOfInt(int) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfInt
-
- indexOfKey(Object) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap
-
- indexOfKey(Object) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.SubMapByIndices
-
- indexOfKey(Object) - Method in class com.bluegosling.collections.maps.DescendingRandomAccessMap
-
- indexOfKey(Object) - Method in interface com.bluegosling.collections.maps.RandomAccessNavigableMap
-
Determines the random access index at which the given key is found in the map.
- indexOfKey(Object) - Method in class com.bluegosling.collections.maps.WeightBalancedTreeMap
-
- indexOfLong(long) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfLong
-
- indexOfLong(long) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfLong
-
- indexOfShort(short) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfShort
-
- indexOfShort(short) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfShort
-
- inferBinaryName(JavaFileManager.Location, JavaFileObject) - Method in class com.bluegosling.apt.testing.TestJavaFileManager
-
- initialCapacity(int) - Method in class com.bluegosling.collections.concurrent.ConcurrentSortedArraySet.Builder
-
Sets the initial capacity of the set.
- initialContents(Collection<? extends E>) - Method in class com.bluegosling.collections.concurrent.ConcurrentSortedArraySet.Builder
-
Sets the initial contents of the set.
- initialDelay(TimeUnit) - Method in interface com.bluegosling.concurrent.scheduler.TaskDefinition
-
Returns the delay, in the specified unit, from the time the task is submitted to
the time the first instance of the task should be invoked.
- InitializeProcessorField - Annotation Type in com.bluegosling.apt.testing
-
- InputFiles - Annotation Type in com.bluegosling.apt.testing
-
A set of input files that are loaded from resources.
- inputKeys() - Method in class com.bluegosling.graph.Graph
-
The input keys that must be bound to the graph in order to compute it.
- inputKeys() - Method in class com.bluegosling.graph.Node
-
The distinct set of inputs that are defined as
Key
s.
- inputs() - Method in class com.bluegosling.graph.Node
-
Returns the list of input edges to this node.
- insert(int, Object) - Method in class com.bluegosling.tuples.NTuple
-
Inserts the specified value at the given index.
- insertFifth(T) - Method in class com.bluegosling.tuples.NTuple
-
- insertFifth(T) - Method in class com.bluegosling.tuples.Quadruple
-
- insertFifth(T) - Method in class com.bluegosling.tuples.Quintuple
-
- insertFifth(T) - Method in interface com.bluegosling.tuples.Tuple.Ops4
-
Inserts an item into the fifth position of this tuple.
- insertFirst(T) - Method in class com.bluegosling.tuples.Empty
-
- insertFirst(T) - Method in class com.bluegosling.tuples.NTuple
-
- insertFirst(T) - Method in class com.bluegosling.tuples.Pair
-
- insertFirst(T) - Method in class com.bluegosling.tuples.Quadruple
-
- insertFirst(T) - Method in class com.bluegosling.tuples.Quintuple
-
- insertFirst(T) - Method in class com.bluegosling.tuples.Single
-
- insertFirst(T) - Method in class com.bluegosling.tuples.Triple
-
- insertFirst(T) - Method in interface com.bluegosling.tuples.Tuple
-
Adds an item into the first position of this tuple.
- insertFirst(T) - Method in interface com.bluegosling.tuples.Tuple.Ops1
-
- insertFirst(T) - Method in interface com.bluegosling.tuples.Tuple.Ops2
-
- insertFirst(T) - Method in interface com.bluegosling.tuples.Tuple.Ops3
-
- insertFirst(T) - Method in interface com.bluegosling.tuples.Tuple.Ops4
-
- insertFourth(T) - Method in class com.bluegosling.tuples.NTuple
-
- insertFourth(T) - Method in class com.bluegosling.tuples.Quadruple
-
- insertFourth(T) - Method in class com.bluegosling.tuples.Quintuple
-
- insertFourth(T) - Method in class com.bluegosling.tuples.Triple
-
- insertFourth(T) - Method in interface com.bluegosling.tuples.Tuple.Ops3
-
Inserts an item into the fourth position of this tuple.
- insertFourth(T) - Method in interface com.bluegosling.tuples.Tuple.Ops4
-
- insertItem(T, int, T[], int) - Static method in class com.bluegosling.collections.ArrayUtils
-
Insert an item into an array, shifting elements around if necessary.
- insertSecond(T) - Method in class com.bluegosling.tuples.NTuple
-
- insertSecond(T) - Method in class com.bluegosling.tuples.Pair
-
- insertSecond(T) - Method in class com.bluegosling.tuples.Quadruple
-
- insertSecond(T) - Method in class com.bluegosling.tuples.Quintuple
-
- insertSecond(T) - Method in class com.bluegosling.tuples.Single
-
- insertSecond(T) - Method in class com.bluegosling.tuples.Triple
-
- insertSecond(T) - Method in interface com.bluegosling.tuples.Tuple.Ops1
-
Inserts an item into the second position of this tuple.
- insertSecond(T) - Method in interface com.bluegosling.tuples.Tuple.Ops2
-
- insertSecond(T) - Method in interface com.bluegosling.tuples.Tuple.Ops3
-
- insertSecond(T) - Method in interface com.bluegosling.tuples.Tuple.Ops4
-
- insertThird(T) - Method in class com.bluegosling.tuples.NTuple
-
- insertThird(T) - Method in class com.bluegosling.tuples.Pair
-
- insertThird(T) - Method in class com.bluegosling.tuples.Quadruple
-
- insertThird(T) - Method in class com.bluegosling.tuples.Quintuple
-
- insertThird(T) - Method in class com.bluegosling.tuples.Triple
-
- insertThird(T) - Method in interface com.bluegosling.tuples.Tuple.Ops2
-
Inserts an item into the third position of this tuple.
- insertThird(T) - Method in interface com.bluegosling.tuples.Tuple.Ops3
-
- insertThird(T) - Method in interface com.bluegosling.tuples.Tuple.Ops4
-
- install(T) - Method in interface com.bluegosling.concurrent.executors.ContextPropagator
-
Installs the given context in the current thread.
- INSTANCE - Static variable in class com.bluegosling.tuples.Empty
-
The singleton instance of this class.
- intercept(Executor, Runnable) - Method in interface com.bluegosling.concurrent.executors.InterceptingExecutor.Interceptor
-
Intercepts the given task.
- intercept(ExecutorService, Callable<T>) - Method in interface com.bluegosling.concurrent.executors.InterceptingExecutorService.Interceptor
-
Intercepts the given task.
- InterceptingExecutor - Class in com.bluegosling.concurrent.executors
-
An executor that provides an interceptor pattern, to apply cross-cutting concerns in the course
of executing tasks.
- InterceptingExecutor(Executor, Iterable<? extends InterceptingExecutor.Interceptor>) - Constructor for class com.bluegosling.concurrent.executors.InterceptingExecutor
-
Constructs a new intercepting executor.
- InterceptingExecutor.Decorator - Interface in com.bluegosling.concurrent.executors
-
A decorator, that can perform actions before and after each task.
- InterceptingExecutor.Decorator.Builder - Class in com.bluegosling.concurrent.executors
-
Builds a decorator, composing up to three functional interfaces.
- InterceptingExecutor.Interceptor - Interface in com.bluegosling.concurrent.executors
-
An interceptor for tasks.
- InterceptingExecutor.Interceptor.ListBuilder - Class in com.bluegosling.concurrent.executors
-
Builds a list of interceptors.
- InterceptingExecutorService - Class in com.bluegosling.concurrent.executors
-
An executor service that provides an interceptor pattern, to apply cross-cutting concerns in the
course of executing tasks.
- InterceptingExecutorService(ExecutorService, Iterable<? extends InterceptingExecutorService.Interceptor>) - Constructor for class com.bluegosling.concurrent.executors.InterceptingExecutorService
-
Constructs a new intercepting executor service.
- InterceptingExecutorService.Decorator - Interface in com.bluegosling.concurrent.executors
-
A decorator, that can perform actions before and after each task.
- InterceptingExecutorService.Decorator.Builder - Class in com.bluegosling.concurrent.executors
-
Builds a decorator, composing up to three functional interfaces.
- InterceptingExecutorService.Interceptor - Interface in com.bluegosling.concurrent.executors
-
An interceptor for tasks.
- InterceptingExecutorService.Interceptor.ListBuilder - Class in com.bluegosling.concurrent.executors
-
Builds a list of interceptors.
- InterceptingScheduledExecutorService - Class in com.bluegosling.concurrent.executors
-
- InterceptingScheduledExecutorService(ScheduledExecutorService, Iterable<? extends InterceptingExecutorService.Interceptor>) - Constructor for class com.bluegosling.concurrent.executors.InterceptingScheduledExecutorService
-
Constructs a new intercepting scheduled executor service.
- InterfaceVerifier<T> - Class in com.bluegosling.testing
-
An object that can verify an implementation of an interface by comparing its behavior to that of
a reference implementation.
- InterfaceVerifier(Class<T>) - Constructor for class com.bluegosling.testing.InterfaceVerifier
-
Constructs a new verifier for a single interface.
- InterfaceVerifier(Class<? extends T>...) - Constructor for class com.bluegosling.testing.InterfaceVerifier
-
Constructs a new verifier for one or more interfaces.
- InterfaceVerifier(Collection<Class<? extends T>>) - Constructor for class com.bluegosling.testing.InterfaceVerifier
-
Constructs a new verifier for one or more interfaces.
- InterfaceVerifier.MethodConfiguration<T> - Interface in com.bluegosling.testing
-
A MethodConfigurator
with accessors to inspect the current configuration.
- InterfaceVerifier.MethodConfigurator<T> - Interface in com.bluegosling.testing
-
Configures how one or more methods are executed and verified during interface verification.
- internal() - Method in class com.bluegosling.collections.FilteringCollection
-
Gets the wrapped collection.
- internal() - Method in class com.bluegosling.collections.FilteringIterable
-
Gets the wrapped iterable.
- internal() - Method in class com.bluegosling.collections.FilteringIterator
-
Gets the wrapped iterator.
- internal() - Method in class com.bluegosling.collections.FilteringList
-
Gets the wrapped list.
- internal() - Method in class com.bluegosling.collections.FilteringListIterator
-
Gets the wrapped list iterator.
- internal() - Method in class com.bluegosling.collections.FilteringMap
-
- internal() - Method in class com.bluegosling.collections.FilteringNavigableMap
-
- internal() - Method in class com.bluegosling.collections.FilteringNavigableSet
-
- internal() - Method in class com.bluegosling.collections.FilteringSet
-
- internal() - Method in class com.bluegosling.collections.FilteringSortedMap
-
- internal() - Method in class com.bluegosling.collections.FilteringSortedSet
-
- internal() - Method in class com.bluegosling.collections.sets.TransformingRandomAccessSet.Bidi
-
Gets the wrapped random access set.
- internal() - Method in class com.bluegosling.collections.sets.TransformingRandomAccessSet
-
Gets the wrapped random access set.
- internal() - Method in class com.bluegosling.collections.sets.TransformingRandomAccessSet.ReadOnly
-
Gets the wrapped random access set.
- internal() - Method in class com.bluegosling.collections.TransformingCollection
-
Gets the wrapped collection.
- internal() - Method in class com.bluegosling.collections.TransformingIterable
-
Gets the wrapped iterable.
- internal() - Method in class com.bluegosling.collections.TransformingIterator
-
Gets the wrapped iterator.
- internal() - Method in class com.bluegosling.collections.TransformingList
-
Gets the wrapped list.
- internal() - Method in class com.bluegosling.collections.TransformingListIterator
-
Gets the wrapped list iterator.
- internal() - Method in class com.bluegosling.collections.TransformingMap
-
The underlying map whose keys and/or values are being transformed.
- internal() - Method in class com.bluegosling.collections.TransformingMapEntry
-
- internal() - Method in class com.bluegosling.collections.TransformingSet.Bidi
-
Gets the wrapped set.
- internal() - Method in class com.bluegosling.collections.TransformingSet
-
Gets the wrapped set.
- internal() - Method in class com.bluegosling.collections.TransformingSet.ReadOnly
-
Gets the wrapped set.
- interrupt() - Method in class com.bluegosling.concurrent.fluent.AbstractFluentFuture
-
Invoked when the task is cancelled and allowed to interrupt a running task.
- interrupt() - Method in class com.bluegosling.concurrent.fluent.SettableRunnableFluentFuture
-
- interrupt() - Method in class com.bluegosling.concurrent.futures.InterruptibleCompletableFuture
-
Invoked when the task is cancelled and allowed to interrupt a running task.
- interrupt() - Method in class com.bluegosling.concurrent.futures.RunnableCompletableFuture
-
Interrupts the thread running the task that this future represents, if it is currently
running.
- interrupt() - Method in class com.bluegosling.concurrent.futures.RunnableReadOnlyCompletableFuture
-
Interrupts the thread running the task that this future represents, if it is currently
running.
- InterruptibleCompletableFuture<T> - Class in com.bluegosling.concurrent.futures
-
A
CompletableFuture
that provides a mechanism for interrupting an in-progress computation
when the future is cancelled.
- InterruptibleCompletableFuture() - Constructor for class com.bluegosling.concurrent.futures.InterruptibleCompletableFuture
-
- intValue() - Method in class com.bluegosling.vars.VariableByte
-
- intValue() - Method in class com.bluegosling.vars.VariableDouble
-
- intValue() - Method in class com.bluegosling.vars.VariableFloat
-
- intValue() - Method in class com.bluegosling.vars.VariableInt
-
- intValue() - Method in class com.bluegosling.vars.VariableLong
-
- intValue() - Method in class com.bluegosling.vars.VariableShort
-
- inverseFunction() - Method in class com.bluegosling.collections.TransformingCollection.Bidi
-
Gets the function used to transform elements from the "output" domain to the "input"
domain.
- invokeAll(Collection<? extends Callable<T>>) - Method in interface com.bluegosling.concurrent.executors.CompletableExecutorService
- invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in interface com.bluegosling.concurrent.executors.CompletableExecutorService
- invokeAll(Collection<? extends Callable<T>>) - Method in class com.bluegosling.concurrent.executors.WrappingExecutorService
-
- invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.bluegosling.concurrent.executors.WrappingExecutorService
-
- invokeAll(Collection<? extends Callable<T>>) - Method in interface com.bluegosling.concurrent.fluent.FluentExecutorService
- invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in interface com.bluegosling.concurrent.fluent.FluentExecutorService
- invokeAll(Collection<? extends Callable<T>>) - Method in class com.bluegosling.concurrent.scheduler.ScheduledTaskManager
-
- invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.bluegosling.concurrent.scheduler.ScheduledTaskManager
-
- invokeAny(Collection<? extends Callable<T>>) - Method in class com.bluegosling.concurrent.executors.WrappingExecutorService
-
- invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.bluegosling.concurrent.executors.WrappingExecutorService
-
- invokeAny(Collection<? extends Callable<T>>) - Method in class com.bluegosling.concurrent.scheduler.ScheduledTaskManager
-
- invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.bluegosling.concurrent.scheduler.ScheduledTaskManager
-
- invokeProcessor() - Method in class com.bluegosling.apt.testing.TestEnvironment
-
- isAccessible(Member, Class<?>) - Static method in class com.bluegosling.reflect.Members
-
Determines if the given member is accessible from the given calling class, per the rules of
member visibility in the Java language.
- isAllowingUnsupportedOperations() - Method in class com.bluegosling.reflect.caster.Caster
-
- isAncestor(ClassLoader, ClassLoader) - Static method in class com.bluegosling.reflect.ClassLoaders
-
Returns true if the second classloader can be found in the first classloader's delegation
chain.
- isAnnotation() - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns true if this class object represents an annotation type.
- isAnnotation() - Method in class com.bluegosling.reflect.TypeRef
-
Determines if this type is an annotation.
- isAnnotation(Type) - Static method in class com.bluegosling.reflect.Types
-
Determines if the given type is an annotation type.
- isAnnotationPresent(ArClass) - Method in interface com.bluegosling.apt.reflect.ArAnnotatedConstruct
-
Determines whether an annotation of the specified type exists on the object.
- isAnnotationPresent(Class<? extends Annotation>) - Method in interface com.bluegosling.apt.reflect.ArAnnotatedConstruct
-
Determines whether an annotation of the specified type exists on the object.
- isAnnotationPresent(ArClass) - Method in class com.bluegosling.apt.reflect.ArClass
-
- isAnnotationPresent(Class<? extends Annotation>) - Method in class com.bluegosling.apt.reflect.ArClass
-
- isAnonymousClass() - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns true if this is an anonymous inner class.
- isArray() - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns true if this class object represents an array type.
- isArray() - Method in class com.bluegosling.reflect.TypeRef
-
Determines if this type is an array.
- isArray(Type) - Static method in class com.bluegosling.reflect.Types
-
Returns true if the given type represents an array type.
- isAssignable(AnnotatedType, AnnotatedType, TypeAnnotationChecker) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
Determines if a given annotated type is assignable from another.
- isAssignable(AnnotatedType, AnnotatedType, TypeAnnotationChecker, Predicate<? super Annotation>, Predicate<? super Annotation>) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- isAssignable(AnnotatedType, AnnotatedType, TypeAnnotationChecker, Collection<? extends Annotation>, Collection<? extends Annotation>) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- isAssignable(AnnotatedType, AnnotatedType, TypeAnnotationChecker, Predicate<? super Annotation>, Collection<? extends Annotation>, Predicate<? super Annotation>, Collection<? extends Annotation>) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- isAssignable(Annotation, Annotation) - Method in interface com.bluegosling.reflect.TypeAnnotationChecker
-
Determines if the given annotation is assignable to the other.
- isAssignable(Collection<? extends Annotation>, Collection<? extends Annotation>) - Method in interface com.bluegosling.reflect.TypeAnnotationChecker
-
Determines if the one set of annotations is assignable to a second set of annotations.
- isAssignable(Annotation[], Annotation[]) - Method in interface com.bluegosling.reflect.TypeAnnotationChecker
-
Determines if a given set of annotations is assignable to a second set of annotations.
- isAssignable(Type, Type) - Static method in class com.bluegosling.reflect.Types
-
Determines if one type is assignable to another.
- isAssignableFrom(ArClass) - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns true if the specified type is assignable to this type.
- isAssignableFrom(AnnotatedTypeRef<?>, TypeAnnotationChecker) - Method in class com.bluegosling.reflect.AnnotatedTypeRef
-
- isAssignableFrom(TypeRef<?>) - Method in class com.bluegosling.reflect.TypeRef
-
- isAssignableStrict(AnnotatedType, AnnotatedType, TypeAnnotationChecker) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
Determines if a given annotated type is strictly assignable to another.
- isAssignableStrict(Type, Type) - Static method in class com.bluegosling.reflect.Types
-
Determines if one type is assignable to another, with restrictions.
- isAssignableStrictFrom(AnnotatedTypeRef<?>, TypeAnnotationChecker) - Method in class com.bluegosling.reflect.AnnotatedTypeRef
-
Determines if the type this token represents can be assigned from the given type.
- isAssignableStrictFrom(TypeRef<?>) - Method in class com.bluegosling.reflect.TypeRef
-
Determines if the type this token represents can be assigned from the given type.
- isAsync() - Method in class com.bluegosling.graph.Node.Input
-
Returns true if this is an asynchronous input or not.
- isBlaster(Object) - Static method in class com.bluegosling.reflect.blaster.Blaster
-
Returns true if the specified object is a blasting proxy.
- isBlocked() - Method in class com.bluegosling.concurrent.atoms.AsynchronousAtom
-
Returns true if the atom is blocked due to an earlier failure.
- isCancelled() - Method in class com.bluegosling.concurrent.fluent.AbstractFluentFuture
-
- isCancelled() - Method in interface com.bluegosling.concurrent.scheduler.ScheduledTaskDefinition
-
Returns whether or not the task definition is cancelled.
- isCastingArguments() - Method in class com.bluegosling.reflect.caster.DispatchSettings
-
- isCastingReturnTypes() - Method in class com.bluegosling.reflect.caster.DispatchSettings
-
- isCheckHashCodesAfterMutation() - Method in class com.bluegosling.testing.InterfaceVerifier
-
Returns whether hash codes are verified after mutator methods are invoked.
- isCloningArguments() - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfiguration
-
Returns true if any arguments are cloned prior to method execution.
- isDerivedFrom(Class<?>, Class<?>) - Static method in class com.bluegosling.derivations.Derivations
-
Returns true if the specified type is derived from the other.
- IsDerivedFrom - Annotation Type in com.bluegosling.util
-
- isDone() - Method in interface com.bluegosling.concurrent.Awaitable
-
Returns true if the event has occurred.
- isDone() - Method in class com.bluegosling.concurrent.fluent.AbstractFluentFuture
-
- isDone() - Method in class com.bluegosling.concurrent.UpAndDownLatch
-
- isDone() - Method in class com.bluegosling.reflect.scanner.PackageScanner.ScanResult
-
- isEmpty() - Method in class com.bluegosling.collections.AbstractNavigableMap
- isEmpty() - Method in class com.bluegosling.collections.concurrent.ConcurrentSortedArraySet
- isEmpty() - Method in class com.bluegosling.collections.concurrent.DoubleInstanceLockedTreeMap
-
- isEmpty() - Method in class com.bluegosling.collections.concurrent.LockFreeArrayBlockingQueue
-
- isEmpty() - Method in class com.bluegosling.collections.concurrent.LockFreeSkipListBlockingQueue
-
- isEmpty() - Method in class com.bluegosling.collections.concurrent.PersistentListBackedConcurrentList
-
- isEmpty() - Method in class com.bluegosling.collections.concurrent.PersistentMapBackedConcurrentMap
-
- isEmpty() - Method in class com.bluegosling.collections.concurrent.SimpleTreiberStack
-
- isEmpty() - Method in class com.bluegosling.collections.DescendingMap
-
- isEmpty() - Method in class com.bluegosling.collections.DescendingSet
-
- isEmpty() - Method in class com.bluegosling.collections.FilteringCollection
-
- isEmpty() - Method in class com.bluegosling.collections.FilteringMap
-
- isEmpty() - Method in class com.bluegosling.collections.immutable.HamtPersistentMap
-
- isEmpty() - Method in class com.bluegosling.collections.immutable.LinkedPersistentList
-
- isEmpty() - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.SubMapByIndices
-
- isEmpty() - Method in class com.bluegosling.collections.maps.HamtMap
-
- isEmpty() - Method in class com.bluegosling.collections.maps.WeightBalancedTreeMap
-
- isEmpty() - Method in interface com.bluegosling.collections.queues.PriorityQueue
-
- isEmpty() - Method in class com.bluegosling.collections.queues.RandomAccessArrayDeque
-
- isEmpty() - Method in class com.bluegosling.collections.sets.RandomAccessSetList
-
- isEmpty() - Method in class com.bluegosling.collections.sets.SortedArraySet
- isEmpty() - Method in interface com.bluegosling.collections.tables.Table2D
-
- isEmpty() - Method in interface com.bluegosling.collections.tables.Table3D
-
- isEmpty() - Method in interface com.bluegosling.collections.tables.Table4D
-
- isEmpty() - Method in interface com.bluegosling.collections.tables.Table5D
-
- isEmpty() - Method in class com.bluegosling.collections.TransformingCollection
-
- isEmpty() - Method in class com.bluegosling.collections.TransformingMap
-
- isEmpty() - Method in class com.bluegosling.collections.tries.ArrayMappedBitwiseTrie
-
- isEmpty() - Method in class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- isEmpty() - Method in class com.bluegosling.tuples.Empty
-
- isEmpty() - Method in class com.bluegosling.tuples.NTuple
-
- isEmpty() - Method in class com.bluegosling.tuples.Pair
-
- isEmpty() - Method in class com.bluegosling.tuples.Quadruple
-
- isEmpty() - Method in class com.bluegosling.tuples.Quintuple
-
- isEmpty() - Method in class com.bluegosling.tuples.Single
-
- isEmpty() - Method in class com.bluegosling.tuples.Triple
-
- isEmpty() - Method in interface com.bluegosling.tuples.Tuple
-
Determines whether the tuple has any items.
- isEnum() - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns true if this class object represents an enum.
- isEnum() - Method in class com.bluegosling.reflect.TypeRef
-
Determines if this type is an enum.
- isEnum(Type) - Static method in class com.bluegosling.reflect.Types
-
Determines if the given type is an enum type.
- isEnumConstant() - Method in class com.bluegosling.apt.reflect.ArField
-
Returns true if this field is an enum constant for an enum type.
- isEquivalent(Annotation, Annotation) - Method in interface com.bluegosling.reflect.TypeAnnotationChecker
-
Determines if the given two annotations are equivalent.
- isEquivalent(Collection<? extends Annotation>, Collection<? extends Annotation>) - Method in interface com.bluegosling.reflect.TypeAnnotationChecker
-
Determines if a given set of annotations is equivalent to a second set of annotations.
- isEquivalent(Annotation[], Annotation[]) - Method in interface com.bluegosling.reflect.TypeAnnotationChecker
-
Determines if a given set of annotations is equivalent to a second set of annotations.
- isExpandingVarArgs() - Method in class com.bluegosling.reflect.caster.DispatchSettings
-
- isFailed() - Method in class com.bluegosling.concurrent.fluent.AbstractFluentFuture
-
- isFailed() - Method in interface com.bluegosling.concurrent.fluent.FluentFuture
-
Returns true if the future is done and failed.
- isFailed() - Method in class com.bluegosling.concurrent.fluent.FluentFutureTask
-
- isFailed() - Method in class com.bluegosling.result.Result
-
Determines if this result is a failure or not.
- isFair() - Method in class com.bluegosling.concurrent.locks.NonReentrantLock
-
Returns true if this is a fair lock.
- isFinished() - Method in interface com.bluegosling.concurrent.scheduler.ScheduledTaskDefinition
-
Returns whether or not the task definition is finished.
- isFixedRate() - Method in interface com.bluegosling.concurrent.scheduler.TaskDefinition
-
Returns whether or not a repeating task is scheduled based on a fixed
rate or with fixed delays between invocations.
- isFullyResolved() - Method in class com.bluegosling.reflect.AnnotatedTypeRef
-
Returns true if this type token is fully resolved, which means that this type
is resolved and so are the values for all type arguments (if it is a
parameterized type) or for the component type (if it is an array type).
- isFullyResolved() - Method in class com.bluegosling.reflect.TypeRef
-
Returns true if this type token is fully resolved, which means that this type
is resolved and so are the values for all type arguments (if it is a
parameterized type) or for the component type (if it is an array type).
- isFunctionalInterface() - Method in class com.bluegosling.reflect.AnnotatedTypeRef
-
- isFunctionalInterface() - Method in class com.bluegosling.reflect.TypeRef
-
- isFunctionalInterface(Type) - Static method in class com.bluegosling.reflect.Types
-
Returns true if the given type represents a functional interface.
- isGeneric(Type) - Static method in class com.bluegosling.reflect.Types
-
Determines if the given type is a generic type.
- isGeneric(Class<?>) - Static method in class com.bluegosling.reflect.Types
-
Determines if the given class is generic.
- isIgnoringAmbiguities() - Method in class com.bluegosling.reflect.caster.DispatchSettings
-
- isInIgnorePath(File) - Method in class com.bluegosling.buildgen.BuildGen.Settings
-
- isInRange(Object) - Method in class com.bluegosling.collections.AbstractNavigableMap.SubMap
-
Returns true if the specified key is within the sub-map's bounds.
- isInRange(T, T, boolean, T, boolean, Comparator<? super T>) - Static method in class com.bluegosling.collections.CollectionUtils
-
Checks if the given object is within the given bounds.
- isInRange(Object) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.RandomAccessSubMap
-
Returns true if the specified key is within the sub-map's bounds.
- isInRangeHigh(T, boolean, T, boolean, Comparator<? super T>) - Static method in class com.bluegosling.collections.CollectionUtils
-
Checks if the given object (or range upper bound) falls under another
upper bound.
- isInRangeLow(T, boolean, T, boolean, Comparator<? super T>) - Static method in class com.bluegosling.collections.CollectionUtils
-
Checks if the given object (or range lower bound) lies above another
lower bound.
- isInterface() - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns true if this class object represents an interface.
- isInterface() - Method in class com.bluegosling.reflect.TypeRef
-
Determines if this type is an interface.
- isInterface(Type) - Static method in class com.bluegosling.reflect.Types
-
Determines if the given type is an interface type.
- isInTestPath(File) - Method in class com.bluegosling.buildgen.BuildGen.Settings
-
- isInTransaction() - Static method in class com.bluegosling.concurrent.atoms.Transaction
-
Determines whether a transaction is in progress on the current thread.
- isKeyWithinBounds(Object) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.SubMapByIndicesAndByValueBounds
-
Returns true if the specified key is within the sub-map's bounds.
- isLocalClass() - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns true if this is a local class.
- isMemberClass() - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns true if this is a member class.
- isMoreSpecific(Method, Method) - Static method in class com.bluegosling.reflect.Members
-
Returns true if the first specified method is more specific than the second.
- isMutator() - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfiguration
-
Returns true if this method is a mutator method.
- isNull() - Static method in class com.bluegosling.function.Predicates
-
Returns a predicate that returns true if its given argument is null
.
- isOneOf(T...) - Static method in class com.bluegosling.function.Predicates
-
- isOneOf(Collection<? extends T>) - Static method in class com.bluegosling.function.Predicates
-
- isOptional() - Method in class com.bluegosling.graph.Node.Input
-
Returns true if this is an optional input or not.
- isPackageKnown() - Method in class com.bluegosling.buildgen.JavaClass
-
- isPaused() - Method in interface com.bluegosling.concurrent.scheduler.ScheduledTaskDefinition
-
Returns whether or not this task definition is currently paused.
- isPeriodic() - Method in class com.bluegosling.concurrent.fluent.FluentRepeatingFutureTask
-
- isPeriodic() - Method in class com.bluegosling.concurrent.fluent.FluentScheduledFutureTask
-
- isPipelineQuiescent(K) - Method in class com.bluegosling.concurrent.executors.PipeliningExecutor
-
Returns true if the specified pipeline has no tasks running or queued.
- isPresent() - Method in class com.bluegosling.possible.Holder
-
- isPresent() - Method in interface com.bluegosling.possible.Possible
-
Returns true if a value is present.
- isPresent() - Method in class com.bluegosling.possible.Reference
-
- isPrimitive() - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns true if this class objects represents one of the nine non-reference types.
- isPrimitive() - Method in class com.bluegosling.reflect.TypeRef
-
Determines if this type is any of the eight primitive types or void
.
- isPrimitive(Type) - Static method in class com.bluegosling.reflect.Types
-
Determines if the given type is one of the eight primitive types or void
.
- isProcessingOver() - Method in class com.bluegosling.apt.reflect.ArRoundEnvironment
-
Returns true if this is the last round of processing.
- isQueued(Thread) - Method in class com.bluegosling.concurrent.AbstractQueuedReferenceSynchronizer
-
Returns true if the given thread is currently queued.
- isQuiescent() - Method in class com.bluegosling.concurrent.executors.PipeliningExecutor
-
Returns true if this executor has no tasks running or queued.
- isRepeating() - Method in interface com.bluegosling.concurrent.scheduler.TaskDefinition
-
Returns whether or not this is a repeating task vs.
- isResolved() - Method in class com.bluegosling.reflect.AnnotatedTypeRef
-
Returns true if this type token is resolved, which means that the actual type is known.
- isResolved() - Method in class com.bluegosling.reflect.TypeRef
-
Returns true if this type token is resolved, which means that the actual type is known.
- isSameAs(T) - Static method in class com.bluegosling.function.Predicates
-
Returns a predicate that returns true only if its given argument is the same instance as the
given object.
- isSameFile(FileObject, FileObject) - Method in class com.bluegosling.apt.testing.TestJavaFileManager
-
- isSameType(AnnotatedType, AnnotatedType, TypeAnnotationChecker) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
Determines whether two given types represent the same type.
- isSameType(AnnotatedType, AnnotatedType) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- isSameType(Type, Type) - Static method in class com.bluegosling.reflect.Types
-
Determines whether two given types represent the same type.
- isShutdown() - Method in class com.bluegosling.concurrent.executors.ActorThreadPool
-
Returns true if this executor is shutdown.
- isShutdown() - Method in class com.bluegosling.concurrent.executors.ThreadLimitingExecutorService
-
- isShutdown() - Method in class com.bluegosling.concurrent.executors.WorkSharingThreadPool
-
- isShutdown() - Method in class com.bluegosling.concurrent.executors.WrappingExecutorService
-
- isShutdown() - Method in class com.bluegosling.concurrent.scheduler.ScheduledTaskManager
-
- isStarted() - Method in interface com.bluegosling.concurrent.scheduler.ScheduledTask
-
Returns whether the scheduled task has begun executing or not.
- isSubtype(AnnotatedType, AnnotatedType, TypeAnnotationChecker) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
Determines if one type is a proper subtype of another.
- isSubtype(Type, Type) - Static method in class com.bluegosling.reflect.Types
-
Determines if one type is a proper subtype of another.
- isSubTypeOf(ArClass) - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns true if this class is a sub-type of the specified class.
- isSubtypeOf(AnnotatedTypeRef<?>, TypeAnnotationChecker) - Method in class com.bluegosling.reflect.AnnotatedTypeRef
-
Determines if this is a proper subtype of the specified type token.
- isSubtypeOf(TypeRef<?>) - Method in class com.bluegosling.reflect.TypeRef
-
Determines if this is a proper subtype of the specified type token.
- isSubtypeStrict(AnnotatedType, AnnotatedType, TypeAnnotationChecker) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
Determines if one type is a proper subtype of another, with restrictions.
- isSubtypeStrict(Type, Type) - Static method in class com.bluegosling.reflect.Types
-
Determines if one type is a proper subtype of another, with restrictions.
- isSubtypeStrictOf(AnnotatedTypeRef<?>, TypeAnnotationChecker) - Method in class com.bluegosling.reflect.AnnotatedTypeRef
-
- isSubtypeStrictOf(TypeRef<?>) - Method in class com.bluegosling.reflect.TypeRef
-
- isSuccessful() - Method in class com.bluegosling.concurrent.fluent.AbstractFluentFuture
-
- isSuccessful() - Method in interface com.bluegosling.concurrent.fluent.FluentFuture
-
Returns true if the future is done and was successful.
- isSuccessful() - Method in class com.bluegosling.concurrent.fluent.FluentFutureTask
-
- isSuccessful() - Method in class com.bluegosling.result.Result
-
Determines if this result is successful or not.
- isSuperTypeOf(ArClass) - Method in class com.bluegosling.apt.reflect.ArClass
-
Returns true if this class is a super-type of the specified class.
- isSupportedOption(String) - Method in class com.bluegosling.apt.testing.TestJavaFileManager
-
- isSuppressExceptions() - Method in class com.bluegosling.testing.InterfaceVerifier
-
Returns true if exceptions will be suppressed during method invocations.
- isTentativelyEmpty() - Method in class com.bluegosling.collections.concurrent.AbstractLockFreeBlockingDeque
-
Returns true if this deque is tentatively empty.
- isTentativelyEmpty() - Method in class com.bluegosling.collections.concurrent.AbstractLockFreeBlockingQueue
-
Returns true if this queue is tentatively empty.
- isTentativelyEmpty() - Method in class com.bluegosling.collections.concurrent.LockFreeArrayBlockingQueue
-
- isTerminated() - Method in class com.bluegosling.concurrent.executors.ActorThreadPool
-
Returns true if this executor is terminated.
- isTerminated() - Method in class com.bluegosling.concurrent.executors.ThreadLimitingExecutorService
-
- isTerminated() - Method in class com.bluegosling.concurrent.executors.WorkSharingThreadPool
-
- isTerminated() - Method in class com.bluegosling.concurrent.executors.WrappingExecutorService
-
- isTerminated() - Method in class com.bluegosling.concurrent.scheduler.ScheduledTaskManager
-
- isTerminating() - Method in class com.bluegosling.concurrent.executors.ActorThreadPool
-
Returns true if this executor is in the process of terminating.
- isUsingDynamicDispatch() - Method in class com.bluegosling.reflect.caster.Caster
-
- isVarArgs() - Method in interface com.bluegosling.apt.reflect.ArExecutableMember
-
Determines whether this executable member can be invoked with variable arity (aka var-args).
- isVerbose() - Method in class com.bluegosling.apt.testing.CategorizingDiagnosticCollector
-
- isVerifyingArguments() - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfiguration
-
Returns true if any arguments are verified after method execution.
- isVisible(int) - Method in enum com.bluegosling.reflect.caster.DispatchSettings.Visibility
-
Returns true if the given modifiers indicate a method that has this level of visibility
or higher.
- iterator() - Method in class com.bluegosling.collections.AbstractNavigableMap.EntrySet
-
- iterator() - Method in class com.bluegosling.collections.AbstractNavigableMap.KeySet
-
- iterator() - Method in class com.bluegosling.collections.AbstractNavigableMap.ValueCollection
-
- iterator() - Method in interface com.bluegosling.collections.bits.BitSequence
-
Returns an iterator over the values in the sequence.
- iterator(int) - Method in interface com.bluegosling.collections.bits.BitSequence
-
Returns an iterator over the values in the sequence starting at the specified index.
- iterator() - Method in class com.bluegosling.collections.concurrent.ArrayBlockingDeque
-
- iterator() - Method in class com.bluegosling.collections.concurrent.ConcurrentSkipListOrderedQueue
-
- iterator() - Method in class com.bluegosling.collections.concurrent.ConcurrentSortedArraySet
- iterator() - Method in class com.bluegosling.collections.concurrent.LockFreeArrayBlockingQueue
-
- iterator() - Method in class com.bluegosling.collections.concurrent.LockFreeLinkedBlockingDeque
-
- iterator() - Method in class com.bluegosling.collections.concurrent.LockFreeLinkedBlockingQueue
-
- iterator() - Method in class com.bluegosling.collections.concurrent.LockFreeSkipListBlockingQueue
-
- iterator() - Method in class com.bluegosling.collections.concurrent.PersistentListBackedConcurrentList
-
- iterator() - Method in class com.bluegosling.collections.concurrent.SimpleTreiberStack
-
- iterator() - Method in class com.bluegosling.collections.concurrent.TreiberStack
-
- iterator() - Method in class com.bluegosling.collections.DescendingSet
-
- iterator() - Method in class com.bluegosling.collections.FilteringCollection
-
- iterator() - Method in class com.bluegosling.collections.FilteringIterable
-
- iterator() - Method in class com.bluegosling.collections.immutable.AbstractImmutableList
-
- iterator() - Method in class com.bluegosling.collections.immutable.AbstractLinkedImmutableList
-
- iterator() - Method in class com.bluegosling.collections.lists.ArrayBackedLinkedList
- iterator() - Method in class com.bluegosling.collections.lists.TreeList
-
- iterator() - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList
-
- iterator() - Method in interface com.bluegosling.collections.primitive.PrimitiveList
-
- iterator() - Method in class com.bluegosling.collections.queues.FibonacciHeapOrderedQueue
-
- iterator() - Method in class com.bluegosling.collections.queues.RandomAccessArrayDeque
-
- iterator() - Method in class com.bluegosling.collections.queues.RandomizedQueue
-
- iterator() - Method in class com.bluegosling.collections.queues.SetBackedOrderedQueue
-
- iterator() - Method in class com.bluegosling.collections.queues.SkewHeapOrderedQueue
-
- iterator() - Method in class com.bluegosling.collections.sets.RandomAccessSetList
-
- iterator() - Method in class com.bluegosling.collections.sets.SortedArraySet
- iterator() - Method in class com.bluegosling.collections.TransformingCollection.ReadOnly
-
- iterator() - Method in class com.bluegosling.collections.TransformingIterable
-
- iterator() - Method in class com.bluegosling.collections.TransformingIterable.ReadOnly
-
- iterator() - Method in class com.bluegosling.collections.TransformingList.ReadOnly
-
- iterator() - Method in class com.bluegosling.concurrent.RateLimitedBlockingQueue
-
- iterator() - Method in class com.bluegosling.tuples.Empty
-
- iterator() - Method in class com.bluegosling.tuples.NTuple
-
- iterator() - Method in class com.bluegosling.tuples.Pair
-
- iterator() - Method in class com.bluegosling.tuples.Quadruple
-
- iterator() - Method in class com.bluegosling.tuples.Quintuple
-
- iterator() - Method in class com.bluegosling.tuples.Single
-
- iterator() - Method in class com.bluegosling.tuples.Triple
-
- IteratorModifiedState - Enum in com.bluegosling.collections
-
Enumeration of possible modification states of the iterator.
- name() - Method in interface com.bluegosling.reflect.EnumType.EnumElement
-
Returns the enum element's name
- name(T) - Method in class com.bluegosling.reflect.EnumType
-
Returns the name of the enum element with the given value.
- nanos(long) - Static method in class com.bluegosling.concurrent.Duration
-
Returns a new duration whose length is the specified number of nanoseconds.
- nanoTime() - Method in interface com.bluegosling.util.Clock
-
- nanoTime() - Method in class com.bluegosling.util.FakeClock
-
- nanoTime() - Method in enum com.bluegosling.util.SystemClock
-
- naturalOrder() - Static method in class com.bluegosling.collections.CollectionUtils
-
- NavigableCompositeTrie<K,C,V> - Interface in com.bluegosling.collections.tries
-
- navigableKeySet() - Method in class com.bluegosling.collections.AbstractNavigableMap
- navigableKeySet() - Method in class com.bluegosling.collections.concurrent.DoubleInstanceLockedTreeMap
-
- navigableKeySet() - Method in class com.bluegosling.collections.DescendingMap
-
- navigableKeySet() - Method in class com.bluegosling.collections.FilteringNavigableMap
-
- navigableKeySet() - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap
-
- navigableKeySet() - Method in class com.bluegosling.collections.maps.DescendingRandomAccessMap
-
- navigableKeySet() - Method in interface com.bluegosling.collections.maps.RandomAccessNavigableMap
- navigableKeySet() - Method in class com.bluegosling.collections.maps.WeightBalancedTreeMap
-
- navigableKeySet() - Method in class com.bluegosling.collections.tries.ArrayMappedBitwiseTrie
-
- navigableKeySet() - Method in class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- navigableKeySet() - Method in class com.bluegosling.collections.tries.SimpleBitwiseTrie
-
- NavigableSequenceTrie<K,V> - Interface in com.bluegosling.collections.tries
-
- nearestEntry(K) - Method in class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- nearestEntry(K) - Method in class com.bluegosling.collections.tries.SimpleBitwiseTrie
-
- nearestKey(K) - Method in class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- nearestKey(K) - Method in class com.bluegosling.collections.tries.SimpleBitwiseTrie
-
- negate() - Method in interface com.bluegosling.function.BooleanPredicate
-
Returns a predicate that represents the logical negation of this predicate.
- negate() - Method in interface com.bluegosling.function.BytePredicate
-
Returns a predicate that represents the logical negation of this predicate.
- negate() - Method in interface com.bluegosling.function.CharPredicate
-
Returns a predicate that represents the logical negation of this predicate.
- negate() - Method in interface com.bluegosling.function.FloatPredicate
-
Returns a predicate that represents the logical negation of this predicate.
- negate() - Method in interface com.bluegosling.function.ShortPredicate
-
Returns a predicate that represents the logical negation of this predicate.
- negate() - Method in interface com.bluegosling.function.TriPredicate
-
Returns a predicate that represents the logical negation of this predicate.
- newAnnotatedArrayType(GenericArrayType, Annotation...) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- newAnnotatedArrayType(GenericArrayType, Iterable<? extends Annotation>) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- newAnnotatedArrayType(AnnotatedType, Annotation...) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- newAnnotatedArrayType(AnnotatedType, Iterable<? extends Annotation>) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- newAnnotatedDeclaredType(Class<?>, Annotation...) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- newAnnotatedDeclaredType(Class<?>, Iterable<? extends Annotation>) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- newAnnotatedDeclaredType(AnnotatedType, Class<?>, Annotation...) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- newAnnotatedDeclaredType(AnnotatedType, Class<?>, Iterable<? extends Annotation>) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- newAnnotatedParameterizedType(ParameterizedType, Annotation...) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- newAnnotatedParameterizedType(ParameterizedType, Iterable<? extends Annotation>) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- newAnnotatedParameterizedType(Class<?>, List<? extends AnnotatedType>, Annotation...) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- newAnnotatedParameterizedType(Class<?>, List<? extends AnnotatedType>, Iterable<? extends Annotation>) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- newAnnotatedParameterizedType(AnnotatedType, Class<?>, List<? extends AnnotatedType>, Annotation...) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- newAnnotatedParameterizedType(AnnotatedType, Class<?>, List<? extends AnnotatedType>, Iterable<? extends Annotation>) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- newAnnotatedType(Type, Annotation...) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- newAnnotatedType(Class<?>, Annotation...) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- newAnnotatedType(Class<?>, Iterable<? extends Annotation>) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- newAnnotatedType(Type, Iterable<? extends Annotation>) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- newAnnotatedTypeVariable(TypeVariable<?>, Annotation...) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- newAnnotatedTypeVariable(TypeVariable<?>, Iterable<? extends Annotation>) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- newAnnotatedWildcardType(WildcardType, Annotation...) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- newAnnotatedWildcardType(WildcardType, Iterable<? extends Annotation>) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- newArrayIfTooSmall(T[], int) - Static method in class com.bluegosling.collections.ArrayUtils
-
Returns the specified array if it has sufficient capacity or a new larger array otherwise.
- newBuilder() - Static method in class com.bluegosling.concurrent.executors.ActorThreadPool
-
- newBuilder() - Static method in class com.bluegosling.graph.ComputationFactory
-
- newBuilder() - Static method in class com.bluegosling.reflect.EnumType
-
Returns a new builder, for defining the elements of an enum type.
- newCanonicalSetFromMap(Map<E, E>) - Static method in interface com.bluegosling.collections.sets.CanonicalSet
-
Creates a new canonical set backed by the given map.
- newChild() - Method in class com.bluegosling.concurrent.locks.HierarchicalLock
-
Creates a new child of this lock.
- newComponent() - Method in class com.bluegosling.concurrent.atoms.TransactionalAtom
-
Creates a new component atom with a null
initial value and no validator.
- newComponent(U) - Method in class com.bluegosling.concurrent.atoms.TransactionalAtom
-
Creates a new atom with the specified initial value and no validator.
- newComponent(U, Predicate<? super U>) - Method in class com.bluegosling.concurrent.atoms.TransactionalAtom
-
Creates a new atom with the specified initial value and the specified validator.
- newComputation(Graph<T>) - Method in class com.bluegosling.graph.ComputationFactory
-
- newComputation() - Method in class com.bluegosling.graph.Graph
-
Creates a new computation for this graph using a default
factory.
- newCondition() - Method in class com.bluegosling.concurrent.locks.NonReentrantLock
-
- newCondition() - Method in class com.bluegosling.concurrent.locks.SpinLock
-
- newCustomTable2D(Supplier<Map<Object, Object>>) - Static method in interface com.bluegosling.collections.tables.Table2D
-
- newCustomTable2D(IntFunction<Map<Object, Object>>) - Static method in interface com.bluegosling.collections.tables.Table2D
-
- newCustomTable3D(Supplier<Map<Object, Object>>) - Static method in interface com.bluegosling.collections.tables.Table3D
-
- newCustomTable3D(IntFunction<Map<Object, Object>>) - Static method in interface com.bluegosling.collections.tables.Table3D
-
- newCustomTable4D(Supplier<Map<Object, Object>>) - Static method in interface com.bluegosling.collections.tables.Table4D
-
- newCustomTable4D(IntFunction<Map<Object, Object>>) - Static method in interface com.bluegosling.collections.tables.Table4D
-
- newCustomTable5D(Supplier<Map<Object, Object>>) - Static method in interface com.bluegosling.collections.tables.Table5D
-
- newCustomTable5D(IntFunction<Map<Object, Object>>) - Static method in interface com.bluegosling.collections.tables.Table5D
-
- newExecutorFor(K) - Method in interface com.bluegosling.concurrent.executors.SerializingExecutor
-
Returns an executor that associates all tasks with the given key.
- newExecutorServiceFor(K) - Method in class com.bluegosling.concurrent.executors.PipeliningExecutor
-
Creates a new service whose tasks are submitted to the specified pipeline.
- newExtendsAnnotatedWildcardType(AnnotatedType, Annotation...) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
Creates a new
WildcardType
with an upper bound, i.e.
? extends T
.
- newExtendsAnnotatedWildcardType(AnnotatedType, Iterable<? extends Annotation>) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- newExtendsWildcardType(Type) - Static method in class com.bluegosling.reflect.Types
-
Creates a new
WildcardType
with an upper bound, i.e.
? extends T
.
- newGenericArrayType(Type) - Static method in class com.bluegosling.reflect.Types
-
- newGroupingDaemonThreadFactory(ThreadGroup) - Static method in class com.bluegosling.concurrent.ThreadFactories
-
Returns a thread factory that creates daemon threads belonging to the given group and named
after the given group.
- newGroupingDaemonThreadFactory(ThreadGroup, String) - Static method in class com.bluegosling.concurrent.ThreadFactories
-
Returns a thread factory that creates daemon threads belonging to the given group and with
the given name prefix.
- newGroupingDaemonThreadFactory(String) - Static method in class com.bluegosling.concurrent.ThreadFactories
-
Returns a thread factory that creates daemon threads belonging to the given group and with the
given name prefix.
- newGroupingThreadFactory(ThreadGroup) - Static method in class com.bluegosling.concurrent.ThreadFactories
-
Returns a thread factory that creates threads belonging to the given group and named after the
given group.
- newGroupingThreadFactory(ThreadGroup, String) - Static method in class com.bluegosling.concurrent.ThreadFactories
-
Returns a thread factory that creates threads belonging to the given group and with the given
name prefix.
- newGroupingThreadFactory(String) - Static method in class com.bluegosling.concurrent.ThreadFactories
-
Returns a thread factory that creates threads belonging to the given group and with the given
name prefix.
- newHashTable2D() - Static method in interface com.bluegosling.collections.tables.Table2D
-
- newHashTable3D() - Static method in interface com.bluegosling.collections.tables.Table3D
-
- newHashTable4D() - Static method in interface com.bluegosling.collections.tables.Table4D
-
- newHashTable5D() - Static method in interface com.bluegosling.collections.tables.Table5D
-
- newInstance(Class<T>, int) - Static method in class com.bluegosling.reflect.ArrayUtils
-
Constructs a new array of the given non-primitive component type and length.
- newLinkedHashTable2D() - Static method in interface com.bluegosling.collections.tables.Table2D
-
- newLinkedHashTable3D() - Static method in interface com.bluegosling.collections.tables.Table3D
-
- newLinkedHashTable4D() - Static method in interface com.bluegosling.collections.tables.Table4D
-
- newLinkedHashTable5D() - Static method in interface com.bluegosling.collections.tables.Table5D
-
- newList() - Static method in interface com.bluegosling.concurrent.executors.InterceptingExecutor.Interceptor
-
Returns a new builder, for building a list of interceptors from both interceptor and
decorator instances.
- newList() - Static method in interface com.bluegosling.concurrent.executors.InterceptingExecutorService.Interceptor
-
Returns a new builder, for building a list of interceptors from both interceptor and
decorator instances.
- newLock(T) - Static method in class com.bluegosling.concurrent.locks.DoubleInstanceLock
-
Constructs a new double instance lock around the given object.
- newLock(T, Cloner<T>) - Static method in class com.bluegosling.concurrent.locks.DoubleInstanceLock
-
Constructs a new double instance lock around the given object that uses the given cloner to
create additional instances.
- newNavigableSetFromMap(NavigableMap<E, Boolean>) - Static method in class com.bluegosling.collections.MoreSets
-
Returns a navigable set that is backed by the given map.
- newNode(C, HashCompositeTrie.TrieNode<C, K, V>) - Method in class com.bluegosling.collections.tries.HashCompositeTrie
-
- newNode(K, HashSequenceTrie.TrieNode<K, V>) - Method in class com.bluegosling.collections.tries.HashSequenceTrie
-
- newNode(C, SortedArrayCompositeTrie.TrieNode<K, C, V>) - Method in class com.bluegosling.collections.tries.SortedArrayCompositeTrie
-
- newNode(K, SortedArraySequenceTrie.TrieNode<K, V>) - Method in class com.bluegosling.collections.tries.SortedArraySequenceTrie
-
- newParameterizedType(Class<?>, Type...) - Static method in class com.bluegosling.reflect.Types
-
- newParameterizedType(Class<?>, List<Type>) - Static method in class com.bluegosling.reflect.Types
-
- newParameterizedType(ParameterizedType, Class<?>, Type...) - Static method in class com.bluegosling.reflect.Types
-
- newParameterizedType(ParameterizedType, Class<?>, List<Type>) - Static method in class com.bluegosling.reflect.Types
-
- newSet(Comparator<? super T>) - Method in interface com.bluegosling.collections.queues.SetBackedOrderedQueue.SetFactory
-
- newSetFromMap(PersistentMap<E, Boolean>) - Static method in interface com.bluegosling.collections.immutable.PersistentSet
-
Returns a persistent set that is backed by the given persistent map.
- newSortedSetFromMap(SortedMap<E, Boolean>) - Static method in class com.bluegosling.collections.MoreSets
-
Returns a sorted set that is backed by the given map.
- newSuperAnnotatedWildcardType(AnnotatedType, Annotation...) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
Creates a new
WildcardType
with a lower bound, i.e.
? super T
.
- newSuperAnnotatedWildcardType(AnnotatedType, Iterable<? extends Annotation>) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- newSuperWildcardType(Type) - Static method in class com.bluegosling.reflect.Types
-
Creates a new
WildcardType
with a lower bound, i.e.
? super T
.
- newTask() - Method in class com.bluegosling.apt.testing.CompilationContext
-
Returns a new task builder that can execute a task during the annotation processing phase of
the compiler.
- newTaskFor(Callable<T>) - Method in class com.bluegosling.concurrent.executors.ThreadLimitingExecutorService
-
- newTaskFor(Runnable, T) - Method in class com.bluegosling.concurrent.executors.ThreadLimitingExecutorService
-
- newTreeTable2D() - Static method in interface com.bluegosling.collections.tables.Table2D
-
- newTreeTable3D() - Static method in interface com.bluegosling.collections.tables.Table3D
-
- newTreeTable4D() - Static method in interface com.bluegosling.collections.tables.Table4D
-
- newTreeTable5D() - Static method in interface com.bluegosling.collections.tables.Table5D
-
- next - Variable in class com.bluegosling.collections.AbstractNavigableMap.BaseIteratorImpl
-
- next() - Method in class com.bluegosling.collections.AbstractNavigableMap.BaseIteratorImpl
-
- next() - Method in interface com.bluegosling.collections.bits.BitStream
-
Returns the next bit in the stream.
- next(int, BitSequence.BitOrder) - Method in interface com.bluegosling.collections.bits.BitStream
-
Returns the next chunk of bits in the stream.
- next(int) - Method in interface com.bluegosling.collections.bits.BitStream
-
Returns the next chunk of bits in the stream.
- next() - Method in class com.bluegosling.collections.FilteringIterator
-
- next() - Method in class com.bluegosling.collections.FilteringListIterator
-
- next() - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.BaseListIteratorImpl
-
- next() - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.SubMapByIndicesIterator
-
- next() - Method in interface com.bluegosling.collections.primitive.BooleanIterator
-
- next() - Method in interface com.bluegosling.collections.primitive.ByteIterator
-
- next() - Method in interface com.bluegosling.collections.primitive.CharIterator
-
- next() - Method in interface com.bluegosling.collections.primitive.FloatIterator
-
- next() - Method in interface com.bluegosling.collections.primitive.PrimitiveListIterator.OfBoolean
-
- next() - Method in interface com.bluegosling.collections.primitive.PrimitiveListIterator.OfByte
-
- next() - Method in interface com.bluegosling.collections.primitive.PrimitiveListIterator.OfChar
-
- next() - Method in interface com.bluegosling.collections.primitive.PrimitiveListIterator.OfDouble
-
- next() - Method in interface com.bluegosling.collections.primitive.PrimitiveListIterator.OfFloat
-
- next() - Method in interface com.bluegosling.collections.primitive.PrimitiveListIterator.OfInt
-
- next() - Method in interface com.bluegosling.collections.primitive.PrimitiveListIterator.OfLong
-
- next() - Method in interface com.bluegosling.collections.primitive.PrimitiveListIterator.OfShort
-
- next() - Method in interface com.bluegosling.collections.primitive.ShortIterator
-
- next() - Method in class com.bluegosling.collections.TransformingIterator
-
- next(U) - Method in interface com.bluegosling.generator.Sequence
-
Supplies a value to the generator and then returns the next element in the sequence.
- next() - Method in interface com.bluegosling.generator.Sequence
-
Returns the next element in the sequence.
- next() - Method in class com.bluegosling.util.PrimeIterator
-
Returns the next generated prime.
- nextAsSequence(int) - Method in interface com.bluegosling.collections.bits.BitStream
-
Returns the next chunk of bits in the stream.
- nextBoolean() - Method in interface com.bluegosling.collections.primitive.BooleanIterator
-
Returns the next boolean in the iteration.
- nextByte() - Method in interface com.bluegosling.collections.primitive.ByteIterator
-
Returns the next byte in the iteration.
- nextChar() - Method in interface com.bluegosling.collections.primitive.CharIterator
-
Returns the next character in the iteration.
- nextFloat() - Method in interface com.bluegosling.collections.primitive.FloatIterator
-
Returns the next float in the iteration.
- nextIndex() - Method in class com.bluegosling.collections.FilteringListIterator
-
- nextIndex() - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.BaseListIteratorImpl
-
- nextIndex() - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.SubMapByIndicesIterator
-
- nextIndex() - Method in class com.bluegosling.collections.TransformingListIterator
-
- nextKeyedIndex(int) - Method in class com.bluegosling.collections.lists.AssociativeArrayList
-
- nextKeyedIndex(int) - Method in interface com.bluegosling.collections.lists.AssociativeList
-
Returns the next index in the list, that is greater than or equal to the specified index, that
has an associated key.
- nextShort() - Method in interface com.bluegosling.collections.primitive.ShortIterator
-
Returns the next short in the iteration.
- nextUpstream(StreamNode.Upstream<U>) - Method in class com.bluegosling.streams.AbstractStreamNode
-
Pulls data from the given upstream producer, returning whether or not data was pulled.
- NO_OP - Static variable in class com.bluegosling.testing.ObjectVerifiers
-
An object verifier that doesn't actually do any verification but just returns the test object.
- noCloneAndVerifyArguments() - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfiguration
-
Indicates that arguments should not be cloned prior to method execution, which implies that
arguments do not need to be verified after execution.
- noCloneAndVerifyArguments() - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfigurator
-
Indicates that arguments should not be cloned prior to method execution, which implies that
arguments do not need to be verified after execution.
- NoCopyGrowableArray<T> - Class in com.bluegosling.collections
-
A growable array that does not require doubling and copying an underlying array.
- NoCopyGrowableArray() - Constructor for class com.bluegosling.collections.NoCopyGrowableArray
-
- NoCopyGrowableArray(int) - Constructor for class com.bluegosling.collections.NoCopyGrowableArray
-
- NoCopyGrowableArray(Collection<? extends T>) - Constructor for class com.bluegosling.collections.NoCopyGrowableArray
-
- Node<T> - Class in com.bluegosling.graph
-
A node in a computation graph.
- node() - Method in class com.bluegosling.graph.Node.Input
-
Returns the node associated with this input.
- Node.Input<T> - Class in com.bluegosling.graph
-
An input to a node.
- Node.NodeBuilder0 - Class in com.bluegosling.graph
-
A factory for nodes with zero or more inputs.
- Node.NodeBuilder1<A> - Class in com.bluegosling.graph
-
A factory for nodes with one or more inputs.
- Node.NodeBuilder10<A,B,C,D,E,F,G,H,I,J> - Class in com.bluegosling.graph
-
A factory for nodes with ten inputs.
- Node.NodeBuilder2<A,B> - Class in com.bluegosling.graph
-
A factory for nodes with two or more inputs.
- Node.NodeBuilder3<A,B,C> - Class in com.bluegosling.graph
-
A factory for nodes with three or more inputs.
- Node.NodeBuilder4<A,B,C,D> - Class in com.bluegosling.graph
-
A factory for nodes with four or more inputs.
- Node.NodeBuilder5<A,B,C,D,E> - Class in com.bluegosling.graph
-
A factory for nodes with five or more inputs.
- Node.NodeBuilder6<A,B,C,D,E,F> - Class in com.bluegosling.graph
-
A factory for nodes with six or more inputs.
- Node.NodeBuilder7<A,B,C,D,E,F,G> - Class in com.bluegosling.graph
-
A factory for nodes with seven or more inputs.
- Node.NodeBuilder8<A,B,C,D,E,F,G,H> - Class in com.bluegosling.graph
-
A factory for nodes with eight or more inputs.
- Node.NodeBuilder9<A,B,C,D,E,F,G,H,I> - Class in com.bluegosling.graph
-
A factory for nodes with nine or more inputs.
- NodeBuilder0() - Constructor for class com.bluegosling.graph.Node.NodeBuilder0
-
- NodeDecorator - Interface in com.bluegosling.graph
-
An object used to decorate a node operation.
- NodeOperations - Class in com.bluegosling.graph
-
Functional interfaces that represent operations executed by nodes in a computation graph.
- NodeOperations.Operation1<A,T> - Interface in com.bluegosling.graph
-
An operation that accepts a single input and produces a result.
- NodeOperations.Operation10<A,B,C,D,E,F,G,H,I,J,T> - Interface in com.bluegosling.graph
-
An operation that accepts ten inputs and produces a result.
- NodeOperations.Operation2<A,B,T> - Interface in com.bluegosling.graph
-
An operation that accepts two inputs and produces a result.
- NodeOperations.Operation3<A,B,C,T> - Interface in com.bluegosling.graph
-
An operation that accepts three inputs and produces a result.
- NodeOperations.Operation4<A,B,C,D,T> - Interface in com.bluegosling.graph
-
An operation that accepts four inputs and produces a result.
- NodeOperations.Operation5<A,B,C,D,E,T> - Interface in com.bluegosling.graph
-
An operation that accepts five inputs and produces a result.
- NodeOperations.Operation6<A,B,C,D,E,F,T> - Interface in com.bluegosling.graph
-
An operation that accepts six inputs and produces a result.
- NodeOperations.Operation7<A,B,C,D,E,F,G,T> - Interface in com.bluegosling.graph
-
An operation that accepts seven inputs and produces a result.
- NodeOperations.Operation8<A,B,C,D,E,F,G,H,T> - Interface in com.bluegosling.graph
-
An operation that accepts eight inputs and produces a result.
- NodeOperations.Operation9<A,B,C,D,E,F,G,H,I,T> - Interface in com.bluegosling.graph
-
An operation that accepts nine inputs and produces a result.
- NonReentrantLock - Class in com.bluegosling.concurrent.locks
-
A non-reentrant lock.
- NonReentrantLock() - Constructor for class com.bluegosling.concurrent.locks.NonReentrantLock
-
Constructs a new, unfair lock.
- NonReentrantLock(boolean) - Constructor for class com.bluegosling.concurrent.locks.NonReentrantLock
-
Constructs a new lock.
- NoProcess - Annotation Type in com.bluegosling.apt.testing
-
Indicates a test method that should be run as a normal test, not in the context of
annotation processing.
- not(BitSequence) - Static method in class com.bluegosling.collections.bits.BitSequences
-
Returns a new sequence whose bits are the inverse of the specified sequence.
- notMutator() - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfiguration
-
Indicates that the method is not a mutator method.
- notMutator() - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfigurator
-
Indicates that the method is not a mutator method.
- notNull() - Static method in class com.bluegosling.function.Predicates
-
Returns a predicate that returns true if its given argument is non-null
.
- notNull(Possible<T>) - Static method in interface com.bluegosling.possible.Possible
-
Converts a possible null
value to an optional one.
- noVerifyArguments() - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfiguration
-
Indicates that arguments do not need to be verified after execution.
- noVerifyArguments() - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfigurator
-
Indicates that arguments do not need to be verified after execution.
- now() - Method in class com.bluegosling.concurrent.fluent.FluentScheduledFutureTask
-
- NTuple<A,B,C,D,E> - Class in com.bluegosling.tuples
-
A tuple that has more than five elements.
- nTupleNaturalOrdering() - Method in class com.bluegosling.tuples.Tuples
-
- nullIfFailed(Collection<? extends Result<? extends T, ?>>) - Static method in class com.bluegosling.result.Result
-
Returns a list of the given results' values, substituting null
as the value for any
failed result.
- nullIfNotPresent(Collection<? extends Optional<? extends T>>) - Static method in class com.bluegosling.possible.Optionals
-
- nullIfNotPresent(Collection<? extends Possible<? extends T>>) - Static method in interface com.bluegosling.possible.Possible
-
Returns a list of the values, null
if no value is present, from the specified
collection of possible values.
- NULLS - Static variable in class com.bluegosling.testing.ObjectVerifiers
-
An object that verifies that the test object is null if the reference object is null and
non-null otherwise.
- PackageDirectory - Class in com.bluegosling.buildgen
-
- PackageDirectory(File) - Constructor for class com.bluegosling.buildgen.PackageDirectory
-
- PackageDirectory(File, JavaPackage) - Constructor for class com.bluegosling.buildgen.PackageDirectory
-
- PackageScanner - Class in com.bluegosling.reflect.scanner
-
Scans directories and JARs for classes, indexing them by package.
- PackageScanner() - Constructor for class com.bluegosling.reflect.scanner.PackageScanner
-
Creates a new package scanner.
- PackageScanner.ClassInfo - Class in com.bluegosling.reflect.scanner
-
- PackageScanner.PathResult - Class in com.bluegosling.reflect.scanner
-
The results of scanning a single path.
- PackageScanner.ScanResult - Class in com.bluegosling.reflect.scanner
-
The results of a scan.
- pageIndex() - Method in interface com.bluegosling.collections.tables.Table4D
-
- pageIndex() - Method in interface com.bluegosling.collections.tables.Table5D
-
- pageKeySet() - Method in interface com.bluegosling.collections.tables.Table3D
-
- pageKeySet() - Method in interface com.bluegosling.collections.tables.Table4D
-
- pageKeySet() - Method in interface com.bluegosling.collections.tables.Table5D
-
- Pair<A,B> - Class in com.bluegosling.tuples
-
A tuple with two items.
- pairNaturalOrdering() - Method in class com.bluegosling.tuples.Tuples
-
- parallel() - Method in interface com.bluegosling.streams.FluentStream
- ParallelSort - Class in com.bluegosling.collections.sorting
-
A utility for sorting large lists using multiple CPUs/cores.
- ParallelSort() - Constructor for class com.bluegosling.collections.sorting.ParallelSort
-
- ParallelSort2 - Class in com.bluegosling.collections.sorting
-
A utility for sorting large lists using multiple CPUs/cores.
- ParallelSort2() - Constructor for class com.bluegosling.collections.sorting.ParallelSort2
-
- parallelStreamOfDouble() - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfDouble
-
- parallelStreamOfDouble() - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfDouble
-
- parallelStreamOfInt() - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfInt
-
- parallelStreamOfInt() - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfInt
-
- parallelStreamOfLong() - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfLong
-
- parallelStreamOfLong() - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfLong
-
- PartialBiFunction<T,U,R> - Interface in com.bluegosling.function
-
A partial function that computes a value from two inputs.
- PartialFunction<T,R> - Interface in com.bluegosling.function
-
A function that does not fully map the input domain to the output domain.
- PartialFunctions - Class in com.bluegosling.function
-
- PartialTriFunction<T,U,V,R> - Interface in com.bluegosling.function
-
A partial function that computes a value from three inputs.
- partition(Predicate<? super T>) - Method in interface com.bluegosling.streams.FluentStream
-
Partitions this stream into two, with elements that match the given predicate in the first
partition and elements that do not match it in the second partition.
- path - Variable in class com.bluegosling.buildgen.BuildGen.Target
-
- pause() - Method in interface com.bluegosling.concurrent.scheduler.ScheduledTaskDefinition
-
Pauses this task definition.
- peek() - Method in class com.bluegosling.collections.AbstractDeque
-
- peek(int) - Method in class com.bluegosling.collections.CircularBuffer
-
Returns the item in the buffer at the specified position, where zero is the position of the
first item.
- peek() - Method in class com.bluegosling.collections.concurrent.LockFreeArrayBlockingQueue
-
- peek() - Method in class com.bluegosling.collections.concurrent.LockFreeLinkedBlockingQueue
-
- peek() - Method in class com.bluegosling.collections.concurrent.SimpleTreiberStack
-
- peek() - Method in class com.bluegosling.collections.concurrent.TreiberStack
-
Peeks at the value on the top of the stack.
- peek() - Method in class com.bluegosling.collections.lists.ArrayBackedLinkedList
- peek() - Method in class com.bluegosling.collections.lists.UnrolledLinkedList
-
- peek() - Method in class com.bluegosling.collections.queues.FibonacciHeapOrderedQueue
-
- peek() - Method in interface com.bluegosling.collections.queues.OrderedDeque
-
- peek() - Method in interface com.bluegosling.collections.queues.PriorityQueue
-
Queries for the minimum entry.
- peek() - Method in class com.bluegosling.collections.queues.RandomAccessArrayDeque
-
- peek() - Method in class com.bluegosling.collections.queues.RandomizedQueue
-
- peek() - Method in class com.bluegosling.collections.queues.SetBackedOrderedQueue
-
- peek() - Method in class com.bluegosling.collections.queues.SkewHeapOrderedQueue
-
- peek() - Method in interface com.bluegosling.collections.Stack
-
Returns the element at the top of the stack or null
if the stack is empty.
- peek() - Method in class com.bluegosling.concurrent.RateLimitedBlockingQueue
-
- peek(Consumer<? super T>) - Method in interface com.bluegosling.streams.FluentStream
- peekFirst() - Method in class com.bluegosling.collections.CircularBuffer
-
Returns the first item in the buffer.
- peekFirst() - Method in class com.bluegosling.collections.concurrent.ArrayBlockingDeque
-
- peekFirst() - Method in class com.bluegosling.collections.concurrent.ConcurrentSkipListOrderedQueue
-
- peekFirst() - Method in class com.bluegosling.collections.concurrent.LockFreeLinkedBlockingDeque
-
- peekFirst() - Method in class com.bluegosling.collections.concurrent.LockFreeSkipListBlockingQueue
-
- peekFirst() - Method in class com.bluegosling.collections.lists.ArrayBackedLinkedList
- peekFirst() - Method in class com.bluegosling.collections.lists.UnrolledLinkedList
-
- peekFirst() - Method in interface com.bluegosling.collections.queues.OrderedDeque
-
- peekFirst() - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- peekFirst() - Method in class com.bluegosling.collections.queues.RandomAccessArrayDeque
-
- peekLast() - Method in class com.bluegosling.collections.CircularBuffer
-
Returns the last item in the buffer.
- peekLast() - Method in class com.bluegosling.collections.concurrent.ArrayBlockingDeque
-
- peekLast() - Method in class com.bluegosling.collections.concurrent.ConcurrentSkipListOrderedQueue
-
- peekLast() - Method in class com.bluegosling.collections.concurrent.LockFreeLinkedBlockingDeque
-
- peekLast() - Method in class com.bluegosling.collections.concurrent.LockFreeSkipListBlockingQueue
-
- peekLast() - Method in class com.bluegosling.collections.lists.ArrayBackedLinkedList
- peekLast() - Method in class com.bluegosling.collections.lists.UnrolledLinkedList
-
- peekLast() - Method in interface com.bluegosling.collections.queues.OrderedDeque
-
- peekLast() - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- peekLast() - Method in class com.bluegosling.collections.queues.RandomAccessArrayDeque
-
- periodDelay(TimeUnit) - Method in interface com.bluegosling.concurrent.scheduler.TaskDefinition
-
Returns the period (for fixed rate tasks) or delay (for fixed delay tasks)
for this task.
- permitsAvailable() - Method in class com.bluegosling.concurrent.RateLimiter
-
Returns the number of permits currently available.
- PersistentCollection<E> - Interface in com.bluegosling.collections.immutable
-
A fully persistent collection.
- PersistentList<E> - Interface in com.bluegosling.collections.immutable
-
A fully persistent list.
- PersistentListBackedConcurrentList<E> - Class in com.bluegosling.collections.concurrent
-
- PersistentMap<K,V> - Interface in com.bluegosling.collections.immutable
-
- PersistentMapBackedConcurrentMap<K,V> - Class in com.bluegosling.collections.concurrent
-
A concurrent map that is backed by a persistent map.
- PersistentMapBackedConcurrentMap(PersistentMap<K, V>) - Constructor for class com.bluegosling.collections.concurrent.PersistentMapBackedConcurrentMap
-
Constructs a new concurrent map whose initial state is the given persistent map.
- PersistentSet<E> - Interface in com.bluegosling.collections.immutable
-
A fully persistent set.
- pin() - Method in class com.bluegosling.concurrent.atoms.TransactionalAtom
-
Pins an atom so that no concurrent transaction can modify it.
- PipeliningExecutor<K> - Class in com.bluegosling.concurrent.executors
-
An executor that runs multiple sequential pipelines.
- PipeliningExecutor(Executor) - Constructor for class com.bluegosling.concurrent.executors.PipeliningExecutor
-
Constructs a new pipelining executor that uses the specified executor for actually running
tasks.
- PipeliningExecutor(Executor, int) - Constructor for class com.bluegosling.concurrent.executors.PipeliningExecutor
-
Constructs a new pipelining executor that uses the specified executor for actually running
tasks and runs up to the given number of tasks in a batch.
- PipeliningExecutor(Executor, long, TimeUnit) - Constructor for class com.bluegosling.concurrent.executors.PipeliningExecutor
-
Constructs a new pipelining executor that uses the specified executor for actually running
tasks and runs tasks in batches up to the given duration.
- PipeliningExecutor(Executor, int, long, TimeUnit) - Constructor for class com.bluegosling.concurrent.executors.PipeliningExecutor
-
Constructs a new pipelining executor that uses the specified executor for actually running
tasks and runs up to the given number of tasks in a batch, for up to the given duration.
- plus(Duration) - Method in class com.bluegosling.concurrent.Duration
-
Returns the sum of this duration and the specified duration.
- plus(long, TimeUnit) - Method in class com.bluegosling.concurrent.Duration
-
Returns the sum of this duration and the specified duration.
- poll() - Method in class com.bluegosling.collections.AbstractDeque
-
- poll(long, TimeUnit) - Method in class com.bluegosling.collections.concurrent.AbstractLockFreeBlockingDeque
-
- poll(long, TimeUnit) - Method in class com.bluegosling.collections.concurrent.AbstractLockFreeBlockingOrderedDeque
-
- poll(long, TimeUnit) - Method in class com.bluegosling.collections.concurrent.AbstractLockFreeBlockingQueue
-
- poll(long, TimeUnit) - Method in interface com.bluegosling.collections.concurrent.BlockingOrderedDeque
-
- poll() - Method in class com.bluegosling.collections.concurrent.LockFreeArrayBlockingQueue
-
- poll() - Method in class com.bluegosling.collections.concurrent.LockFreeLinkedBlockingQueue
-
- poll() - Method in class com.bluegosling.collections.concurrent.SimpleTreiberStack
-
- poll() - Method in class com.bluegosling.collections.concurrent.TreiberStack
-
Polls for the value at the top of the stack.
- poll() - Method in class com.bluegosling.collections.lists.ArrayBackedLinkedList
- poll() - Method in class com.bluegosling.collections.lists.UnrolledLinkedList
-
- poll() - Method in class com.bluegosling.collections.queues.FibonacciHeapOrderedQueue
-
- poll() - Method in interface com.bluegosling.collections.queues.OrderedDeque
-
- poll() - Method in interface com.bluegosling.collections.queues.PriorityQueue
-
Removes the minimum entry from the queue if present.
- poll(long, TimeUnit) - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- poll() - Method in class com.bluegosling.collections.queues.RandomAccessArrayDeque
-
- poll() - Method in class com.bluegosling.collections.queues.RandomizedQueue
-
- poll() - Method in class com.bluegosling.collections.queues.SetBackedOrderedQueue
-
- poll() - Method in class com.bluegosling.collections.queues.SkewHeapOrderedQueue
-
- poll() - Method in interface com.bluegosling.collections.Stack
-
Removes the element from the top of the stack and returns it or returns null
if the
stack is empty.
- poll() - Method in class com.bluegosling.concurrent.RateLimitedBlockingQueue
-
- poll(long, TimeUnit) - Method in class com.bluegosling.concurrent.RateLimitedBlockingQueue
-
- pollFirst() - Method in class com.bluegosling.collections.AbstractNavigableMap.KeySet
-
- pollFirst(long, TimeUnit) - Method in class com.bluegosling.collections.concurrent.AbstractLockFreeBlockingDeque
-
- pollFirst(long, TimeUnit) - Method in class com.bluegosling.collections.concurrent.AbstractLockFreeBlockingOrderedDeque
-
- pollFirst() - Method in class com.bluegosling.collections.concurrent.ArrayBlockingDeque
-
- pollFirst(long, TimeUnit) - Method in interface com.bluegosling.collections.concurrent.BlockingOrderedDeque
-
- pollFirst() - Method in class com.bluegosling.collections.concurrent.ConcurrentSkipListOrderedQueue
-
- pollFirst() - Method in class com.bluegosling.collections.concurrent.ConcurrentSortedArraySet
- pollFirst() - Method in class com.bluegosling.collections.concurrent.LockFreeLinkedBlockingDeque
-
- pollFirst() - Method in class com.bluegosling.collections.concurrent.LockFreeSkipListBlockingQueue
-
- pollFirst() - Method in class com.bluegosling.collections.DescendingSet
-
- pollFirst() - Method in class com.bluegosling.collections.FilteringNavigableSet
-
- pollFirst() - Method in class com.bluegosling.collections.lists.ArrayBackedLinkedList
- pollFirst() - Method in class com.bluegosling.collections.lists.UnrolledLinkedList
-
- pollFirst() - Method in interface com.bluegosling.collections.queues.OrderedDeque
-
- pollFirst() - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- pollFirst(long, TimeUnit) - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- pollFirst() - Method in class com.bluegosling.collections.queues.RandomAccessArrayDeque
-
- pollFirst() - Method in class com.bluegosling.collections.sets.SortedArraySet
- pollFirstEntry() - Method in class com.bluegosling.collections.AbstractNavigableMap
- pollFirstEntry() - Method in class com.bluegosling.collections.concurrent.DoubleInstanceLockedTreeMap
-
- pollFirstEntry() - Method in class com.bluegosling.collections.DescendingMap
-
- pollFirstEntry() - Method in class com.bluegosling.collections.FilteringNavigableMap
-
- pollFirstEntry() - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.SubMapByIndices
-
- pollFirstEntry() - Method in class com.bluegosling.collections.maps.WeightBalancedTreeMap
-
- pollFirstEntry() - Method in class com.bluegosling.collections.tries.ArrayMappedBitwiseTrie
-
- pollFirstEntry() - Method in class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- pollFirstEntry() - Method in class com.bluegosling.collections.tries.SimpleBitwiseTrie
-
- pollFirstInterruptibly() - Method in class com.bluegosling.collections.concurrent.AbstractLockFreeBlockingDeque
-
Removes the first element in the deque, allowing interruption.
- pollFirstInterruptibly() - Method in class com.bluegosling.collections.concurrent.AbstractLockFreeBlockingOrderedDeque
-
- pollFirstInterruptibly() - Method in class com.bluegosling.collections.concurrent.ArrayBlockingDeque
-
- pollInterruptibly() - Method in class com.bluegosling.collections.concurrent.AbstractLockFreeBlockingOrderedDeque
-
- pollInterruptibly() - Method in class com.bluegosling.collections.concurrent.AbstractLockFreeBlockingQueue
-
Removes the first element in the queue, allowing interruption.
- pollLast() - Method in class com.bluegosling.collections.AbstractNavigableMap.KeySet
-
- pollLast(long, TimeUnit) - Method in class com.bluegosling.collections.concurrent.AbstractLockFreeBlockingDeque
-
- pollLast(long, TimeUnit) - Method in class com.bluegosling.collections.concurrent.AbstractLockFreeBlockingOrderedDeque
-
- pollLast() - Method in class com.bluegosling.collections.concurrent.ArrayBlockingDeque
-
- pollLast(long, TimeUnit) - Method in interface com.bluegosling.collections.concurrent.BlockingOrderedDeque
-
- pollLast() - Method in class com.bluegosling.collections.concurrent.ConcurrentSkipListOrderedQueue
-
- pollLast() - Method in class com.bluegosling.collections.concurrent.ConcurrentSortedArraySet
- pollLast() - Method in class com.bluegosling.collections.concurrent.LockFreeLinkedBlockingDeque
-
- pollLast() - Method in class com.bluegosling.collections.concurrent.LockFreeSkipListBlockingQueue
-
- pollLast() - Method in class com.bluegosling.collections.DescendingSet
-
- pollLast() - Method in class com.bluegosling.collections.FilteringNavigableSet
-
- pollLast() - Method in class com.bluegosling.collections.lists.ArrayBackedLinkedList
- pollLast() - Method in class com.bluegosling.collections.lists.UnrolledLinkedList
-
- pollLast() - Method in interface com.bluegosling.collections.queues.OrderedDeque
-
- pollLast() - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- pollLast(long, TimeUnit) - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- pollLast() - Method in class com.bluegosling.collections.queues.RandomAccessArrayDeque
-
- pollLast() - Method in class com.bluegosling.collections.sets.SortedArraySet
- pollLastEntry() - Method in class com.bluegosling.collections.AbstractNavigableMap
- pollLastEntry() - Method in class com.bluegosling.collections.concurrent.DoubleInstanceLockedTreeMap
-
- pollLastEntry() - Method in class com.bluegosling.collections.DescendingMap
-
- pollLastEntry() - Method in class com.bluegosling.collections.FilteringNavigableMap
-
- pollLastEntry() - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.SubMapByIndices
-
- pollLastEntry() - Method in class com.bluegosling.collections.maps.WeightBalancedTreeMap
-
- pollLastEntry() - Method in class com.bluegosling.collections.tries.ArrayMappedBitwiseTrie
-
- pollLastEntry() - Method in class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- pollLastEntry() - Method in class com.bluegosling.collections.tries.SimpleBitwiseTrie
-
- pollLastInterruptibly() - Method in class com.bluegosling.collections.concurrent.AbstractLockFreeBlockingDeque
-
Removes the last element in the deque, allowing interruption.
- pollLastInterruptibly() - Method in class com.bluegosling.collections.concurrent.AbstractLockFreeBlockingOrderedDeque
-
- pollLastInterruptibly() - Method in class com.bluegosling.collections.concurrent.ArrayBlockingDeque
-
- pop() - Method in class com.bluegosling.collections.AbstractDeque
-
- pop() - Method in class com.bluegosling.collections.concurrent.SimpleTreiberStack
-
- pop() - Method in class com.bluegosling.collections.concurrent.TreiberStack
-
Pops a value off of the stack.
- pop() - Method in class com.bluegosling.collections.lists.ArrayBackedLinkedList
- pop() - Method in class com.bluegosling.collections.lists.UnrolledLinkedList
-
- pop() - Method in class com.bluegosling.collections.NoCopyGrowableArray
-
- pop() - Method in class com.bluegosling.collections.queues.RandomAccessArrayDeque
-
- pop() - Method in interface com.bluegosling.collections.Stack
-
Removes the element from the top of the stack and returns it.
- Possible<T> - Interface in com.bluegosling.possible
-
A possible value.
- Possible.Visitor<T,R> - Interface in com.bluegosling.possible
-
A visitor of possible values.
- possibleFromFuture(Future<? extends T>) - Static method in class com.bluegosling.concurrent.extras.FuturePossibles
-
Returns a view of a future as a possible value.
- postOrderVisit() - Method in class com.bluegosling.reflect.ClassHierarchyScanner.Builder
-
Indicates that a post-order traversal is performed.
- predicate() - Method in class com.bluegosling.collections.FilteringIterable
-
Gets the predicate that is responsible for filtering elements.
- predicate() - Method in class com.bluegosling.collections.FilteringIterator
-
Gets the predicate that is responsible for filtering elements.
- predicate() - Method in class com.bluegosling.collections.FilteringListIterator
-
Gets the predicate that is responsible for filtering elements.
- predicate() - Method in class com.bluegosling.collections.FilteringMap
-
- Predicates - Class in com.bluegosling.function
-
Numerous utility methods related to using
Predicate
s.
- prefixMap(Boolean) - Method in class com.bluegosling.collections.tries.ArrayMappedBitwiseTrie
-
- prefixMap(Iterable<Boolean>) - Method in class com.bluegosling.collections.tries.ArrayMappedBitwiseTrie
-
- prefixMap(Iterable<Boolean>, int) - Method in class com.bluegosling.collections.tries.ArrayMappedBitwiseTrie
-
- prefixMap(Boolean) - Method in class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- prefixMap(Iterable<Boolean>) - Method in class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- prefixMap(Iterable<Boolean>, int) - Method in class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- prefixMap(BitSequence) - Method in class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- prefixMap(BitSequence, int) - Method in class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- prefixMap(C) - Method in interface com.bluegosling.collections.tries.CompositeTrie
-
Generates a view of all mappings whose keys have the specified prefix.
- prefixMap(Iterable<C>) - Method in interface com.bluegosling.collections.tries.CompositeTrie
-
Generates a view of all mappings whose keys have the specified prefix.
- prefixMap(Iterable<C>, int) - Method in interface com.bluegosling.collections.tries.CompositeTrie
-
Generates a view of all mappings whose keys have the specified prefix.
- prefixMap(C) - Method in class com.bluegosling.collections.tries.DescendingCompositeTrie
-
- prefixMap(Iterable<C>) - Method in class com.bluegosling.collections.tries.DescendingCompositeTrie
-
- prefixMap(Iterable<C>, int) - Method in class com.bluegosling.collections.tries.DescendingCompositeTrie
-
- prefixMap(K) - Method in class com.bluegosling.collections.tries.DescendingSequenceTrie
-
- prefixMap(Iterable<K>) - Method in class com.bluegosling.collections.tries.DescendingSequenceTrie
-
- prefixMap(Iterable<K>, int) - Method in class com.bluegosling.collections.tries.DescendingSequenceTrie
-
- prefixMap(C) - Method in interface com.bluegosling.collections.tries.NavigableCompositeTrie
-
- prefixMap(Iterable<C>) - Method in interface com.bluegosling.collections.tries.NavigableCompositeTrie
-
- prefixMap(Iterable<C>, int) - Method in interface com.bluegosling.collections.tries.NavigableCompositeTrie
-
- prefixMap(K) - Method in interface com.bluegosling.collections.tries.NavigableSequenceTrie
-
- prefixMap(Iterable<K>) - Method in interface com.bluegosling.collections.tries.NavigableSequenceTrie
-
- prefixMap(Iterable<K>, int) - Method in interface com.bluegosling.collections.tries.NavigableSequenceTrie
-
- prefixMap(K) - Method in interface com.bluegosling.collections.tries.SequenceTrie
-
Generates a view of all mappings whose keys start with the specified value.
- prefixMap(Iterable<K>) - Method in interface com.bluegosling.collections.tries.SequenceTrie
-
Generates a view of all mappings whose keys have the specified prefix.
- prefixMap(Iterable<K>, int) - Method in interface com.bluegosling.collections.tries.SequenceTrie
-
Generates a view of all mappings whose keys have the specified prefix.
- prefixMap(Boolean) - Method in class com.bluegosling.collections.tries.SimpleBitwiseTrie
-
- prefixMap(Iterable<Boolean>) - Method in class com.bluegosling.collections.tries.SimpleBitwiseTrie
-
- prefixMap(Iterable<Boolean>, int) - Method in class com.bluegosling.collections.tries.SimpleBitwiseTrie
-
- prefixMapByKey(K) - Method in class com.bluegosling.collections.tries.ArrayMappedBitwiseTrie
-
- prefixMapByKey(K, int) - Method in class com.bluegosling.collections.tries.ArrayMappedBitwiseTrie
-
- prefixMapByKey(K) - Method in class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- prefixMapByKey(K, int) - Method in class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- prefixMapByKey(K) - Method in interface com.bluegosling.collections.tries.CompositeTrie
-
Generates a view of all mappings whose keys have the specified prefix.
- prefixMapByKey(K, int) - Method in interface com.bluegosling.collections.tries.CompositeTrie
-
Generates a view of all mappings whose keys have the specified prefix.
- prefixMapByKey(K) - Method in class com.bluegosling.collections.tries.DescendingCompositeTrie
-
- prefixMapByKey(K, int) - Method in class com.bluegosling.collections.tries.DescendingCompositeTrie
-
- prefixMapByKey(K) - Method in interface com.bluegosling.collections.tries.NavigableCompositeTrie
-
- prefixMapByKey(K, int) - Method in interface com.bluegosling.collections.tries.NavigableCompositeTrie
-
- prefixMapByKey(K) - Method in class com.bluegosling.collections.tries.SimpleBitwiseTrie
-
- prefixMapByKey(K, int) - Method in class com.bluegosling.collections.tries.SimpleBitwiseTrie
-
- preOrderVisit() - Method in class com.bluegosling.reflect.ClassHierarchyScanner.Builder
-
Indicates that a pre-order traversal is performed.
- present(T) - Method in interface com.bluegosling.possible.Possible.Visitor
-
Visits a possible value where a value is present.
- presentOnly(Collection<? extends Possible<? extends T>>) - Static method in interface com.bluegosling.possible.Possible
-
Returns a list of the present values from the specified collection of possible values.
- prestartAllCoreThreads() - Method in class com.bluegosling.concurrent.executors.ActorThreadPool
-
Starts all core threads in an idle state.
- prestartCoreThread() - Method in class com.bluegosling.concurrent.executors.ActorThreadPool
-
Starts an idle core thread.
- previous() - Method in class com.bluegosling.collections.FilteringListIterator
-
- previous() - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.BaseListIteratorImpl
-
- previous() - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.SubMapByIndicesIterator
-
- previous() - Method in interface com.bluegosling.collections.primitive.PrimitiveListIterator.OfBoolean
-
- previous() - Method in interface com.bluegosling.collections.primitive.PrimitiveListIterator.OfByte
-
- previous() - Method in interface com.bluegosling.collections.primitive.PrimitiveListIterator.OfChar
-
- previous() - Method in interface com.bluegosling.collections.primitive.PrimitiveListIterator.OfDouble
-
- previous() - Method in interface com.bluegosling.collections.primitive.PrimitiveListIterator.OfFloat
-
- previous() - Method in interface com.bluegosling.collections.primitive.PrimitiveListIterator.OfInt
-
- previous() - Method in interface com.bluegosling.collections.primitive.PrimitiveListIterator.OfLong
-
- previous() - Method in interface com.bluegosling.collections.primitive.PrimitiveListIterator.OfShort
-
- previous() - Method in class com.bluegosling.collections.TransformingListIterator
-
- previousBoolean() - Method in interface com.bluegosling.collections.primitive.PrimitiveListIterator.OfBoolean
-
- previousByte() - Method in interface com.bluegosling.collections.primitive.PrimitiveListIterator.OfByte
-
- previousChar() - Method in interface com.bluegosling.collections.primitive.PrimitiveListIterator.OfChar
-
- previousDouble() - Method in interface com.bluegosling.collections.primitive.PrimitiveListIterator.OfDouble
-
- previousFloat() - Method in interface com.bluegosling.collections.primitive.PrimitiveListIterator.OfFloat
-
- previousIndex() - Method in class com.bluegosling.collections.FilteringListIterator
-
- previousIndex() - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.BaseListIteratorImpl
-
- previousIndex() - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.SubMapByIndicesIterator
-
- previousIndex() - Method in class com.bluegosling.collections.TransformingListIterator
-
- previousInt() - Method in interface com.bluegosling.collections.primitive.PrimitiveListIterator.OfInt
-
- previousLong() - Method in interface com.bluegosling.collections.primitive.PrimitiveListIterator.OfLong
-
- previousShort() - Method in interface com.bluegosling.collections.primitive.PrimitiveListIterator.OfShort
-
- primeBigDecimalGenerator() - Static method in class com.bluegosling.util.PrimeIterator
-
Constructs an iterator of
BigDecimal
s that are prime.
- primeBigIntegerGenerator() - Static method in class com.bluegosling.util.PrimeIterator
-
Constructs an iterator of
BigInteger
s that are prime.
- primeByteIterator() - Static method in class com.bluegosling.util.PrimeIterator
-
Constructs an iterator of byte
s that are prime.
- primeDoubleIterator() - Static method in class com.bluegosling.util.PrimeIterator
-
Constructs an iterator of double
s that are prime.
- primeFloatIterator() - Static method in class com.bluegosling.util.PrimeIterator
-
Constructs an iterator of float
s that are prime.
- primeIntegerIterator() - Static method in class com.bluegosling.util.PrimeIterator
-
Constructs an iterator of int
s that are prime.
- PrimeIterator<T extends Number & Comparable<T>> - Class in com.bluegosling.util
-
Iterates through prime numbers.
- primeLongIterator() - Static method in class com.bluegosling.util.PrimeIterator
-
Constructs an iterator of long
s that are prime.
- primeShortIterator() - Static method in class com.bluegosling.util.PrimeIterator
-
Constructs an iterator of short
s that are prime.
- PrimitiveList<T,T_CONS,T_ITER extends PrimitiveIterator<T,T_CONS>,T_LISTITER extends PrimitiveListIterator<T,T_CONS>,T_LIST extends PrimitiveList<T,T_CONS,T_ITER,T_LISTITER,T_LIST>> - Interface in com.bluegosling.collections.primitive
-
Primitive specializations of the
List
interface.
- PrimitiveList.OfBoolean - Interface in com.bluegosling.collections.primitive
-
- PrimitiveList.OfByte - Interface in com.bluegosling.collections.primitive
-
- PrimitiveList.OfChar - Interface in com.bluegosling.collections.primitive
-
- PrimitiveList.OfDouble - Interface in com.bluegosling.collections.primitive
-
- PrimitiveList.OfFloat - Interface in com.bluegosling.collections.primitive
-
- PrimitiveList.OfInt - Interface in com.bluegosling.collections.primitive
-
- PrimitiveList.OfLong - Interface in com.bluegosling.collections.primitive
-
- PrimitiveList.OfShort - Interface in com.bluegosling.collections.primitive
-
- PrimitiveListIterator<T,T_CONS> - Interface in com.bluegosling.collections.primitive
-
- PrimitiveListIterator.OfBoolean - Interface in com.bluegosling.collections.primitive
-
- PrimitiveListIterator.OfByte - Interface in com.bluegosling.collections.primitive
-
- PrimitiveListIterator.OfChar - Interface in com.bluegosling.collections.primitive
-
- PrimitiveListIterator.OfDouble - Interface in com.bluegosling.collections.primitive
-
- PrimitiveListIterator.OfFloat - Interface in com.bluegosling.collections.primitive
-
- PrimitiveListIterator.OfInt - Interface in com.bluegosling.collections.primitive
-
- PrimitiveListIterator.OfLong - Interface in com.bluegosling.collections.primitive
-
- PrimitiveListIterator.OfShort - Interface in com.bluegosling.collections.primitive
-
- println() - Method in class com.bluegosling.util.IndentingPrintWriter
-
- priorities() - Method in interface com.bluegosling.collections.queues.PriorityQueue
-
- PriorityQueue<E,P> - Interface in com.bluegosling.collections.queues
-
A priority queue abstract data structure.
- PriorityQueue.Entry<E,P> - Interface in com.bluegosling.collections.queues
-
An entry in a priority queue.
- PriorityQueues - Class in com.bluegosling.collections.queues
-
- PriorityQueues.AutoEntry<P,E extends PriorityQueues.AutoEntry<P,E>> - Class in com.bluegosling.collections.queues
-
A type of value that automatically associates itself with a queue entry when added to a
PriorityQueue
.
- PriorityQueues.MeldableQueue<E> - Interface in com.bluegosling.collections.queues
-
A simple meldable ordered queue.
- process(Set<? extends TypeElement>, RoundEnvironment) - Method in class com.bluegosling.apt.AbstractProcessor
-
- process(Set<ArClass>) - Method in class com.bluegosling.apt.reflect.ArProcessor
-
Processes annotations.
- processingClasses(Iterable<Class<?>>) - Method in interface com.bluegosling.apt.testing.CompilationContext.TaskBuilder
-
Adds classes to be processed by the annotation processing round of compilation.
- processingClasses(Class<?>...) - Method in interface com.bluegosling.apt.testing.CompilationContext.TaskBuilder
-
Adds classes to be processed by the annotation processing round of compilation.
- processingClasses(Iterable<Class<?>>) - Method in interface com.bluegosling.apt.testing.CompilationContext.TaskBuilderWithProcessor
-
- processingClasses(Class<?>...) - Method in interface com.bluegosling.apt.testing.CompilationContext.TaskBuilderWithProcessor
-
- processingEnvironment() - Method in class com.bluegosling.apt.testing.TestEnvironment
-
Gets the current processing environment.
- ProcessingEnvironments - Class in com.bluegosling.apt
-
Static helper methods related to the current processing environment.
- processingFiles(Iterable<JavaFileObject>) - Method in interface com.bluegosling.apt.testing.CompilationContext.TaskBuilder
-
Adds files to the list of things to process during compilation.
- processingFiles(JavaFileObject...) - Method in interface com.bluegosling.apt.testing.CompilationContext.TaskBuilder
-
Adds files to the list of things to process during compilation.
- processingFiles(Iterable<JavaFileObject>) - Method in interface com.bluegosling.apt.testing.CompilationContext.TaskBuilderWithProcessor
-
- processingFiles(JavaFileObject...) - Method in interface com.bluegosling.apt.testing.CompilationContext.TaskBuilderWithProcessor
-
- ProcessingTask<T> - Interface in com.bluegosling.apt.testing
-
- ProcessorUnderTest - Annotation Type in com.bluegosling.apt.testing
-
Indicates the type of processor to test.
- processorUnderTest() - Method in class com.bluegosling.apt.testing.TestEnvironment
-
Gets the current processor under test or null
if there isn't one.
- promoteToExclusive() - Method in class com.bluegosling.concurrent.locks.HierarchicalLock.SharedLock
-
Promotes this shared lock into an exclusive lock.
- promoteToExclusiveInterruptibly() - Method in class com.bluegosling.concurrent.locks.HierarchicalLock.SharedLock
-
Promotes this shared lock into an exclusive lock, waiting interruptibly until the exclusive
lock becomes available.
- promoteToParent() - Method in interface com.bluegosling.concurrent.locks.HierarchicalLock.AcquiredLock
-
Promotes this lock to a lock of the same type (exclusive or shared) on its parent.
- promoteToParent() - Method in class com.bluegosling.concurrent.locks.HierarchicalLock.ExclusiveLock
-
Promotes this lock to an exclusive lock on its parent.
- promoteToParent() - Method in class com.bluegosling.concurrent.locks.HierarchicalLock.SharedLock
-
Promotes this lock to a shared lock on its parent.
- promoteToParentInterruptibly() - Method in class com.bluegosling.concurrent.locks.HierarchicalLock.ExclusiveLock
-
Promotes this lock to an exclusive lock on its parent, waiting interruptibly until it
becomes available.
- promoteToWrite() - Method in interface com.bluegosling.concurrent.locks.Locking.StampedLocking
-
Promotes a held read lock into a write lock.
- propagateOnAnyException() - Method in class com.bluegosling.reflect.blaster.Blaster
-
- propagateOnNullTarget() - Method in class com.bluegosling.reflect.blaster.Blaster
-
- pullFirst(int, CircularBuffer<? extends E>) - Method in class com.bluegosling.collections.CircularBuffer
-
Pulls elements from the front of the specified buffer and adds them to the end of this buffer.
- pullLast(int, CircularBuffer<? extends E>) - Method in class com.bluegosling.collections.CircularBuffer
-
Pulls elements from the end of the specified buffer and adds them to the front of this buffer.
- push(E) - Method in class com.bluegosling.collections.AbstractDeque
-
- push(T) - Method in class com.bluegosling.collections.concurrent.SimpleTreiberStack
-
- push(T) - Method in class com.bluegosling.collections.concurrent.TreiberStack
-
Pushes a new value onto the stack.
- push(E) - Method in class com.bluegosling.collections.lists.ArrayBackedLinkedList
-
- push(E) - Method in class com.bluegosling.collections.lists.UnrolledLinkedList
-
- push(Iterator<? extends E>, E) - Static method in class com.bluegosling.collections.MoreIterators
-
Pushes the given element onto the head of the given iterator.
- push(Iterator<? extends E>, E, Runnable) - Static method in class com.bluegosling.collections.MoreIterators
-
Pushes the given element onto the head of the given iterator.
- push(Iterator<? extends E>, E...) - Static method in class com.bluegosling.collections.MoreIterators
-
Pushes the given elements onto the head of the given iterator.
- push(Iterator<? extends E>, Iterable<E>) - Static method in class com.bluegosling.collections.MoreIterators
-
Pushes the given elements onto the head of the given iterator.
- push(T) - Method in class com.bluegosling.collections.NoCopyGrowableArray
-
- push(E) - Method in class com.bluegosling.collections.queues.RandomAccessArrayDeque
-
- push(T) - Method in interface com.bluegosling.collections.Stack
-
Pushes a value onto the stack.
- pushFirst(int, CircularBuffer<? super E>) - Method in class com.bluegosling.collections.CircularBuffer
-
Pushes to the front of the specified buffer elements that are removed from the end of this
buffer.
- pushLast(int, CircularBuffer<? super E>) - Method in class com.bluegosling.collections.CircularBuffer
-
Pushes to the end of the specified buffer elements that are removed from the front of this
buffer.
- put(K, V) - Method in class com.bluegosling.collections.AbstractNavigableMap.SubMap
- put(E) - Method in class com.bluegosling.collections.concurrent.AbstractLockFreeBlockingDeque
-
- put(E) - Method in class com.bluegosling.collections.concurrent.AbstractLockFreeBlockingQueue
-
- put(K, V) - Method in class com.bluegosling.collections.concurrent.DoubleInstanceLockedTreeMap
-
- put(K, V) - Method in class com.bluegosling.collections.concurrent.PersistentMapBackedConcurrentMap
-
- put(K, V) - Method in class com.bluegosling.collections.DescendingMap
-
- put(K, V) - Method in class com.bluegosling.collections.FilteringMap
-
- put(K, V) - Method in class com.bluegosling.collections.immutable.AbstractImmutableMap
-
Deprecated.
- put(K, V) - Method in interface com.bluegosling.collections.immutable.PersistentMap
-
Deprecated.
- put(K, V) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.RandomAccessSubMap
- put(K, V) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.SubMapByIndices
-
- put(K, V) - Method in class com.bluegosling.collections.maps.HamtMap
-
- put(K, V) - Method in class com.bluegosling.collections.maps.LinearHashingMap
-
- put(K, V) - Method in interface com.bluegosling.collections.maps.MapBuilder
-
Adds an item to the map being built.
- put(K, V) - Method in class com.bluegosling.collections.maps.SortedArrayMap
-
- put(K, V) - Method in class com.bluegosling.collections.maps.WeightBalancedTreeMap
-
- put(E) - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- put(R, C, V) - Method in interface com.bluegosling.collections.tables.Table2D
-
- put(P, R, C, V) - Method in interface com.bluegosling.collections.tables.Table3D
-
- put(S, P, R, C, V) - Method in interface com.bluegosling.collections.tables.Table4D
-
- put(L, S, P, R, C, V) - Method in interface com.bluegosling.collections.tables.Table5D
-
- put(KO, VO) - Method in class com.bluegosling.collections.TransformingMap.Bidi
-
- put(KO, VO) - Method in class com.bluegosling.collections.TransformingMap
-
- put(K, V) - Method in class com.bluegosling.collections.tries.ArrayMappedBitwiseTrie
-
- put(K, V) - Method in class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- put(Iterable<K>, V) - Method in class com.bluegosling.collections.tries.DescendingSequenceTrie
-
- put(long, V) - Method in class com.bluegosling.collections.tries.RadixTrieMap
-
Puts a value at the specified key.
- put(Long, V) - Method in class com.bluegosling.collections.tries.RadixTrieMap
-
- put(Iterable<K>, V) - Method in interface com.bluegosling.collections.tries.SequenceTrie
-
A convenience method for storing mappings and using non-list collections as keys.
- put(K, V) - Method in class com.bluegosling.collections.tries.SimpleBitwiseTrie
-
- put(E) - Method in class com.bluegosling.concurrent.RateLimitedBlockingQueue
-
- putAll(Map<? extends K, ? extends V>) - Method in class com.bluegosling.collections.AbstractNavigableMap
- putAll(Map<? extends K, ? extends V>) - Method in class com.bluegosling.collections.AbstractNavigableMap.SubMap
- putAll(Map<? extends K, ? extends V>) - Method in class com.bluegosling.collections.concurrent.DoubleInstanceLockedTreeMap
-
- putAll(Map<? extends K, ? extends V>) - Method in class com.bluegosling.collections.DescendingMap
-
- putAll(Map<? extends K, ? extends V>) - Method in class com.bluegosling.collections.FilteringMap
-
- putAll(Map<? extends K, ? extends V>) - Method in class com.bluegosling.collections.immutable.AbstractImmutableMap
-
Deprecated.
- putAll(Map<? extends K, ? extends V>) - Method in interface com.bluegosling.collections.immutable.PersistentMap
-
Deprecated.
- putAll(Map<? extends K, ? extends V>) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.RandomAccessSubMap
- putAll(Map<? extends K, ? extends V>) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.SubMapByIndices
-
- putAll(Map<? extends K, ? extends V>) - Method in interface com.bluegosling.collections.maps.MapBuilder
-
Adds all items from another map into the map being built.
- putAll(Map<? extends K, ? extends V>) - Method in class com.bluegosling.collections.maps.SortedArrayMap
-
- putAll(Map<? extends K, ? extends V>) - Method in class com.bluegosling.collections.maps.WeightBalancedTreeMap
-
- putAll(Table2D<? extends R, ? extends C, ? extends V>) - Method in interface com.bluegosling.collections.tables.Table2D
-
- putAll(Table3D<? extends P, ? extends R, ? extends C, ? extends V>) - Method in interface com.bluegosling.collections.tables.Table3D
-
- putAll(Table4D<? extends S, ? extends P, ? extends R, ? extends C, ? extends V>) - Method in interface com.bluegosling.collections.tables.Table4D
-
- putAll(Table5D<? extends L, ? extends S, ? extends P, ? extends R, ? extends C, ? extends V>) - Method in interface com.bluegosling.collections.tables.Table5D
-
- putAll(Map<? extends KO, ? extends VO>) - Method in class com.bluegosling.collections.TransformingMap.Bidi
-
- putAll(Map<? extends KO, ? extends VO>) - Method in class com.bluegosling.collections.TransformingMap
-
- putAll(Map<? extends K, ? extends V>) - Method in class com.bluegosling.collections.tries.ArrayMappedBitwiseTrie
-
- putAll(Map<? extends K, ? extends V>) - Method in class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- putBack(long) - Method in class com.bluegosling.concurrent.RateLimiter
-
Returns the given number of permits.
- putFirst(E) - Method in class com.bluegosling.collections.concurrent.AbstractLockFreeBlockingDeque
-
- putFirst(E) - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- putIfAbsent(K, V) - Method in class com.bluegosling.collections.concurrent.DoubleInstanceLockedTreeMap
-
- putIfAbsent(K, V) - Method in class com.bluegosling.collections.concurrent.PersistentMapBackedConcurrentMap
-
- putIfAbsent(K, V) - Method in class com.bluegosling.collections.immutable.AbstractImmutableMap
-
Deprecated.
- putIfAbsent(K, V) - Method in interface com.bluegosling.collections.immutable.PersistentMap
-
Deprecated.
- putIfAbsent(K, V) - Method in class com.bluegosling.collections.maps.LinearHashingMap
-
- putLast(E) - Method in class com.bluegosling.collections.concurrent.AbstractLockFreeBlockingDeque
-
- putLast(E) - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- RadixTrieMap<V> - Class in com.bluegosling.collections.tries
-
A structure that can be used to perform radix sort and can be used to efficiently represent very
sparse arrays.
- RadixTrieMap() - Constructor for class com.bluegosling.collections.tries.RadixTrieMap
-
- RandomAccess(L, Function<? super I, ? extends O>, Function<? super O, ? extends I>) - Constructor for class com.bluegosling.collections.TransformingList.Bidi.RandomAccess
-
- RandomAccess(L, Function<? super I, ? extends O>) - Constructor for class com.bluegosling.collections.TransformingList.RandomAccess
-
Constructs a new random access transforming list.
- RandomAccess(L, Function<? super I, ? extends O>) - Constructor for class com.bluegosling.collections.TransformingList.ReadOnly.RandomAccess
-
- RandomAccessArrayBlockingDeque<E> - Class in com.bluegosling.collections.queues
-
- RandomAccessArrayBlockingDeque() - Constructor for class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- RandomAccessArrayBlockingDeque(Collection<? extends E>) - Constructor for class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- RandomAccessArrayBlockingDeque(int, int) - Constructor for class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- RandomAccessArrayDeque<E> - Class in com.bluegosling.collections.queues
-
A double-ended queue that is backed by an array and, in addition to standard
Deque
operations, also exposes random access operations on its contents.
- RandomAccessArrayDeque() - Constructor for class com.bluegosling.collections.queues.RandomAccessArrayDeque
-
- RandomAccessArrayDeque(Collection<? extends E>) - Constructor for class com.bluegosling.collections.queues.RandomAccessArrayDeque
-
- RandomAccessArrayDeque(int, int) - Constructor for class com.bluegosling.collections.queues.RandomAccessArrayDeque
-
- RandomAccessEntrySet() - Constructor for class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.RandomAccessEntrySet
-
- RandomAccessKeySet() - Constructor for class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.RandomAccessKeySet
-
- RandomAccessNavigableMap<K,V> - Interface in com.bluegosling.collections.maps
-
A navigable map that provides random access over its elements.
- RandomAccessNavigableSet<E> - Interface in com.bluegosling.collections.sets
-
A navigable set that also provides random access to its members.
- RandomAccessSet<E> - Interface in com.bluegosling.collections.sets
-
A set that also provides for random access to its members.
- RandomAccessSetList<E> - Class in com.bluegosling.collections.sets
-
- RandomAccessSetList(RandomAccessSet<E>) - Constructor for class com.bluegosling.collections.sets.RandomAccessSetList
-
- RandomAccessSubMap(K, BoundType, K, BoundType) - Constructor for class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.RandomAccessSubMap
-
Constructs a new sub-map view with the given bounds.
- RandomizedQueue<E> - Class in com.bluegosling.collections.queues
-
- RandomizedQueue() - Constructor for class com.bluegosling.collections.queues.RandomizedQueue
-
- RandomizedQueue(int) - Constructor for class com.bluegosling.collections.queues.RandomizedQueue
-
- RandomizedQueue(int, Random) - Constructor for class com.bluegosling.collections.queues.RandomizedQueue
-
- RandomizedQueue(Collection<? extends E>) - Constructor for class com.bluegosling.collections.queues.RandomizedQueue
-
- RandomizedQueue(Collection<? extends E>, Random) - Constructor for class com.bluegosling.collections.queues.RandomizedQueue
-
- rangeCheck(int) - Method in class com.bluegosling.collections.immutable.AbstractLinkedImmutableList
-
- rangeCheck(int) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap
-
Checks that the specified index is greater than or equal to zero and less than this map's
Map.size()
.
- rangeCheckWide(int) - Method in class com.bluegosling.collections.immutable.AbstractLinkedImmutableList
-
Checks that the specified index is greater than or equal to zero and less than or equal to
this list's
AbstractCollection.size()
.
- rangeCheckWide(int) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap
-
Checks that the specified index is greater than or equal to zero and less than or equal to
this map's
Map.size()
.
- RateLimitedBlockingQueue<E> - Class in com.bluegosling.concurrent
-
- RateLimiter - Class in com.bluegosling.concurrent
-
A synchronizer that can be used to limit the rate, or frequency, of an operation.
- RateLimiter(double) - Constructor for class com.bluegosling.concurrent.RateLimiter
-
Creates a new limiter with the given number of permits allowed per second.
- RateLimiter(double, long) - Constructor for class com.bluegosling.concurrent.RateLimiter
-
Creates a new limiter with the given number of permits allowed per second and maximum
capacity.
- RateLimiter(double, long, long) - Constructor for class com.bluegosling.concurrent.RateLimiter
-
Creates a new limiter with the given number of permits allowed per second, maximum capacity,
and initial capacity.
- RateLimiter(double, long, long, double) - Constructor for class com.bluegosling.concurrent.RateLimiter
-
Creates a new "jittered" limiter with the given number of permits allowed per second,
maximum capacity, and initial capacity.
- RateLimiter(double, long, long, double, Clock) - Constructor for class com.bluegosling.concurrent.RateLimiter
-
Creates a new "jittered" limiter that uses the given clock and the given number of permits
allowed per second, maximum capacity, and initial capacity.
- read(Function<? super T, ? extends U>) - Method in class com.bluegosling.concurrent.locks.DoubleInstanceLock
-
Performs a read operation that produces a result value.
- ReadOnly(RandomAccessSet<I>, Function<? super I, ? extends O>) - Constructor for class com.bluegosling.collections.sets.TransformingRandomAccessSet.ReadOnly
-
Constructs a new read-only transforming random access set.
- ReadOnly(Collection<I>, Function<? super I, ? extends O>) - Constructor for class com.bluegosling.collections.TransformingCollection.ReadOnly
-
Constructs a new read-only transforming collection.
- ReadOnly(Iterable<I>, Function<? super I, ? extends O>) - Constructor for class com.bluegosling.collections.TransformingIterable.ReadOnly
-
Constructs a new read-only transforming iterable.
- ReadOnly(Iterator<I>, Function<? super I, ? extends O>) - Constructor for class com.bluegosling.collections.TransformingIterator.ReadOnly
-
Constructs a new read-only transforming iterator.
- ReadOnly(List<I>, Function<? super I, ? extends O>) - Constructor for class com.bluegosling.collections.TransformingList.ReadOnly
-
Constructs a new read-only transforming list.
- ReadOnly(ListIterator<I>, Function<? super I, ? extends O>) - Constructor for class com.bluegosling.collections.TransformingListIterator.ReadOnly
-
Constructs a new read-only transforming list iterator.
- ReadOnly(Map<KI, VI>, Function<? super KI, ? extends KO>, BiFunction<? super KI, ? super VI, ? extends VO>) - Constructor for class com.bluegosling.collections.TransformingMap.ReadOnly
-
Constructs a new unmodifiable map that can transform both map keys and values.
- ReadOnly(Set<I>, Function<? super I, ? extends O>) - Constructor for class com.bluegosling.collections.TransformingSet.ReadOnly
-
Constructs a new read-only transforming set.
- readOnly(CompletableFuture<T>) - Static method in class com.bluegosling.concurrent.futures.CompletableFutures
-
Returns a copy of the given future that completes with the same result or failure as the given
completable future.
- ReadOnlyCompletableFuture<T> - Class in com.bluegosling.concurrent.futures
-
A completable future whose public API is read-only.
- ReadOnlyCompletableFuture() - Constructor for class com.bluegosling.concurrent.futures.ReadOnlyCompletableFuture
-
- readWith(Consumer<? super T>) - Method in class com.bluegosling.concurrent.locks.DoubleInstanceLock
-
Performs a read operation that does not produce a result value.
- recover(Function<Throwable, ? extends T>) - Method in interface com.bluegosling.concurrent.fluent.FluentFuture
-
Recovers a future value by applying the specified function to any exception from this future.
- recover(Function<? super E, ? extends T>) - Method in class com.bluegosling.result.Result
-
Recovers a failed result into a successful one.
- ReentranceException - Exception in com.bluegosling.concurrent
-
An exception indicating that a reentrant lock acquisition was attempted but is not unsupported.
- ReentranceException() - Constructor for exception com.bluegosling.concurrent.ReentranceException
-
- ReentranceException(String) - Constructor for exception com.bluegosling.concurrent.ReentranceException
-
- ReentranceException(Throwable) - Constructor for exception com.bluegosling.concurrent.ReentranceException
-
- ReentranceException(String, Throwable) - Constructor for exception com.bluegosling.concurrent.ReentranceException
-
- Reentrant - Annotation Type in com.bluegosling.apt.testing
-
Annotates a test method as being re-entrant.
- Reference<T> - Class in com.bluegosling.possible
-
A
possible value that, even if present, can be
null
.
- relaxedExceptions(Set<Class<? extends Throwable>>) - Static method in class com.bluegosling.testing.ObjectVerifiers
-
Returns an object that verifies that the test exception is compatible with the
reference exception.
- relaxedExceptions(Class<? extends Throwable>...) - Static method in class com.bluegosling.testing.ObjectVerifiers
-
Returns an object that verifies that the test exception is compatible with the
reference exception.
- relaxedExceptionVerifier() - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfiguration
-
Specifies that exceptions should be verified using relaxed checking.
- relaxedExceptionVerifier() - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfigurator
-
Specifies that exceptions should be verified using relaxed checking.
- release(R) - Method in class com.bluegosling.concurrent.AbstractQueuedReferenceSynchronizer
-
Releases in exclusive mode.
- releaseShared(R) - Method in class com.bluegosling.concurrent.AbstractQueuedReferenceSynchronizer
-
Releases in shared mode.
- remaining() - Method in interface com.bluegosling.collections.bits.BitStream
-
Returns the remaining number of bits in the stream.
- remainingCapacity() - Method in class com.bluegosling.collections.CircularBuffer
-
Returns the remaining capacity of the buffer.
- remainingCapacity() - Method in class com.bluegosling.collections.concurrent.ArrayBlockingDeque
-
- remainingCapacity() - Method in class com.bluegosling.collections.concurrent.LockFreeArrayBlockingQueue
-
- remainingCapacity() - Method in class com.bluegosling.collections.concurrent.LockFreeLinkedBlockingDeque
-
- remainingCapacity() - Method in class com.bluegosling.collections.concurrent.LockFreeLinkedBlockingQueue
-
- remainingCapacity() - Method in class com.bluegosling.collections.concurrent.LockFreeSkipListBlockingQueue
-
- remainingCapacity() - Method in class com.bluegosling.collections.concurrent.SharedCapacityDequeFactory
-
Returns the remaining capacity for this factory.
- remainingCapacity() - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- remainingCapacity() - Method in class com.bluegosling.concurrent.RateLimitedBlockingQueue
-
- remove() - Method in class com.bluegosling.collections.AbstractDeque
-
- remove(Object) - Method in class com.bluegosling.collections.AbstractDeque
-
- remove() - Method in class com.bluegosling.collections.AbstractNavigableMap.BaseIteratorImpl
-
- remove(Object) - Method in class com.bluegosling.collections.AbstractNavigableMap.EntrySet
-
- remove(Object) - Method in class com.bluegosling.collections.AbstractNavigableMap.KeySet
-
- remove(Object) - Method in class com.bluegosling.collections.AbstractNavigableMap
- remove(Object) - Method in class com.bluegosling.collections.concurrent.ArrayBlockingDeque
-
- remove(int, E) - Method in interface com.bluegosling.collections.concurrent.ConcurrentList
-
Removes the given value at the given index.
- remove(Object) - Method in class com.bluegosling.collections.concurrent.ConcurrentSortedArraySet
- remove(Object) - Method in class com.bluegosling.collections.concurrent.DoubleInstanceLockedTreeMap
-
- remove(Object, Object) - Method in class com.bluegosling.collections.concurrent.DoubleInstanceLockedTreeMap
-
- remove(Object) - Method in class com.bluegosling.collections.concurrent.LockFreeArrayBlockingQueue
-
- remove(Object) - Method in class com.bluegosling.collections.concurrent.LockFreeLinkedBlockingQueue
-
- remove(Object) - Method in class com.bluegosling.collections.concurrent.PersistentMapBackedConcurrentMap
-
- remove(Object, Object) - Method in class com.bluegosling.collections.concurrent.PersistentMapBackedConcurrentMap
-
- remove(Object) - Method in class com.bluegosling.collections.concurrent.SimpleTreiberStack
-
- remove(Object) - Method in class com.bluegosling.collections.concurrent.TreiberStack
-
- remove(Object) - Method in class com.bluegosling.collections.DescendingMap
-
- remove(Object) - Method in class com.bluegosling.collections.DescendingSet
-
- remove(Object) - Method in class com.bluegosling.collections.FilteringCollection
-
- remove() - Method in class com.bluegosling.collections.FilteringIterator
-
Removes the last item retrieved from the underlying iterable.
- remove(int) - Method in class com.bluegosling.collections.FilteringList
-
- remove() - Method in class com.bluegosling.collections.FilteringListIterator
-
Removes the last item retrieved from the underlying iterable.
- remove(Object) - Method in class com.bluegosling.collections.FilteringMap
-
- remove(Object) - Method in class com.bluegosling.collections.immutable.AbstractImmutableCollection
-
Deprecated.
- remove(Object) - Method in class com.bluegosling.collections.immutable.AbstractImmutableList
-
Deprecated.
- remove(int) - Method in class com.bluegosling.collections.immutable.AbstractImmutableList
-
Deprecated.
- remove(Object) - Method in class com.bluegosling.collections.immutable.AbstractImmutableMap
-
Deprecated.
- remove(Object, Object) - Method in class com.bluegosling.collections.immutable.AbstractImmutableMap
-
Deprecated.
- remove(Object) - Method in class com.bluegosling.collections.immutable.AbstractImmutableSet
-
Deprecated.
- remove(Object) - Method in interface com.bluegosling.collections.immutable.PersistentCollection
-
Deprecated.
- remove(int) - Method in interface com.bluegosling.collections.immutable.PersistentList
-
Deprecated.
- remove(Object) - Method in interface com.bluegosling.collections.immutable.PersistentList
-
Deprecated.
- remove(Object) - Method in interface com.bluegosling.collections.immutable.PersistentMap
-
Deprecated.
- remove(Object, Object) - Method in interface com.bluegosling.collections.immutable.PersistentMap
-
Deprecated.
- remove(Object) - Method in interface com.bluegosling.collections.immutable.PersistentSet
-
Deprecated.
- remove() - Method in class com.bluegosling.collections.lists.ArrayBackedLinkedList
- remove(int) - Method in class com.bluegosling.collections.lists.ArrayBackedLinkedList
- remove(Object) - Method in class com.bluegosling.collections.lists.AssociativeArrayList
-
- remove(int) - Method in class com.bluegosling.collections.lists.AssociativeArrayList
-
- remove(int) - Method in class com.bluegosling.collections.lists.TreeList
-
- remove(int) - Method in class com.bluegosling.collections.lists.UnrolledLinkedList
-
- remove() - Method in class com.bluegosling.collections.lists.UnrolledLinkedList
-
- remove() - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.BaseListIteratorImpl
-
- remove(int) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.RandomAccessEntrySet
-
- remove(int) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.RandomAccessKeySet
-
- remove(Object) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.SubMapByIndices
-
- remove() - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.SubMapByIndicesIterator
-
- remove(int) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.ValueList
-
- remove(Object) - Method in class com.bluegosling.collections.maps.HamtMap
-
- remove(Object) - Method in class com.bluegosling.collections.maps.LinearHashingMap
-
- remove(Object, Object) - Method in class com.bluegosling.collections.maps.LinearHashingMap
-
- remove(Object) - Method in class com.bluegosling.collections.maps.WeightBalancedTreeMap
-
- remove(int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfBoolean
-
- remove(int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfByte
-
- remove(int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfChar
-
- remove(int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfDouble
-
- remove(int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfFloat
-
- remove(int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfInt
-
- remove(int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfLong
-
- remove(int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfShort
-
- remove() - Method in class com.bluegosling.collections.queues.FibonacciHeapOrderedQueue
-
- remove() - Method in interface com.bluegosling.collections.queues.OrderedDeque
-
- remove() - Method in interface com.bluegosling.collections.queues.PriorityQueue.Entry
-
Removes this entry from the queue.
- remove() - Method in interface com.bluegosling.collections.queues.PriorityQueue
-
Removes the minimum entry from the queue.
- remove() - Method in class com.bluegosling.collections.queues.PriorityQueues.AutoEntry
-
Removes the object from the queue that contains it.
- remove(int) - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- remove(Object) - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- remove(int) - Method in class com.bluegosling.collections.queues.RandomAccessArrayDeque
-
- remove() - Method in class com.bluegosling.collections.queues.RandomAccessArrayDeque
-
- remove() - Method in class com.bluegosling.collections.queues.RandomizedQueue
-
- remove() - Method in class com.bluegosling.collections.queues.SkewHeapOrderedQueue
-
- remove(int) - Method in class com.bluegosling.collections.sets.DescendingRandomAccessSet
-
- remove(int) - Method in interface com.bluegosling.collections.sets.RandomAccessSet
-
Removes the item at the specified index.
- remove(Object) - Method in class com.bluegosling.collections.sets.RandomAccessSetList
-
- remove(int) - Method in class com.bluegosling.collections.sets.RandomAccessSetList
-
- remove(Object) - Method in class com.bluegosling.collections.sets.SortedArraySet
- remove(int) - Method in class com.bluegosling.collections.sets.TransformingRandomAccessSet.Bidi
-
- remove(int) - Method in class com.bluegosling.collections.sets.TransformingRandomAccessSet.ReadOnly
-
- remove(int) - Method in class com.bluegosling.collections.sets.TransformingRandomAccessSet
-
- remove(Object, Object) - Method in interface com.bluegosling.collections.tables.Table2D
-
- remove(Object, Object, Object) - Method in interface com.bluegosling.collections.tables.Table3D
-
- remove(Object, Object, Object, Object) - Method in interface com.bluegosling.collections.tables.Table4D
-
- remove(Object, Object, Object, Object, Object) - Method in interface com.bluegosling.collections.tables.Table5D
-
- remove(Object) - Method in interface com.bluegosling.collections.tables.TableMapView
-
Removes the value mapped to the given key and returns it.
- remove(Object) - Method in class com.bluegosling.collections.TransformingCollection.Bidi
-
- remove(Object) - Method in class com.bluegosling.collections.TransformingCollection.ReadOnly
-
- remove(Object) - Method in class com.bluegosling.collections.TransformingCollection
-
- remove() - Method in class com.bluegosling.collections.TransformingIterator.ReadOnly
-
- remove() - Method in class com.bluegosling.collections.TransformingIterator
-
- remove(Object) - Method in class com.bluegosling.collections.TransformingList.Bidi
-
- remove(int) - Method in class com.bluegosling.collections.TransformingList.ReadOnly
-
- remove(int) - Method in class com.bluegosling.collections.TransformingList
-
- remove() - Method in class com.bluegosling.collections.TransformingListIterator.ReadOnly
-
- remove(Object) - Method in class com.bluegosling.collections.TransformingMap.Bidi
-
- remove(Object) - Method in class com.bluegosling.collections.TransformingMap.ReadOnly
-
- remove(Object) - Method in class com.bluegosling.collections.TransformingMap
-
- remove(Object) - Method in class com.bluegosling.collections.TransformingMap.ValuesOnly
-
- remove(Object) - Method in class com.bluegosling.collections.tries.ArrayMappedBitwiseTrie
-
- remove(Object) - Method in class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- remove(long) - Method in class com.bluegosling.collections.tries.RadixTrieMap
-
Removes a value from the specified key.
- remove(Object) - Method in class com.bluegosling.collections.tries.RadixTrieMap
-
- remove(Object) - Method in class com.bluegosling.collections.tries.SimpleBitwiseTrie
-
- remove(int) - Method in class com.bluegosling.tuples.NTuple
-
Removes the value at the given index.
- remove() - Method in class com.bluegosling.util.PrimeIterator
-
Optional operation not supported.
- removeAll(Collection<?>, Iterator<?>) - Static method in class com.bluegosling.collections.CollectionUtils
-
Removes from a collection all items retrieved from a specified iterator.
- removeAll(Set<?>, Iterator<?>) - Static method in class com.bluegosling.collections.CollectionUtils
-
Removes from a set all items retrieved from a specified iterator.
- removeAll(Collection<?>) - Method in class com.bluegosling.collections.concurrent.ArrayBlockingDeque
-
- removeAll(Collection<?>) - Method in class com.bluegosling.collections.concurrent.ConcurrentSortedArraySet
- removeAll() - Method in interface com.bluegosling.collections.concurrent.ConcurrentStack
-
Atomically drains the stack and returns its contents in a new instance.
- removeAll(Collection<?>) - Method in class com.bluegosling.collections.concurrent.LockFreeArrayBlockingQueue
-
- removeAll() - Method in class com.bluegosling.collections.concurrent.SimpleTreiberStack
-
- removeAll(Collection<?>) - Method in class com.bluegosling.collections.concurrent.SimpleTreiberStack
-
- removeAll() - Method in class com.bluegosling.collections.concurrent.TreiberStack
-
Clears all elements from the stack and returns them in a new stack.
- removeAll(Collection<?>) - Method in class com.bluegosling.collections.DescendingSet
-
- removeAll(Collection<?>) - Method in class com.bluegosling.collections.FilteringCollection
-
- removeAll(Collection<?>) - Method in class com.bluegosling.collections.immutable.AbstractImmutableCollection
-
Deprecated.
- removeAll(Collection<?>) - Method in class com.bluegosling.collections.immutable.AbstractImmutableList
-
Deprecated.
- removeAll(Collection<?>) - Method in class com.bluegosling.collections.immutable.AbstractImmutableSet
-
Deprecated.
- removeAll() - Method in class com.bluegosling.collections.immutable.AmtPersistentList
-
- removeAll() - Method in class com.bluegosling.collections.immutable.HamtPersistentMap
-
- removeAll() - Method in class com.bluegosling.collections.immutable.LinkedPersistentList
-
- removeAll(Collection<?>) - Method in interface com.bluegosling.collections.immutable.PersistentCollection
-
Deprecated.
- removeAll() - Method in interface com.bluegosling.collections.immutable.PersistentCollection
-
Returns an empty collection.
- removeAll(Collection<?>) - Method in interface com.bluegosling.collections.immutable.PersistentList
-
Deprecated.
- removeAll() - Method in interface com.bluegosling.collections.immutable.PersistentList
-
Returns an empty list.
- removeAll() - Method in interface com.bluegosling.collections.immutable.PersistentMap
-
- removeAll(Collection<?>) - Method in interface com.bluegosling.collections.immutable.PersistentSet
-
Deprecated.
- removeAll() - Method in interface com.bluegosling.collections.immutable.PersistentSet
-
Returns an empty set.
- removeAll(Collection<?>) - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- removeAll(Collection<?>) - Method in class com.bluegosling.collections.sets.RandomAccessSetList
-
- removeAll(Collection<?>) - Method in class com.bluegosling.collections.sets.SortedArraySet
- removeAll(Collection<?>) - Method in class com.bluegosling.collections.TransformingCollection.Bidi
-
- removeAll(Collection<?>) - Method in class com.bluegosling.collections.TransformingCollection.ReadOnly
-
- removeAll(Collection<?>) - Method in class com.bluegosling.collections.TransformingCollection
-
- removeAll(Collection<?>) - Method in class com.bluegosling.collections.TransformingList.Bidi
-
- removeBoolean(int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfBoolean
-
- removeBoolean(int) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfBoolean
-
- removeBooleanIf(BooleanPredicate) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfBoolean
-
- removeBooleanIf(BooleanPredicate) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfBoolean
-
- removeByKey(K) - Method in class com.bluegosling.collections.lists.AssociativeArrayList
-
- removeByKey(K) - Method in interface com.bluegosling.collections.lists.AssociativeList
-
Removes an element via its associative key.
- removeByte(int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfByte
-
- removeByte(int) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfByte
-
- removeByteIf(BytePredicate) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfByte
-
- removeByteIf(BytePredicate) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfByte
-
- removeChar(int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfChar
-
- removeChar(int) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfChar
-
- removeCharIf(CharPredicate) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfChar
-
- removeCharIf(CharPredicate) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfChar
-
- removeDouble(int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfDouble
-
- removeDouble(int) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfDouble
-
- removeDoubleIf(DoublePredicate) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfDouble
-
- removeDoubleIf(DoublePredicate) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfDouble
-
- removeEntry(Object) - Method in class com.bluegosling.collections.AbstractNavigableMap
-
Removes a mapping for the specified key and returns the removed entry.
- removeEntry(Object) - Method in class com.bluegosling.collections.AbstractNavigableMap.SubMap
-
Removes a mapping for the specified key and returns the removed entry.
- removeEntry(Object) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.RandomAccessSubMap
-
Removes a mapping for the specified key and returns the removed entry.
- removeEntry(int) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.RandomAccessSubMap
-
- removeEntry(Object) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.SubMapByIndices
-
- removeEntry(int) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.SubMapByIndices
-
- removeEntry(int) - Method in class com.bluegosling.collections.maps.DescendingRandomAccessMap
-
- removeEntry(int) - Method in interface com.bluegosling.collections.maps.RandomAccessNavigableMap
-
Removes an entry from the map by random access index.
- removeEntry(Object) - Method in class com.bluegosling.collections.maps.SortedArrayMap
-
- removeEntry(int) - Method in class com.bluegosling.collections.maps.WeightBalancedTreeMap
-
- removeFifth() - Method in class com.bluegosling.tuples.NTuple
-
Removes the fifth item from the tuple.
- removeFifth() - Method in class com.bluegosling.tuples.Quintuple
-
- removeFifth() - Method in interface com.bluegosling.tuples.Tuple.Ops5
-
Removes the fifth item from the tuple.
- removeFirst() - Method in class com.bluegosling.collections.AbstractDeque
-
- removeFirst() - Method in class com.bluegosling.collections.CircularBuffer
-
Removes the first item from the buffer.
- removeFirst() - Method in class com.bluegosling.collections.lists.ArrayBackedLinkedList
- removeFirst() - Method in class com.bluegosling.collections.lists.UnrolledLinkedList
-
- removeFirst() - Method in interface com.bluegosling.collections.queues.OrderedDeque
-
- removeFirst() - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- removeFirst() - Method in class com.bluegosling.collections.queues.RandomAccessArrayDeque
-
- removeFirst() - Method in class com.bluegosling.tuples.NTuple
-
Removes the first item from the tuple.
- removeFirst() - Method in class com.bluegosling.tuples.Pair
-
- removeFirst() - Method in class com.bluegosling.tuples.Quadruple
-
- removeFirst() - Method in class com.bluegosling.tuples.Quintuple
-
- removeFirst() - Method in class com.bluegosling.tuples.Single
-
- removeFirst() - Method in class com.bluegosling.tuples.Triple
-
- removeFirst() - Method in interface com.bluegosling.tuples.Tuple.Ops1
-
Removes the first item from the tuple.
- removeFirst() - Method in interface com.bluegosling.tuples.Tuple.Ops2
-
- removeFirst() - Method in interface com.bluegosling.tuples.Tuple.Ops3
-
- removeFirst() - Method in interface com.bluegosling.tuples.Tuple.Ops4
-
- removeFirst() - Method in interface com.bluegosling.tuples.Tuple.Ops5
-
- removeFirstOccurrence(Object) - Method in class com.bluegosling.collections.AbstractDeque
-
- removeFirstOccurrence(Object) - Method in class com.bluegosling.collections.concurrent.LockFreeLinkedBlockingDeque
-
- removeFirstOccurrence(Object) - Method in class com.bluegosling.collections.lists.ArrayBackedLinkedList
- removeFirstOccurrence(Object) - Method in class com.bluegosling.collections.lists.UnrolledLinkedList
-
- removeFirstOccurrence(Object) - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- removeFirstOccurrence(Object) - Method in class com.bluegosling.collections.queues.RandomAccessArrayDeque
-
- removeFloat(int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfFloat
-
- removeFloat(int) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfFloat
-
- removeFloatIf(FloatPredicate) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfFloat
-
- removeFloatIf(FloatPredicate) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfFloat
-
- removeFourth() - Method in class com.bluegosling.tuples.NTuple
-
Removes the fourth item from the tuple.
- removeFourth() - Method in class com.bluegosling.tuples.Quadruple
-
- removeFourth() - Method in class com.bluegosling.tuples.Quintuple
-
- removeFourth() - Method in interface com.bluegosling.tuples.Tuple.Ops4
-
Removes the fourth item from the tuple.
- removeFourth() - Method in interface com.bluegosling.tuples.Tuple.Ops5
-
- removeIf(Predicate<? super E>) - Method in class com.bluegosling.collections.immutable.AbstractImmutableCollection
-
Deprecated.
- removeIf(Predicate<? super E>) - Method in class com.bluegosling.collections.immutable.AbstractImmutableList
-
Deprecated.
- removeIf(Predicate<? super E>) - Method in class com.bluegosling.collections.immutable.AbstractImmutableSet
-
Deprecated.
- removeIf(Predicate<? super E>) - Method in interface com.bluegosling.collections.immutable.PersistentCollection
-
Deprecated.
- removeIndex(int, Object[], int) - Static method in class com.bluegosling.collections.ArrayUtils
-
Removes the an item from the specified array, shifting elements around
if necessary.
- removeInt(int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfInt
-
- removeInt(int) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfInt
-
- removeIntIf(IntPredicate) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfInt
-
- removeIntIf(IntPredicate) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfInt
-
- removeLast() - Method in class com.bluegosling.collections.AbstractDeque
-
- removeLast() - Method in class com.bluegosling.collections.CircularBuffer
-
Removes the last item from the buffer.
- removeLast() - Method in class com.bluegosling.collections.lists.ArrayBackedLinkedList
- removeLast() - Method in class com.bluegosling.collections.lists.UnrolledLinkedList
-
- removeLast() - Method in interface com.bluegosling.collections.queues.OrderedDeque
-
- removeLast() - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- removeLast() - Method in class com.bluegosling.collections.queues.RandomAccessArrayDeque
-
- removeLastOccurrence(Object) - Method in class com.bluegosling.collections.AbstractDeque
-
- removeLastOccurrence(Object) - Method in class com.bluegosling.collections.concurrent.LockFreeLinkedBlockingDeque
-
- removeLastOccurrence(Object) - Method in class com.bluegosling.collections.lists.ArrayBackedLinkedList
- removeLastOccurrence(Object) - Method in class com.bluegosling.collections.lists.UnrolledLinkedList
-
- removeLastOccurrence(Object) - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- removeLastOccurrence(Object) - Method in class com.bluegosling.collections.queues.RandomAccessArrayDeque
-
- removeListener(ScheduledTaskListener<? super V>) - Method in interface com.bluegosling.concurrent.scheduler.ScheduledTaskDefinition
-
Removes a listener.
- removeLong(int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfLong
-
- removeLong(int) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfLong
-
- removeLongIf(LongPredicate) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfLong
-
- removeLongIf(LongPredicate) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfLong
-
- removeObject(Object, Iterator<?>, boolean) - Static method in class com.bluegosling.collections.CollectionUtils
-
Removes a specified object using an iterator.
- removeRange(int, int) - Method in class com.bluegosling.collections.immutable.AbstractImmutableList
-
Deprecated.
- removeRange(int, int) - Method in class com.bluegosling.collections.lists.AssociativeArrayList
-
- removeRange(int, int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList
-
- removeRange(int, int) - Method in class com.bluegosling.collections.queues.RandomAccessArrayDeque
-
- removeSecond() - Method in class com.bluegosling.tuples.NTuple
-
Removes the second item from the tuple.
- removeSecond() - Method in class com.bluegosling.tuples.Pair
-
- removeSecond() - Method in class com.bluegosling.tuples.Quadruple
-
- removeSecond() - Method in class com.bluegosling.tuples.Quintuple
-
- removeSecond() - Method in class com.bluegosling.tuples.Triple
-
- removeSecond() - Method in interface com.bluegosling.tuples.Tuple.Ops2
-
Removes the second item from the tuple.
- removeSecond() - Method in interface com.bluegosling.tuples.Tuple.Ops3
-
- removeSecond() - Method in interface com.bluegosling.tuples.Tuple.Ops4
-
- removeSecond() - Method in interface com.bluegosling.tuples.Tuple.Ops5
-
- removeShort(int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfShort
-
- removeShort(int) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfShort
-
- removeShortIf(ShortPredicate) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfShort
-
- removeShortIf(ShortPredicate) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfShort
-
- removeThird() - Method in class com.bluegosling.tuples.NTuple
-
Removes the third item from the tuple.
- removeThird() - Method in class com.bluegosling.tuples.Quadruple
-
- removeThird() - Method in class com.bluegosling.tuples.Quintuple
-
- removeThird() - Method in class com.bluegosling.tuples.Triple
-
- removeThird() - Method in interface com.bluegosling.tuples.Tuple.Ops3
-
Removes the third item from the tuple.
- removeThird() - Method in interface com.bluegosling.tuples.Tuple.Ops4
-
- removeThird() - Method in interface com.bluegosling.tuples.Tuple.Ops5
-
- removeWatcher(Atom.Watcher<? super T>) - Method in interface com.bluegosling.concurrent.atoms.Atom
-
Unregisters a watcher.
- repeat(Rescheduler<? super V>) - Method in class com.bluegosling.concurrent.scheduler.TaskDefinition.Builder
-
Configures the task to recur using the given rescheduler for computing when subsequent
invocations will start.
- repeatAtFixedRate(long, TimeUnit) - Method in class com.bluegosling.concurrent.scheduler.TaskDefinition.Builder
-
Configures the task to repeat on a fixed rate schedule.
- RepeatingScheduledTask<V> - Interface in com.bluegosling.concurrent.scheduler
-
Represents a repeating task.
- repeatWithFixedDelay(long, TimeUnit) - Method in class com.bluegosling.concurrent.scheduler.TaskDefinition.Builder
-
Configures the task to repeat with a fixed delay between invocations.
- replace(int, E, E) - Method in interface com.bluegosling.collections.concurrent.ConcurrentList
-
Replaces the given value at the given index.
- replace(K, V, V) - Method in class com.bluegosling.collections.concurrent.DoubleInstanceLockedTreeMap
-
- replace(K, V) - Method in class com.bluegosling.collections.concurrent.DoubleInstanceLockedTreeMap
-
- replace(K, V, V) - Method in class com.bluegosling.collections.concurrent.PersistentMapBackedConcurrentMap
-
- replace(K, V) - Method in class com.bluegosling.collections.concurrent.PersistentMapBackedConcurrentMap
-
- replace(K, V, V) - Method in class com.bluegosling.collections.immutable.AbstractImmutableMap
-
Deprecated.
- replace(K, V) - Method in class com.bluegosling.collections.immutable.AbstractImmutableMap
-
Deprecated.
- replace(K, V) - Method in interface com.bluegosling.collections.immutable.PersistentMap
-
Deprecated.
- replace(K, V, V) - Method in interface com.bluegosling.collections.immutable.PersistentMap
-
Deprecated.
- replace(K, V) - Method in class com.bluegosling.collections.maps.LinearHashingMap
-
- replace(K, V, V) - Method in class com.bluegosling.collections.maps.LinearHashingMap
-
- replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class com.bluegosling.collections.concurrent.DoubleInstanceLockedTreeMap
-
- replaceAll(UnaryOperator<E>) - Method in class com.bluegosling.collections.immutable.AbstractImmutableList
-
Deprecated.
- replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class com.bluegosling.collections.immutable.AbstractImmutableMap
-
Deprecated.
- replaceAll(UnaryOperator<E>) - Method in interface com.bluegosling.collections.immutable.PersistentList
-
Deprecated.
- replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in interface com.bluegosling.collections.immutable.PersistentMap
-
Deprecated.
- replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class com.bluegosling.collections.maps.HamtMap
-
- replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class com.bluegosling.collections.maps.LinearHashingMap
-
- replaceAllBooleans(BooleanUnaryOperator) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfBoolean
-
- replaceAllBooleans(BooleanUnaryOperator) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfBoolean
-
- replaceAllBytes(ByteUnaryOperator) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfByte
-
- replaceAllBytes(ByteUnaryOperator) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfByte
-
- replaceAllChars(CharUnaryOperator) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfChar
-
- replaceAllChars(CharUnaryOperator) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfChar
-
- replaceAllDoubles(DoubleUnaryOperator) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfDouble
-
- replaceAllDoubles(DoubleUnaryOperator) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfDouble
-
- replaceAllFloats(FloatUnaryOperator) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfFloat
-
- replaceAllFloats(FloatUnaryOperator) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfFloat
-
- replaceAllInts(IntUnaryOperator) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfInt
-
- replaceAllInts(IntUnaryOperator) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfInt
-
- replaceAllLongs(LongUnaryOperator) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfLong
-
- replaceAllLongs(LongUnaryOperator) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfLong
-
- replaceAllShorts(ShortUnaryOperator) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfShort
-
- replaceAllShorts(ShortUnaryOperator) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfShort
-
- replaceAnnotations(AnnotatedType, Annotation...) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- replaceAnnotations(AnnotatedType, Collection<? extends Annotation>) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- replaceAnnotations(AnnotatedParameterizedType, Annotation...) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- replaceAnnotations(AnnotatedParameterizedType, Collection<? extends Annotation>) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- replaceAnnotations(AnnotatedArrayType, Annotation...) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- replaceAnnotations(AnnotatedArrayType, Collection<? extends Annotation>) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- replaceAnnotations(AnnotatedWildcardType, Annotation...) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- replaceAnnotations(AnnotatedWildcardType, Collection<? extends Annotation>) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- replaceAnnotations(AnnotatedTypeVariable, Annotation...) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- replaceAnnotations(AnnotatedTypeVariable, Collection<? extends Annotation>) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- replaceTypeVariable(AnnotatedType, TypeVariable<?>, AnnotatedType) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
Computes a new version of the given type by replacing all occurrences of a given type variable
with a given value for that variable.
- replaceTypeVariable(Type, TypeVariable<?>, Type) - Static method in class com.bluegosling.reflect.Types
-
Computes a new version of the given type by replacing all occurrences of a given type variable
with a given value for that variable.
- replaceTypeVariables(AnnotatedType, Map<TypeVariable<?>, AnnotatedType>) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
Computes a new version of the given type by replacing all occurrences of mapped type variables
with the given mapped values.
- replaceTypeVariables(Type, Map<TypeVariable<?>, Type>) - Static method in class com.bluegosling.reflect.Types
-
Computes a new version of the given type by replacing all occurrences of mapped type variables
with the given mapped values.
- Rescheduler<T> - Interface in com.bluegosling.concurrent.fluent
-
Handles rescheduling a periodic task.
- rescheduler() - Method in interface com.bluegosling.concurrent.scheduler.TaskDefinition
-
Returns the rescheduler, used to compute the start time for subsequent invocations of a
repeating task.
- reserve() - Method in class com.bluegosling.concurrent.RateLimiter
-
Reserves a permit, returning the duration between now and the time the permit becomes
available.
- reserve(long) - Method in class com.bluegosling.concurrent.RateLimiter
-
Reserves the given number of permits, returning the duration between now and the time the
permits become available.
- reset() - Static method in class com.bluegosling.apt.ProcessingEnvironments
-
Resets the current thread, clearing thread-local state related to the current environment.
- reset() - Method in class com.bluegosling.apt.testing.CategorizingDiagnosticCollector
-
- reset() - Method in class com.bluegosling.apt.testing.TestJavaFileManager
-
Resets the file system.
- reset() - Method in interface com.bluegosling.collections.maps.MapBuilder
-
Resets the map so it can be re-used to construct another map.
- reset() - Method in class com.bluegosling.testing.InterfaceVerifier
-
Resets the verifier to the default configuration.
- resetModCount() - Method in class com.bluegosling.collections.AbstractNavigableMap.BaseIteratorImpl
-
Resets the iterator to be in sync with the map's latest
modCount
.
- resetModCount() - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.SubMapByIndicesIterator
-
Resets the iterator to be in sync with the map's latest
modCount
.
- resolveSupertype(AnnotatedType, Class<?>) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
For the given annotated type, computes the annotated super-type corresponding to the given raw
class token.
- resolveSupertype(Type, Class<?>) - Static method in class com.bluegosling.reflect.Types
-
For the given generic type, computes the generic supertype corresponding to the given raw
class token.
- resolveSupertypeRef(AnnotatedTypeRef<T>, Class<S>) - Static method in class com.bluegosling.reflect.AnnotatedTypeRef
-
Returns a supertype of the given type, as a
TypeRef
.
- resolveSupertypeRef(Class<?>) - Method in class com.bluegosling.reflect.AnnotatedTypeRef
-
Returns a supertype of the current type, as a TypeRef
.
- resolveSupertypeRef(TypeRef<T>, Class<S>) - Static method in class com.bluegosling.reflect.TypeRef
-
Returns a supertype of the given type, as a
TypeRef
.
- resolveSupertypeRef(Class<?>) - Method in class com.bluegosling.reflect.TypeRef
-
Returns a supertype of the current type, as a TypeRef
.
- resolveType(AnnotatedType, AnnotatedType) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
Resolves the given type in the context of another type.
- resolveType(Type, Type) - Static method in class com.bluegosling.reflect.Types
-
Resolves the given type in the context of another type.
- resolveTypeParameterNamed(String) - Method in class com.bluegosling.reflect.AnnotatedTypeRef
-
Resolves the specified type parameter into a TypeRef
.
- resolveTypeParameterNamed(String) - Method in class com.bluegosling.reflect.TypeRef
-
Resolves the specified type parameter into a TypeRef
.
- resolveTypeVariable(AnnotatedType, TypeVariable<?>) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
Resolves the given type variable in the context of the given type.
- resolveTypeVariable(Type, TypeVariable<?>) - Static method in class com.bluegosling.reflect.Types
-
Resolves the given type variable in the context of the given type.
- rest() - Method in class com.bluegosling.collections.immutable.AbstractLinkedImmutableList.LinkedSubList
-
- rest() - Method in interface com.bluegosling.collections.immutable.ConsList
-
Returns the rest of the list, excluding the first element.
- rest() - Method in class com.bluegosling.collections.immutable.LinkedPersistentList
-
- restart() - Method in class com.bluegosling.concurrent.atoms.AsynchronousAtom
-
Restarts mutation operations in a blocked atom.
- restart(T, boolean) - Method in class com.bluegosling.concurrent.atoms.AsynchronousAtom
-
Restarts mutation operations in a blocked atom with the given new seed value.
- restore(T) - Method in interface com.bluegosling.concurrent.executors.ContextPropagator
-
Restores the given context in the current thread.
- Result<T,E> - Class in com.bluegosling.result
-
The result of an operation, which can either represent a successful value or a cause of failure.
- Result.Visitor<T,E,R> - Interface in com.bluegosling.result
-
A visitor of results, for implementing the visitor pattern (double-dispatch) with results.
- resultNode() - Method in class com.bluegosling.graph.Graph
-
The node in the graph that supplies the final product of the graph.
- resume() - Method in class com.bluegosling.concurrent.atoms.AsynchronousAtom
-
Resumes mutation operations in a blocked atom.
- resume() - Method in interface com.bluegosling.concurrent.scheduler.ScheduledTaskDefinition
-
Resumes this task definition.
- retainAll(Collection<?>) - Method in class com.bluegosling.collections.concurrent.ArrayBlockingDeque
-
- retainAll(Collection<?>) - Method in class com.bluegosling.collections.concurrent.ConcurrentSortedArraySet
- retainAll(Collection<?>) - Method in class com.bluegosling.collections.concurrent.LockFreeArrayBlockingQueue
-
- retainAll(Collection<?>) - Method in class com.bluegosling.collections.concurrent.SimpleTreiberStack
-
- retainAll(Collection<?>) - Method in class com.bluegosling.collections.DescendingSet
-
- retainAll(Collection<?>) - Method in class com.bluegosling.collections.FilteringCollection
-
- retainAll(Collection<?>) - Method in class com.bluegosling.collections.immutable.AbstractImmutableCollection
-
Deprecated.
- retainAll(Collection<?>) - Method in class com.bluegosling.collections.immutable.AbstractImmutableList
-
Deprecated.
- retainAll(Collection<?>) - Method in class com.bluegosling.collections.immutable.AbstractImmutableSet
-
Deprecated.
- retainAll(Collection<?>) - Method in interface com.bluegosling.collections.immutable.PersistentCollection
-
Deprecated.
- retainAll(Collection<?>) - Method in interface com.bluegosling.collections.immutable.PersistentList
-
Deprecated.
- retainAll(Collection<?>) - Method in interface com.bluegosling.collections.immutable.PersistentSet
-
Deprecated.
- retainAll(Collection<?>) - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- retainAll(Collection<?>) - Method in class com.bluegosling.collections.sets.RandomAccessSetList
-
- retainAll(Collection<?>) - Method in class com.bluegosling.collections.sets.SortedArraySet
- retainAll(Collection<?>) - Method in class com.bluegosling.collections.TransformingCollection.Bidi
-
- retainAll(Collection<?>) - Method in class com.bluegosling.collections.TransformingCollection.ReadOnly
-
- retainAll(Collection<?>) - Method in class com.bluegosling.collections.TransformingCollection
-
- retainAll(Collection<?>) - Method in class com.bluegosling.collections.TransformingList.Bidi
-
- retreat(K) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.BaseListIteratorImpl
-
- returning(T) - Static method in class com.bluegosling.function.Functions
-
- returnVerifier(ObjectVerifier<R>, Class<R>) - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfiguration
-
Specifies how to verify the return values after the method is called.
- returnVerifier(ObjectVerifier<?>) - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfiguration
-
Specifies how to verify the return values after the method is called.
- returnVerifier(ObjectVerifier<R>, Class<R>) - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfigurator
-
Specifies how to verify the return values after the method is called.
- returnVerifier(ObjectVerifier<?>) - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfigurator
-
Specifies how to verify the return values after the method is called.
- reverse(Object[]) - Static method in class com.bluegosling.collections.ArrayUtils
-
Reverses the specified array in place.
- reverse(BitSequence) - Static method in class com.bluegosling.collections.bits.BitSequences
-
Returns a new sequence that represents the reverse of the specified sequence.
- reversed(Iterable<E>) - Static method in class com.bluegosling.collections.MoreIterables
-
Returns an iterator that navigates over the given iterable in reverse order.
- reverseListIterator(ListIterator<E>) - Static method in class com.bluegosling.collections.MoreIterators
-
Returns an iterator that traverses elements in the opposite order of the specified iterator.
- rollback() - Method in class com.bluegosling.concurrent.atoms.Transaction
-
Rolls back the current transaction.
- rollbackTo(Transaction.Savepoint) - Method in class com.bluegosling.concurrent.atoms.Transaction
-
Performs a partial roll back.
- rotate() - Method in interface com.bluegosling.collections.tables.Table2D
-
- rotate() - Method in interface com.bluegosling.collections.tables.Table3D
-
- rotate() - Method in interface com.bluegosling.collections.tables.Table4D
-
- rotate() - Method in interface com.bluegosling.collections.tables.Table5D
-
- roundEnv - Variable in class com.bluegosling.apt.reflect.ArProcessor
-
The environment of the current processing round.
- roundEnvironment() - Method in class com.bluegosling.apt.testing.TestEnvironment
-
Gets the round environment for the current round of processing.
- roundNumber() - Method in class com.bluegosling.apt.testing.TestEnvironment
-
Gets the number of the current round (first round is number one).
- rowIndex() - Method in interface com.bluegosling.collections.tables.Table3D
-
- rowIndex() - Method in interface com.bluegosling.collections.tables.Table4D
-
- rowIndex() - Method in interface com.bluegosling.collections.tables.Table5D
-
- rowKeySet() - Method in interface com.bluegosling.collections.tables.Table2D
-
- rowKeySet() - Method in interface com.bluegosling.collections.tables.Table3D
-
- rowKeySet() - Method in interface com.bluegosling.collections.tables.Table4D
-
- rowKeySet() - Method in interface com.bluegosling.collections.tables.Table5D
-
- run(TestEnvironment) - Method in interface com.bluegosling.apt.testing.CheckedProcessingTask
-
Runs the task.
- run(CheckedProcessingTask<T, X>) - Method in interface com.bluegosling.apt.testing.CompilationContext.TaskBuilder
-
Invokes the compiler and runs the specified task during the annotation processing phase.
- run() - Method in interface com.bluegosling.apt.testing.CompilationContext.TaskBuilderWithProcessor
-
Invokes the compiler and runs the processor under test during the annotation processing
phase.
- run() - Method in class com.bluegosling.concurrent.fluent.FluentRepeatingFutureTask
-
- run() - Method in class com.bluegosling.concurrent.fluent.SettableRunnableFluentFuture
-
- run() - Method in class com.bluegosling.concurrent.futures.RunnableCompletableFuture
-
Runs the task associated with this future.
- run() - Method in class com.bluegosling.concurrent.futures.RunnableReadOnlyCompletableFuture
-
Runs the task associated with this future.
- run(U, Generator.Output<T, U>) - Method in class com.bluegosling.generator.Generator
-
Performs generation logic.
- run() - Method in interface com.bluegosling.testing.MoreAsserts.Block
-
- runInterruptiblyAsync(Runnable) - Static method in class com.bluegosling.concurrent.futures.CompletableFutures
-
- runInterruptiblyAsync(Runnable, Executor) - Static method in class com.bluegosling.concurrent.futures.CompletableFutures
-
- RunnableCompletableFuture<T> - Class in com.bluegosling.concurrent.futures
-
A completable future that represents a task.
- RunnableCompletableFuture(Callable<T>) - Constructor for class com.bluegosling.concurrent.futures.RunnableCompletableFuture
-
Creates a new future that represents the given task.
- RunnableCompletionStageFuture<T> - Interface in com.bluegosling.concurrent.futures
-
- RunnableFluentFuture<T> - Interface in com.bluegosling.concurrent.fluent
-
- RunnableReadOnlyCompletableFuture<T> - Class in com.bluegosling.concurrent.futures
-
A read-only completable future that represents a task.
- RunnableReadOnlyCompletableFuture(Callable<T>) - Constructor for class com.bluegosling.concurrent.futures.RunnableReadOnlyCompletableFuture
-
Creates a new future that represents the given task.
- Runner() - Constructor for class com.bluegosling.concurrent.atoms.Transaction.Runner
-
- runnerUpdater - Static variable in class com.bluegosling.concurrent.fluent.SettableRunnableFluentFuture
-
- runReentrant(CheckedProcessingTask<T, X>) - Method in interface com.bluegosling.apt.testing.CompilationContext.TaskBuilder
-
Invokes the compiler and runs the specified task during the annotation processing phase.
- runWithExclusiveLock(Runnable) - Method in class com.bluegosling.concurrent.locks.HierarchicalLock
-
Invokes the specified runnable while holding this lock in exclusive mode.
- runWithLock(Runnable) - Method in interface com.bluegosling.concurrent.locks.Locking
-
Runs the given action while holding a lock.
- runWithOptimisticReadLock(Runnable) - Method in interface com.bluegosling.concurrent.locks.Locking.StampedLocking
-
Runs the given action without acquiring a lock, relying on optimistic concurrency.
- runWithReadLock(Runnable) - Method in interface com.bluegosling.concurrent.locks.Locking.ReadWriteLocking
-
Runs the given action while holding a read (e.g.
- runWithSharedLock(Runnable) - Method in class com.bluegosling.concurrent.locks.HierarchicalLock
-
Invokes the specified runnable while holding this lock in shared mode.
- runWithWriteLock(Runnable) - Method in interface com.bluegosling.concurrent.locks.Locking.ReadWriteLocking
-
Runs the given action while holding a write (e.g.
- SAME - Static variable in class com.bluegosling.testing.ObjectVerifiers
-
An object that verifies that the test object is the same instance as the reference object (via
the == operator).
- SameThreadExecutor - Class in com.bluegosling.concurrent
-
A simple executor that runs each task synchronously in the same thread that submits it.
- sameThreadExecutorService() - Static method in interface com.bluegosling.concurrent.executors.CompletableExecutorService
-
Returns a new executor service that runs each task synchronously in the same thread that
submits it.
- sameThreadExecutorService() - Static method in interface com.bluegosling.concurrent.fluent.FluentExecutorService
-
Returns a new executor service that runs each task synchronously in the same thread that
submits it.
- savepoint() - Method in class com.bluegosling.concurrent.atoms.Transaction
-
Creates a checkpoint in the transaction.
- scan(Class<?>, P) - Method in class com.bluegosling.reflect.ClassHierarchyScanner
-
Scans the hierarchy of the specified type.
- scanEverything() - Method in class com.bluegosling.reflect.ClassHierarchyScanner.Builder
-
Indicates that all types are scanned.
- scanUntilValueFound() - Method in class com.bluegosling.reflect.ClassHierarchyScanner.Builder
-
Indicates that crawling should end as soon as visiting one of the types results in a
non-null value.
- scanWith(Class<?>, P, BiFunction<Class<?>, P, R>) - Static method in class com.bluegosling.reflect.ClassHierarchyScanner
-
Scans the hierarchy of the specified type using the specified action.
- schedule(Runnable, long, TimeUnit) - Method in class com.bluegosling.concurrent.executors.ContextPropagatingScheduledExecutorService
-
- schedule(Callable<V>, long, TimeUnit) - Method in class com.bluegosling.concurrent.executors.ContextPropagatingScheduledExecutorService
-
- schedule(Runnable, long, TimeUnit) - Method in class com.bluegosling.concurrent.executors.InterceptingScheduledExecutorService
-
- schedule(Callable<V>, long, TimeUnit) - Method in class com.bluegosling.concurrent.executors.InterceptingScheduledExecutorService
-
- schedule(Runnable, long, TimeUnit) - Method in class com.bluegosling.concurrent.executors.WrappingScheduledExecutorService
-
- schedule(Callable<V>, long, TimeUnit) - Method in class com.bluegosling.concurrent.executors.WrappingScheduledExecutorService
-
- schedule(Runnable, long, TimeUnit) - Method in interface com.bluegosling.concurrent.fluent.FluentScheduledExecutorService
- schedule(Callable<V>, long, TimeUnit) - Method in interface com.bluegosling.concurrent.fluent.FluentScheduledExecutorService
- schedule(Callable<V>, long, TimeUnit) - Method in class com.bluegosling.concurrent.scheduler.ScheduledTaskManager
-
Schedules the specified task for execution.
- schedule(Runnable, long, TimeUnit) - Method in class com.bluegosling.concurrent.scheduler.ScheduledTaskManager
-
Schedules the specified task for execution.
- schedule(TaskDefinition<V>) - Method in class com.bluegosling.concurrent.scheduler.ScheduledTaskManager
-
Schedules the specified task definition for execution.
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class com.bluegosling.concurrent.executors.ContextPropagatingScheduledExecutorService
-
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class com.bluegosling.concurrent.executors.InterceptingScheduledExecutorService
-
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class com.bluegosling.concurrent.executors.WrappingScheduledExecutorService
-
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in interface com.bluegosling.concurrent.fluent.FluentScheduledExecutorService
- scheduleAtFixedRate(Callable<V>, long, long, TimeUnit) - Method in class com.bluegosling.concurrent.scheduler.ScheduledTaskManager
-
Schedules the specified task for periodic execution.
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class com.bluegosling.concurrent.scheduler.ScheduledTaskManager
-
- Scheduled - Interface in com.bluegosling.concurrent
-
A specialization of
Delayed
that allows for more accurate comparisons between the time
at which instances are scheduled.
- scheduledStartNanoTime() - Method in interface com.bluegosling.concurrent.scheduler.ScheduledTaskDefinition
-
Returns the time, in
system nanos, when this task is scheduled
to execute.
- scheduledStartTimeMillis() - Method in interface com.bluegosling.concurrent.scheduler.ScheduledTask
-
Returns the scheduled start time of this invocation, in milliseconds.
- scheduledStartTimeMillis() - Method in interface com.bluegosling.concurrent.scheduler.ScheduledTaskDefinition
-
Returns the timestamp, in milliseconds, when this task is scheduled to execute.
- ScheduledTask<V> - Interface in com.bluegosling.concurrent.scheduler
-
- ScheduledTaskDefinition<V> - Interface in com.bluegosling.concurrent.scheduler
-
- ScheduledTaskListener<V> - Interface in com.bluegosling.concurrent.scheduler
-
- ScheduledTaskManager - Class in com.bluegosling.concurrent.scheduler
-
- ScheduledTaskManager(int) - Constructor for class com.bluegosling.concurrent.scheduler.ScheduledTaskManager
-
Constructs a new task manager that uses the specified number of threads to execute tasks.
- ScheduledTaskManager(int, ThreadFactory) - Constructor for class com.bluegosling.concurrent.scheduler.ScheduledTaskManager
-
Constructs a new task manager with the specified number of threads and specified thread
factory.
- ScheduledTaskManager(int, ThreadFactory, RejectedExecutionHandler) - Constructor for class com.bluegosling.concurrent.scheduler.ScheduledTaskManager
-
Constructs a new task manager with the specified number of threads, specified thread factory,
and specified rejection handler.
- ScheduledTaskManager(int, RejectedExecutionHandler) - Constructor for class com.bluegosling.concurrent.scheduler.ScheduledTaskManager
-
Constructs a new task manager with the specified number of threads and specified rejection
handler.
- ScheduleNextTaskPolicies - Enum in com.bluegosling.concurrent.scheduler
-
- ScheduleNextTaskPolicy<V> - Interface in com.bluegosling.concurrent.scheduler
-
A policy that governs whether a task should be repeated or retried.
- scheduleNextTaskPolicy() - Method in interface com.bluegosling.concurrent.scheduler.TaskDefinition
-
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class com.bluegosling.concurrent.executors.ContextPropagatingScheduledExecutorService
-
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class com.bluegosling.concurrent.executors.InterceptingScheduledExecutorService
-
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class com.bluegosling.concurrent.executors.WrappingScheduledExecutorService
-
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in interface com.bluegosling.concurrent.fluent.FluentScheduledExecutorService
- scheduleWithFixedDelay(Callable<V>, long, long, TimeUnit) - Method in class com.bluegosling.concurrent.scheduler.ScheduledTaskManager
-
Schedules the specified task for repeated execution.
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class com.bluegosling.concurrent.scheduler.ScheduledTaskManager
-
- seconds(long) - Static method in class com.bluegosling.concurrent.Duration
-
Returns a new duration whose length is the specified number of seconds.
- sectionIndex() - Method in interface com.bluegosling.collections.tables.Table5D
-
- sectionKeySet() - Method in interface com.bluegosling.collections.tables.Table4D
-
- sectionKeySet() - Method in interface com.bluegosling.collections.tables.Table5D
-
- SecureUtils - Class in com.bluegosling.reflect
-
Several utility methods for checking security for reflective access.
- separate(Collection<Pair<T, U>>) - Static method in class com.bluegosling.tuples.Pair
-
Separates the values in a collection of pairs to produce a pair of collections.
- separate(Collection<Quadruple<T, U, V, W>>) - Static method in class com.bluegosling.tuples.Quadruple
-
Separates the values in a collection of quartets to produce a quartet of collections.
- separate(Collection<Quintuple<T, U, V, W, X>>) - Static method in class com.bluegosling.tuples.Quintuple
-
Separates the values in a collection of quintets to produce a quintet of collections.
- separate(Collection<Triple<T, U, V>>) - Static method in class com.bluegosling.tuples.Triple
-
Separates the values in a collection of trios to produce a trio of collections.
- Sequence<T,U,X extends Throwable> - Interface in com.bluegosling.generator
-
Represents a sequence of items produced by a
Generator
.
- SequenceAbandonedException - Exception in com.bluegosling.generator
-
An exception thrown in the generator thread to indicate that the corresponding sequence has been
abandoned.
- SequenceFinishedException - Exception in com.bluegosling.generator
-
An exception thrown during
generation of a sequence of elements.
- SequenceFinishedException() - Constructor for exception com.bluegosling.generator.SequenceFinishedException
-
- SequenceFinishedException(String) - Constructor for exception com.bluegosling.generator.SequenceFinishedException
-
- SequenceFinishedException(Throwable) - Constructor for exception com.bluegosling.generator.SequenceFinishedException
-
- SequenceFinishedException(String, Throwable) - Constructor for exception com.bluegosling.generator.SequenceFinishedException
-
- SequenceTrie<K,V> - Interface in com.bluegosling.collections.tries
-
A
trie whose keys are lists of values.
- sequential() - Method in interface com.bluegosling.streams.FluentStream
- SerializingExecutor<K> - Interface in com.bluegosling.concurrent.executors
-
An executor that serializes multiple tasks that correspond to the same key.
- set(int, E) - Method in class com.bluegosling.collections.FilteringList
-
- set(E) - Method in class com.bluegosling.collections.FilteringListIterator
-
- set(int, E) - Method in class com.bluegosling.collections.immutable.AbstractImmutableList
-
Deprecated.
- set(int, E) - Method in interface com.bluegosling.collections.immutable.PersistentList
-
Deprecated.
- set(int, E) - Method in class com.bluegosling.collections.lists.ArrayBackedLinkedList
- set(int, E) - Method in class com.bluegosling.collections.lists.TreeList
-
- set(int, E) - Method in class com.bluegosling.collections.lists.UnrolledLinkedList
-
- set(T) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.BaseListIteratorImpl
-
- set(Map.Entry<K, V>) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.SubMapByIndicesIterator
-
- set(int, T) - Method in class com.bluegosling.collections.NoCopyGrowableArray
-
- set(int, Boolean) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfBoolean
-
- set(int, Byte) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfByte
-
- set(int, Character) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfChar
-
- set(int, Double) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfDouble
-
- set(int, Float) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfFloat
-
- set(int, Integer) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfInt
-
- set(int, Long) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfLong
-
- set(int, Short) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfShort
-
- set(int, E) - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- set(int, E) - Method in class com.bluegosling.collections.queues.RandomAccessArrayDeque
-
- set(int, E) - Method in class com.bluegosling.collections.sets.RandomAccessSetList
-
- set(int, O) - Method in class com.bluegosling.collections.TransformingList.Bidi
-
- set(int, O) - Method in class com.bluegosling.collections.TransformingList
-
- set(O) - Method in class com.bluegosling.collections.TransformingListIterator.Bidi
-
- set(O) - Method in class com.bluegosling.collections.TransformingListIterator
-
- set(T) - Method in class com.bluegosling.concurrent.atoms.AsynchronousAtom
-
Submits a mutation that will set the atom to the specified value.
- set(T) - Method in class com.bluegosling.concurrent.atoms.SimpleAtom
-
- set(T) - Method in interface com.bluegosling.concurrent.atoms.SynchronousAtom
-
Sets the atom's value to the one specified and returns the previous value.
- set(T) - Method in class com.bluegosling.concurrent.atoms.ThreadLocalAtom
-
- set(T) - Method in class com.bluegosling.concurrent.atoms.TransactionalAtom
-
Sets the atom's value to the one specified and returns the previous value.
- set(boolean) - Method in class com.bluegosling.concurrent.contended.ContendedBoolean
-
Unconditionally sets to the given value.
- set(int) - Method in class com.bluegosling.concurrent.contended.ContendedInteger
-
Sets to the given value.
- set(long) - Method in class com.bluegosling.concurrent.contended.ContendedLong
-
Sets to the given value.
- set(V) - Method in class com.bluegosling.concurrent.contended.ContendedReference
-
Sets to the given value.
- set(T) - Method in class com.bluegosling.possible.Holder
-
Sets the held value.
- set(int, Object) - Method in class com.bluegosling.tuples.NTuple
-
Sets the item at the given index to the specified value.
- set(T) - Method in class com.bluegosling.vars.Variable
-
Sets this variable's value.
- set(boolean) - Method in class com.bluegosling.vars.VariableBoolean
-
Sets this variable's value.
- set(byte) - Method in class com.bluegosling.vars.VariableByte
-
Sets this variable's value.
- set(char) - Method in class com.bluegosling.vars.VariableChar
-
Sets this variable's value.
- set(double) - Method in class com.bluegosling.vars.VariableDouble
-
Sets this variable's value.
- set(float) - Method in class com.bluegosling.vars.VariableFloat
-
Sets this variable's value.
- set(int) - Method in class com.bluegosling.vars.VariableInt
-
Sets this variable's value.
- set(long) - Method in class com.bluegosling.vars.VariableLong
-
Sets this variable's value.
- set(short) - Method in class com.bluegosling.vars.VariableShort
-
Sets this variable's value.
- SetBackedOrderedQueue<E> - Class in com.bluegosling.collections.queues
-
An ordered queue that is backed by a navigable set and breaks ties in FIFO manner.
- SetBackedOrderedQueue(SetBackedOrderedQueue.SetFactory, Comparator<? super E>) - Constructor for class com.bluegosling.collections.queues.SetBackedOrderedQueue
-
Creates a new ordered queue backed by a set constructed using the given factory.
- SetBackedOrderedQueue.SetFactory - Interface in com.bluegosling.collections.queues
-
- setBoolean(int, boolean) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfBoolean
-
- setBoolean(int, boolean) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfBoolean
-
- setByte(int, byte) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfByte
-
- setByte(int, byte) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfByte
-
- setCancelled() - Method in class com.bluegosling.concurrent.fluent.AbstractFluentFuture
-
Sets the future as cancelled.
- setChar(int, char) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfChar
-
- setChar(int, char) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfChar
-
- setCheckHashCodesAfterMutation(boolean) - Method in class com.bluegosling.testing.InterfaceVerifier
-
Sets whether hash codes are verified after mutator methods are invoked.
- setCorePoolSize(int) - Method in class com.bluegosling.concurrent.executors.ActorThreadPool.Builder
-
- setCorePoolSize(int) - Method in class com.bluegosling.concurrent.executors.ActorThreadPool
-
Changes the size of the core pool of worker threads.
- setDefaultExceptionVerifier(ObjectVerifier<Throwable>) - Method in class com.bluegosling.testing.InterfaceVerifier
-
Sets the default verifier used to verify the exceptions thrown by methods.
- setDefaultMutatorVerifier(ObjectVerifier<? super T>) - Method in class com.bluegosling.testing.InterfaceVerifier
-
Sets the default verifier used to verify the implementations of mutator methods.
- setDouble(int, double) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfDouble
-
- setDouble(int, double) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfDouble
-
- setElement(E) - Method in interface com.bluegosling.collections.queues.PriorityQueue.Entry
-
Changes the value of the element in this entry
- setErrorHandler(AsynchronousAtom.ErrorHandler<? super T>) - Method in class com.bluegosling.concurrent.atoms.AsynchronousAtom
-
Sets the atom's error handler.
- setExecutor(Executor) - Method in class com.bluegosling.graph.ComputationFactory.Builder
-
- setFailure(Throwable) - Method in class com.bluegosling.concurrent.fluent.AbstractFluentFuture
-
Sets the future as failed with the specified cause of failure.
- setFailure(Throwable) - Method in class com.bluegosling.concurrent.fluent.SettableFluentFuture
-
- setFailure(Throwable) - Method in class com.bluegosling.concurrent.futures.ReadOnlyCompletableFuture
-
Marks the future as failed due to the given cause.
- setFifth(T) - Method in class com.bluegosling.tuples.NTuple
-
- setFifth(T) - Method in class com.bluegosling.tuples.Quintuple
-
- setFifth(T) - Method in interface com.bluegosling.tuples.Tuple.Ops5
-
Sets the fifth item in the tuple.
- setFirst(T) - Method in class com.bluegosling.tuples.NTuple
-
- setFirst(T) - Method in class com.bluegosling.tuples.Pair
-
- setFirst(T) - Method in class com.bluegosling.tuples.Quadruple
-
- setFirst(T) - Method in class com.bluegosling.tuples.Quintuple
-
- setFirst(T) - Method in class com.bluegosling.tuples.Single
-
- setFirst(T) - Method in class com.bluegosling.tuples.Triple
-
- setFirst(T) - Method in interface com.bluegosling.tuples.Tuple.Ops1
-
Sets the first item in the tuple.
- setFirst(T) - Method in interface com.bluegosling.tuples.Tuple.Ops2
-
- setFirst(T) - Method in interface com.bluegosling.tuples.Tuple.Ops3
-
- setFirst(T) - Method in interface com.bluegosling.tuples.Tuple.Ops4
-
- setFirst(T) - Method in interface com.bluegosling.tuples.Tuple.Ops5
-
- setFloat(int, float) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfFloat
-
- setFloat(int, float) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfFloat
-
- setFourth(T) - Method in class com.bluegosling.tuples.NTuple
-
- setFourth(T) - Method in class com.bluegosling.tuples.Quadruple
-
- setFourth(T) - Method in class com.bluegosling.tuples.Quintuple
-
- setFourth(T) - Method in interface com.bluegosling.tuples.Tuple.Ops4
-
Sets the fourth item in the tuple.
- setFourth(T) - Method in interface com.bluegosling.tuples.Tuple.Ops5
-
- setInt(int, int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfInt
-
- setInt(int, int) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfInt
-
- setJitter(double) - Method in class com.bluegosling.concurrent.RateLimiter
-
Sets the jitter amount.
- setKeepAlive(long, TimeUnit) - Method in class com.bluegosling.concurrent.executors.ActorThreadPool.Builder
-
- setKeepAliveTime(long, TimeUnit) - Method in class com.bluegosling.concurrent.executors.ActorThreadPool
-
Sets the duration for which idle (non-core) worker threads are kept alive.
- setLong(int, long) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfLong
-
- setLong(int, long) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfLong
-
- setMaxBatchDuration(long, TimeUnit) - Method in class com.bluegosling.concurrent.executors.ActorThreadPool.Builder
-
- setMaxBatchSize(int) - Method in class com.bluegosling.concurrent.executors.ActorThreadPool.Builder
-
- setMaximumPoolSize(int) - Method in class com.bluegosling.concurrent.executors.ActorThreadPool.Builder
-
- setMaximumPoolSize(int) - Method in class com.bluegosling.concurrent.executors.ActorThreadPool
-
Sets the maximum size for the pool of worker threads.
- setMaxPermits(long) - Method in class com.bluegosling.concurrent.RateLimiter
-
Sets the maximum capacity of permits, for bursts.
- setPoolSize(int) - Method in class com.bluegosling.concurrent.executors.ActorThreadPool.Builder
-
- setPriority(P) - Method in interface com.bluegosling.collections.queues.PriorityQueue.Entry
-
Changes the priority associated with the element in this entry.
- setPriority(P) - Method in class com.bluegosling.collections.queues.PriorityQueues.AutoEntry
-
Changes the priority associated with this object.
- setRate(double) - Method in class com.bluegosling.concurrent.RateLimiter
-
Sets the allowed rate of permit acquisition, in permits per second.
- setRelaxedDefaultExceptionVerifier() - Method in class com.bluegosling.testing.InterfaceVerifier
-
Sets the default verifier used to verify the exceptions thrown by methods to use relaxed
checking.
- setRootValue(T) - Method in class com.bluegosling.concurrent.atoms.ThreadLocalAtom
-
Sets the atom's root value.
- setScheduledNanoTime(long) - Method in class com.bluegosling.concurrent.fluent.FluentScheduledFutureTask
-
- setSecond(T) - Method in class com.bluegosling.tuples.NTuple
-
- setSecond(T) - Method in class com.bluegosling.tuples.Pair
-
- setSecond(T) - Method in class com.bluegosling.tuples.Quadruple
-
- setSecond(T) - Method in class com.bluegosling.tuples.Quintuple
-
- setSecond(T) - Method in class com.bluegosling.tuples.Triple
-
- setSecond(T) - Method in interface com.bluegosling.tuples.Tuple.Ops2
-
Sets the second item in the tuple.
- setSecond(T) - Method in interface com.bluegosling.tuples.Tuple.Ops3
-
- setSecond(T) - Method in interface com.bluegosling.tuples.Tuple.Ops4
-
- setSecond(T) - Method in interface com.bluegosling.tuples.Tuple.Ops5
-
- setShort(int, short) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfShort
-
- setShort(int, short) - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfShort
-
- setState(S) - Method in class com.bluegosling.concurrent.AbstractQueuedReferenceSynchronizer
-
Sets the value of synchronization state.
- setStrictDefaultExceptionVerifier() - Method in class com.bluegosling.testing.InterfaceVerifier
-
Sets the default verifier used to verify the exceptions thrown by methods to use strict
checking.
- setSuppressExceptions(boolean) - Method in class com.bluegosling.testing.InterfaceVerifier
-
Sets whether exceptions should be suppressed during method invocation.
- SettableFluentFuture<T> - Class in com.bluegosling.concurrent.fluent
-
A future whose result is set programmatically.
- SettableFluentFuture() - Constructor for class com.bluegosling.concurrent.fluent.SettableFluentFuture
-
- SettableRunnableFluentFuture<T> - Class in com.bluegosling.concurrent.fluent
-
A
runnable
future that is also settable.
- SettableRunnableFluentFuture(Runnable) - Constructor for class com.bluegosling.concurrent.fluent.SettableRunnableFluentFuture
-
Constructs a new future that will run the given task.
- SettableRunnableFluentFuture(Runnable, T) - Constructor for class com.bluegosling.concurrent.fluent.SettableRunnableFluentFuture
-
Constructs a new future that will run the given task.
- SettableRunnableFluentFuture(Callable<T>) - Constructor for class com.bluegosling.concurrent.fluent.SettableRunnableFluentFuture
-
Constructs a new future that will run the given computation.
- setThird(T) - Method in class com.bluegosling.tuples.NTuple
-
- setThird(T) - Method in class com.bluegosling.tuples.Quadruple
-
- setThird(T) - Method in class com.bluegosling.tuples.Quintuple
-
- setThird(T) - Method in class com.bluegosling.tuples.Triple
-
- setThird(T) - Method in interface com.bluegosling.tuples.Tuple.Ops3
-
Sets the third item in the tuple.
- setThird(T) - Method in interface com.bluegosling.tuples.Tuple.Ops4
-
- setThird(T) - Method in interface com.bluegosling.tuples.Tuple.Ops5
-
- setThreadFactory(ThreadFactory) - Method in class com.bluegosling.concurrent.executors.ActorThreadPool.Builder
-
- setThreadFactory(ThreadFactory) - Method in class com.bluegosling.concurrent.executors.ActorThreadPool
-
Sets the factory used to create worker threads.
- setTo(T) - Static method in class com.bluegosling.possible.Reference
-
Creates a reference set to the specified value.
- setup(ProcessingEnvironment) - Static method in class com.bluegosling.apt.ProcessingEnvironments
-
Sets up the environment for the current thread.
- setValue(V) - Method in interface com.bluegosling.collections.tables.Table2D.Cell2D
-
- setValue(V) - Method in interface com.bluegosling.collections.tables.Table3D.Cell3D
-
- setValue(V) - Method in interface com.bluegosling.collections.tables.Table4D.Cell4D
-
- setValue(V) - Method in interface com.bluegosling.collections.tables.Table5D.Cell5D
-
- setValue(VO) - Method in class com.bluegosling.collections.TransformingMapEntry.Bidi
-
- setValue(VO) - Method in class com.bluegosling.collections.TransformingMapEntry
-
- setValue(T) - Method in class com.bluegosling.concurrent.fluent.AbstractFluentFuture
-
Sets the future as successfully completed with the specified result.
- setValue(T) - Method in class com.bluegosling.concurrent.fluent.SettableFluentFuture
-
- setValue(T) - Method in class com.bluegosling.concurrent.futures.ReadOnlyCompletableFuture
-
Completes the future with the given value.
- setVerbose(boolean) - Method in class com.bluegosling.apt.testing.CategorizingDiagnosticCollector
-
- ShardedConcurrentSets - Class in com.bluegosling.collections.concurrent
-
This utility class provides concurrent set implementations that wrap
normal (non-concurrent) sets to provide thread-safe access.
- ShardedConcurrentSets.Builder<E,T extends Set<E>> - Class in com.bluegosling.collections.concurrent
-
Creates concurrent set objects using the builder pattern.
- shareCapacityWith(Queue<T>) - Method in class com.bluegosling.collections.concurrent.SharedCapacityDequeFactory
-
Wraps the specified queue so that it shares the factory's capacity.
- shareCapacityWith(Deque<T>) - Method in class com.bluegosling.collections.concurrent.SharedCapacityDequeFactory
-
Wraps the specified deque so that it shares the factory's capacity.
- shareCapacityWith(BlockingQueue<T>) - Method in class com.bluegosling.collections.concurrent.SharedCapacityDequeFactory
-
Wraps the specified queue so that it shares the factory's capacity.
- shareCapacityWith(BlockingDeque<T>) - Method in class com.bluegosling.collections.concurrent.SharedCapacityDequeFactory
-
Wraps the specified deque so that it shares the factory's capacity.
- SharedCapacityDequeFactory - Class in com.bluegosling.collections.concurrent
-
A producer of queues and deques that all share a single bound.
- SharedCapacityDequeFactory(int) - Constructor for class com.bluegosling.collections.concurrent.SharedCapacityDequeFactory
-
Constructs a new factory.
- SharedCapacityDequeFactory.CloseableBlockingDeque<T> - Interface in com.bluegosling.collections.concurrent
-
- SharedCapacityDequeFactory.CloseableBlockingQueue<T> - Interface in com.bluegosling.collections.concurrent
-
- SharedCapacityDequeFactory.CloseableDeque<T> - Interface in com.bluegosling.collections.concurrent
-
A
Deque
that can be closed.
- SharedCapacityDequeFactory.CloseableQueue<T> - Interface in com.bluegosling.collections.concurrent
-
A
Queue
that can be closed.
- sharedLock() - Method in class com.bluegosling.concurrent.locks.HierarchicalLock
-
Acquires the lock in shared mode, waiting if necessary for it to be available.
- sharedLockInterruptibly() - Method in class com.bluegosling.concurrent.locks.HierarchicalLock
-
Acquires the lock in shared mode, waiting interruptibly if necessary for it to be available.
- ShortBinaryOperator - Interface in com.bluegosling.function
-
Represents an operation upon two short
-valued operands and producing a
short
-valued result.
- ShortConsumer - Interface in com.bluegosling.function
-
- ShortIterator - Interface in com.bluegosling.collections.primitive
-
An
Iterator
that can provide primitive (un-boxed) shorts.
- ShortPredicate - Interface in com.bluegosling.function
-
Represents a predicate (boolean-valued function) of one short
-valued
argument.
- ShortUnaryOperator - Interface in com.bluegosling.function
-
Represents an operation on a single short
-valued operand that produces a
short
-valued result.
- shortValue() - Method in class com.bluegosling.vars.VariableByte
-
- shortValue() - Method in class com.bluegosling.vars.VariableLong
-
- shortValue() - Method in class com.bluegosling.vars.VariableShort
-
- shouldScheduleNext(ScheduledTask<? extends V>) - Method in interface com.bluegosling.concurrent.scheduler.ScheduleNextTaskPolicy
-
Determines whether a given task definition should be invoked again.
- shrinkBy(int) - Method in class com.bluegosling.collections.NoCopyGrowableArray
-
- shutdown() - Method in class com.bluegosling.concurrent.executors.ActorThreadPool
-
Shuts down the executor.
- shutdown() - Method in class com.bluegosling.concurrent.executors.ThreadLimitingExecutorService
-
- shutdown() - Method in class com.bluegosling.concurrent.executors.WorkSharingThreadPool
-
- shutdown() - Method in class com.bluegosling.concurrent.executors.WrappingExecutorService
-
- shutdown() - Method in class com.bluegosling.concurrent.scheduler.ScheduledTaskManager
-
- shutdownNow() - Method in class com.bluegosling.concurrent.executors.ActorThreadPool
-
Shuts down the executor immediately, interrupting in-process tasks and removing all queued
tasks.
- shutdownNow() - Method in class com.bluegosling.concurrent.executors.ThreadLimitingExecutorService
-
- shutdownNow() - Method in class com.bluegosling.concurrent.executors.WorkSharingThreadPool
-
- shutdownNow() - Method in class com.bluegosling.concurrent.executors.WrappingExecutorService
-
- shutdownNow() - Method in class com.bluegosling.concurrent.scheduler.ScheduledTaskManager
-
- signalNotEmpty() - Method in class com.bluegosling.collections.concurrent.AbstractLockFreeBlockingDeque
-
Signals a waiting thread that the deque is no longer empty.
- signalNotEmpty() - Method in class com.bluegosling.collections.concurrent.AbstractLockFreeBlockingQueue
-
Signals a waiting thread that the queue is no longer empty.
- signalNotFull() - Method in class com.bluegosling.collections.concurrent.AbstractLockFreeBlockingDeque
-
Signals a waiting thread that the deque is no longer full.
- signalNotFull() - Method in class com.bluegosling.collections.concurrent.AbstractLockFreeBlockingQueue
-
Signals a waiting thread that the queue is no longer full.
- SimpleAtom<T> - Class in com.bluegosling.concurrent.atoms
-
An atom with a volatile value.
- SimpleAtom() - Constructor for class com.bluegosling.concurrent.atoms.SimpleAtom
-
Constructs a new atom with a null
value and no validator.
- SimpleAtom(T) - Constructor for class com.bluegosling.concurrent.atoms.SimpleAtom
-
Constructs a new atom with the specified value and no validator.
- SimpleAtom(T, Predicate<? super T>) - Constructor for class com.bluegosling.concurrent.atoms.SimpleAtom
-
Constructs a new atom with the specified value and the specified validator.
- SimpleBitwiseTrie<K,V> - Class in com.bluegosling.collections.tries
-
A trie structure that most closely resembles a binary tree.
- SimpleBitwiseTrie(BitConverter<? super K>) - Constructor for class com.bluegosling.collections.tries.SimpleBitwiseTrie
-
- SimpleBitwiseTrie(BitConverter<? super K>, Comparator<? super K>) - Constructor for class com.bluegosling.collections.tries.SimpleBitwiseTrie
-
- SimpleFutureVisitor<T> - Class in com.bluegosling.concurrent.fluent
-
A simple visitor implementation that is suitable for sub-classing.
- SimpleFutureVisitor() - Constructor for class com.bluegosling.concurrent.fluent.SimpleFutureVisitor
-
- SimpleFutureVisitor.Builder<T> - Class in com.bluegosling.concurrent.fluent
-
- SimpleStringTrie<V> - Class in com.bluegosling.collections.tries
-
- SimpleStringTrie() - Constructor for class com.bluegosling.collections.tries.SimpleStringTrie
-
- SimpleStringTrie(Locale) - Constructor for class com.bluegosling.collections.tries.SimpleStringTrie
-
- SimpleStringTrie(Collator) - Constructor for class com.bluegosling.collections.tries.SimpleStringTrie
-
- SimpleStringTrie(Map<? extends CharSequence, ? extends V>) - Constructor for class com.bluegosling.collections.tries.SimpleStringTrie
-
- SimpleStringTrie(Locale, Map<? extends CharSequence, ? extends V>) - Constructor for class com.bluegosling.collections.tries.SimpleStringTrie
-
- SimpleStringTrie(Collator, Map<? extends CharSequence, ? extends V>) - Constructor for class com.bluegosling.collections.tries.SimpleStringTrie
-
- SimpleTreiberStack<T> - Class in com.bluegosling.collections.concurrent
-
A very simple, thread-safe stack.
- SimpleTreiberStack() - Constructor for class com.bluegosling.collections.concurrent.SimpleTreiberStack
-
- SimpleTreiberStack(Collection<? extends T>) - Constructor for class com.bluegosling.collections.concurrent.SimpleTreiberStack
-
- Single<A> - Class in com.bluegosling.tuples
-
A tuple with a single item.
- singleton(boolean) - Static method in class com.bluegosling.collections.bits.BitSequences
-
Returns a sequence that contains a single bit.
- size() - Method in class com.bluegosling.collections.AbstractNavigableMap.EntrySet
-
- size() - Method in class com.bluegosling.collections.AbstractNavigableMap.KeySet
-
- size() - Method in class com.bluegosling.collections.AbstractNavigableMap.SubMap
- size() - Method in class com.bluegosling.collections.AbstractNavigableMap.ValueCollection
-
- size() - Method in class com.bluegosling.collections.concurrent.ArrayBlockingDeque
-
- size() - Method in class com.bluegosling.collections.concurrent.ConcurrentSkipListOrderedQueue
-
- size() - Method in class com.bluegosling.collections.concurrent.ConcurrentSortedArraySet
- size() - Method in class com.bluegosling.collections.concurrent.DoubleInstanceLockedTreeMap
-
- size() - Method in class com.bluegosling.collections.concurrent.LockFreeArrayBlockingQueue
-
- size() - Method in class com.bluegosling.collections.concurrent.LockFreeLinkedBlockingDeque
-
- size() - Method in class com.bluegosling.collections.concurrent.LockFreeLinkedBlockingQueue
-
- size() - Method in class com.bluegosling.collections.concurrent.LockFreeSkipListBlockingQueue
-
- size() - Method in class com.bluegosling.collections.concurrent.PersistentListBackedConcurrentList
-
- size() - Method in class com.bluegosling.collections.concurrent.PersistentMapBackedConcurrentMap
-
- size() - Method in class com.bluegosling.collections.concurrent.SimpleTreiberStack
-
- size() - Method in class com.bluegosling.collections.concurrent.TreiberStack
-
- size() - Method in class com.bluegosling.collections.DescendingMap
-
- size() - Method in class com.bluegosling.collections.DescendingSet
-
- size() - Method in class com.bluegosling.collections.FilteringCollection
-
- size() - Method in class com.bluegosling.collections.FilteringMap
-
- size() - Method in class com.bluegosling.collections.immutable.AbstractLinkedImmutableList.LinkedSubList
-
- size() - Method in class com.bluegosling.collections.immutable.AmtPersistentList
-
- size() - Method in class com.bluegosling.collections.immutable.HamtPersistentMap
-
- size() - Method in class com.bluegosling.collections.immutable.LinkedPersistentList
-
- size() - Method in class com.bluegosling.collections.lists.ArrayBackedLinkedList
- size() - Method in class com.bluegosling.collections.lists.TreeList
-
- size() - Method in class com.bluegosling.collections.lists.UnrolledLinkedList
-
- size() - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.RandomAccessSubMap
- size() - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.SubMapByIndices
-
- size() - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.ValueList
-
- size() - Method in class com.bluegosling.collections.maps.HamtMap
-
- size() - Method in class com.bluegosling.collections.maps.LinearHashingMap
-
- size() - Method in class com.bluegosling.collections.maps.SortedArrayMap
-
- size() - Method in class com.bluegosling.collections.maps.WeightBalancedTreeMap
-
- size() - Method in class com.bluegosling.collections.NoCopyGrowableArray
-
- size() - Method in class com.bluegosling.collections.queues.FibonacciHeapOrderedQueue
-
- size() - Method in interface com.bluegosling.collections.queues.PriorityQueue
-
- size() - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- size() - Method in class com.bluegosling.collections.queues.RandomAccessArrayDeque
-
- size() - Method in class com.bluegosling.collections.queues.RandomizedQueue
-
- size() - Method in class com.bluegosling.collections.queues.SetBackedOrderedQueue
-
- size() - Method in class com.bluegosling.collections.queues.SkewHeapOrderedQueue
-
- size() - Method in class com.bluegosling.collections.sets.RandomAccessSetList
-
- size() - Method in class com.bluegosling.collections.sets.SortedArraySet
- size() - Method in interface com.bluegosling.collections.tables.Table2D
-
- size() - Method in interface com.bluegosling.collections.tables.Table3D
-
- size() - Method in interface com.bluegosling.collections.tables.Table4D
-
- size() - Method in interface com.bluegosling.collections.tables.Table5D
-
- size() - Method in class com.bluegosling.collections.TransformingCollection
-
- size() - Method in class com.bluegosling.collections.TransformingMap
-
- size() - Method in class com.bluegosling.collections.tries.ArrayMappedBitwiseTrie
-
- size() - Method in class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- size() - Method in class com.bluegosling.collections.tries.SimpleBitwiseTrie
-
- size() - Method in class com.bluegosling.concurrent.RateLimitedBlockingQueue
-
- size() - Method in class com.bluegosling.tuples.Empty
-
- size() - Method in class com.bluegosling.tuples.NTuple
-
- size() - Method in class com.bluegosling.tuples.Pair
-
- size() - Method in class com.bluegosling.tuples.Quadruple
-
- size() - Method in class com.bluegosling.tuples.Quintuple
-
- size() - Method in class com.bluegosling.tuples.Single
-
- size() - Method in class com.bluegosling.tuples.Triple
-
- size() - Method in interface com.bluegosling.tuples.Tuple
-
Returns the number of items in the tuple.
- SkewHeapOrderedQueue<E> - Class in com.bluegosling.collections.queues
-
- SkewHeapOrderedQueue() - Constructor for class com.bluegosling.collections.queues.SkewHeapOrderedQueue
-
Constructs a new, empty queue that uses elements'
natural order to
determine order.
- SkewHeapOrderedQueue(Comparator<? super E>) - Constructor for class com.bluegosling.collections.queues.SkewHeapOrderedQueue
-
Constructs a new, empty queue that uses the given comparator to determine order.
- SkewHeapOrderedQueue(Collection<? extends E>) - Constructor for class com.bluegosling.collections.queues.SkewHeapOrderedQueue
-
Constructs a new queue that uses elements'
natural order to determine
order and contains the given elements.
- SkewHeapOrderedQueue(Collection<? extends E>, Comparator<? super E>) - Constructor for class com.bluegosling.collections.queues.SkewHeapOrderedQueue
-
Constructs a new queue that uses the given comparator to determine order and contains the
given elements.
- SkewHeapOrderedQueue(OrderedQueue<E>) - Constructor for class com.bluegosling.collections.queues.SkewHeapOrderedQueue
-
Creates a new queue that duplicates the given queue.
- skip(long) - Method in interface com.bluegosling.streams.FluentStream
- skippingInterfaces() - Method in class com.bluegosling.reflect.ClassHierarchyScanner.Builder
-
Indicates that interfaces are skipped during the scan.
- sleep(long, TimeUnit) - Method in interface com.bluegosling.util.Clock
-
- sleep(long, TimeUnit) - Method in enum com.bluegosling.util.SystemClock
-
- sleepUntilMillis(long) - Method in interface com.bluegosling.util.Clock
-
- sleepUntilNanoTime(long) - Method in interface com.bluegosling.util.Clock
-
- sleepUntilNanoTime(long) - Method in class com.bluegosling.util.FakeClock
-
- sleepUntilNanoTime(long) - Method in enum com.bluegosling.util.SystemClock
-
- SlowParallelSort - Class in com.bluegosling.collections.sorting
-
A thought experiment into sorting large lists using multiple CPUs/cores.
- SlowParallelSort() - Constructor for class com.bluegosling.collections.sorting.SlowParallelSort
-
- SmoothSort - Class in com.bluegosling.collections.sorting
-
Sorts arrays and collections using the
Smoothsort algorithm.
- snapshot(Iterable<? extends E>) - Static method in class com.bluegosling.collections.MoreIterables
-
Creates a snapshot of the given iterable.
- snapshot(Iterator<? extends E>) - Static method in class com.bluegosling.collections.MoreIterators
-
Creates a snapshot of the given iterator.
- snapshot() - Method in class com.bluegosling.concurrent.locks.DoubleInstanceLock
-
Returns a snapshot of the data, like for performing expensive work that requires a strongly
consistent view.
- snapshot(Possible<? extends T>) - Static method in interface com.bluegosling.possible.Possible
-
Captures the current possible value into a new immutable possible value.
- sort(Comparator<? super E>) - Method in class com.bluegosling.collections.immutable.AbstractImmutableList
-
Deprecated.
- sort(Comparator<? super E>) - Method in class com.bluegosling.collections.lists.ArrayBackedLinkedList
- sort(List<T>, int) - Static method in class com.bluegosling.collections.sorting.ParallelSort
-
Sorts the specified list using the specified number of threads.
- sort(List<T>, Comparator<? super T>, int) - Static method in class com.bluegosling.collections.sorting.ParallelSort
-
Sorts the specified list using the specified number of threads.
- sort(List<T>, int) - Static method in class com.bluegosling.collections.sorting.ParallelSort2
-
Sorts the specified list using the specified executor for running concurrent sub-tasks.
- sort(List<T>, Comparator<? super T>, int) - Static method in class com.bluegosling.collections.sorting.ParallelSort2
-
Sorts the specified list using the specified executor for running concurrent sub-tasks.
- sort(List<? extends T>, int) - Static method in class com.bluegosling.collections.sorting.SlowParallelSort
-
Sorts the specified list using the specified number of threads.
- sort(List<? extends T>, Comparator<? super T>, int) - Static method in class com.bluegosling.collections.sorting.SlowParallelSort
-
Sorts the specified list using the specified number of threads.
- sort(List<T>) - Static method in class com.bluegosling.collections.sorting.SmoothSort
-
- sort(List<T>, Comparator<? super T>) - Static method in class com.bluegosling.collections.sorting.SmoothSort
-
Sorts the given list according to the specified comparator.
- sort(T[]) - Static method in class com.bluegosling.collections.sorting.SmoothSort
-
- sort(T[], Comparator<? super T>) - Static method in class com.bluegosling.collections.sorting.SmoothSort
-
Sorts the given array according to the specified comparator.
- sorted() - Method in interface com.bluegosling.streams.FluentStream
- sorted(Comparator<? super T>) - Method in interface com.bluegosling.streams.FluentStream
- SortedArrayCompositeTrie<K,C,V> - Class in com.bluegosling.collections.tries
-
- SortedArrayCompositeTrie(Componentizer<? super K, ? extends C>) - Constructor for class com.bluegosling.collections.tries.SortedArrayCompositeTrie
-
- SortedArrayCompositeTrie(Componentizer<? super K, ? extends C>, Comparator<? super C>) - Constructor for class com.bluegosling.collections.tries.SortedArrayCompositeTrie
-
- SortedArrayCompositeTrie(CompositeTrie<K, ? extends C, ? extends V>) - Constructor for class com.bluegosling.collections.tries.SortedArrayCompositeTrie
-
- SortedArrayCompositeTrie(CompositeTrie<K, ? extends C, ? extends V>, Comparator<? super C>) - Constructor for class com.bluegosling.collections.tries.SortedArrayCompositeTrie
-
- SortedArrayCompositeTrie(NavigableCompositeTrie<K, C, ? extends V>) - Constructor for class com.bluegosling.collections.tries.SortedArrayCompositeTrie
-
- SortedArrayCompositeTrie(Componentizer<? super K, ? extends C>, Map<? extends K, ? extends V>) - Constructor for class com.bluegosling.collections.tries.SortedArrayCompositeTrie
-
- SortedArrayCompositeTrie(Componentizer<? super K, ? extends C>, Comparator<? super C>, Map<? extends K, ? extends V>) - Constructor for class com.bluegosling.collections.tries.SortedArrayCompositeTrie
-
- SortedArrayMap<K,V> - Class in com.bluegosling.collections.maps
-
- SortedArrayMap() - Constructor for class com.bluegosling.collections.maps.SortedArrayMap
-
- SortedArrayMap(int) - Constructor for class com.bluegosling.collections.maps.SortedArrayMap
-
- SortedArrayMap(Comparator<? super K>) - Constructor for class com.bluegosling.collections.maps.SortedArrayMap
-
- SortedArrayMap(int, Comparator<? super K>) - Constructor for class com.bluegosling.collections.maps.SortedArrayMap
-
- SortedArrayMap(Map<? extends K, ? extends V>) - Constructor for class com.bluegosling.collections.maps.SortedArrayMap
-
- SortedArrayMap(Map<? extends K, ? extends V>, Comparator<? super K>) - Constructor for class com.bluegosling.collections.maps.SortedArrayMap
-
- SortedArrayMap(SortedMap<K, ? extends V>) - Constructor for class com.bluegosling.collections.maps.SortedArrayMap
-
- SortedArraySequenceTrie<K,V> - Class in com.bluegosling.collections.tries
-
- SortedArraySequenceTrie() - Constructor for class com.bluegosling.collections.tries.SortedArraySequenceTrie
-
- SortedArraySequenceTrie(Comparator<? super K>) - Constructor for class com.bluegosling.collections.tries.SortedArraySequenceTrie
-
- SortedArraySequenceTrie(Map<? extends List<K>, ? extends V>) - Constructor for class com.bluegosling.collections.tries.SortedArraySequenceTrie
-
- SortedArraySequenceTrie(Map<? extends List<K>, ? extends V>, Comparator<? super K>) - Constructor for class com.bluegosling.collections.tries.SortedArraySequenceTrie
-
- SortedArraySet<E> - Class in com.bluegosling.collections.sets
-
An implementation of
NavigableSet
that is optimized for memory efficiency at the cost of
slower mutations.
- SortedArraySet() - Constructor for class com.bluegosling.collections.sets.SortedArraySet
-
Constructs a new empty set.
- SortedArraySet(Comparator<? super E>) - Constructor for class com.bluegosling.collections.sets.SortedArraySet
-
Constructs a new empty set using the specified comparator to sort items within the set.
- SortedArraySet(int) - Constructor for class com.bluegosling.collections.sets.SortedArraySet
-
Constructs a new empty set with an internal array sized as specified.
- SortedArraySet(int, Comparator<? super E>) - Constructor for class com.bluegosling.collections.sets.SortedArraySet
-
Constructs a new empty set.
- SortedArraySet(Collection<? extends E>) - Constructor for class com.bluegosling.collections.sets.SortedArraySet
-
Constructs a new set populated with the items in the given collection.
- SortedArraySet(SortedSet<E>) - Constructor for class com.bluegosling.collections.sets.SortedArraySet
-
Constructs a new set that is a copy of the specified sorted set.
- SortedArraySet(Collection<? extends E>, Comparator<? super E>) - Constructor for class com.bluegosling.collections.sets.SortedArraySet
-
Constructs a new set populated with the items in the given collection.
- SourceDependencyAnalyzer - Class in com.bluegosling.buildgen
-
Performs analysis of all Java source files in a given directory.
- SourceDependencyAnalyzer(File) - Constructor for class com.bluegosling.buildgen.SourceDependencyAnalyzer
-
Constructs an analyzer that will examine the given directory or java source file.
- SourceDependencyAnalyzer(Iterable<? extends File>) - Constructor for class com.bluegosling.buildgen.SourceDependencyAnalyzer
-
Constructs an analyzer that will examine all of the given directories and/or java source
files.
- SourceDependencyAnalyzer(File...) - Constructor for class com.bluegosling.buildgen.SourceDependencyAnalyzer
-
Constructs an analyzer that will examine all of the given directories and/or java source
files.
- SourceDependencyAnalyzer(File, Consumer<File>) - Constructor for class com.bluegosling.buildgen.SourceDependencyAnalyzer
-
Constructs an analyzer that will examine the given directory or java source file and invoke
the given callback as each file is analyzed.
- SourceDependencyAnalyzer(Iterable<? extends File>, Consumer<File>) - Constructor for class com.bluegosling.buildgen.SourceDependencyAnalyzer
-
Constructs an analyzer that will examine all of the given directories and/or java source
files and invoke the given callback as each file is analyzed.
- SourceDependencyAnalyzer(Consumer<File>, File...) - Constructor for class com.bluegosling.buildgen.SourceDependencyAnalyzer
-
Constructs an analyzer that will examine all of the given directories and/or java source
files and invoke the given callback as each file is analyzed.
- SourceDependencyAnalyzer.Results - Class in com.bluegosling.buildgen
-
Analysis over a corpus of Java source code.
- SpinLock - Class in com.bluegosling.concurrent.locks
-
A non-reentrant and unfair lock that "spins" while waiting to lock.
- SpinLock() - Constructor for class com.bluegosling.concurrent.locks.SpinLock
-
Constructs a new spin lock.
- spliterator() - Method in class com.bluegosling.collections.concurrent.TreiberStack
-
- spliterator() - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfDouble
-
- spliterator() - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfInt
-
- spliterator() - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfLong
-
- spliterator() - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfDouble
-
- spliterator() - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfInt
-
- spliterator() - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfLong
-
- SpliteratorCharacteristics - Enum in com.bluegosling.collections
-
- spliteratorCharacteristics(int) - Method in interface com.bluegosling.streams.StreamOperator
-
Adjusts the input characteristics, returning the output characteristics.
- spliteratorEstimatedSize(long) - Method in interface com.bluegosling.streams.StreamOperator
-
Adjusts the estimated size of the data source.
- Stack<T> - Interface in com.bluegosling.collections
-
A simple stack interface.
- start() - Method in class com.bluegosling.collections.AbstractNavigableMap.BaseIteratorImpl
-
Returns the first entry that will be visited during iteration.
- start() - Method in class com.bluegosling.collections.AbstractNavigableMap.DescendingKeyIteratorImpl
-
Returns the first entry that will be visited during iteration.
- start() - Method in class com.bluegosling.generator.Generator
-
Starts generation of a sequence of values.
- start() - Method in class com.bluegosling.generator.UncheckedGenerator
-
- start() - Method in class com.bluegosling.reflect.scanner.PackageScanner
-
Starts the scan.
- startStream() - Method in interface com.bluegosling.streams.StreamOperator
-
Performs initialization needed prior to processing the stream.
- StreamBridge<T,U> - Interface in com.bluegosling.streams
-
A stream bridge provides a non-trivial intermediate operation, or stage, in a stream.
- StreamNode<T,U> - Interface in com.bluegosling.streams
-
A node in a stream pipeline.
- StreamNode.Upstream<T> - Interface in com.bluegosling.streams
-
The interface used to pull data from an upstream node.
- streamOfDouble() - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfDouble
-
- streamOfDouble() - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfDouble
-
- streamOfInt() - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfInt
-
- streamOfInt() - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfInt
-
- streamOfLong() - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfLong
-
- streamOfLong() - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfLong
-
- StreamOperator<T,U> - Interface in com.bluegosling.streams
-
A stream operator provides a simple intermediate operation, or stage, in a stream.
- STRICT_EXCEPTIONS - Static variable in class com.bluegosling.testing.ObjectVerifiers
-
An object that verifies that the test exception has the same class as that of the reference
exception.
- strictExceptionVerifier() - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfiguration
-
Specifies that exceptions should be verified using strict checking.
- strictExceptionVerifier() - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfigurator
-
Specifies that exceptions should be verified using strict checking.
- subList(int, int) - Method in interface com.bluegosling.collections.concurrent.ConcurrentList
-
Returns a view of the portion of this list between the specified indices.
- subList(int, int) - Method in class com.bluegosling.collections.FilteringList
-
- subList(int, int) - Method in class com.bluegosling.collections.immutable.AbstractImmutableList
-
- subList(int, int) - Method in class com.bluegosling.collections.immutable.AbstractLinkedImmutableList.LinkedSubList
-
- subList(int, int) - Method in class com.bluegosling.collections.immutable.AbstractLinkedImmutableList
-
- subList(int, int) - Method in class com.bluegosling.collections.immutable.AmtPersistentList
-
- subList(int, int) - Method in interface com.bluegosling.collections.immutable.ConsList
- subList(int, int) - Method in class com.bluegosling.collections.immutable.LinkedPersistentList
-
- subList(int, int) - Method in interface com.bluegosling.collections.immutable.PersistentList
- subList(int, int) - Method in class com.bluegosling.collections.lists.ArrayBackedLinkedList
- subList(int, int) - Method in class com.bluegosling.collections.lists.AssociativeArrayList
-
- subList(int, int) - Method in interface com.bluegosling.collections.lists.AssociativeList
-
Returns a view of a subset of this list.
- subList(int, int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfBoolean
-
- subList(int, int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfByte
-
- subList(int, int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfChar
-
- subList(int, int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfDouble
-
- subList(int, int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfFloat
-
- subList(int, int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfInt
-
- subList(int, int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfLong
-
- subList(int, int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfShort
-
- subList(int, int) - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList
-
- subList(int, int) - Method in interface com.bluegosling.collections.primitive.PrimitiveList
-
- subList(int, int) - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- subList(int, int) - Method in class com.bluegosling.collections.sets.RandomAccessSetList
-
- subList(int, int) - Method in class com.bluegosling.collections.TransformingList.Bidi
-
- subList(int, int) - Method in class com.bluegosling.collections.TransformingList.ReadOnly
-
- subList(int, int) - Method in class com.bluegosling.collections.TransformingList
-
- subMap(K, boolean, K, boolean) - Method in class com.bluegosling.collections.AbstractNavigableMap
- subMap(K, K) - Method in class com.bluegosling.collections.AbstractNavigableMap
- SubMap(K, BoundType, K, BoundType) - Constructor for class com.bluegosling.collections.AbstractNavigableMap.SubMap
-
Constructs a new sub-map view with the given bounds.
- subMap(K, boolean, K, boolean) - Method in class com.bluegosling.collections.AbstractNavigableMap.SubMap
-
Provides a new sub-map view (sub-sub-map?).
- subMap(K, boolean, K, boolean) - Method in class com.bluegosling.collections.concurrent.DoubleInstanceLockedTreeMap
-
- subMap(K, K) - Method in class com.bluegosling.collections.concurrent.DoubleInstanceLockedTreeMap
-
- subMap(K, boolean, K, boolean) - Method in class com.bluegosling.collections.DescendingMap
-
- subMap(K, K) - Method in class com.bluegosling.collections.DescendingMap
-
- subMap(K, boolean, K, boolean) - Method in class com.bluegosling.collections.FilteringNavigableMap
-
- subMap(K, K) - Method in class com.bluegosling.collections.FilteringNavigableMap
-
- subMap(K, K) - Method in class com.bluegosling.collections.FilteringSortedMap
-
- subMap(K, boolean, K, boolean) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.RandomAccessSubMap
-
Provides a new sub-map view (sub-sub-map?).
- subMap(K, boolean, K, boolean) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap
-
- subMap(K, K) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap
-
- subMap(K, boolean, K, boolean) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.SubMapByIndices
-
- subMap(K, boolean, K, boolean) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.SubMapByIndicesAndByValueBounds
-
- subMap(K, boolean, K, boolean) - Method in class com.bluegosling.collections.maps.DescendingRandomAccessMap
-
- subMap(K, K) - Method in class com.bluegosling.collections.maps.DescendingRandomAccessMap
-
- subMap(K, boolean, K, boolean) - Method in interface com.bluegosling.collections.maps.RandomAccessNavigableMap
- subMap(K, K) - Method in interface com.bluegosling.collections.maps.RandomAccessNavigableMap
- subMap(K, boolean, K, boolean) - Method in class com.bluegosling.collections.maps.WeightBalancedTreeMap
-
- subMap(K, K) - Method in class com.bluegosling.collections.maps.WeightBalancedTreeMap
-
- subMap(K, boolean, K, boolean) - Method in class com.bluegosling.collections.tries.ArrayMappedBitwiseTrie
-
- subMap(K, K) - Method in class com.bluegosling.collections.tries.ArrayMappedBitwiseTrie
-
- subMap(K, boolean, K, boolean) - Method in class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- subMap(K, K) - Method in class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- subMap(K, boolean, K, boolean) - Method in class com.bluegosling.collections.tries.DescendingCompositeTrie
-
- subMap(K, K) - Method in class com.bluegosling.collections.tries.DescendingCompositeTrie
-
- subMap(List<K>, boolean, List<K>, boolean) - Method in class com.bluegosling.collections.tries.DescendingSequenceTrie
-
- subMap(List<K>, List<K>) - Method in class com.bluegosling.collections.tries.DescendingSequenceTrie
-
- subMap(Iterable<K>, boolean, Iterable<K>, boolean) - Method in class com.bluegosling.collections.tries.DescendingSequenceTrie
-
- subMap(Iterable<K>, Iterable<K>) - Method in class com.bluegosling.collections.tries.DescendingSequenceTrie
-
- subMap(K, boolean, K, boolean) - Method in interface com.bluegosling.collections.tries.NavigableCompositeTrie
-
- subMap(K, K) - Method in interface com.bluegosling.collections.tries.NavigableCompositeTrie
-
- subMap(List<K>, boolean, List<K>, boolean) - Method in interface com.bluegosling.collections.tries.NavigableSequenceTrie
-
- subMap(List<K>, List<K>) - Method in interface com.bluegosling.collections.tries.NavigableSequenceTrie
-
- subMap(Iterable<K>, boolean, Iterable<K>, boolean) - Method in interface com.bluegosling.collections.tries.NavigableSequenceTrie
-
- subMap(Iterable<K>, Iterable<K>) - Method in interface com.bluegosling.collections.tries.NavigableSequenceTrie
-
- subMap(K, boolean, K, boolean) - Method in class com.bluegosling.collections.tries.SimpleBitwiseTrie
-
- subMap(K, K) - Method in class com.bluegosling.collections.tries.SimpleBitwiseTrie
-
- subMapByIndices(int, int) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.RandomAccessSubMap
-
- subMapByIndices(int, int) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap
-
- subMapByIndices(int, int) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.SubMapByIndices
-
- subMapByIndices(int, int) - Method in class com.bluegosling.collections.maps.DescendingRandomAccessMap
-
- subMapByIndices(int, int) - Method in interface com.bluegosling.collections.maps.RandomAccessNavigableMap
-
Returns a view of a region of this map.
- subMapByIndices(int, int) - Method in class com.bluegosling.collections.maps.WeightBalancedTreeMap
-
- submit(Callable<T>) - Method in interface com.bluegosling.concurrent.executors.CompletableExecutorService
- submit(Runnable, T) - Method in interface com.bluegosling.concurrent.executors.CompletableExecutorService
- submit(Runnable) - Method in interface com.bluegosling.concurrent.executors.CompletableExecutorService
- submit(K, Runnable) - Method in interface com.bluegosling.concurrent.executors.SerializingExecutor
-
Executes the given task, associated with the given key, and returns a future that will
complete when the task completes or is cancelled.
- submit(K, Runnable, T) - Method in interface com.bluegosling.concurrent.executors.SerializingExecutor
-
Executes the given task, associated with the given key, and returns a future that will
complete when the task completes or is cancelled.
- submit(K, Callable<T>) - Method in interface com.bluegosling.concurrent.executors.SerializingExecutor
-
Executes the given task, associated with the given key, and returns a future that will
complete when the task completes or is cancelled.
- submit(Callable<T>) - Method in class com.bluegosling.concurrent.executors.ThreadLimitingExecutorService
-
- submit(Runnable, T) - Method in class com.bluegosling.concurrent.executors.ThreadLimitingExecutorService
-
- submit(Runnable) - Method in class com.bluegosling.concurrent.executors.ThreadLimitingExecutorService
-
- submit(Callable<T>) - Method in class com.bluegosling.concurrent.executors.WrappingExecutorService
-
- submit(Runnable, T) - Method in class com.bluegosling.concurrent.executors.WrappingExecutorService
-
- submit(Runnable) - Method in class com.bluegosling.concurrent.executors.WrappingExecutorService
-
- submit(Callable<T>) - Method in interface com.bluegosling.concurrent.fluent.FluentExecutorService
- submit(Runnable, T) - Method in interface com.bluegosling.concurrent.fluent.FluentExecutorService
- submit(Runnable) - Method in interface com.bluegosling.concurrent.fluent.FluentExecutorService
- submit(Callable<V>) - Method in class com.bluegosling.concurrent.scheduler.ScheduledTaskManager
- submit(Runnable) - Method in class com.bluegosling.concurrent.scheduler.ScheduledTaskManager
- submit(Runnable, V) - Method in class com.bluegosling.concurrent.scheduler.ScheduledTaskManager
- submitTimeMillis() - Method in interface com.bluegosling.concurrent.scheduler.ScheduledTaskDefinition
-
Returns the timestamp, in milliseconds, when this task definition was submitted
to a
ScheduledTaskManager
.
- subSequence(int, int) - Method in interface com.bluegosling.collections.bits.BitSequence
-
Returns a view of a portion of this sequence.
- subSet(K, boolean, K, boolean) - Method in class com.bluegosling.collections.AbstractNavigableMap.KeySet
-
- subSet(K, K) - Method in class com.bluegosling.collections.AbstractNavigableMap.KeySet
-
- subSet(E, E) - Method in class com.bluegosling.collections.concurrent.ConcurrentSortedArraySet
- subSet(E, boolean, E, boolean) - Method in class com.bluegosling.collections.concurrent.ConcurrentSortedArraySet
- subSet(E, E) - Method in class com.bluegosling.collections.DescendingSet
-
- subSet(E, boolean, E, boolean) - Method in class com.bluegosling.collections.DescendingSet
-
- subSet(E, boolean, E, boolean) - Method in class com.bluegosling.collections.FilteringNavigableSet
-
- subSet(E, E) - Method in class com.bluegosling.collections.FilteringNavigableSet
-
- subSet(E, E) - Method in class com.bluegosling.collections.FilteringSortedSet
-
- subSet(K, boolean, K, boolean) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.RandomAccessKeySet
-
- subSet(K, K) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.RandomAccessKeySet
-
- subSet(E, E) - Method in class com.bluegosling.collections.sets.DescendingRandomAccessSet
-
- subSet(E, boolean, E, boolean) - Method in class com.bluegosling.collections.sets.DescendingRandomAccessSet
-
- subSet(E, boolean, E, boolean) - Method in interface com.bluegosling.collections.sets.RandomAccessNavigableSet
- subSet(E, E) - Method in interface com.bluegosling.collections.sets.RandomAccessNavigableSet
- subSet(E, E) - Method in class com.bluegosling.collections.sets.SortedArraySet
- subSet(E, boolean, E, boolean) - Method in class com.bluegosling.collections.sets.SortedArraySet
- subSetByIndices(int, int) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.RandomAccessEntrySet
-
- subSetByIndices(int, int) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.RandomAccessKeySet
-
- subSetByIndices(int, int) - Method in class com.bluegosling.collections.sets.DescendingRandomAccessSet
-
- subSetByIndices(int, int) - Method in interface com.bluegosling.collections.sets.RandomAccessNavigableSet
-
Returns the sub-set of elements between the specified starting index (inclusive) and ending
index (exclusive).
- subSetByIndices(int, int) - Method in interface com.bluegosling.collections.sets.RandomAccessSet
-
Returns the sub-set of elements between the specified starting index (inclusive) and ending
index (exclusive).
- subSetByIndices(int, int) - Method in class com.bluegosling.collections.sets.TransformingRandomAccessSet.Bidi
-
- subSetByIndices(int, int) - Method in class com.bluegosling.collections.sets.TransformingRandomAccessSet.ReadOnly
-
- subSetByIndices(int, int) - Method in class com.bluegosling.collections.sets.TransformingRandomAccessSet
-
- success() - Method in class com.bluegosling.reflect.blaster.Blaster.Result
-
Returns true if the method invocation was successful (e.g.
- successCount() - Method in interface com.bluegosling.concurrent.scheduler.ScheduledTaskDefinition
-
Returns the number of times that tasks have succeeded for this task
definition.
- successful(T) - Method in interface com.bluegosling.concurrent.fluent.FutureVisitor
-
Invoked when the visited future completed successfully.
- successful(T) - Method in class com.bluegosling.concurrent.fluent.SimpleFutureVisitor
-
Invoked when the visited future completed successfully.
- successfulOnly(Collection<? extends Result<? extends T, ?>>) - Static method in class com.bluegosling.result.Result
-
Returns a list of the given results' values, omitting values for any failed results.
- Suppliers - Class in com.bluegosling.function
-
Utility methods for constructing and using
Supplier
s.
- SupportedAnnotationClasses - Annotation Type in com.bluegosling.apt
-
An annotation used to indicate what annotation types an annotation processor supports.
- swap() - Method in class com.bluegosling.choice.Either
-
Returns a new object with the same choice present as this object, but with positions swapped.
- swap() - Method in class com.bluegosling.choice.Union2
-
- swap() - Method in class com.bluegosling.tuples.Pair
-
- synchronizedTable(Table2D<R, C, V>) - Static method in interface com.bluegosling.collections.tables.Table2D
-
- synchronizedTable(Table3D<P, R, C, V>) - Static method in interface com.bluegosling.collections.tables.Table3D
-
- SynchronousAtom<T> - Interface in com.bluegosling.concurrent.atoms
-
An atom whose value is modified synchronously and immediately.
- SystemClock - Enum in com.bluegosling.util
-
- Table2D<R,C,V> - Interface in com.bluegosling.collections.tables
-
- Table2D.Cell2D<R,C,V> - Interface in com.bluegosling.collections.tables
-
- Table3D<P,R,C,V> - Interface in com.bluegosling.collections.tables
-
- Table3D.Cell3D<P,R,C,V> - Interface in com.bluegosling.collections.tables
-
- Table4D<S,P,R,C,V> - Interface in com.bluegosling.collections.tables
-
- Table4D.Cell4D<S,P,R,C,V> - Interface in com.bluegosling.collections.tables
-
- Table5D<L,S,P,R,C,V> - Interface in com.bluegosling.collections.tables
-
- Table5D.Cell5D<L,S,P,R,C,V> - Interface in com.bluegosling.collections.tables
-
- TableMapView<K,V> - Interface in com.bluegosling.collections.tables
-
A view of data in a table as a
Map
.
- tailList(int) - Method in interface com.bluegosling.collections.concurrent.ConcurrentList
-
Returns a view of the tail of this list.
- tailMap(K, boolean) - Method in class com.bluegosling.collections.AbstractNavigableMap.SubMap
-
Provides a new view of the tail of this sub-map.
- tailMap(K, boolean) - Method in class com.bluegosling.collections.AbstractNavigableMap
- tailMap(K) - Method in class com.bluegosling.collections.AbstractNavigableMap
- tailMap(K, boolean) - Method in class com.bluegosling.collections.concurrent.DoubleInstanceLockedTreeMap
-
- tailMap(K) - Method in class com.bluegosling.collections.concurrent.DoubleInstanceLockedTreeMap
-
- tailMap(K, boolean) - Method in class com.bluegosling.collections.DescendingMap
-
- tailMap(K) - Method in class com.bluegosling.collections.DescendingMap
-
- tailMap(K, boolean) - Method in class com.bluegosling.collections.FilteringNavigableMap
-
- tailMap(K) - Method in class com.bluegosling.collections.FilteringNavigableMap
-
- tailMap(K) - Method in class com.bluegosling.collections.FilteringSortedMap
-
- tailMap(K, boolean) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.RandomAccessSubMap
-
Provides a new view of the tail of this sub-map.
- tailMap(K, boolean) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.SubMapByIndices
-
- tailMap(K, boolean) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.SubMapByIndicesAndByValueBounds
-
- tailMap(K, boolean) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap
-
- tailMap(K) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap
-
- tailMap(K, boolean) - Method in class com.bluegosling.collections.maps.DescendingRandomAccessMap
-
- tailMap(K) - Method in class com.bluegosling.collections.maps.DescendingRandomAccessMap
-
- tailMap(K, boolean) - Method in interface com.bluegosling.collections.maps.RandomAccessNavigableMap
- tailMap(K) - Method in interface com.bluegosling.collections.maps.RandomAccessNavigableMap
- tailMap(K, boolean) - Method in class com.bluegosling.collections.maps.WeightBalancedTreeMap
-
- tailMap(K) - Method in class com.bluegosling.collections.maps.WeightBalancedTreeMap
-
- tailMap(K, boolean) - Method in class com.bluegosling.collections.tries.ArrayMappedBitwiseTrie
-
- tailMap(K) - Method in class com.bluegosling.collections.tries.ArrayMappedBitwiseTrie
-
- tailMap(K, boolean) - Method in class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- tailMap(K) - Method in class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- tailMap(K, boolean) - Method in class com.bluegosling.collections.tries.DescendingCompositeTrie
-
- tailMap(K) - Method in class com.bluegosling.collections.tries.DescendingCompositeTrie
-
- tailMap(List<K>, boolean) - Method in class com.bluegosling.collections.tries.DescendingSequenceTrie
-
- tailMap(List<K>) - Method in class com.bluegosling.collections.tries.DescendingSequenceTrie
-
- tailMap(Iterable<K>, boolean) - Method in class com.bluegosling.collections.tries.DescendingSequenceTrie
-
- tailMap(Iterable<K>) - Method in class com.bluegosling.collections.tries.DescendingSequenceTrie
-
- tailMap(K, boolean) - Method in interface com.bluegosling.collections.tries.NavigableCompositeTrie
-
- tailMap(K) - Method in interface com.bluegosling.collections.tries.NavigableCompositeTrie
-
- tailMap(List<K>, boolean) - Method in interface com.bluegosling.collections.tries.NavigableSequenceTrie
-
- tailMap(List<K>) - Method in interface com.bluegosling.collections.tries.NavigableSequenceTrie
-
- tailMap(Iterable<K>, boolean) - Method in interface com.bluegosling.collections.tries.NavigableSequenceTrie
-
- tailMap(Iterable<K>) - Method in interface com.bluegosling.collections.tries.NavigableSequenceTrie
-
- tailMap(K, boolean) - Method in class com.bluegosling.collections.tries.SimpleBitwiseTrie
-
- tailMap(K) - Method in class com.bluegosling.collections.tries.SimpleBitwiseTrie
-
- tailSet(K, boolean) - Method in class com.bluegosling.collections.AbstractNavigableMap.KeySet
-
- tailSet(K) - Method in class com.bluegosling.collections.AbstractNavigableMap.KeySet
-
- tailSet(E) - Method in class com.bluegosling.collections.concurrent.ConcurrentSortedArraySet
- tailSet(E, boolean) - Method in class com.bluegosling.collections.concurrent.ConcurrentSortedArraySet
- tailSet(E) - Method in class com.bluegosling.collections.DescendingSet
-
- tailSet(E, boolean) - Method in class com.bluegosling.collections.DescendingSet
-
- tailSet(E, boolean) - Method in class com.bluegosling.collections.FilteringNavigableSet
-
- tailSet(E) - Method in class com.bluegosling.collections.FilteringNavigableSet
-
- tailSet(E) - Method in class com.bluegosling.collections.FilteringSortedSet
-
- tailSet(K, boolean) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.RandomAccessKeySet
-
- tailSet(K) - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.RandomAccessKeySet
-
- tailSet(E) - Method in class com.bluegosling.collections.sets.DescendingRandomAccessSet
-
- tailSet(E, boolean) - Method in class com.bluegosling.collections.sets.DescendingRandomAccessSet
-
- tailSet(E, boolean) - Method in interface com.bluegosling.collections.sets.RandomAccessNavigableSet
- tailSet(E) - Method in interface com.bluegosling.collections.sets.RandomAccessNavigableSet
- tailSet(E) - Method in class com.bluegosling.collections.sets.SortedArraySet
- tailSet(E, boolean) - Method in class com.bluegosling.collections.sets.SortedArraySet
- take() - Method in class com.bluegosling.collections.concurrent.AbstractLockFreeBlockingDeque
-
- take() - Method in class com.bluegosling.collections.concurrent.AbstractLockFreeBlockingOrderedDeque
-
- take() - Method in class com.bluegosling.collections.concurrent.AbstractLockFreeBlockingQueue
-
- take() - Method in interface com.bluegosling.collections.concurrent.BlockingOrderedDeque
-
- take() - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- take() - Method in class com.bluegosling.concurrent.RateLimitedBlockingQueue
-
- takeAll() - Method in class com.bluegosling.concurrent.RateLimiter
-
Takes all permits currently available, returning the count of taken permits.
- takeFirst() - Method in class com.bluegosling.collections.concurrent.AbstractLockFreeBlockingDeque
-
- takeFirst() - Method in class com.bluegosling.collections.concurrent.AbstractLockFreeBlockingOrderedDeque
-
- takeFirst() - Method in interface com.bluegosling.collections.concurrent.BlockingOrderedDeque
-
- takeFirst() - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- takeLast() - Method in class com.bluegosling.collections.concurrent.AbstractLockFreeBlockingDeque
-
- takeLast() - Method in class com.bluegosling.collections.concurrent.AbstractLockFreeBlockingOrderedDeque
-
- takeLast() - Method in interface com.bluegosling.collections.concurrent.BlockingOrderedDeque
-
- takeLast() - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- task() - Method in interface com.bluegosling.concurrent.scheduler.TaskDefinition
-
Returns the implementation of the task.
- taskCompleted(ScheduledTask<? extends V>) - Method in interface com.bluegosling.concurrent.scheduler.ScheduledTaskListener
-
Called when the specified task completes (either normally or abnormally).
- taskDefinition() - Method in interface com.bluegosling.concurrent.scheduler.RepeatingScheduledTask
-
Returns the task definition for which this task was created.
- taskDefinition() - Method in interface com.bluegosling.concurrent.scheduler.ScheduledTask
-
Returns the task definition for which this task was created.
- TaskDefinition<V> - Interface in com.bluegosling.concurrent.scheduler
-
- TaskDefinition.Builder<V> - Class in com.bluegosling.concurrent.scheduler
-
- TaskImplementation<V> - Class in com.bluegosling.concurrent.scheduler
-
- TaskImplementation.Visitor<R,V> - Interface in com.bluegosling.concurrent.scheduler
-
A visitor, for accessing the underlying task implementation using the visitor pattern.
- tentativeRemainingCapacity() - Method in class com.bluegosling.collections.concurrent.AbstractLockFreeBlockingDeque
-
Returns the tentative remaining capacity in the deque.
- tentativeRemainingCapacity() - Method in class com.bluegosling.collections.concurrent.AbstractLockFreeBlockingQueue
-
Returns the tentative remaining capacity in the queue.
- tentativeRemainingCapacity() - Method in class com.bluegosling.collections.concurrent.LockFreeArrayBlockingQueue
-
- ternary() - Static method in class com.bluegosling.function.Functions
-
- test(boolean) - Method in interface com.bluegosling.function.BooleanPredicate
-
Evaluates this predicate on the given argument.
- test(byte) - Method in interface com.bluegosling.function.BytePredicate
-
Evaluates this predicate on the given argument.
- test(char) - Method in interface com.bluegosling.function.CharPredicate
-
Evaluates this predicate on the given argument.
- test(float) - Method in interface com.bluegosling.function.FloatPredicate
-
Evaluates this predicate on the given argument.
- test(short) - Method in interface com.bluegosling.function.ShortPredicate
-
Evaluates this predicate on the given argument.
- test(T, U, V) - Method in interface com.bluegosling.function.TriPredicate
-
Tests three objects.
- test(BiPredicate<? super A, ? super B>) - Method in class com.bluegosling.tuples.Pair
-
Tests the pair of values using the specified predicate.
- test(Predicate<? super A>) - Method in class com.bluegosling.tuples.Single
-
Tests the contained value using the specified predicate.
- test(TriPredicate<? super A, ? super B, ? super C>) - Method in class com.bluegosling.tuples.Triple
-
Tests the trio of values using the specified predicate.
- TestEnvironment - Class in com.bluegosling.apt.testing
-
Information about the current test, processing, and round environments.
- TestJavaFileManager - Class in com.bluegosling.apt.testing
-
An in-memory file manager.
- TestJavaFileManager(JavaFileManager) - Constructor for class com.bluegosling.apt.testing.TestJavaFileManager
-
Constructs a new file manager.
- TestJavaFileManager(JavaFileManager, ClassLoader) - Constructor for class com.bluegosling.apt.testing.TestJavaFileManager
-
Constructs a new file manager.
- TestJavaFileObject - Class in com.bluegosling.apt.testing
-
A simple in-memory file.
- ThreadFactories - Class in com.bluegosling.concurrent
-
Utility methods for creating thread factories.
- ThreadLimitingExecutorService - Class in com.bluegosling.concurrent.executors
-
An executor service that uses threads from another executor but imposes limits on parallelism
and the number of threads used for its tasks.
- ThreadLimitingExecutorService(Executor, int) - Constructor for class com.bluegosling.concurrent.executors.ThreadLimitingExecutorService
-
- ThreadLocalAtom<T> - Class in com.bluegosling.concurrent.atoms
-
An atom whose values are in thread-local storage.
- ThreadLocalAtom() - Constructor for class com.bluegosling.concurrent.atoms.ThreadLocalAtom
-
Constructs a new thread-local atom with a null
value and no validator.
- ThreadLocalAtom(T) - Constructor for class com.bluegosling.concurrent.atoms.ThreadLocalAtom
-
Constructs a new thread-local atom with the specified value and no validator.
- ThreadLocalAtom(T, Predicate<? super T>) - Constructor for class com.bluegosling.concurrent.atoms.ThreadLocalAtom
-
Constructs a new thread-local atom with the specified value and the specified validator.
- Throwables - Class in com.bluegosling.util
-
- Throwables() - Constructor for class com.bluegosling.util.Throwables
-
- throwOnAnyException() - Method in class com.bluegosling.reflect.blaster.Blaster
-
- throwOnNullTarget() - Method in class com.bluegosling.reflect.blaster.Blaster
-
- times(long) - Method in class com.bluegosling.concurrent.Duration
-
Returns this duration multiplied by the specified number of times.
- to(TimeUnit) - Method in class com.bluegosling.concurrent.Duration
-
Returns the length of this duration in the specified unit.
- to(Class<O>) - Method in class com.bluegosling.reflect.caster.Caster.Builder
-
Creates a builder with the same properties as this one except that it creates casters that
cast to a different target interface.
- to(Class<O>) - Method in class com.bluegosling.reflect.caster.Caster
-
Creates a caster with the same properties as this one except that it casts to a different
target interface.
- toArray(Collection<?>) - Static method in class com.bluegosling.collections.CollectionUtils
-
- toArray(Collection<?>, T[]) - Static method in class com.bluegosling.collections.CollectionUtils
-
- toArray() - Method in class com.bluegosling.collections.concurrent.ConcurrentSortedArraySet
- toArray(T[]) - Method in class com.bluegosling.collections.concurrent.ConcurrentSortedArraySet
- toArray() - Method in class com.bluegosling.collections.concurrent.PersistentListBackedConcurrentList
-
- toArray(T[]) - Method in class com.bluegosling.collections.concurrent.PersistentListBackedConcurrentList
-
- toArray() - Method in class com.bluegosling.collections.DescendingSet
-
- toArray(T[]) - Method in class com.bluegosling.collections.DescendingSet
-
- toArray() - Method in class com.bluegosling.collections.FilteringCollection
-
- toArray(T[]) - Method in class com.bluegosling.collections.FilteringCollection
-
- toArray() - Method in class com.bluegosling.collections.lists.ArrayBackedLinkedList
- toArray(T[]) - Method in class com.bluegosling.collections.lists.ArrayBackedLinkedList
- toArray(Iterable<?>) - Static method in class com.bluegosling.collections.MoreIterables
-
Creates a snapshot of the given iterable as an array.
- toArray(Iterable<?>, T[]) - Static method in class com.bluegosling.collections.MoreIterables
-
Creates a snapshot of the given iterable as an array of the given type.
- toArray(Iterator<?>) - Static method in class com.bluegosling.collections.MoreIterators
-
Creates a snapshot of the given iterator as an array.
- toArray(Iterator<?>, T[]) - Static method in class com.bluegosling.collections.MoreIterators
-
Creates a snapshot of the given iterator as an array of the given type.
- toArray() - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- toArray(T[]) - Method in class com.bluegosling.collections.queues.RandomAccessArrayBlockingDeque
-
- toArray() - Method in class com.bluegosling.collections.queues.RandomAccessArrayDeque
-
- toArray(T[]) - Method in class com.bluegosling.collections.queues.RandomAccessArrayDeque
-
- toArray() - Method in class com.bluegosling.collections.sets.RandomAccessSetList
-
- toArray(T[]) - Method in class com.bluegosling.collections.sets.RandomAccessSetList
-
- toArray() - Method in class com.bluegosling.collections.sets.SortedArraySet
- toArray(T[]) - Method in class com.bluegosling.collections.sets.SortedArraySet
- toArray() - Method in class com.bluegosling.collections.TransformingCollection
-
- toArray(T[]) - Method in class com.bluegosling.collections.TransformingCollection
-
- toArray() - Method in class com.bluegosling.tuples.Empty
-
- toArray(T[]) - Method in class com.bluegosling.tuples.Empty
-
- toArray() - Method in class com.bluegosling.tuples.NTuple
-
- toArray(T[]) - Method in class com.bluegosling.tuples.NTuple
-
- toArray() - Method in class com.bluegosling.tuples.Pair
-
- toArray(T[]) - Method in class com.bluegosling.tuples.Pair
-
- toArray() - Method in class com.bluegosling.tuples.Quadruple
-
- toArray(T[]) - Method in class com.bluegosling.tuples.Quadruple
-
- toArray() - Method in class com.bluegosling.tuples.Quintuple
-
- toArray(T[]) - Method in class com.bluegosling.tuples.Quintuple
-
- toArray() - Method in class com.bluegosling.tuples.Single
-
- toArray(T[]) - Method in class com.bluegosling.tuples.Single
-
- toArray() - Method in class com.bluegosling.tuples.Triple
-
- toArray(T[]) - Method in class com.bluegosling.tuples.Triple
-
- toArray() - Method in interface com.bluegosling.tuples.Tuple
-
Returns an array of the items in this tuple.
- toArray(T[]) - Method in interface com.bluegosling.tuples.Tuple
-
Returns an array of the items in this tuple.
- toBitfield(EnumSet<ArModifier>) - Static method in enum com.bluegosling.apt.reflect.ArModifier
-
Converts the specified set of modifiers to an integer bitfield.
- toBits(BitSequence) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- toBitTuples(BitSequence, int) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- toBitTuples(BitSequence, int, BitSequence.BitOrder) - Static method in class com.bluegosling.collections.bits.BitSequences
-
- toBooleanArray() - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfBoolean
-
- toBooleanArray() - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfBoolean
-
- toByteArray() - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfByte
-
- toByteArray() - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfByte
-
- toBytes(BitSequence) - Static method in class com.bluegosling.collections.bits.BitSequences
-
Returns a byte array that represents the specified sequence of bits.
- toBytes(BitSequence, BitSequence.BitOrder) - Static method in class com.bluegosling.collections.bits.BitSequences
-
Returns a byte array that represents the specified sequence of bits.
- toCharArray() - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfChar
-
- toCharArray() - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfChar
-
- toChars(BitSequence) - Static method in class com.bluegosling.collections.bits.BitSequences
-
Returns a char array that represents the specified sequence of bits.
- toChars(BitSequence, BitSequence.BitOrder) - Static method in class com.bluegosling.collections.bits.BitSequences
-
Returns a char array that represents the specified sequence of bits.
- toChars(BitSequence, Charset) - Static method in class com.bluegosling.collections.bits.BitSequences
-
Returns a char array that represents the specified sequence of bits.
- toChars(BitSequence, BitSequence.BitOrder, Charset) - Static method in class com.bluegosling.collections.bits.BitSequences
-
Returns a char array that represents the specified sequence of bits.
- toCompletableFuture() - Method in class com.bluegosling.concurrent.futures.ReadOnlyCompletableFuture
-
Returns a new
CompletableFuture
that completes with the same value or cause of failure
as this future.
- toDays() - Method in class com.bluegosling.concurrent.Duration
-
Returns the length of this duration in days.
- ToDo - Annotation Type in com.bluegosling.util
-
Describes a "TODO" task for the annotated element.
- ToDos - Annotation Type in com.bluegosling.util
-
A container for one or more "TODO" annotations.
- toDoubleArray() - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfDouble
-
- toDoubleArray() - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfDouble
-
- toFloatArray() - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfFloat
-
- toFloatArray() - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfFloat
-
- toGraph() - Method in class com.bluegosling.graph.Node
-
Returns a graph consisting of this node and its transitive dependencies.
- toHours() - Method in class com.bluegosling.concurrent.Duration
-
Returns the length of this duration in hours.
- toInt() - Method in enum com.bluegosling.collections.SpliteratorCharacteristics
-
Returns the value of this characteristic as an int.
- toInt(Iterable<SpliteratorCharacteristics>) - Static method in enum com.bluegosling.collections.SpliteratorCharacteristics
-
Returns the int bitmask value for the given set of characteristics.
- toIntArray() - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfInt
-
- toIntArray() - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfInt
-
- toInts(BitSequence) - Static method in class com.bluegosling.collections.bits.BitSequences
-
Returns an int array that represents the specified sequence of bits.
- toInts(BitSequence, BitSequence.BitOrder) - Static method in class com.bluegosling.collections.bits.BitSequences
-
Returns an int array that represents the specified sequence of bits.
- toLongArray() - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfLong
-
- toLongArray() - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfLong
-
- toLongs(BitSequence) - Static method in class com.bluegosling.collections.bits.BitSequences
-
Returns a long array that represents the specified sequence of bits.
- toLongs(BitSequence, BitSequence.BitOrder) - Static method in class com.bluegosling.collections.bits.BitSequences
-
Returns a long array that represents the specified sequence of bits.
- toMap(Annotation) - Static method in class com.bluegosling.reflect.Annotations
-
Returns a map of values that correspond to the annotation's methods.
- toMap(Annotation, boolean) - Static method in class com.bluegosling.reflect.Annotations
-
- toMap(Annotation, Predicate<? super Method>) - Static method in class com.bluegosling.reflect.Annotations
-
Returns a map of values that correspond to the annotation's methods that match the specified
predicate.
- toMap(Annotation, boolean, Predicate<? super Method>) - Static method in class com.bluegosling.reflect.Annotations
-
Returns a map of values that correspond to the annotation's methods that match the specified
predicate, optionally including the
Annotation.annotationType()
.
- toMicros() - Method in class com.bluegosling.concurrent.Duration
-
Returns the length of this duration in microseconds.
- toMillis() - Method in class com.bluegosling.concurrent.Duration
-
Returns the length of this duration in milliseconds.
- toMinutes() - Method in class com.bluegosling.concurrent.Duration
-
Returns the length of this duration in minutes.
- toNanos() - Method in class com.bluegosling.concurrent.Duration
-
Returns the length of this duration in nanoseconds.
- TooManyMatchesException - Exception in com.bluegosling.testing
-
Thrown when a query for a method signature isn't specific enough.
- TooManyMatchesException(String, int) - Constructor for exception com.bluegosling.testing.TooManyMatchesException
-
Constructs a new exception.
- toPossible(Optional<T>) - Static method in class com.bluegosling.possible.Optionals
-
- toSeconds() - Method in class com.bluegosling.concurrent.Duration
-
Returns the length of this duration in seconds.
- toShortArray() - Method in class com.bluegosling.collections.primitive.AbstractPrimitiveList.OfShort
-
- toShortArray() - Method in interface com.bluegosling.collections.primitive.PrimitiveList.OfShort
-
- toShorts(BitSequence) - Static method in class com.bluegosling.collections.bits.BitSequences
-
Returns a short array that represents the specified sequence of bits.
- toShorts(BitSequence, BitSequence.BitOrder) - Static method in class com.bluegosling.collections.bits.BitSequences
-
Returns a short array that represents the specified sequence of bits.
- toString() - Method in class com.bluegosling.apt.reflect.ArAnnotation
-
- toString() - Method in class com.bluegosling.apt.reflect.ArArrayType
-
- toString() - Method in class com.bluegosling.apt.reflect.ArClass
-
- toString() - Method in class com.bluegosling.apt.reflect.ArDeclaredType
-
- toString() - Method in class com.bluegosling.apt.reflect.ArField
-
- toString() - Method in class com.bluegosling.apt.reflect.ArGenericMethodSignature
-
- toString() - Method in class com.bluegosling.apt.reflect.ArMethodSignature
-
- toString() - Method in class com.bluegosling.apt.reflect.ArPackage
-
- toString() - Method in class com.bluegosling.apt.reflect.ArParameter
-
- toString() - Method in class com.bluegosling.apt.reflect.ArPrimitiveType
-
- toString() - Method in class com.bluegosling.apt.reflect.ArType
-
Returns a string representation of this type, suitable for constructing a representation of
this type that could be used in Java source code.
- toString() - Method in class com.bluegosling.apt.reflect.ArTypeParameter
-
- toString() - Method in class com.bluegosling.apt.reflect.ArTypeVariable
-
- toString() - Method in class com.bluegosling.apt.reflect.ArWildcardType
-
- toString() - Method in class com.bluegosling.buildgen.JavaClass
-
- toString() - Method in class com.bluegosling.buildgen.JavaPackage
-
- toString() - Method in class com.bluegosling.choice.AnyOfFive
-
- toString() - Method in class com.bluegosling.choice.AnyOfFour
-
- toString() - Method in class com.bluegosling.choice.AnyOfThree
-
- toString() - Method in class com.bluegosling.choice.Either
-
- toString() - Method in class com.bluegosling.choice.Union2
-
- toString() - Method in class com.bluegosling.choice.Union3
-
- toString() - Method in class com.bluegosling.choice.Union4
-
- toString() - Method in class com.bluegosling.choice.Union5
-
- toString() - Method in class com.bluegosling.collections.AbstractNavigableMap
-
- toString() - Method in class com.bluegosling.collections.CircularBuffer
-
- toString(Iterable<?>) - Static method in class com.bluegosling.collections.CollectionUtils
-
Constructs a string representation of the specified collection.
- toString() - Method in class com.bluegosling.collections.concurrent.ConcurrentSortedArraySet
-
- toString() - Method in class com.bluegosling.collections.concurrent.DoubleInstanceLockedTreeMap
-
- toString() - Method in class com.bluegosling.collections.concurrent.PersistentMapBackedConcurrentMap
-
- toString() - Method in class com.bluegosling.collections.DescendingMap
-
- toString() - Method in class com.bluegosling.collections.DescendingSet
-
- toString() - Method in class com.bluegosling.collections.FilteringCollection
-
- toString() - Method in class com.bluegosling.collections.FilteringMap
-
- toString() - Method in class com.bluegosling.collections.maps.WeightBalancedTreeMap
-
- toString(Map<K, V>) - Static method in class com.bluegosling.collections.MapUtils
-
- toString(Map.Entry<?, ?>) - Static method in class com.bluegosling.collections.MapUtils
-
- toString() - Method in class com.bluegosling.collections.sets.RandomAccessSetList
-
- toString() - Method in class com.bluegosling.collections.sets.SortedArraySet
- toString() - Method in class com.bluegosling.collections.TransformingCollection
-
- toString() - Method in class com.bluegosling.collections.TransformingMap
-
- toString() - Method in class com.bluegosling.collections.TransformingMapEntry
-
- toString() - Method in class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- toString() - Method in class com.bluegosling.concurrent.AbstractQueuedReferenceSynchronizer
-
Returns a string identifying this synchronizer, as well as its state.
- toString() - Method in class com.bluegosling.concurrent.contended.ContendedBoolean
-
Returns the String representation of the current value.
- toString() - Method in class com.bluegosling.concurrent.contended.ContendedInteger
-
Returns the String representation of the current value.
- toString() - Method in class com.bluegosling.concurrent.contended.ContendedLong
-
Returns the String representation of the current value.
- toString() - Method in class com.bluegosling.concurrent.contended.ContendedReference
-
Returns the String representation of the current value.
- toString() - Method in class com.bluegosling.concurrent.Duration
-
- toString() - Method in class com.bluegosling.concurrent.UpAndDownLatch
-
- toString() - Method in class com.bluegosling.graph.Key
-
- toString() - Method in class com.bluegosling.graph.Node.Input
-
- toString() - Method in class com.bluegosling.possible.Holder
-
- toString() - Method in class com.bluegosling.possible.Reference
-
- toString() - Method in class com.bluegosling.reflect.AnnotatedTypeRef
-
- toString(AnnotatedType) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
Constructs a string representation of the given type.
- toString(T) - Static method in class com.bluegosling.reflect.Annotations
-
Returns a string representation of the specified annotation object.
- toString(T, Predicate<? super Method>) - Static method in class com.bluegosling.reflect.Annotations
-
Returns a string representation of the annotation, with only the attributes that match the
specified predicate.
- toString(Object) - Static method in class com.bluegosling.reflect.ArrayUtils
-
Constructs a string representation for the given array that describes its contents (as
opposed to the default
Object.toString()
version that arrays inherit).
- toString() - Method in class com.bluegosling.reflect.EnumType
-
- toString() - Method in class com.bluegosling.reflect.GenericMethodSignature
-
- toString() - Method in class com.bluegosling.reflect.MethodSignature
-
- toString() - Method in class com.bluegosling.reflect.scanner.PackageScanner.ClassInfo
-
- toString() - Method in class com.bluegosling.reflect.TypeRef
-
- toString(Type) - Static method in class com.bluegosling.reflect.Types
-
Constructs a string representation of the given type.
- toString() - Method in class com.bluegosling.result.Result
-
- toString() - Method in class com.bluegosling.tuples.Empty
-
- toString() - Method in class com.bluegosling.tuples.NTuple
-
- toString() - Method in class com.bluegosling.tuples.Pair
-
- toString() - Method in class com.bluegosling.tuples.Quadruple
-
- toString() - Method in class com.bluegosling.tuples.Quintuple
-
- toString() - Method in class com.bluegosling.tuples.Single
-
- toString() - Method in class com.bluegosling.tuples.Triple
-
- toString() - Method in class com.bluegosling.vars.Variable
-
- toString() - Method in class com.bluegosling.vars.VariableBoolean
-
- toString() - Method in class com.bluegosling.vars.VariableByte
-
- toString() - Method in class com.bluegosling.vars.VariableChar
-
- toString() - Method in class com.bluegosling.vars.VariableDouble
-
- toString() - Method in class com.bluegosling.vars.VariableFloat
-
- toString() - Method in class com.bluegosling.vars.VariableInt
-
- toString() - Method in class com.bluegosling.vars.VariableLong
-
- toString() - Method in class com.bluegosling.vars.VariableShort
-
- totalCapacity() - Method in class com.bluegosling.collections.concurrent.SharedCapacityDequeFactory
-
Returns the total capacity for this factory.
- Transaction - Class in com.bluegosling.concurrent.atoms
-
- Transaction.Computation<T,X extends Throwable> - Interface in com.bluegosling.concurrent.atoms
-
A computation that produces a value and executes in (or with) a transaction.
- Transaction.IsolationLevel - Enum in com.bluegosling.concurrent.atoms
-
The isolation level of a transaction.
- Transaction.Runner - Class in com.bluegosling.concurrent.atoms
-
An object that can initiate execution of code in a transaction.
- Transaction.Savepoint - Class in com.bluegosling.concurrent.atoms
-
Represents a checkpoint in the transaction.
- Transaction.Task<X extends Throwable> - Interface in com.bluegosling.concurrent.atoms
-
A task that executes in (or with) a transaction.
- Transaction.UncheckedComputation<T> - Interface in com.bluegosling.concurrent.atoms
-
A computation that produces a value, executes in a transaction, and does not throw any checked
exceptions.
- Transaction.UncheckedTask - Interface in com.bluegosling.concurrent.atoms
-
A task to execute in a transaction that does not throw any checked exceptions.
- TransactionalAtom<T> - Class in com.bluegosling.concurrent.atoms
-
An atom whose updates are coordinated in a
Transaction
.
- TransactionalAtom() - Constructor for class com.bluegosling.concurrent.atoms.TransactionalAtom
-
Constructs a new atom with a null
value and no validator.
- TransactionalAtom(T) - Constructor for class com.bluegosling.concurrent.atoms.TransactionalAtom
-
Constructs a new atom with the specified value and no validator.
- TransactionalAtom(T, Predicate<? super T>) - Constructor for class com.bluegosling.concurrent.atoms.TransactionalAtom
-
Constructs a new atom with the specified value and the specified validator.
- TransactionIsolationException - Exception in com.bluegosling.concurrent.atoms
-
An unchecked exception thrown from non-idempotent transactions that encounter serialization
errors due to concurrent access.
- TransactionIsolationException() - Constructor for exception com.bluegosling.concurrent.atoms.TransactionIsolationException
-
Constructs a new exception with a null
message and no cause.
- TransactionIsolationException(String) - Constructor for exception com.bluegosling.concurrent.atoms.TransactionIsolationException
-
Constructs a new exception with the given message and no cause.
- TransactionIsolationException(Throwable) - Constructor for exception com.bluegosling.concurrent.atoms.TransactionIsolationException
-
Constructs a new exception with a null
message and the given cause.
- TransactionIsolationException(String, Throwable) - Constructor for exception com.bluegosling.concurrent.atoms.TransactionIsolationException
-
Constructs a new exception with the given message and the given cause.
- transform(Table2D<R, C, VI>, Function<? super VI, ? extends VO>) - Static method in interface com.bluegosling.collections.tables.Table2D
-
- transform(int, Function<Object, ?>) - Method in class com.bluegosling.tuples.NTuple
-
Transforms the value at the given index using the given function.
- transform(Function<? super A, ? extends B>) - Method in class com.bluegosling.tuples.Single
-
Transforms the contained value and returns the results.
- transformAll(Function<Object, ? extends T>) - Method in class com.bluegosling.tuples.Empty
-
- transformAll(Function<Object, ? extends T>) - Method in class com.bluegosling.tuples.NTuple
-
- transformAll(Function<Object, ? extends T>) - Method in class com.bluegosling.tuples.Pair
-
- transformAll(Function<Object, ? extends T>) - Method in class com.bluegosling.tuples.Quadruple
-
- transformAll(Function<Object, ? extends T>) - Method in class com.bluegosling.tuples.Quintuple
-
- transformAll(Function<Object, ? extends T>) - Method in class com.bluegosling.tuples.Single
-
- transformAll(Function<Object, ? extends T>) - Method in class com.bluegosling.tuples.Triple
-
- transformAll(Function<Object, ? extends T>) - Method in interface com.bluegosling.tuples.Tuple.Ops1
-
- transformAll(Function<Object, ? extends T>) - Method in interface com.bluegosling.tuples.Tuple.Ops2
-
- transformAll(Function<Object, ? extends T>) - Method in interface com.bluegosling.tuples.Tuple.Ops3
-
- transformAll(Function<Object, ? extends T>) - Method in interface com.bluegosling.tuples.Tuple.Ops4
-
- transformAll(Function<Object, ? extends T>) - Method in interface com.bluegosling.tuples.Tuple.Ops5
-
- transformAll(Function<Object, ? extends T>) - Method in interface com.bluegosling.tuples.Tuple
-
Transforms every item in this tuple by applying the specified function to each one.
- transformFifth(Function<? super E, ? extends T>) - Method in class com.bluegosling.tuples.NTuple
-
- transformFifth(Function<? super E, ? extends T>) - Method in class com.bluegosling.tuples.Quintuple
-
- transformFifth(Function<? super E, ? extends T>) - Method in interface com.bluegosling.tuples.Tuple.Ops5
-
Transforms the fifth item in the tuple using the specified function.
- transformFirst(Function<? super A, ? extends T>) - Method in class com.bluegosling.tuples.NTuple
-
- transformFirst(Function<? super A, ? extends T>) - Method in class com.bluegosling.tuples.Pair
-
- transformFirst(Function<? super A, ? extends T>) - Method in class com.bluegosling.tuples.Quadruple
-
- transformFirst(Function<? super A, ? extends T>) - Method in class com.bluegosling.tuples.Quintuple
-
- transformFirst(Function<? super A, ? extends T>) - Method in class com.bluegosling.tuples.Single
-
- transformFirst(Function<? super A, ? extends T>) - Method in class com.bluegosling.tuples.Triple
-
- transformFirst(Function<? super A, ? extends T>) - Method in interface com.bluegosling.tuples.Tuple.Ops1
-
Transforms the first item in the tuple using the specified function.
- transformFirst(Function<? super A, ? extends T>) - Method in interface com.bluegosling.tuples.Tuple.Ops2
-
- transformFirst(Function<? super A, ? extends T>) - Method in interface com.bluegosling.tuples.Tuple.Ops3
-
- transformFirst(Function<? super A, ? extends T>) - Method in interface com.bluegosling.tuples.Tuple.Ops4
-
- transformFirst(Function<? super A, ? extends T>) - Method in interface com.bluegosling.tuples.Tuple.Ops5
-
- transformFourth(Function<? super D, ? extends T>) - Method in class com.bluegosling.tuples.NTuple
-
- transformFourth(Function<? super D, ? extends T>) - Method in class com.bluegosling.tuples.Quadruple
-
- transformFourth(Function<? super D, ? extends T>) - Method in class com.bluegosling.tuples.Quintuple
-
- transformFourth(Function<? super D, ? extends T>) - Method in interface com.bluegosling.tuples.Tuple.Ops4
-
Transforms the fourth item in the tuple using the specified function.
- transformFourth(Function<? super D, ? extends T>) - Method in interface com.bluegosling.tuples.Tuple.Ops5
-
- TransformingCollection<I,O> - Class in com.bluegosling.collections
-
A collection whose elements are the results of applying a function to another collection.
- TransformingCollection(Collection<I>, Function<? super I, ? extends O>) - Constructor for class com.bluegosling.collections.TransformingCollection
-
Constructs a new transforming collection.
- TransformingCollection.Bidi<I,O> - Class in com.bluegosling.collections
-
A transforming collection that can transform values in both directions.
- TransformingCollection.ReadOnly<I,O> - Class in com.bluegosling.collections
-
An unmodifiable transforming collection.
- TransformingIterable<I,O> - Class in com.bluegosling.collections
-
An iterable whose elements are the results of applying a function to another iterable.
- TransformingIterable(Iterable<I>, Function<? super I, ? extends O>) - Constructor for class com.bluegosling.collections.TransformingIterable
-
Constructs a new transforming iterable.
- TransformingIterable.ReadOnly<I,O> - Class in com.bluegosling.collections
-
An unmodifiable transforming iterable.
- TransformingIterator<I,O> - Class in com.bluegosling.collections
-
An iterator whose elements are the results of applying a function to results from another
iterator.
- TransformingIterator(Iterator<I>, Function<? super I, ? extends O>) - Constructor for class com.bluegosling.collections.TransformingIterator
-
Constructs a new transforming iterator.
- TransformingIterator.ReadOnly<I,O> - Class in com.bluegosling.collections
-
An unmodifiable transforming iterator.
- transformingKeys(Map<KI, V>, Function<? super KI, ? extends KO>, Function<? super KO, ? extends KI>) - Static method in class com.bluegosling.collections.TransformingMap.Bidi
-
Creates a new bidirectional map that only transforms map keys.
- transformingKeys(Map<KI, V>, Function<? super KI, ? extends KO>) - Static method in class com.bluegosling.collections.TransformingMap.ReadOnly
-
Creates a new unmodifiable map that only transforms map keys.
- transformingKeys(Map<KI, V>, Function<? super KI, ? extends KO>) - Static method in class com.bluegosling.collections.TransformingMap
-
Creates a transforming wrapper that only transforms map keys.
- TransformingList<I,O> - Class in com.bluegosling.collections
-
A list whose elements are the results of applying a function to another list.
- TransformingList(List<I>, Function<? super I, ? extends O>) - Constructor for class com.bluegosling.collections.TransformingList
-
Constructs a new transforming list.
- TransformingList.Bidi<I,O> - Class in com.bluegosling.collections
-
A transforming list that can transform values in both directions.
- TransformingList.Bidi.RandomAccess<I,O> - Class in com.bluegosling.collections
-
A bidirectional transforming list that also has the
RandomAccess
marker
interface.
- TransformingList.RandomAccess<I,O> - Class in com.bluegosling.collections
-
A transforming list that supports random access to its elements.
- TransformingList.ReadOnly<I,O> - Class in com.bluegosling.collections
-
An unmodifiable transforming list.
- TransformingList.ReadOnly.RandomAccess<I,O> - Class in com.bluegosling.collections
-
A read-only transforming list that also has the
RandomAccess
marker
interface.
- TransformingListIterator<I,O> - Class in com.bluegosling.collections
-
A list iterator whose elements are the results of applying a function to results from another
iterator.
- TransformingListIterator(ListIterator<I>, Function<? super I, ? extends O>) - Constructor for class com.bluegosling.collections.TransformingListIterator
-
Constructs a new transforming list iterator.
- TransformingListIterator.Bidi<I,O> - Class in com.bluegosling.collections
-
A transforming list iterator that can transform values in both directions.
- TransformingListIterator.ReadOnly<I,O> - Class in com.bluegosling.collections
-
An unmodifiable transforming list iterator.
- TransformingMap<KI,VI,KO,VO> - Class in com.bluegosling.collections
-
A map whose keys and/or values are the results of applying functions to the keys and/or values of
another map.
- TransformingMap(Map<KI, VI>, Function<? super KI, ? extends KO>, BiFunction<? super KI, ? super VI, ? extends VO>) - Constructor for class com.bluegosling.collections.TransformingMap
-
Constructs a transforming wrapper that may transform both keys and values.
- TransformingMap.Bidi<KI,VI,KO,VO> - Class in com.bluegosling.collections
-
A transforming map that can transform keys and values in both directions.
- TransformingMap.ReadOnly<KI,VI,KO,VO> - Class in com.bluegosling.collections
-
An unmodifiable transforming map.
- TransformingMap.ReadOnly.ValuesOnly<K,VI,VO> - Class in com.bluegosling.collections
-
An unmodifiable transforming map that can only transform values, not keys.
- TransformingMap.ValuesOnly<K,VI,VO> - Class in com.bluegosling.collections
-
- TransformingMapEntry<KI,VI,KO,VO> - Class in com.bluegosling.collections
-
- TransformingMapEntry(Map.Entry<KI, VI>, Function<? super KI, ? extends KO>, BiFunction<? super KI, ? super VI, ? extends VO>) - Constructor for class com.bluegosling.collections.TransformingMapEntry
-
- TransformingMapEntry.Bidi<KI,VI,KO,VO> - Class in com.bluegosling.collections
-
- TransformingRandomAccessSet<I,O> - Class in com.bluegosling.collections.sets
-
A set whose elements are the results of applying a function to another collection.
- TransformingRandomAccessSet(RandomAccessSet<I>, Function<? super I, ? extends O>) - Constructor for class com.bluegosling.collections.sets.TransformingRandomAccessSet
-
Constructs a new transforming random access set.
- TransformingRandomAccessSet.Bidi<I,O> - Class in com.bluegosling.collections.sets
-
A transforming random access set that can transform values in both directions.
- TransformingRandomAccessSet.ReadOnly<I,O> - Class in com.bluegosling.collections.sets
-
An unmodifiable transforming random access set.
- TransformingSet<I,O> - Class in com.bluegosling.collections
-
A set whose elements are the results of applying a function to another collection.
- TransformingSet(Set<I>, Function<? super I, ? extends O>) - Constructor for class com.bluegosling.collections.TransformingSet
-
Constructs a new transforming set.
- TransformingSet.Bidi<I,O> - Class in com.bluegosling.collections
-
A transforming set that can transform values in both directions.
- TransformingSet.ReadOnly<I,O> - Class in com.bluegosling.collections
-
An unmodifiable transforming set.
- transformingValues(Map<K, VI>, Function<? super VI, ? extends VO>, Function<? super VO, ? extends VI>) - Static method in class com.bluegosling.collections.TransformingMap.Bidi
-
Creates a new bidirectional map that only transforms map values.
- transformingValues(Map<K, VI>, BiFunction<? super K, ? super VI, ? extends VO>, Function<? super VO, ? extends VI>) - Static method in class com.bluegosling.collections.TransformingMap.Bidi
-
Creates a new bidirectional map that only transforms map values.
- transformingValues(Map<K, VI>, Function<? super VI, ? extends VO>) - Static method in class com.bluegosling.collections.TransformingMap.ReadOnly
-
Creates a new unmodifiable map that only transforms map values.
- transformingValues(Map<K, VI>, BiFunction<? super K, ? super VI, ? extends VO>) - Static method in class com.bluegosling.collections.TransformingMap.ReadOnly
-
Creates a new unmodifiable map that only transforms map values.
- transformingValues(Map<K, VI>, Function<? super VI, ? extends VO>) - Static method in class com.bluegosling.collections.TransformingMap
-
Creates a transforming wrapper that only transforms map values.
- transformingValues(Map<K, VI>, BiFunction<? super K, ? super VI, ? extends VO>) - Static method in class com.bluegosling.collections.TransformingMap
-
Creates a transforming wrapper that only transforms map values.
- transformKey(Map.Entry<KI, V>, Function<? super KI, ? extends KO>) - Static method in class com.bluegosling.collections.TransformingMapEntry
-
- transformSecond(Function<? super B, ? extends T>) - Method in class com.bluegosling.tuples.NTuple
-
- transformSecond(Function<? super B, ? extends T>) - Method in class com.bluegosling.tuples.Pair
-
- transformSecond(Function<? super B, ? extends T>) - Method in class com.bluegosling.tuples.Quadruple
-
- transformSecond(Function<? super B, ? extends T>) - Method in class com.bluegosling.tuples.Quintuple
-
- transformSecond(Function<? super B, ? extends T>) - Method in class com.bluegosling.tuples.Triple
-
- transformSecond(Function<? super B, ? extends T>) - Method in interface com.bluegosling.tuples.Tuple.Ops2
-
Transforms the second item in the tuple using the specified function.
- transformSecond(Function<? super B, ? extends T>) - Method in interface com.bluegosling.tuples.Tuple.Ops3
-
- transformSecond(Function<? super B, ? extends T>) - Method in interface com.bluegosling.tuples.Tuple.Ops4
-
- transformSecond(Function<? super B, ? extends T>) - Method in interface com.bluegosling.tuples.Tuple.Ops5
-
- transformThird(Function<? super C, ? extends T>) - Method in class com.bluegosling.tuples.NTuple
-
- transformThird(Function<? super C, ? extends T>) - Method in class com.bluegosling.tuples.Quadruple
-
- transformThird(Function<? super C, ? extends T>) - Method in class com.bluegosling.tuples.Quintuple
-
- transformThird(Function<? super C, ? extends T>) - Method in class com.bluegosling.tuples.Triple
-
- transformThird(Function<? super C, ? extends T>) - Method in interface com.bluegosling.tuples.Tuple.Ops3
-
Transforms the third item in the tuple using the specified function.
- transformThird(Function<? super C, ? extends T>) - Method in interface com.bluegosling.tuples.Tuple.Ops4
-
- transformThird(Function<? super C, ? extends T>) - Method in interface com.bluegosling.tuples.Tuple.Ops5
-
- transformValue(Map.Entry<K, VI>, Function<? super VI, ? extends VO>, Function<? super VO, ? extends VI>) - Static method in class com.bluegosling.collections.TransformingMapEntry.Bidi
-
- transformValue(Map.Entry<K, VI>, BiFunction<? super K, ? super VI, ? extends VO>, Function<? super VO, ? extends VI>) - Static method in class com.bluegosling.collections.TransformingMapEntry.Bidi
-
- transformValue(Map.Entry<K, VI>, Function<? super VI, ? extends VO>) - Static method in class com.bluegosling.collections.TransformingMapEntry
-
- transformValue(Map.Entry<K, VI>, BiFunction<? super K, ? super VI, ? extends VO>) - Static method in class com.bluegosling.collections.TransformingMapEntry
-
- transpose() - Method in interface com.bluegosling.collections.tables.Table2D
-
- transpose() - Method in interface com.bluegosling.collections.tables.Table3D
-
- transpose() - Method in interface com.bluegosling.collections.tables.Table4D
-
- transpose() - Method in interface com.bluegosling.collections.tables.Table5D
-
- TreeList<E> - Class in com.bluegosling.collections.lists
-
A list structure that is stored as a binary tree.
- TreeList() - Constructor for class com.bluegosling.collections.lists.TreeList
-
- TreeList(Collection<? extends E>) - Constructor for class com.bluegosling.collections.lists.TreeList
-
- TreiberStack<T> - Class in com.bluegosling.collections.concurrent
-
A thread-safe stack.
- TreiberStack() - Constructor for class com.bluegosling.collections.concurrent.TreiberStack
-
Constructs a new collection.
- TreiberStack(Collection<? extends T>) - Constructor for class com.bluegosling.collections.concurrent.TreiberStack
-
Constructs a new collection with the specified initial contents.
- TriConsumer<T,U,V> - Interface in com.bluegosling.function
-
- TriFunction<T,U,V,R> - Interface in com.bluegosling.function
-
A functional interface that accepts three arguments and returns a value.
- trimToSize() - Method in class com.bluegosling.collections.concurrent.ConcurrentSortedArraySet
-
Trims the internal array buffers to be exactly the required size to accommodate the
set's contents.
- trimToSize() - Method in class com.bluegosling.collections.lists.ArrayBackedLinkedList
-
Shrinks the internal buffer as much as possible without performing any other more aggressive
reorganization.
- trimToSize() - Method in class com.bluegosling.collections.maps.SortedArrayMap
-
Shrinks the internal array so that it is exactly the necessary size.
- trimToSize() - Method in class com.bluegosling.collections.sets.SortedArraySet
-
Shrinks the internal array so that it is exactly the necessary size.
- trioNaturalOrdering() - Method in class com.bluegosling.tuples.Tuples
-
- Triple<A,B,C> - Class in com.bluegosling.tuples
-
A tuple with three items.
- TriPredicate<T,U,V> - Interface in com.bluegosling.function
-
Like a
TriFunction
, but returns a primitive boolean value.
- tryAcquire(R) - Method in class com.bluegosling.concurrent.AbstractQueuedReferenceSynchronizer
-
Attempts to acquire in exclusive mode.
- tryAcquire() - Method in class com.bluegosling.concurrent.RateLimiter
-
Tries to acquires a single permit immediately, returning false if a permit is not available.
- tryAcquire(long) - Method in class com.bluegosling.concurrent.RateLimiter
-
Tries to acquires a the given number of permits immediately, returning false if the permits
are not all available.
- tryAcquire(long, TimeUnit) - Method in class com.bluegosling.concurrent.RateLimiter
-
Tries to acquire a permit, waiting up to the given time limit if one is not immediately
available.
- tryAcquire(long, long, TimeUnit) - Method in class com.bluegosling.concurrent.RateLimiter
-
Tries to acquire the given number of permits, waiting up to the given time limit if they are
not all immediately available.
- tryAcquireNanos(R, long) - Method in class com.bluegosling.concurrent.AbstractQueuedReferenceSynchronizer
-
Attempts to acquire in exclusive mode, aborting if interrupted, and failing if the given
timeout elapses.
- tryAcquireShared(R) - Method in class com.bluegosling.concurrent.AbstractQueuedReferenceSynchronizer
-
Attempts to acquire in shared mode.
- tryAcquireSharedNanos(R, long) - Method in class com.bluegosling.concurrent.AbstractQueuedReferenceSynchronizer
-
Attempts to acquire in shared mode, aborting if interrupted, and failing if the given timeout
elapses.
- tryDemoteToChild(HierarchicalLock) - Method in class com.bluegosling.concurrent.locks.HierarchicalLock.SharedLock
-
Tries to demote this lock to a shared lock on one of its children, returning immediately if
the child lock is unavailable.
- tryDemoteToChild(HierarchicalLock, long, TimeUnit) - Method in class com.bluegosling.concurrent.locks.HierarchicalLock.SharedLock
-
Tries to demote this lock to a shared lock on one of its children, waiting for the
specified amount of time before giving up.
- tryExclusiveLock() - Method in class com.bluegosling.concurrent.locks.HierarchicalLock
-
Tries to acquire this lock in exclusive mode, but does not block if it is not available.
- tryExclusiveLock(long, TimeUnit) - Method in class com.bluegosling.concurrent.locks.HierarchicalLock
-
Tries to acquire this lock in exclusive mode and waits up to the specified amount of time if
the lock is unavailable.
- tryFifth() - Method in class com.bluegosling.choice.AnyOfFive
-
- tryFifth() - Method in interface com.bluegosling.choice.Choice.Ops5
-
Retrieves the possible value of the fifth option.
- tryFifth() - Method in class com.bluegosling.choice.Union5
-
- tryFirst() - Method in class com.bluegosling.choice.AnyOfFive
-
- tryFirst() - Method in class com.bluegosling.choice.AnyOfFour
-
- tryFirst() - Method in class com.bluegosling.choice.AnyOfThree
-
- tryFirst() - Method in interface com.bluegosling.choice.Choice
-
Retrieves the possible value of the first option.
- tryFirst() - Method in class com.bluegosling.choice.Either
-
- tryFirst() - Method in class com.bluegosling.choice.Union2
-
- tryFirst() - Method in class com.bluegosling.choice.Union3
-
- tryFirst() - Method in class com.bluegosling.choice.Union4
-
- tryFirst() - Method in class com.bluegosling.choice.Union5
-
- tryFourth() - Method in class com.bluegosling.choice.AnyOfFive
-
- tryFourth() - Method in class com.bluegosling.choice.AnyOfFour
-
- tryFourth() - Method in interface com.bluegosling.choice.Choice.Ops4
-
Retrieves the possible value of the fourth option.
- tryFourth() - Method in class com.bluegosling.choice.Union4
-
- tryFourth() - Method in class com.bluegosling.choice.Union5
-
- tryLock() - Method in class com.bluegosling.concurrent.locks.NonReentrantLock
-
- tryLock(long, TimeUnit) - Method in class com.bluegosling.concurrent.locks.NonReentrantLock
-
- tryLock() - Method in class com.bluegosling.concurrent.locks.SpinLock
-
- tryLock(long, TimeUnit) - Method in class com.bluegosling.concurrent.locks.SpinLock
-
- tryPromoteToExclusive() - Method in class com.bluegosling.concurrent.locks.HierarchicalLock.SharedLock
-
Promotes this shared lock into an exclusive lock, returning immediately if the exclusive
lock is unavailable.
- tryPromoteToExclusive(long, TimeUnit) - Method in class com.bluegosling.concurrent.locks.HierarchicalLock.SharedLock
-
Promotes this shared lock into an exclusive lock, waiting up to the given amount of time
before giving up.
- tryPromoteToParent() - Method in class com.bluegosling.concurrent.locks.HierarchicalLock.ExclusiveLock
-
Tries to promote this lock to an exclusive lock on its parent, returning immediately if
the parent lock is unavailable.
- tryPromoteToParent(long, TimeUnit) - Method in class com.bluegosling.concurrent.locks.HierarchicalLock.ExclusiveLock
-
Tries to promote this lock to an exclusive lock on its parent, waiting up to the specified
amount of time before giving up.
- tryRelease(R) - Method in class com.bluegosling.concurrent.AbstractQueuedReferenceSynchronizer
-
Attempts to set the state to reflect a release in exclusive mode.
- tryReleaseShared(R) - Method in class com.bluegosling.concurrent.AbstractQueuedReferenceSynchronizer
-
Attempts to set the state to reflect a release in shared mode.
- tryReserve(long, TimeUnit) - Method in class com.bluegosling.concurrent.RateLimiter
-
Reserves a permit if the duration between now and when the permit becomes available is less
than or equal to the given time limit.
- tryReserve(long, long, TimeUnit) - Method in class com.bluegosling.concurrent.RateLimiter
-
Reserves a permit if the duration between now and when the permit becomes available is less
than or equal to the given time limit.
- trySecond() - Method in class com.bluegosling.choice.AnyOfFive
-
- trySecond() - Method in class com.bluegosling.choice.AnyOfFour
-
- trySecond() - Method in class com.bluegosling.choice.AnyOfThree
-
- trySecond() - Method in interface com.bluegosling.choice.Choice
-
Retrieves the possible value of the second option.
- trySecond() - Method in class com.bluegosling.choice.Either
-
- trySecond() - Method in class com.bluegosling.choice.Union2
-
- trySecond() - Method in class com.bluegosling.choice.Union3
-
- trySecond() - Method in class com.bluegosling.choice.Union4
-
- trySecond() - Method in class com.bluegosling.choice.Union5
-
- trySharedLock() - Method in class com.bluegosling.concurrent.locks.HierarchicalLock
-
Tries to acquire this lock in shared mode, but does not block if it is not available.
- trySharedLock(long, TimeUnit) - Method in class com.bluegosling.concurrent.locks.HierarchicalLock
-
Tries to acquire this lock in shared mode and waits up to the specified amount of time if the
lock is unavailable.
- trySize(Iterable<?>) - Static method in class com.bluegosling.collections.MoreIterables
-
Queries for the size of the given iterable, if known.
- tryThird() - Method in class com.bluegosling.choice.AnyOfFive
-
- tryThird() - Method in class com.bluegosling.choice.AnyOfFour
-
- tryThird() - Method in class com.bluegosling.choice.AnyOfThree
-
- tryThird() - Method in interface com.bluegosling.choice.Choice.Ops3
-
Retrieves the possible value of the third option.
- tryThird() - Method in class com.bluegosling.choice.Union3
-
- tryThird() - Method in class com.bluegosling.choice.Union4
-
- tryThird() - Method in class com.bluegosling.choice.Union5
-
- Tuple - Interface in com.bluegosling.tuples
-
Base interface implemented by all type-safe tuples.
- Tuple.Ops1<A> - Interface in com.bluegosling.tuples
-
Operations supported by tuples that have at least one element.
- Tuple.Ops2<A,B> - Interface in com.bluegosling.tuples
-
Operations supported by tuples that have at least two elements.
- Tuple.Ops3<A,B,C> - Interface in com.bluegosling.tuples
-
Operations supported by tuples that have at least three elements.
- Tuple.Ops4<A,B,C,D> - Interface in com.bluegosling.tuples
-
Operations supported by tuples that have at least four elements.
- Tuple.Ops5<A,B,C,D,E> - Interface in com.bluegosling.tuples
-
Operations supported by tuples that have at least five elements.
- tupleNaturalOrdering() - Method in class com.bluegosling.tuples.Tuples
-
- Tuples - Class in com.bluegosling.tuples
-
Utility methods for creating and using
Tuple
instances.
- two() - Method in class com.bluegosling.util.PrimeIterator
-
Returns the current numeric type's representation of the number two.
- type - Variable in class com.bluegosling.buildgen.BuildGen.Target
-
- type() - Method in class com.bluegosling.graph.Key
-
Returns the type of the key.
- TypeAnnotationChecker - Interface in com.bluegosling.reflect
-
Checks if a given type annotation is assignable to another.
- TypeAnnotationHierarchy - Interface in com.bluegosling.reflect
-
Models a type hierarchy for type annotations.
- TypeAnnotationHierarchy.Builder - Class in com.bluegosling.reflect
-
- TypeRef<T> - Class in com.bluegosling.reflect
-
A type token that represents a generic type.
- TypeRef() - Constructor for class com.bluegosling.reflect.TypeRef
-
Constructs a new type reference.
- types() - Static method in class com.bluegosling.apt.ProcessingEnvironments
-
Gets the current implementation of utility methods relating to types.
- Types - Interface in com.bluegosling.reflect.model
-
An extension of the standard
Types
interface that provides
methods for inter-op with core reflection.
- Types - Class in com.bluegosling.reflect
-
Numerous utility methods for using, constructing, and inspecting
generic types.
- TypeVisitor<R,P> - Interface in com.bluegosling.reflect
-
A visitor for generic types.
- TypeVisitor.Builder<R,P> - Class in com.bluegosling.reflect
-
A builder of visitors, using functional interfaces as the building blocks.
- validateAnnotations(Annotation[]) - Method in interface com.bluegosling.reflect.TypeAnnotationChecker
-
Validates that the given set of annotations is consistent.
- validateAnnotations(Collection<? extends Annotation>) - Method in interface com.bluegosling.reflect.TypeAnnotationChecker
-
Validates that the given set of annotations is consistent.
- validateGeneratedFile(FileObject, String) - Method in class com.bluegosling.apt.testing.TestEnvironment
-
Validates the contents of the specified file by comparing them to the contents of the
specified resource.
- validateGeneratedFile(FileObject, String, boolean) - Method in class com.bluegosling.apt.testing.TestEnvironment
-
Validates the contents of the specified file by comparing them to the contents of the
specified resource.
- ValidateGeneratedFiles - Annotation Type in com.bluegosling.apt.testing
-
An annotation on a test class or method that defines the output files to validate.
- validateInstanceMethods(List<Throwable>) - Method in class com.bluegosling.apt.testing.AnnotationProcessorTestRunner
-
- validateType(AnnotatedType, TypeAnnotationChecker) - Static method in class com.bluegosling.reflect.AnnotatedTypes
-
- ValueCollection() - Constructor for class com.bluegosling.collections.AbstractNavigableMap.ValueCollection
-
- valueFunction() - Method in class com.bluegosling.collections.TransformingMap
-
The function used to compute transformed values.
- valueFunction() - Method in class com.bluegosling.collections.TransformingMapEntry
-
- valueInverseFunction() - Method in class com.bluegosling.collections.TransformingMap.Bidi
-
Returns the function that inverts value transformations.
- ValueIteratorImpl() - Constructor for class com.bluegosling.collections.AbstractNavigableMap.ValueIteratorImpl
-
- ValueList() - Constructor for class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap.ValueList
-
- valueOf(String) - Static method in enum com.bluegosling.apt.reflect.ArClass.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bluegosling.apt.reflect.ArModifier
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bluegosling.buildgen.BuildGen.TargetType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bluegosling.collections.bits.BitSequence.BitOrder
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bluegosling.collections.BoundType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bluegosling.collections.IteratorModifiedState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bluegosling.collections.SpliteratorCharacteristics
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bluegosling.concurrent.atoms.AsynchronousAtom.ErrorAction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bluegosling.concurrent.atoms.Transaction.IsolationLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bluegosling.concurrent.scheduler.ScheduleNextTaskPolicies
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bluegosling.reflect.caster.DispatchSettings.Visibility
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Method in class com.bluegosling.reflect.EnumType
-
Returns the enum element with the given name.
- valueOf(String) - Static method in enum com.bluegosling.util.SystemClock
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum com.bluegosling.apt.reflect.ArClass.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bluegosling.apt.reflect.ArModifier
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bluegosling.buildgen.BuildGen.TargetType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class com.bluegosling.collections.AbstractNavigableMap
- values() - Static method in enum com.bluegosling.collections.bits.BitSequence.BitOrder
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bluegosling.collections.BoundType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class com.bluegosling.collections.concurrent.DoubleInstanceLockedTreeMap
-
- values() - Method in class com.bluegosling.collections.concurrent.PersistentMapBackedConcurrentMap
-
- values() - Method in class com.bluegosling.collections.DescendingMap
-
- values() - Method in class com.bluegosling.collections.FilteringMap
-
- values() - Method in class com.bluegosling.collections.immutable.AbstractImmutableMap
-
- values() - Method in interface com.bluegosling.collections.immutable.PersistentMap
-
Returns a view of this map's values as an immutable collection.
- values() - Static method in enum com.bluegosling.collections.IteratorModifiedState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class com.bluegosling.collections.maps.AbstractRandomAccessNavigableMap
-
- values() - Method in class com.bluegosling.collections.maps.DescendingRandomAccessMap
-
- values() - Method in interface com.bluegosling.collections.maps.RandomAccessNavigableMap
- values() - Method in class com.bluegosling.collections.maps.WeightBalancedTreeMap
-
- values() - Static method in enum com.bluegosling.collections.SpliteratorCharacteristics
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in interface com.bluegosling.collections.tables.Table2D
-
- values() - Method in interface com.bluegosling.collections.tables.Table3D
-
- values() - Method in interface com.bluegosling.collections.tables.Table4D
-
- values() - Method in interface com.bluegosling.collections.tables.Table5D
-
- values() - Method in class com.bluegosling.collections.TransformingMap.ReadOnly
-
- values() - Method in class com.bluegosling.collections.TransformingMap
-
- values() - Method in class com.bluegosling.collections.tries.ArrayMappedBitwiseTrie
-
- values() - Method in class com.bluegosling.collections.tries.CompactBitwiseTrie
-
- values() - Static method in enum com.bluegosling.concurrent.atoms.AsynchronousAtom.ErrorAction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bluegosling.concurrent.atoms.Transaction.IsolationLevel
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bluegosling.concurrent.scheduler.ScheduleNextTaskPolicies
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bluegosling.reflect.caster.DispatchSettings.Visibility
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class com.bluegosling.reflect.EnumType
-
Returns the list of enum elements in this enum type, in order.
- values() - Static method in enum com.bluegosling.util.SystemClock
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- ValuesOnly(Map<K, VI>, BiFunction<? super K, ? super VI, ? extends VO>) - Constructor for class com.bluegosling.collections.TransformingMap.ReadOnly.ValuesOnly
-
Constructs a new unmodifiable map that wraps the given map, transforming its values
using the given function.
- ValuesOnly(Map<K, VI>, BiFunction<? super K, ? super VI, ? extends VO>) - Constructor for class com.bluegosling.collections.TransformingMap.ValuesOnly
-
Constructs a new map that wraps the given map, transforming its values using the given
function.
- ValueType - Annotation Type in com.bluegosling.util
-
A marker interface for "value types".
- ValueTypeProcessor - Class in com.bluegosling.processors
-
Verifies, to the extent possible by an annotation processor, that the
ValueType
annotation is used correctly.
- ValueTypeProcessor() - Constructor for class com.bluegosling.processors.ValueTypeProcessor
-
- Variable<T> - Class in com.bluegosling.vars
-
A simple variable reference.
- Variable() - Constructor for class com.bluegosling.vars.Variable
-
Creates a new variable whose value is null.
- Variable(T) - Constructor for class com.bluegosling.vars.Variable
-
Creates a new variable with the given value.
- VariableBoolean - Class in com.bluegosling.vars
-
A simple variable reference for a boolean
.
- VariableBoolean() - Constructor for class com.bluegosling.vars.VariableBoolean
-
Creates a new variable whose value is false.
- VariableBoolean(boolean) - Constructor for class com.bluegosling.vars.VariableBoolean
-
Creates a new variable with the given value.
- VariableByte - Class in com.bluegosling.vars
-
A simple variable reference for a byte
.
- VariableByte() - Constructor for class com.bluegosling.vars.VariableByte
-
Creates a new variable whose value is zero.
- VariableByte(byte) - Constructor for class com.bluegosling.vars.VariableByte
-
Creates a new variable with the given value.
- VariableChar - Class in com.bluegosling.vars
-
A simple variable reference for a char
.
- VariableChar() - Constructor for class com.bluegosling.vars.VariableChar
-
Creates a new variable whose value is zero.
- VariableChar(char) - Constructor for class com.bluegosling.vars.VariableChar
-
Creates a new variable with the given value.
- VariableDouble - Class in com.bluegosling.vars
-
A simple variable reference for a double
.
- VariableDouble() - Constructor for class com.bluegosling.vars.VariableDouble
-
Creates a new variable whose value is zero.
- VariableDouble(double) - Constructor for class com.bluegosling.vars.VariableDouble
-
Creates a new variable with the given value.
- VariableFloat - Class in com.bluegosling.vars
-
A simple variable reference for a float
.
- VariableFloat() - Constructor for class com.bluegosling.vars.VariableFloat
-
Creates a new variable whose value is zero.
- VariableFloat(float) - Constructor for class com.bluegosling.vars.VariableFloat
-
Creates a new variable with the given value.
- VariableInt - Class in com.bluegosling.vars
-
A simple variable reference for an int
.
- VariableInt() - Constructor for class com.bluegosling.vars.VariableInt
-
Creates a new variable whose value is zero.
- VariableInt(int) - Constructor for class com.bluegosling.vars.VariableInt
-
Creates a new variable with the given value.
- VariableLong - Class in com.bluegosling.vars
-
A simple variable reference for a long
.
- VariableLong() - Constructor for class com.bluegosling.vars.VariableLong
-
Creates a new variable whose value is zero.
- VariableLong(long) - Constructor for class com.bluegosling.vars.VariableLong
-
Creates a new variable with the given value.
- VariableShort - Class in com.bluegosling.vars
-
A simple variable reference for a short
.
- VariableShort() - Constructor for class com.bluegosling.vars.VariableShort
-
Creates a new variable whose value is zero.
- VariableShort(short) - Constructor for class com.bluegosling.vars.VariableShort
-
Creates a new variable with the given value.
- verifierFor(T) - Static method in class com.bluegosling.testing.InterfaceVerifier
-
Returns the InterfaceVerifier
for configuring the specified proxy object.
- verify(T, T) - Method in interface com.bluegosling.testing.ObjectVerifier
-
Verifies that an object sufficiently matches a reference value.
- verifyAllArgumentsWith(ObjectVerifier<?>) - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfiguration
-
Indicates that the arguments should be verified after the method is executed.
- verifyAllArgumentsWith(ObjectVerifier<?>) - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfigurator
-
Indicates that the arguments should be verified after the method is executed.
- verifyArguments() - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfiguration
-
Indicates that the arguments should be verified after the method is executed.
- verifyArguments() - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfigurator
-
Indicates that the arguments should be verified after the method is executed.
- verifyArgumentsWith(ObjectVerifier<?>...) - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfiguration
-
Indicates that the arguments should be verified after the method is executed.
- verifyArgumentsWith(List<ObjectVerifier<?>>) - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfiguration
-
Indicates that the arguments should be verified after the method is executed.
- verifyArgumentsWith(ObjectVerifier<?>...) - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfigurator
-
Indicates that the arguments should be verified after the method is executed.
- verifyArgumentsWith(List<ObjectVerifier<?>>) - Method in interface com.bluegosling.testing.InterfaceVerifier.MethodConfigurator
-
Indicates that the arguments should be verified after the method is executed.
- visibility() - Method in class com.bluegosling.reflect.caster.DispatchSettings
-
- visit(Choice.VisitorOfFive<? super A, ? super B, ? super C, ? super D, ? super E, R>) - Method in class com.bluegosling.choice.AnyOfFive
-
- visit(Choice.VisitorOfFour<? super A, ? super B, ? super C, ? super D, R>) - Method in class com.bluegosling.choice.AnyOfFour
-
- visit(Choice.VisitorOfThree<? super A, ? super B, ? super C, R>) - Method in class com.bluegosling.choice.AnyOfThree
-
- visit(Choice.VisitorOfFive<? super A, ? super B, ? super C, ? super D, ? super E, R>) - Method in interface com.bluegosling.choice.Choice.OfFive
-
Invokes the appropriate visit method on the given visitor.
- visit(Choice.VisitorOfFour<? super A, ? super B, ? super C, ? super D, R>) - Method in interface com.bluegosling.choice.Choice.OfFour
-
Invokes the appropriate visit method on the given visitor.
- visit(Choice.VisitorOfThree<? super A, ? super B, ? super C, R>) - Method in interface com.bluegosling.choice.Choice.OfThree
-
Invokes the appropriate visit method on the given visitor.
- visit(Choice.VisitorOfTwo<? super A, ? super B, R>) - Method in interface com.bluegosling.choice.Choice.OfTwo
-
Invokes the appropriate visit method on the given visitor.
- visit(Choice.VisitorOfTwo<? super A, ? super B, R>) - Method in class com.bluegosling.choice.Either
-
- visit(Choice.VisitorOfTwo<? super A, ? super B, R>) - Method in class com.bluegosling.choice.Union2
-
- visit(Choice.VisitorOfThree<? super A, ? super B, ? super C, R>) - Method in class com.bluegosling.choice.Union3
-
- visit(Choice.VisitorOfFour<? super A, ? super B, ? super C, ? super D, R>) - Method in class com.bluegosling.choice.Union4
-
- visit(Choice.VisitorOfFive<? super A, ? super B, ? super C, ? super D, ? super E, R>) - Method in class com.bluegosling.choice.Union5
-
- visit(FutureVisitor<? super T>) - Method in class com.bluegosling.concurrent.fluent.AbstractFluentFuture
-
- visit(FutureVisitor<? super T>) - Method in interface com.bluegosling.concurrent.fluent.FluentFuture
-
Invokes applicable methods on the specified visitor, depending on the disposition of this
future.
- visit(FutureVisitor<? super T>) - Method in class com.bluegosling.concurrent.fluent.FluentFutureTask
-
- visit(Possible.Visitor<? super T, R>) - Method in class com.bluegosling.possible.AbstractDynamicPossible
-
- visit(Possible.Visitor<? super T, R>) - Method in interface com.bluegosling.possible.Possible
-
Invokes the appropriate method on the specified visitor.
- visit(Possible.Visitor<? super T, R>) - Method in class com.bluegosling.possible.Reference
-
- visit(AnnotatedType, P) - Method in interface com.bluegosling.reflect.AnnotatedTypeVisitor
-
Visits the given type.
- visit(Type, P) - Method in interface com.bluegosling.reflect.TypeVisitor
-
Visits the given type.
- visit(Result.Visitor<? super T, ? super E, ? extends R>) - Method in class com.bluegosling.result.Result
-
Visits this result using the given visitor.
- visitArrayType(AnnotatedArrayType, P) - Method in interface com.bluegosling.reflect.AnnotatedTypeVisitor
-
Invoked when the visited type is a generic array type.
- visitCallable(Callable<? extends V>) - Method in interface com.bluegosling.concurrent.scheduler.TaskImplementation.Visitor
-
Visits the underlying callable, for tasks implemented by a callable.
- visitClass(Class<?>, P) - Method in interface com.bluegosling.reflect.TypeVisitor
-
Invoked when the visited type is a class token.
- visitError(E) - Method in interface com.bluegosling.result.Result.Visitor
-
Visits the value of a failed result.
- visitFifth(E) - Method in interface com.bluegosling.choice.Choice.VisitorOfFive
-
Called when visiting a choice where the fifth option is present.
- visitFirst(A) - Method in interface com.bluegosling.choice.Choice.VisitorOfTwo
-
Called when visiting a choice where the first option is present.
- visitFourth(D) - Method in interface com.bluegosling.choice.Choice.VisitorOfFour
-
Called when visiting a choice where the fourth option is present.
- visitGenericArrayType(GenericArrayType, P) - Method in interface com.bluegosling.reflect.TypeVisitor
-
Invoked when the visited type is a generic array type.
- visitOtherType(AnnotatedType, P) - Method in interface com.bluegosling.reflect.AnnotatedTypeVisitor
-
Invoked when the visited type is not suitable for one of the more specific visit*
methods.
- visitParameterizedType(AnnotatedParameterizedType, P) - Method in interface com.bluegosling.reflect.AnnotatedTypeVisitor
-
Invoked when the visited type is a parameterized type.
- visitParameterizedType(ParameterizedType, P) - Method in interface com.bluegosling.reflect.TypeVisitor
-
Invoked when the visited type is a parameterized type.
- visitRunnable(Runnable, V) - Method in interface com.bluegosling.concurrent.scheduler.TaskImplementation.Visitor
-
Visits the underlying runnable and associated result, for tasks implemented by a runnable.
- visitSecond(B) - Method in interface com.bluegosling.choice.Choice.VisitorOfTwo
-
Called when visiting a choice where the second option is present.
- visitSource(Supplier<? extends V>) - Method in interface com.bluegosling.concurrent.scheduler.TaskImplementation.Visitor
-
Visits the underlying source, for tasks implemented by a source.
- visitThird(C) - Method in interface com.bluegosling.choice.Choice.VisitorOfThree
-
Called when visiting a choice where the third option is present.
- visitTypeVariable(AnnotatedTypeVariable, P) - Method in interface com.bluegosling.reflect.AnnotatedTypeVisitor
-
Invoked when the visited type is a type variable.
- visitTypeVariable(TypeVariable<?>, P) - Method in interface com.bluegosling.reflect.TypeVisitor
-
Invoked when the visited type is a type variable.
- visitUnknownType(Type, P) - Method in interface com.bluegosling.reflect.TypeVisitor
-
Invoked when the visited type is not a known sub-type of the
Type
interface.
- visitValue(T) - Method in interface com.bluegosling.result.Result.Visitor
-
Visits the value of a successful result.
- visitWhenDone(FutureVisitor<? super T>) - Method in interface com.bluegosling.concurrent.fluent.FluentFuture
-
- visitWildcardType(AnnotatedWildcardType, P) - Method in interface com.bluegosling.reflect.AnnotatedTypeVisitor
-
Invoked when the visited type is a wildcard type.
- visitWildcardType(WildcardType, P) - Method in interface com.bluegosling.reflect.TypeVisitor
-
Invoked when the visited type is a wildcard type.
- volumeKeySet() - Method in interface com.bluegosling.collections.tables.Table5D
-