Search Java Classes and Packages

Search Java Frameworks and Libraries

255581 classes and counting ...
Search Tips Index Status



#Java.util.concurrent Classes and Interfaces - 102 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
ConcurrentModificationExceptionAn ConcurrentModificationException is thrown when a Collection is modified and an existing iterator on the Collection is used to modify theClassjava.utilCodeName One