Java.Util.Concurrent Namespace

Implementations.

Classes ThreadPoolExecutor and ScheduledThreadPoolExecutor provide tunable, flexible thread pools.

Classes

AbstractExecutorService

Provides default implementations of ExecutorService execution methods.

ArrayBlockingQueue

A bounded BlockingQueue blocking queue backed by an array.

BrokenBarrierException

Exception thrown when a thread tries to wait upon a barrier that is in a broken state, or which enters the broken state while the thread is waiting.

CancellationException

Exception indicating that the result of a value-producing task, such as a FutureTask, cannot be retrieved because the task was cancelled.

CompletableFuture

A Future that may be explicitly completed (setting its value and status), and may be used as a CompletionStage, supporting dependent functions and actions that trigger upon its completion.

CompletionException

Exception thrown when an error or other exception is encountered in the course of completing a result or task.

ConcurrentHashMap

A hash table supporting full concurrency of retrievals and high expected concurrency for updates.

ConcurrentLinkedDeque

An unbounded concurrent Deque deque based on linked nodes.

ConcurrentLinkedQueue

An unbounded thread-safe Queue queue based on linked nodes.

ConcurrentSkipListMap

A scalable concurrent ConcurrentNavigableMap implementation.

CopyOnWriteArrayList

A thread-safe variant of java.util.ArrayList in which all mutative operations (add, set, and so on) are implemented by making a fresh copy of the underlying array.

CopyOnWriteArraySet

A Set that uses an internal CopyOnWriteArrayList for all of its operations.

CountDownLatch

A synchronization aid that allows one or more threads to wait until a set of operations being performed in other threads completes.

CountedCompleter

A ForkJoinTask with a completion action performed when triggered and there are no remaining pending actions.

CyclicBarrier

A synchronization aid that allows a set of threads to all wait for each other to reach a common barrier point.

DelayQueue

An unbounded BlockingQueue blocking queue of Delayed elements, in which an element can only be taken when its delay has expired.

Exchanger

A synchronization point at which threads can pair and swap elements within pairs.

ExecutionException

Exception thrown when attempting to retrieve the result of a task that aborted by throwing an exception.

ExecutorCompletionService

A CompletionService that uses a supplied Executor to execute tasks.

Executors

Factory and utility methods for Executor, ExecutorService, ScheduledExecutorService, ThreadFactory, and Callable classes defined in this package.

Flow

Interrelated interfaces and static methods for establishing flow-controlled components in which Publisher Publishers produce items consumed by one or more Subscriber Subscribers, each managed by a Subscription Subscription.

ForkJoinPool

An ExecutorService for running ForkJoinTasks.

ForkJoinTask

Abstract base class for tasks that run within a ForkJoinPool.

ForkJoinWorkerThread

A thread managed by a ForkJoinPool, which executes ForkJoinTasks.

FutureTask

A cancellable asynchronous computation.

IBlockingDequeExtensions
IBlockingQueueExtensions
IExecutorServiceExtensions
IFutureExtensions
LinkedBlockingDeque

An optionally-bounded BlockingDeque blocking deque based on linked nodes.

LinkedBlockingQueue

An optionally-bounded BlockingQueue blocking queue based on linked nodes.

LinkedTransferQueue

An unbounded TransferQueue based on linked nodes.

Phaser

A reusable synchronization barrier, similar in functionality to CyclicBarrier and CountDownLatch but supporting more flexible usage.

PriorityBlockingQueue

An unbounded BlockingQueue blocking queue that uses the same ordering rules as class PriorityQueue and supplies blocking retrieval operations.

RecursiveAction

A recursive resultless ForkJoinTask.

RecursiveTask

A recursive result-bearing ForkJoinTask.

RejectedExecutionException

Exception thrown by an Executor when a task cannot be accepted for execution.

ScheduledThreadPoolExecutor

A ThreadPoolExecutor that can additionally schedule commands to run after a given delay, or to execute periodically.

Semaphore

A counting semaphore.

SubmissionPublisher

A Flow.Publisher that asynchronously issues submitted (non-null) items to current subscribers until it is closed.

SynchronousQueue

A BlockingQueue blocking queue in which each insert operation must wait for a corresponding remove operation by another thread, and vice versa.

ThreadLocalRandom

A random number generator (with period 2<sup>64</sup>) isolated to the current thread.

ThreadPoolExecutor

An ExecutorService that executes each submitted task using one of possibly several pooled threads, normally configured using Executors factory methods.

ThreadPoolExecutor.AbortPolicy

A handler for rejected tasks that throws a RejectedExecutionException.

ThreadPoolExecutor.CallerRunsPolicy

A handler for rejected tasks that runs the rejected task directly in the calling thread of the execute method, unless the executor has been shut down, in which case the task is discarded.

ThreadPoolExecutor.DiscardOldestPolicy

A handler for rejected tasks that discards the oldest unhandled request and then retries execute, unless the executor is shut down, in which case the task is discarded.

ThreadPoolExecutor.DiscardPolicy

A handler for rejected tasks that silently discards the rejected task.

TimeoutException

Exception thrown when a blocking operation times out.

TimeUnit

A TimeUnit represents time durations at a given unit of granularity and provides utility methods to convert across units, and to perform timing and delay operations in these units.

Interfaces

CompletableFuture.IAsynchronousCompletionTask

A marker interface identifying asynchronous tasks produced by async methods.

Flow.IProcessor

A component that acts as both a Subscriber and Publisher.

Flow.IPublisher

A producer of items (and related control messages) received by Subscribers.

Flow.ISubscriber

A receiver of messages.

Flow.ISubscription

Message control linking a Publisher and Subscriber.

ForkJoinPool.IForkJoinWorkerThreadFactory

Factory for creating new ForkJoinWorkerThreads.

ForkJoinPool.IManagedBlocker

Interface for extending managed parallelism for tasks running in ForkJoinPools.

IBlockingDeque

A Deque that additionally supports blocking operations that wait for the deque to become non-empty when retrieving an element, and wait for space to become available in the deque when storing an element.

IBlockingQueue

A Queue that additionally supports operations that wait for the queue to become non-empty when retrieving an element, and wait for space to become available in the queue when storing an element.

ICallable

A task that returns a result and may throw an exception.

ICompletionService

A service that decouples the production of new asynchronous tasks from the consumption of the results of completed tasks.

ICompletionStage

A stage of a possibly asynchronous computation, that performs an action or computes a value when another CompletionStage completes.

IConcurrentMap

A Map providing thread safety and atomicity guarantees.

IDelayed

A mix-in style interface for marking objects that should be acted upon after a given delay.

IExecutor

An object that executes submitted Runnable tasks.

IExecutorService

An Executor that provides methods to manage termination and methods that can produce a Future for tracking progress of one or more asynchronous tasks.

IFuture

A Future represents the result of an asynchronous computation.

IRejectedExecutionHandler

A handler for tasks that cannot be executed by a ThreadPoolExecutor.

IRunnableFuture

A Future that is Runnable.

IRunnableScheduledFuture

A ScheduledFuture that is Runnable.

IScheduledExecutorService

An ExecutorService that can schedule commands to run after a given delay, or to execute periodically.

IScheduledFuture

A delayed result-bearing action that can be cancelled.

IThreadFactory

An object that creates new threads on demand.

ITransferQueue

A BlockingQueue in which producers may wait for consumers to receive elements.