Search Java Classes and Packages

Search Java Frameworks and Libraries

255581 classes and counting ...
Search Tips Index Status



#Util.concurrent Classes and Interfaces - 400 results found.
NameDescriptionTypePackageFramework
AbstractExecutorServiceProvides default implementations of ExecutorService execution methods.Classjava.util.concurrentJava SE
AbstractOwnableSynchronizerA synchronizer that may be exclusively owned by a thread.Classjava.util.concurrent.locksJava SE
AbstractQueuedLongSynchronizerA version of AbstractQueuedSynchronizer in which synchronization state is maintained as a long.Classjava.util.concurrent.locksJava SE
AbstractQueuedSynchronizerProvides a framework for implementing blocking locks and related synchronizers (semaphores, events, etc) that rely onClassjava.util.concurrent.locksJava SE
ArrayBlockingQueueA bounded blocking queue backed by an array.Classjava.util.concurrentJava SE
AtomicBooleanA boolean value that may be updated atomically.Classjava.util.concurrent.atomicJava SE
AtomicIntegerAn int value that may be updated atomically.Classjava.util.concurrent.atomicJava SE
AtomicIntegerArrayAn int array in which elements may be updated atomically.Classjava.util.concurrent.atomicJava SE
AtomicIntegerFieldUpdaterA reflection-based utility that enables atomic updates to designated volatile int fields of designated classes.Classjava.util.concurrent.atomicJava SE
AtomicLongA long value that may be updated atomically.Classjava.util.concurrent.atomicJava SE
AtomicLongArrayA long array in which elements may be updated atomically.Classjava.util.concurrent.atomicJava SE
AtomicLongFieldUpdaterA reflection-based utility that enables atomic updates to designated volatile long fields of designated classes.Classjava.util.concurrent.atomicJava SE
AtomicMarkableReferenceAn AtomicMarkableReference maintains an object reference along with a mark bit, that can be updated atomically.Classjava.util.concurrent.atomicJava SE
AtomicReferenceAn object reference that may be updated atomically.Classjava.util.concurrent.atomicJava SE
AtomicReferenceArrayAn array of object references in which elements may be updated atomically.Classjava.util.concurrent.atomicJava SE
AtomicReferenceFieldUpdaterA reflection-based utility that enables atomic updates to designated volatile reference fields of designatedClassjava.util.concurrent.atomicJava SE
AtomicStampedReferenceAn AtomicStampedReference maintains an object reference along with an integer stamp, that can be updated atomically.Classjava.util.concurrent.atomicJava SE
BrokenBarrierExceptionException thrown when a thread tries to wait upon a barrier that is in a broken state, or which enters the broken state while the threadClassjava.util.concurrentJava SE
BlockingDequeA Deque that additionally supports blocking operations that wait for the deque to become non-empty when retrieving an element, and wait forInterfacejava.util.concurrentJava SE
BlockingQueueA Queue that additionally supports operations that wait for the queue to become non-empty when retrieving anInterfacejava.util.concurrentJava SE
CancellationExceptionException indicating that the result of a value-producing task, such as a FutureTask, cannot be retrieved because the taskClassjava.util.concurrentJava SE
CompletableFutureA Future that may be explicitly completed (setting its value and status), and may be used as a CompletionStage,Classjava.util.concurrentJava SE
CompletionExceptionException thrown when an error or other exception is encountered in the course of completing a result or task.Classjava.util.concurrentJava SE
ConcurrentHashMapA hash table supporting full concurrency of retrievals and high expected concurrency for updates.Classjava.util.concurrentJava SE
ConcurrentHashMap .KeySetViewA view of a ConcurrentHashMap as a Set of keys, in which additions may optionally be enabled by mapping to aClassjava.util.concurrent.ConcurrentHashMapJava SE
ConcurrentLinkedDequeAn unbounded concurrent deque based on linked nodes.Classjava.util.concurrentJava SE
ConcurrentLinkedQueueAn unbounded thread-safe queue based on linked nodes.Classjava.util.concurrentJava SE
ConcurrentModificationExceptionThis exception may be thrown by methods that have detected concurrent modification of an object when such modification is not permissible.Classjava.utilJava SE
ConcurrentSkipListMapA scalable concurrent ConcurrentNavigableMap implementation.Classjava.util.concurrentJava SE
ConcurrentSkipListSetA scalable concurrent NavigableSet implementation based on a ConcurrentSkipListMap.Classjava.util.concurrentJava SE
CopyOnWriteArrayListA thread-safe variant of ArrayList in which all mutative operations (add, set, and so on) are implemented byClassjava.util.concurrentJava SE
CopyOnWriteArraySetA Set that uses an internal CopyOnWriteArrayList for all of its operations.Classjava.util.concurrentJava SE
CountDownLatchA synchronization aid that allows one or more threads to wait until a set of operations being performed in other threads completes.Classjava.util.concurrentJava SE
CountedCompleterA ForkJoinTask with a completion action performed when triggered and there are no remaining pending actions.Classjava.util.concurrentJava SE
CyclicBarrierA synchronization aid that allows a set of threads to all wait for each other to reach a common barrier point.Classjava.util.concurrentJava SE
CallableA task that returns a result and may throw an exception.Interfacejava.util.concurrentJava SE
CompletableFuture .AsynchronousCompletionTaskA marker interface identifying asynchronous tasks produced by async methods.Interfacejava.util.concurrent.CompletableFutureJava SE
CompletionServiceA service that decouples the production of new asynchronous tasks from the consumption of the results of completed tasks.Interfacejava.util.concurrentJava SE
CompletionStageA stage of a possibly asynchronous computation, that performs an action or computes a value when another CompletionStage completes.Interfacejava.util.concurrentJava SE
ConcurrentMapA Map providing thread safety and atomicity To maintain the specified guarantees, default implementations ofInterfacejava.util.concurrentJava SE
ConcurrentNavigableMapA ConcurrentMap supporting NavigableMap operations, and recursively so for its navigable sub-maps.Interfacejava.util.concurrentJava SE
ConditionCondition factors out the Object monitor methods (wait, notifyInterfacejava.util.concurrent.locksJava SE
DelayQueueAn unbounded blocking queue of Delayed elements, in which an element can only be takenClassjava.util.concurrentJava SE
DoubleAccumulatorOne or more variables that together maintain a running double value updated using a supplied function.Classjava.util.concurrent.atomicJava SE
DoubleAdderOne or more variables that together maintain an initially zero double sum.Classjava.util.concurrent.atomicJava SE
DelayedA mix-in style interface for marking objects that should be acted upon after a given delay.Interfacejava.util.concurrentJava SE
ExchangerA synchronization point at which threads can pair and swap elements within pairs.Classjava.util.concurrentJava SE
ExecutionExceptionException thrown when attempting to retrieve the result of a task that aborted by throwing an exception.Classjava.util.concurrentJava SE
ExecutorCompletionServiceA CompletionService that uses a supplied Executor to execute tasks.Classjava.util.concurrentJava SE
ExecutorsFactory and utility methods for Executor, ExecutorService, ScheduledExecutorService, ThreadFactory, and Callable classes defined in this package.Classjava.util.concurrentJava SE
ExecutorAn object that executes submitted Runnable tasks.Interfacejava.util.concurrentJava SE
ExecutorServiceAn Executor that provides methods to manage termination and methods that can produce a Future for tracking progress ofInterfacejava.util.concurrentJava SE
FlowInterrelated interfaces and static methods for establishing flow-controlled components in which PublishersClassjava.util.concurrentJava SE
ForkJoinPoolAn ExecutorService for running ForkJoinTasks.Classjava.util.concurrentJava SE
ForkJoinTaskAbstract base class for tasks that run within a ForkJoinPool.Classjava.util.concurrentJava SE
ForkJoinWorkerThreadA thread managed by a ForkJoinPool, which executes This class is subclassable solely for the sake of addingClassjava.util.concurrentJava SE
FutureTaskA cancellable asynchronous computation.Classjava.util.concurrentJava SE
Flow .ProcessorA component that acts as both a Subscriber and Publisher.Interfacejava.util.concurrent.FlowJava SE
Flow .PublisherA producer of items (and related control messages) received by Subscribers.Interfacejava.util.concurrent.FlowJava SE
Flow .SubscriberA receiver of messages.Interfacejava.util.concurrent.FlowJava SE
Flow .SubscriptionMessage control linking a Flow.Interfacejava.util.concurrent.FlowJava SE
ForkJoinPool .ForkJoinWorkerThreadFactoryFactory for creating new ForkJoinWorkerThreads.Interfacejava.util.concurrent.ForkJoinPoolJava SE
ForkJoinPool .ManagedBlocker A ManagedBlocker provides two methods.Interfacejava.util.concurrent.ForkJoinPoolJava SE
FutureA Future represents the result of an asynchronous computation.Interfacejava.util.concurrentJava SE
LinkedBlockingDequeAn optionally-bounded blocking deque based on The optional capacity bound constructor argument serves as aClassjava.util.concurrentJava SE
LinkedBlockingQueueAn optionally-bounded blocking queue based on This queue orders elements FIFO (first-in-first-out).Classjava.util.concurrentJava SE
LinkedTransferQueueAn unbounded TransferQueue based on linked nodes.Classjava.util.concurrentJava SE
LockSupportBasic thread blocking primitives for creating locks and other synchronization classes.Classjava.util.concurrent.locksJava SE
LongAccumulatorOne or more variables that together maintain a running long value updated using a supplied function.Classjava.util.concurrent.atomicJava SE
LongAdderOne or more variables that together maintain an initially zero long sum.Classjava.util.concurrent.atomicJava SE
LockLock implementations provide more extensive locking operations than can be obtained using synchronized methodsInterfacejava.util.concurrent.locksJava SE
PhaserA reusable synchronization barrier, similar in functionality to but supporting more flexible usage.Classjava.util.concurrentJava SE
PriorityBlockingQueueAn unbounded blocking queue that uses the same ordering rules as class PriorityQueue and suppliesClassjava.util.concurrentJava SE
RecursiveActionA recursive resultless ForkJoinTask.Classjava.util.concurrentJava SE
RecursiveTaskA recursive result-bearing ForkJoinTask.Classjava.util.concurrentJava SE
ReentrantLockA reentrant mutual exclusion Lock with the same basic behavior and semantics as the implicit monitor lock accessed usingClassjava.util.concurrent.locksJava SE
ReentrantReadWriteLockAn implementation of ReadWriteLock supporting similar semantics to ReentrantLock.Classjava.util.concurrent.locksJava SE
ReentrantReadWriteLock .ReadLockThe lock returned by method ReentrantReadWriteLock.Classjava.util.concurrent.locks.ReentrantReadWriteLockJava SE
ReentrantReadWriteLock .WriteLockThe lock returned by method ReentrantReadWriteLock.Classjava.util.concurrent.locks.ReentrantReadWriteLockJava SE
RejectedExecutionExceptionException thrown by an Executor when a task cannot be accepted for execution.Classjava.util.concurrentJava SE
ReadWriteLockA ReadWriteLock maintains a pair of associated locks, one for read-only operations and one for writing.Interfacejava.util.concurrent.locksJava SE
RejectedExecutionHandlerA handler for tasks that cannot be executed by a ThreadPoolExecutor.Interfacejava.util.concurrentJava SE
RunnableFutureA Future that is Runnable.Interfacejava.util.concurrentJava SE
RunnableScheduledFutureA ScheduledFuture that is Runnable.Interfacejava.util.concurrentJava SE
ScheduledThreadPoolExecutorA ThreadPoolExecutor that can additionally schedule commands to run after a given delay, or to execute periodically.Classjava.util.concurrentJava SE
SemaphoreA counting semaphore.Classjava.util.concurrentJava SE
StampedLockA capability-based lock with three modes for controlling read/write access.Classjava.util.concurrent.locksJava SE
SubmissionPublisherA Flow.Classjava.util.concurrentJava SE
SynchronousQueueA blocking queue in which each insert operation must wait for a corresponding remove operation by anotherClassjava.util.concurrentJava SE
ScheduledExecutorServiceAn ExecutorService that can schedule commands to run after a given delay, or to execute periodically.Interfacejava.util.concurrentJava SE
ScheduledFutureA delayed result-bearing action that can be cancelled.Interfacejava.util.concurrentJava SE
ThreadLocalRandomA random number generator isolated to the current thread.Classjava.util.concurrentJava SE
ThreadPoolExecutorAn ExecutorService that executes each submitted task using one of possibly several pooled threads, normally configuredClassjava.util.concurrentJava SE
ThreadPoolExecutor .AbortPolicyA handler for rejected tasks that throws a RejectedExecutionException.Classjava.util.concurrent.ThreadPoolExecutorJava SE
ThreadPoolExecutor .CallerRunsPolicyA handler for rejected tasks that runs the rejected task directly in the calling thread of the execute method,Classjava.util.concurrent.ThreadPoolExecutorJava SE
ThreadPoolExecutor .DiscardOldestPolicyA handler for rejected tasks that discards the oldest unhandled request and then retries execute, unless the executorClassjava.util.concurrent.ThreadPoolExecutorJava SE
ThreadPoolExecutor .DiscardPolicyClassjava.util.concurrent.ThreadPoolExecutorJava SE
TimeoutExceptionException thrown when a blocking operation times out.Classjava.util.concurrentJava SE
TimeUnitA TimeUnit represents time durations at a given unit of granularity and provides utility methods to convert across units,Classjava.util.concurrentJava SE
ThreadFactoryAn object that creates new threads on demand.Interfacejava.util.concurrentJava SE
TransferQueueA BlockingQueue in which producers may wait for consumers to receive elements.Interfacejava.util.concurrentJava SE
CompletableToListenableFutureAdapterAdapts a CompletableFuture into a ListenableFuture.Classorg.springframework.util.concurrentSpring MVC
ConcurrentReferenceHashMapA ConcurrentHashMap that uses soft orweak references for both keys and values.Classorg.springframework.utilSpring MVC
ConcurrentReferenceHashMap .EntryClassorg.springframework.util.ConcurrentReferenceHashMapSpring MVC
ConcurrentReferenceHashMap .ReferenceA reference to an ConcurrentReferenceHashMap.Interfaceorg.springframework.util.ConcurrentReferenceHashMapSpring MVC
ConcurrentReferenceHashMap .ReferenceTypeVarious reference types supported by this map.Classorg.springframework.util.ConcurrentReferenceHashMapSpring MVC
ConcurrentReferenceHashMap .RestructureThe types of restructuring that can be performed.Classorg.springframework.util.ConcurrentReferenceHashMapSpring MVC
FailureCallbackDefines the contract for failure callbacks that accept the result of aSince:4.Interfaceorg.springframework.util.concurrentSpring MVC
FutureAdapterAbstract class that adapts a Future parameterized over S into a Future parameterized over T.Classorg.springframework.util.concurrentSpring MVC
ListenableFuturecallbacks.Interfaceorg.springframework.util.concurrentSpring MVC
ListenableFutureAdapterAbstract class that adapts a ListenableFuture parameterized over S into aListenableFuture parameterized over T.Classorg.springframework.util.concurrentSpring MVC
ListenableFutureCallbackDefines the contract for callbacks that accept the result of aSince:4.Interfaceorg.springframework.util.concurrentSpring MVC
ListenableFutureCallbackRegistryRegistry for ListenableFutureCallback instances.Classorg.springframework.util.concurrentSpring MVC
ListenableFutureTaskExtension of FutureTask that implements ListenableFuture.Classorg.springframework.util.concurrentSpring MVC
SettableListenableFuturewhose value can be set via set(Object) orsetException(Throwable).Classorg.springframework.util.concurrentSpring MVC
SuccessCallbackDefines the contract for success callbacks that accept the result of aSince:4.Interfaceorg.springframework.util.concurrentSpring MVC
ConcurrentCacheClassorg.zkoss.zel.impl.utilZKoss (ZK)
ConcurrentHashSetThis class implements the Set interface, backed by a ConcurrentHashMap instance.Classorg.jivesoftware.utilEcho
ConcurrentBarrierA barrier used to execute code in a context where it is guarded by read/write locks.Classorg.apache.tapestry5.ioc.internal.utilApache Tapestry
AtomicExceptionConvenience class for holding an Exception in a thread-safe waySee Also:Serialized FormClassorg.apache.camel.util.concurrentApache Camel
AtomicExchangeConvenience class for holding an Exchange in a thread-safe waySee Also:Serialized FormClassorg.apache.camel.util.concurrentApache Camel
CamelThreadFactoryThread factory which creates threads supporting a naming pattern.Classorg.apache.camel.util.concurrentApache Camel
RejectableFutureTaskA Rejectable FutureTask used by RejectableThreadPoolExecutor.Classorg.apache.camel.util.concurrentApache Camel
RejectableScheduledThreadPoolExecutorScheduled thread pool executor that creates RejectableFutureTask instead of FutureTask when registering new tasks for execution.Classorg.apache.camel.util.concurrentApache Camel
RejectableThreadPoolExecutorThread pool executor that creates RejectableFutureTask instead of FutureTask when registering new tasks for execution.Classorg.apache.camel.util.concurrentApache Camel
SizedScheduledExecutorServiceA sized ScheduledExecutorService which will reject executing tasks if the task queue is full.Classorg.apache.camel.util.concurrentApache Camel
SubmitOrderedCompletionServiceA CompletionService that orders the completed tasks in the same order as they where submitted.Classorg.apache.camel.util.concurrentApache Camel
SynchronousExecutorServiceA synchronous ExecutorService which always invokes the task in the caller thread (just a thread pool facade).Classorg.apache.camel.util.concurrentApache Camel
ThreadHelperVarious helper method for thread naming.Classorg.apache.camel.util.concurrentApache Camel
ConcurrentLFUCacheA LFU cache implementation based upon ConcurrentHashMap.Classorg.apache.solr.utilApache Solr Lucene
ConcurrentLFUCache .EvictionListenerInterfaceorg.apache.solr.util.ConcurrentLFUCacheApache Solr Lucene
ConcurrentLFUCache .StatsClassorg.apache.solr.util.ConcurrentLFUCacheApache Solr Lucene
ConcurrentLRUCacheA LRU cache implementation based upon ConcurrentHashMap and other techniques to reduce contention and synchronization overhead to utilize multiple CPU cores more effectively.Classorg.apache.solr.utilApache Solr Lucene
ConcurrentLRUCache .EvictionListenerInterfaceorg.apache.solr.util.ConcurrentLRUCacheApache Solr Lucene
ConcurrentLRUCache .StatsClassorg.apache.solr.util.ConcurrentLRUCacheApache Solr Lucene
BoundedBufferEfficient array-based bounded buffer class.Classorg.dbunit.util.concurrentSourceForge DBUnit
BoundedChannelA channel that is known to have a capacity, signifying that put operations may block when theInterfaceorg.dbunit.util.concurrentSourceForge DBUnit
BoundedLinkedQueueA bounded variant of class.Classorg.dbunit.util.concurrentSourceForge DBUnit
ChannelMain interface for buffers, queues, pipes, conduits, etc.Interfaceorg.dbunit.util.concurrentSourceForge DBUnit
DefaultChannelCapacityA utility class to set the default capacity of implementations that otherwise require a capacity argumentClassorg.dbunit.util.concurrentSourceForge DBUnit
ExecutorInterface for objects that execute Runnables, as well as various objects that can be wrappedInterfaceorg.dbunit.util.concurrentSourceForge DBUnit
LinkedNodeA standard linked list node used in various queue classesSince:? (pre 2.Classorg.dbunit.util.concurrentSourceForge DBUnit
LinkedQueueA linked list based channel implementation.Classorg.dbunit.util.concurrentSourceForge DBUnit
PropertyChangeMulticasterThis class is interoperable with java.Classorg.dbunit.util.concurrentSourceForge DBUnit
PuttableThis interface exists to enable stricter type checking for channels.Interfaceorg.dbunit.util.concurrentSourceForge DBUnit
SemaphoreBase class for counting semaphores.Classorg.dbunit.util.concurrentSourceForge DBUnit
SemaphoreControlledChannelAbstract class for channels that use Semaphores to control puts and takes.Classorg.dbunit.util.concurrentSourceForge DBUnit
SlotA one-slot buffer, using semaphores to control access.Classorg.dbunit.util.concurrentSourceForge DBUnit
SyncMain interface for locks, gates, and conditions.Interfaceorg.dbunit.util.concurrentSourceForge DBUnit
SynchronizedIntA class useful for offloading synch for int instance variables.Classorg.dbunit.util.concurrentSourceForge DBUnit
SynchronizedVariableBase class for simple, small classes maintaining single values that are always accessedClassorg.dbunit.util.concurrentSourceForge DBUnit
SynchronousChannelA rendezvous channel, similar to those used in CSP and Ada.Classorg.dbunit.util.concurrentSourceForge DBUnit
SynchronousChannel .QueueSimple FIFO queue class to hold waiting puts/takes.Classorg.dbunit.util.concurrent.SynchronousChannelSourceForge DBUnit
TakableThis interface exists to enable stricter type checking for channels.Interfaceorg.dbunit.util.concurrentSourceForge DBUnit
TimeoutExceptionThrown by synchronization classes that report timeouts via exceptions.Classorg.dbunit.util.concurrentSourceForge DBUnit
AbstractExecutorServiceProvides default implementations of ExecutorService execution methods.Classutil.concurrentCode Trails
AbstractOwnableSynchronizerA synchronizer that may be exclusively owned by a thread.Classutil.concurrent.locksCode Trails
AbstractQueuedLongSynchronizerA version of AbstractQueuedSynchronizer in which synchronization state is maintained as a long.Classutil.concurrent.locksCode Trails
AbstractQueuedLongSynchronizer .NodeClassutil.concurrent.locks.AbstractQueuedLongSynchronizerCode Trails
AbstractQueuedSynchronizerProvides a framework for implementing blocking locks and related synchronizers (semaphores, events, etc) that rely onClassutil.concurrent.locksCode Trails
AbstractQueuedSynchronizer .NodeClassutil.concurrent.locks.AbstractQueuedSynchronizerCode Trails
ArrayBlockingQueueA bounded blocking queue backed by an array.Classutil.concurrentCode Trails
AtomicBooleanA boolean value that may be updated atomically.Classutil.concurrent.atomicCode Trails
AtomicIntegerAn int value that may be updated atomically.Classutil.concurrent.atomicCode Trails
AtomicIntegerArrayAn int array in which elements may be updated atomically.Classutil.concurrent.atomicCode Trails
AtomicIntegerFieldUpdaterA reflection-based utility that enables atomic updates to designated volatile int fields of designated classes.Classutil.concurrent.atomicCode Trails
AtomicIntegerFieldUpdater .AtomicIntegerFieldUpdaterImplClassutil.concurrent.atomic.AtomicIntegerFieldUpdaterCode Trails
AtomicLongA long value that may be updated atomically.Classutil.concurrent.atomicCode Trails
AtomicLongArrayA long array in which elements may be updated atomically.Classutil.concurrent.atomicCode Trails
AtomicLongFieldUpdaterA reflection-based utility that enables atomic updates to designated volatile long fields of designated classes.Classutil.concurrent.atomicCode Trails
AtomicLongFieldUpdater .CASUpdaterClassutil.concurrent.atomic.AtomicLongFieldUpdaterCode Trails
AtomicLongFieldUpdater .LockedUpdaterClassutil.concurrent.atomic.AtomicLongFieldUpdaterCode Trails
AtomicMarkableReferenceAn AtomicMarkableReference maintains an object reference along with a mark bit, that can be updated atomically.Classutil.concurrent.atomicCode Trails
AtomicMarkableReference .PairClassutil.concurrent.atomic.AtomicMarkableReferenceCode Trails
AtomicReferenceAn object reference that may be updated atomically.Classutil.concurrent.atomicCode Trails
AtomicReferenceArrayAn array of object references in which elements may be updated atomically.Classutil.concurrent.atomicCode Trails
AtomicReferenceFieldUpdaterA reflection-based utility that enables atomic updates to designated volatile reference fields of designatedClassutil.concurrent.atomicCode Trails
AtomicReferenceFieldUpdater .AtomicReferenceFieldUpdaterImplClassutil.concurrent.atomic.AtomicReferenceFieldUpdaterCode Trails
AtomicStampedReferenceAn AtomicStampedReference maintains an object reference along with an integer "stamp", that can be updated atomically.Classutil.concurrent.atomicCode Trails
AtomicStampedReference .PairClassutil.concurrent.atomic.AtomicStampedReferenceCode Trails
BlockingDequeA Deque that additionally supports blocking operations that wait for the deque to become non-empty when retrieving an element, and wait forInterfaceutil.concurrentCode Trails
BlockingQueueA Queue that additionally supports operations that wait for the queue to become non-empty when retrieving anInterfaceutil.concurrentCode Trails
BrokenBarrierExceptionException thrown when a thread tries to wait upon a barrier that is in a broken state, or which enters the broken state while the threadClassutil.concurrentCode Trails
CallableA task that returns a result and may throw an exception.Interfaceutil.concurrentCode Trails
CancellationExceptionException indicating that the result of a value-producing task, such as a FutureTask, cannot be retrieved because the taskClassutil.concurrentCode Trails
CompletionServiceA service that decouples the production of new asynchronous tasks from the consumption of the results of completed tasks.Interfaceutil.concurrentCode Trails
ConcurrentHashMapA hash table supporting full concurrency of retrievals and adjustable expected concurrency for updates.Classutil.concurrentCode Trails
ConcurrentHashMap .HashEntryClassutil.concurrent.ConcurrentHashMapCode Trails
ConcurrentHashMap .Holderholds values which can't be initialized until after VM is booted.Classutil.concurrent.ConcurrentHashMapCode Trails
ConcurrentHashMap .SegmentClassutil.concurrent.ConcurrentHashMapCode Trails
ConcurrentLinkedDequeAn unbounded concurrent deque based on linked nodes.Classutil.concurrentCode Trails
ConcurrentLinkedDeque .NodeClassutil.concurrent.ConcurrentLinkedDequeCode Trails
ConcurrentLinkedQueueAn unbounded thread-safe queue based on linked nodes.Classutil.concurrentCode Trails
ConcurrentLinkedQueue .NodeClassutil.concurrent.ConcurrentLinkedQueueCode Trails
ConcurrentMapA Map providing additional atomic putIfAbsent, remove, and replace methods.Interfaceutil.concurrentCode Trails
ConcurrentModificationExceptionThis exception may be thrown by methods that have detected concurrent modification of an object when such modification is not permissible.ClassutilCode Trails
ConcurrentNavigableMapA ConcurrentMap supporting NavigableMap operations, and recursively so for its navigable sub-maps.Interfaceutil.concurrentCode Trails
ConcurrentSkipListMapA scalable concurrent ConcurrentNavigableMap implementation.Classutil.concurrentCode Trails
ConcurrentSkipListMap .ComparableUsingComparatorClassutil.concurrent.ConcurrentSkipListMapCode Trails
ConcurrentSkipListMap .EntrySetClassutil.concurrent.ConcurrentSkipListMapCode Trails
ConcurrentSkipListMap .HeadIndexClassutil.concurrent.ConcurrentSkipListMapCode Trails
ConcurrentSkipListMap .IndexClassutil.concurrent.ConcurrentSkipListMapCode Trails
ConcurrentSkipListMap .KeySetClassutil.concurrent.ConcurrentSkipListMapCode Trails
ConcurrentSkipListMap .NodeClassutil.concurrent.ConcurrentSkipListMapCode Trails
ConcurrentSkipListMap .SubMapClassutil.concurrent.ConcurrentSkipListMapCode Trails
ConcurrentSkipListMap .ValuesClassutil.concurrent.ConcurrentSkipListMapCode Trails
ConcurrentSkipListSetA scalable concurrent NavigableSet implementation based on a ConcurrentSkipListMap.Classutil.concurrentCode Trails
ConditionCondition factors out the Object monitor methods (wait, notifyInterfaceutil.concurrent.locksCode Trails
CondVarThis class is designed for fans of POSIX pthreads programming.Classsun.corba.se.impl.orbutil.concurrentCode Trails
CopyOnWriteArrayListA thread-safe variant of ArrayList in which all mutative operations (add, set, and so on) are implemented byClassutil.concurrentCode Trails
CopyOnWriteArrayList .COWIteratorClassutil.concurrent.CopyOnWriteArrayListCode Trails
CopyOnWriteArrayList .COWSubListSublist for CopyOnWriteArrayList.Classutil.concurrent.CopyOnWriteArrayListCode Trails
CopyOnWriteArrayList .COWSubListIteratorClassutil.concurrent.CopyOnWriteArrayListCode Trails
CopyOnWriteArraySetA Set that uses an internal CopyOnWriteArrayList for all of its operations.Classutil.concurrentCode Trails
CountDownLatchA synchronization aid that allows one or more threads to wait until a set of operations being performed in other threads completes.Classutil.concurrentCode Trails
CountDownLatch .SyncSynchronization control For CountDownLatch.Classutil.concurrent.CountDownLatchCode Trails
CyclicBarrierA synchronization aid that allows a set of threads to all wait for each other to reach a common barrier point.Classutil.concurrentCode Trails
CyclicBarrier .GenerationEach use of the barrier is represented as a generation instance.Classutil.concurrent.CyclicBarrierCode Trails
DebugMutexClasssun.corba.se.impl.orbutil.concurrentCode Trails
DelayedA mix-in style interface for marking objects that should be acted upon after a given delay.Interfaceutil.concurrentCode Trails
DelayQueueAn unbounded blocking queue of Delayed elements, in which an element can only be takenClassutil.concurrentCode Trails
AbstractInProcessFutureAn abstract Future that has completedVersion:4.Classorg.infinispan.commons.util.concurrentInfinispan
AbstractInProcessNotifyingFutureAn abstract NotifyingFuture that has completedVersion:4.Classorg.infinispan.commons.util.concurrentInfinispan
BaseNotifyingFutureClassorg.infinispan.commons.util.concurrentInfinispan
CompositeNotifyingFutureCompositeNotifyingFuture aggregates several NotifyingFuture and completes when all of them complete.Classorg.infinispan.commons.util.concurrentInfinispan
ConcurrentWeakKeyHashMapAn alternative weak-key ConcurrentMap which is similar to ConcurrentHashMap.Classorg.infinispan.commons.util.concurrentInfinispan
ConcurrentWeakKeyHashMap .ReusableIteratorInterfaceorg.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMapInfinispan
FutureListenerA listener that is called back when a future is done.Interfaceorg.infinispan.commons.util.concurrentInfinispan
FuturesUtilities for NotifyingFuture composition.Classorg.infinispan.commons.util.concurrentInfinispan
NoOpFutureA future that doesn't do anything and simply returns a given return value.Classorg.infinispan.commons.util.concurrentInfinispan
NotifyingFutureA sub-interface of a Future, that allows for listeners to be attached so that observers can be notified of when the See FutureListener for more details.Interfaceorg.infinispan.commons.util.concurrentInfinispan
NotifyingFutureImplConstructs an instance of a NotifyingFuture.Classorg.infinispan.commons.util.concurrentInfinispan
NotifyingNotifiableFutureAn internal interface which adds the ability to inform the future of completion.Interfaceorg.infinispan.commons.util.concurrentInfinispan
ParallelIterableMapMap implementing this interface provide a mechanism for parallel key/value iteration.Interfaceorg.infinispan.commons.util.concurrentInfinispan
ConcurrentMultiMapAn implementation of a ConcurrentMultiMap Adds/remove is serialized over the specified keyClassakka.utilAkka
ConcurrentArrayQueueA concurrent, unbounded implementation of Queue that uses singly-linked array blocks This class is a drop-in replacement for ConcurrentLinkedQueue, with similar performanceClassorg.eclipse.jetty.utilJetty
ConcurrentArrayQueue .BlockClassorg.eclipse.jetty.util.ConcurrentArrayQueueJetty
ConcurrentHashSetClassorg.eclipse.jetty.utilJetty
ConcurrentHashIndexA fast threadsafe index that supports constant-time lookup in both directions.Classedu.stanford.nlp.util.concurrentStanford Parser
InterruptibleMulticoreWrapperClassedu.stanford.nlp.util.concurrentStanford Parser
MulticoreWrapperProvides convenient multicore processing for threadsafe objects.Classedu.stanford.nlp.util.concurrentStanford Parser
SynchronizedInterner For interning (canonicalizing) things in a multi-threaded environment.Classedu.stanford.nlp.util.concurrentStanford Parser
ThreadsafeProcessorObjects that wish to use MulticoreWrapper for multicore support must implement this interface.Interfaceedu.stanford.nlp.util.concurrentStanford Parser
AbstractCheckedFutureA delegating wrapper around a ListenableFuture that adds support for the checkedGet() and checkedGet(long, TimeUnit) methods.Classcom.google.common.util.concurrentGoogle Guava
AbstractExecutionThreadServiceBase class for services that can implement startUp(), run() and shutDown() methods.Classcom.google.common.util.concurrentGoogle Guava
AbstractFutureAn abstract implementation of the ListenableFuture interface.Classcom.google.common.util.concurrentGoogle Guava
AbstractIdleServiceBase class for services that do not need a thread while running but may need one during startup and shutdown.Classcom.google.common.util.concurrentGoogle Guava
AbstractListeningExecutorServiceAbstract ListeningExecutorService implementation that creates ListenableFutureTask instances for each Runnable and Callable submittedClasscom.google.common.util.concurrentGoogle Guava
AbstractScheduledServiceBase class for services that can implement startUp() and shutDown() but while in the running state need to perform a periodic task.Classcom.google.common.util.concurrentGoogle Guava
AbstractScheduledService .CustomSchedulerA AbstractScheduledService.Classcom.google.common.util.concurrent.AbstractScheduledServiceGoogle Guava
AbstractScheduledService .CustomScheduler .ScheduleA value object that represents an absolute delay until a task should be invoked.Classcom.google.common.util.concurrent.AbstractScheduledService.CustomSchedulerGoogle Guava
AbstractScheduledService .SchedulerA scheduler defines the policy for how the AbstractScheduledService should run its Consider using the newFixedDelaySchedule(long, long, java.Classcom.google.common.util.concurrent.AbstractScheduledServiceGoogle Guava
AbstractServiceBase class for implementing services that can handle doStart() and doStop() requests, responding to them with notifyStarted() and notifyStopped()Classcom.google.common.util.concurrentGoogle Guava
AsyncFunctionTransforms a value, possibly asynchronously.Interfacecom.google.common.util.concurrentGoogle Guava
AtomicDoubleA double value that may be updated atomically.Classcom.google.common.util.concurrentGoogle Guava
AtomicDoubleArrayA double array in which elements may be updated atomically.Classcom.google.common.util.concurrentGoogle Guava
AtomicLongMapA map containing long values that can be atomically updated.Classcom.google.common.util.concurrentGoogle Guava
AtomicsStatic utility methods pertaining to classes in the java.Classcom.google.common.util.concurrentGoogle Guava
CallablesStatic utility methods pertaining to the Callable interface.Classcom.google.common.util.concurrentGoogle Guava
CheckedFutureA CheckedFuture is a ListenableFuture that includes versions of the get methods that can throw a checked exception.Interfacecom.google.common.util.concurrentGoogle Guava
CycleDetectingLockFactoryThe CycleDetectingLockFactory creates ReentrantLock instances and ReentrantReadWriteLock instances that detect potential deadlock by checkingClasscom.google.common.util.concurrentGoogle Guava
CycleDetectingLockFactory .PoliciesPre-defined CycleDetectingLockFactory.Classcom.google.common.util.concurrent.CycleDetectingLockFactoryGoogle Guava
CycleDetectingLockFactory .PolicyEncapsulates the action to be taken when a potential deadlock is encountered.Interfacecom.google.common.util.concurrent.CycleDetectingLockFactoryGoogle Guava
CycleDetectingLockFactory .PotentialDeadlockExceptionRepresents a detected cycle in lock acquisition ordering.Classcom.google.common.util.concurrent.CycleDetectingLockFactoryGoogle Guava
CycleDetectingLockFactory .WithExplicitOrderingA CycleDetectingLockFactory.Classcom.google.common.util.concurrent.CycleDetectingLockFactoryGoogle Guava
ExecutionErrorError variant of ExecutionException.Classcom.google.common.util.concurrentGoogle Guava
ExecutionListA list of listeners, each with an associated Executor, that guarantees that every Runnable that is added willClasscom.google.common.util.concurrentGoogle Guava
FakeTimeLimiterA TimeLimiter implementation which actually does not attempt to limit time at all.Classcom.google.common.util.concurrentGoogle Guava
ForwardingBlockingQueueA BlockingQueue which forwards all its method calls to another BlockingQueue.Classcom.google.common.util.concurrentGoogle Guava
ForwardingCheckedFutureA future which forwards all its method calls to another future.Classcom.google.common.util.concurrentGoogle Guava
ForwardingCheckedFuture .SimpleForwardingCheckedFutureA simplified version of ForwardingCheckedFuture where subclasses can pass in an already constructed CheckedFuture as the delegate.Classcom.google.common.util.concurrent.ForwardingCheckedFutureGoogle Guava
ForwardingExecutorServiceAn executor service which forwards all its method calls to another executor service.Classcom.google.common.util.concurrentGoogle Guava
ForwardingFutureA Future which forwards all its method calls to another future.Classcom.google.common.util.concurrentGoogle Guava
ForwardingFuture .SimpleForwardingFutureA simplified version of ForwardingFuture where subclasses can pass in an already constructed Future as the delegate.Classcom.google.common.util.concurrent.ForwardingFutureGoogle Guava
ForwardingListenableFutureA ListenableFuture which forwards all its method calls to another future.Classcom.google.common.util.concurrentGoogle Guava
ForwardingListenableFuture .SimpleForwardingListenableFutureA simplified version of ForwardingListenableFuture where subclasses can pass in an already constructed ListenableFuture Classcom.google.common.util.concurrent.ForwardingListenableFutureGoogle Guava
ForwardingListeningExecutorServiceA listening executor service which forwards all its method calls to another listening executor service.Classcom.google.common.util.concurrentGoogle Guava
FutureCallbackA callback for accepting the results of a Future computation asynchronously.Interfacecom.google.common.util.concurrentGoogle Guava
FutureFallbackProvides a backup Future to replace an earlier failed Future.Interfacecom.google.common.util.concurrentGoogle Guava
FuturesStatic utility methods pertaining to the Future interface.Classcom.google.common.util.concurrentGoogle Guava
JdkFutureAdaptersUtilities necessary for working with libraries that supply plain Future instances.Classcom.google.common.util.concurrentGoogle Guava
ListenableFutureA Future that accepts completion listeners.Interfacecom.google.common.util.concurrentGoogle Guava
ListenableFutureTaskA FutureTask that also implements the ListenableFuture interface.Classcom.google.common.util.concurrentGoogle Guava
ListenableScheduledFutureHelper interface to implement both ListenableFuture andSince:15.Interfacecom.google.common.util.concurrentGoogle Guava
ListeningExecutorServiceAn ExecutorService that returns ListenableFuture instances.Interfacecom.google.common.util.concurrentGoogle Guava
ListeningScheduledExecutorServiceA ScheduledExecutorService that returns ListenableFuture instances from its ExecutorService methods.Interfacecom.google.common.util.concurrentGoogle Guava
MonitorA synchronization abstraction supporting waiting on arbitrary boolean conditions.Classcom.google.common.util.concurrentGoogle Guava
Monitor .GuardA boolean condition for which a thread may wait.Classcom.google.common.util.concurrent.MonitorGoogle Guava
MoreExecutorsFactory and utility methods for Executor, ExecutorService, and ThreadFactory.Classcom.google.common.util.concurrentGoogle Guava
RateLimiterA rate limiter.Classcom.google.common.util.concurrentGoogle Guava
RunnablesStatic utility methods pertaining to the Runnable interface.Classcom.google.common.util.concurrentGoogle Guava
ServiceAn object with an operational state, plus asynchronous startAsync() and stopAsync() lifecycle methods to transition between states.Interfacecom.google.common.util.concurrentGoogle Guava
Service .ListenerA listener for the various state changes that a Service goes through in its lifecycle.Classcom.google.common.util.concurrent.ServiceGoogle Guava
Service .StateThe lifecycle states of a service.Classcom.google.common.util.concurrent.ServiceGoogle Guava
ServiceManagerA manager for monitoring and controlling a set of services.Classcom.google.common.util.concurrentGoogle Guava
ServiceManager .ListenerA listener for the aggregate state changes of the services that are under management.Classcom.google.common.util.concurrent.ServiceManagerGoogle Guava
SettableFutureA ListenableFuture whose result may be set by a set(Object) or setException(Throwable) call.Classcom.google.common.util.concurrentGoogle Guava
SimpleTimeLimiterA TimeLimiter that runs method calls in the background using an ExecutorService.Classcom.google.common.util.concurrentGoogle Guava
StripedA striped Lock/Semaphore/ReadWriteLock.Classcom.google.common.util.concurrentGoogle Guava
ThreadFactoryBuilderA ThreadFactory builder, providing any combination of these features: whether threads should be marked as daemonClasscom.google.common.util.concurrentGoogle Guava
TimeLimiterProduces proxies that impose a time limit on method calls to the proxied object.Interfacecom.google.common.util.concurrentGoogle Guava
UncaughtExceptionHandlersFactories for Thread.Classcom.google.common.util.concurrentGoogle Guava
UncheckedExecutionExceptionUnchecked variant of ExecutionException.Classcom.google.common.util.concurrentGoogle Guava
UncheckedTimeoutExceptionUnchecked version of TimeoutException.Classcom.google.common.util.concurrentGoogle Guava
UninterruptiblesUtilities for treating interruptible operations as uninterruptible.Classcom.google.common.util.concurrentGoogle Guava
AbstractEventExecutorAbstract base class for EventExecutor implementations.Classio.netty.util.concurrentNetty
AbstractEventExecutorGroupAbstract base class for EventExecutorGroup implementations.Classio.netty.util.concurrentNetty
AbstractFutureAbstract Future implementation which does not allow for cancellation.Classio.netty.util.concurrentNetty
AbstractScheduledEventExecutorAbstract base class for EventExecutors that want to support scheduling.Classio.netty.util.concurrentNetty
BlockingOperationExceptionAn IllegalStateException which is raised when a user performed a blocking operationwhen the user is in an event loop thread.Classio.netty.util.concurrentNetty
CompleteFutureA skeletal Future implementation which represents a Future which has been completed already.Classio.netty.util.concurrentNetty
DefaultEventExecutorClassio.netty.util.concurrentNetty
DefaultEventExecutorGroupDefault implementation of MultithreadEventExecutorGroup which will use DefaultEventExecutorinstances to handle the tasks.Classio.netty.util.concurrentNetty
DefaultExecutorServiceFactoryAn implementation of an ExecutorServiceFactory that creates a new ForkJoinPool on eachcall to newExecutorService(int).Classio.netty.util.concurrentNetty
DefaultProgressivePromiseClassio.netty.util.concurrentNetty
DefaultPromiseClassio.netty.util.concurrentNetty
DefaultThreadFactoryA ThreadFactory implementation with a simple naming rule.Classio.netty.util.concurrentNetty
EventExecutorThe EventExecutor is a special EventExecutorGroup which comeswith some handy methods to see if a Thread is executed in a event loop.Interfaceio.netty.util.concurrentNetty
EventExecutorGroupThe EventExecutorGroup is responsible for providing the EventExecutor's to usevia its next() method.Interfaceio.netty.util.concurrentNetty
ExecutorServiceFactoryAn object that creates new ExecutorService on demand.Interfaceio.netty.util.concurrentNetty
FailedFutureThe CompleteFuture which is failed already.Classio.netty.util.concurrentNetty
FastThreadLocalA special variant of ThreadLocal that yields higher access performance when accessed from aFastThreadLocalThread.Classio.netty.util.concurrentNetty
FastThreadLocalAccessNetty's Thread implementations implement this interface to provide fast access to FastThreadLocalSee Also:FastThreadLocalThreadInterfaceio.netty.util.concurrentNetty
FastThreadLocalThreadA special Thread that provides fast access to FastThreadLocal variables.Classio.netty.util.concurrentNetty
FutureThe result of an asynchronous operation.Interfaceio.netty.util.concurrentNetty
FutureListenerA subtype of GenericFutureListener that hides type parameter for convenience.Interfaceio.netty.util.concurrentNetty
GenericFutureListenerListens to the result of a Future.Interfaceio.netty.util.concurrentNetty
GenericProgressiveFutureListenerInterfaceio.netty.util.concurrentNetty
GlobalEventExecutorSingle-thread singleton EventExecutor.Classio.netty.util.concurrentNetty
ImmediateEventExecutorAbstractEventExecutor which execute tasks in the callers thread.Classio.netty.util.concurrentNetty
ImmediateExecutorExecutor which execute tasks in the callers thread.Classio.netty.util.concurrentNetty
MultithreadEventExecutorGroupClassio.netty.util.concurrentNetty
PausableEventExecutorInterfaceio.netty.util.concurrentNetty
ProgressiveFutureA Future which is used to indicate the progress of an operation.Interfaceio.netty.util.concurrentNetty
ProgressivePromiseSpecial ProgressiveFuture which is writable.Interfaceio.netty.util.concurrentNetty
PromiseSpecial Future which is writable.Interfaceio.netty.util.concurrentNetty
PromiseAggregatorGenericFutureListener implementation which consolidates multiple Futuresinto one, by listening to individual Futures and producing an aggregated resultClassio.netty.util.concurrentNetty
PromiseNotifierGenericFutureListener implementation which takes other Futuresand notifies them on completion.Classio.netty.util.concurrentNetty
ScheduledFutureThe result of an scheduled asynchronous operation.Interfaceio.netty.util.concurrentNetty
SingleThreadEventExecutorAbstract base class for EventExecutor's that execute all its submitted tasks in a single thread.Classio.netty.util.concurrentNetty
SucceededFutureThe CompleteFuture which is succeeded already.Classio.netty.util.concurrentNetty
ThreadPerTaskExecutorClassio.netty.util.concurrentNetty
WrappedEventExecutorA marker interface indicating that the EventExecutor is a wrapper aroundanother EventExecutor implementation.Interfaceio.netty.util.concurrentNetty
AbortExceptionThrown when a task is aborted.Classorg.apache.pivot.util.concurrentApache Pivot
TaskAbstract base class for tasks.Classorg.apache.pivot.util.concurrentApache Pivot
TaskExecutionExceptionThrown when an error occurs during task execution.Classorg.apache.pivot.util.concurrentApache Pivot
TaskGroupTask that runs a group of tasks in parallel and notifies listeners when all tasks are complete.Classorg.apache.pivot.util.concurrentApache Pivot
TaskListenerTask listener interface.Interfaceorg.apache.pivot.util.concurrentApache Pivot
TaskSequenceTask that runs a sequence of tasks in series and notifies listeners when all tasks are complete.Classorg.apache.pivot.util.concurrentApache Pivot
TimeoutExceptionThrown when an executing task has timed out.Classorg.apache.pivot.util.concurrentApache Pivot
ConcurrentHashSet S e e A l s o : S e r i a l i z e d F o r m C o n s t r u c t o r S u m m a r y C o n c u r r e n t H a s h S e t ( ) Classcom.liferay.portal.kernel.utilLiferay Portal
ConcurrentCacheThe ConcurrentCache interface is used to represent a cache that will store key value pairs.Classorg.simpleframework.xml.utilSimple
AsyncConditionsAlternative to class BlockingVariable(s) that allows to evaluate conditions in a thread other than the spec runner's thread(s).Classspock.util.concurrentSpock
BlockingVariableA statically typed variable whose get() method will block until some other thread has set a value with the set() method, or a timeout expires.Classspock.util.concurrentSpock
PollingConditionsRepeatedly evaluates one or more conditions until they are satisfied or a timeout has elapsed.Classspock.util.concurrentSpock
ConcurrentHashIndexA fast threadsafe index that supports constant-time lookup in both directions.Classedu.stanford.nlp.util.concurrentJavaNlp
InterruptibleMulticoreWrapperClassedu.stanford.nlp.util.concurrentJavaNlp
MulticoreWrapperProvides convenient multicore processing for threadsafe objects.Classedu.stanford.nlp.util.concurrentJavaNlp
SynchronizedInterner For interning (canonicalizing) things in a multi-threaded environment.Classedu.stanford.nlp.util.concurrentJavaNlp
ThreadsafeProcessorObjects that wish to use MulticoreWrapper for multicore support must implement this interface.Interfaceedu.stanford.nlp.util.concurrentJavaNlp
ConcurrentModificationExceptionAn ConcurrentModificationException is thrown when a Collection is modified and an existing iterator on the Collection is used to modify theClassjava.utilCodeName One
ConcurrentHashSetThis class implements the Set interface, backed by a ConcurrentHashMap instance.Classorg.jivesoftware.utilOpenFire
AbstractHaltableProcessAbstract base class for tasks whose processing may be halted asynchronously.Classcom.bigdata.util.concurrentBlazeGraph
BufferedConcurrentHashMapA hash table supporting full concurrency of retrievals and adjustable expected concurrency for updates.Classorg.infinispan.util.concurrentBlazeGraph
BufferedConcurrentHashMap .EvictionClassorg.infinispan.util.concurrentBlazeGraph
BufferedConcurrentHashMap .EvictionListenerInterfaceorg.infinispan.util.concurrentBlazeGraph
CanonicalFactoryA pattern for a canonicalizing factory based on a map with weak values.Classcom.bigdata.util.concurrentBlazeGraph
ComputableSomething which computes one value from another.Interfacecom.bigdata.util.concurrentBlazeGraph
DeltaMovingAverageTaskMoving average based on the change in some sampled value.Classcom.bigdata.util.concurrentBlazeGraph
ExecutionExceptionsClass enumerates all exceptions thrown for a set of tasks.Classcom.bigdata.util.concurrentBlazeGraph
ExecutionHelperHelper class for managing the execution of a set of Callable tasks on an ExecutorService.Classcom.bigdata.util.concurrentBlazeGraph
HaltableAbstract base class for tasks whose processing may be halted asynchronously.Classcom.bigdata.util.concurrentBlazeGraph
IHaltableInterface extends Future and provides an interface for managing the termination of a process from within that process.Interfacecom.bigdata.util.concurrentBlazeGraph
IQueueCountersInterface defines and documents the names and meanings of counters pertaining to blocking queues (of tasks) and services executing tasks and includesInterfacecom.bigdata.util.concurrentBlazeGraph
IQueueCounters .ITaskCountersCounters defined by TaskCounters.Interfacecom.bigdata.util.concurrentBlazeGraph
IQueueCounters .IThreadPoolExecutorCountersAdditional counters available for any ThreadPoolExecutor.Interfacecom.bigdata.util.concurrentBlazeGraph
IQueueCounters .IThreadPoolExecutorTaskCountersAdditional counters available for any ThreadPoolExecutor which is processing AbstractTasks.Interfacecom.bigdata.util.concurrentBlazeGraph
IQueueCounters .IWriteServiceExecutorCountersAdditional counters available for the WriteServiceExecutor.Interfacecom.bigdata.util.concurrentBlazeGraph
LatchA synchronization aid that allows one or more threads to await a counter becoming zero.Classcom.bigdata.util.concurrentBlazeGraph
LatchedExecutorA fly weight helper class that runs tasks either sequentially or with limited parallelism against some thread pool.Classcom.bigdata.util.concurrentBlazeGraph
MappedTaskExecutorA fly weight helper class that runs tasks either sequentially or with limited parallelism against some thread pool.Classcom.bigdata.util.concurrentBlazeGraph
MemoizerPattern using a FutureTask to force synchronization only on tasks waiting for the same computation.Classcom.bigdata.util.concurrentBlazeGraph
MonitoredFutureTaskHelper task for monitoring the results of otherwise unwatched tasks.Classcom.bigdata.util.concurrentBlazeGraph
MovingAverageTaskClass tracks a the moving average of some sampled datum.Classcom.bigdata.util.concurrentBlazeGraph
QueueSizeMovingAverageTaskClass tracks the moving average of the queue size.Classcom.bigdata.util.concurrentBlazeGraph
ShutdownHelperHelper class for normal shutdown of an ExecutorService.Classcom.bigdata.util.concurrentBlazeGraph
TaskCountersClass captures various data about the execution of AbstractTasks.Classcom.bigdata.util.concurrentBlazeGraph
TestAllAggregates test suites in increasing dependency order.Classcom.bigdata.util.concurrentBlazeGraph
TestHaltableTest suite for Haltable.Classcom.bigdata.util.concurrentBlazeGraph
TestLatchUnit tests for Latch.Classcom.bigdata.util.concurrentBlazeGraph
ThreadGuardPattern used to guard critical regions that await Conditions when a concurrent event may cause the Condition to become unsatisfiable.Classcom.bigdata.util.concurrentBlazeGraph
ThreadGuard .GuardClasscom.bigdata.util.concurrentBlazeGraph
ThreadPoolExecutorBaseStatisticsTaskClass tracks a variety of information about a ThreadPoolExecutor including the moving average of its queue length, queue size, average activeClasscom.bigdata.util.concurrentBlazeGraph
ThreadPoolExecutorStatisticsTaskClass tracks a variety of information about a ThreadPoolExecutor including the moving average of its queue length, queuing times, etc.Classcom.bigdata.util.concurrentBlazeGraph
WriteTaskCountersClasscom.bigdata.util.concurrentBlazeGraph
CallableFromRunnableWraps a Runnable as a Callable.Classbrooklyn.util.concurrentBrooklyn
ConcurrentUpdateHandlerHandles a a series of updates or events to handle as one.Classlnb.utilLNB
ConcurrentLogjdk-based logger tend to block at java.Classnet.yacy.cora.utilYacy
ConcurrentLog .MessageClassnet.yacy.cora.utilYacy
ConcurrentLog .WorkerClassnet.yacy.cora.utilYacy