A B C D E F G H I J L M N O P Q R S T 

A

adapt(Runnable) - Static method in class jsr166y.ForkJoinTask
Returns a new ForkJoinTask that performs the run method of the given Runnable as its action, and returns a null result upon ForkJoinTask.join().
adapt(Runnable, T) - Static method in class jsr166y.ForkJoinTask
Returns a new ForkJoinTask that performs the run method of the given Runnable as its action, and returns the given result upon ForkJoinTask.join().
adapt(Callable<? extends T>) - Static method in class jsr166y.ForkJoinTask
Returns a new ForkJoinTask that performs the call method of the given Callable as its action, and returns its result upon ForkJoinTask.join(), translating any checked exceptions encountered into RuntimeException.
add(E) - Method in class jsr166y.LinkedTransferQueue
Inserts the specified element at the tail of this queue.
arrive() - Method in class jsr166y.Phaser
Arrives at this phaser, without waiting for others to arrive.
arriveAndAwaitAdvance() - Method in class jsr166y.Phaser
Arrives at this phaser and awaits others.
arriveAndDeregister() - Method in class jsr166y.Phaser
Arrives at this phaser and deregisters from it without waiting for others to arrive.
awaitAdvance(int) - Method in class jsr166y.Phaser
Awaits the phase of this phaser to advance from the given phase value, returning immediately if the current phase is not equal to the given phase value or this phaser is terminated.
awaitAdvanceInterruptibly(int) - Method in class jsr166y.Phaser
Awaits the phase of this phaser to advance from the given phase value, throwing InterruptedException if interrupted while waiting, or returning immediately if the current phase is not equal to the given phase value or this phaser is terminated.
awaitAdvanceInterruptibly(int, long, TimeUnit) - Method in class jsr166y.Phaser
Awaits the phase of this phaser to advance from the given phase value or the given timeout to elapse, throwing InterruptedException if interrupted while waiting, or returning immediately if the current phase is not equal to the given phase value or this phaser is terminated.
awaitTermination(long, TimeUnit) - Method in class jsr166y.ForkJoinPool
Blocks until all tasks have completed execution after a shutdown request, or the timeout occurs, or the current thread is interrupted, whichever happens first.

B

block() - Method in interface jsr166y.ForkJoinPool.ManagedBlocker
Possibly blocks the current thread, for example waiting for a lock or condition.
bulkRegister(int) - Method in class jsr166y.Phaser
Adds the given number of new unarrived parties to this phaser.

C

cancel(boolean) - Method in class jsr166y.ForkJoinTask
Attempts to cancel execution of this task.
complete(V) - Method in class jsr166y.ForkJoinTask
Completes this task, and if not already aborted or cancelled, returning the given value as the result of subsequent invocations of join and related operations.
completeExceptionally(Throwable) - Method in class jsr166y.ForkJoinTask
Completes this task abnormally, and if not already aborted or cancelled, causes it to throw the given exception upon join and related operations.
compute() - Method in class jsr166y.RecursiveAction
The main computation performed by this task.
compute() - Method in class jsr166y.RecursiveTask
The main computation performed by this task.
contains(Object) - Method in class jsr166y.LinkedTransferQueue
Returns true if this queue contains the specified element.
current() - Static method in class jsr166y.ThreadLocalRandom
Returns the current thread's ThreadLocalRandom.

D

defaultForkJoinWorkerThreadFactory - Static variable in class jsr166y.ForkJoinPool
Creates a new ForkJoinWorkerThread.
drainTasksTo(Collection<? super ForkJoinTask<?>>) - Method in class jsr166y.ForkJoinPool
Removes all available unexecuted submitted and forked tasks from scheduling queues and adds them to the given collection, without altering their execution status.
drainTo(Collection<? super E>) - Method in class jsr166y.LinkedTransferQueue
 
drainTo(Collection<? super E>, int) - Method in class jsr166y.LinkedTransferQueue
 

E

exec() - Method in class jsr166y.ForkJoinTask
Immediately performs the base action of this task.
exec() - Method in class jsr166y.RecursiveAction
Implements execution conventions for RecursiveActions.
exec() - Method in class jsr166y.RecursiveTask
Implements execution conventions for RecursiveTask.
execute(ForkJoinTask<?>) - Method in class jsr166y.ForkJoinPool
Arranges for (asynchronous) execution of the given task.
execute(Runnable) - Method in class jsr166y.ForkJoinPool
 

F

forceTermination() - Method in class jsr166y.Phaser
Forces this phaser to enter termination state.
fork() - Method in class jsr166y.ForkJoinTask
Arranges to asynchronously execute this task.
ForkJoinPool - Class in jsr166y
An ExecutorService for running ForkJoinTasks.
ForkJoinPool() - Constructor for class jsr166y.ForkJoinPool
Creates a ForkJoinPool with parallelism equal to Runtime.availableProcessors(), using the default thread factory, no UncaughtExceptionHandler, and non-async LIFO processing mode.
ForkJoinPool(int) - Constructor for class jsr166y.ForkJoinPool
Creates a ForkJoinPool with the indicated parallelism level, the default thread factory, no UncaughtExceptionHandler, and non-async LIFO processing mode.
ForkJoinPool(int, ForkJoinPool.ForkJoinWorkerThreadFactory, Thread.UncaughtExceptionHandler, boolean) - Constructor for class jsr166y.ForkJoinPool
Creates a ForkJoinPool with the given parameters.
ForkJoinPool.ForkJoinWorkerThreadFactory - Interface in jsr166y
Factory for creating new ForkJoinWorkerThreads.
ForkJoinPool.ManagedBlocker - Interface in jsr166y
Interface for extending managed parallelism for tasks running in ForkJoinPools.
ForkJoinTask<V> - Class in jsr166y
Abstract base class for tasks that run within a ForkJoinPool.
ForkJoinTask() - Constructor for class jsr166y.ForkJoinTask
 
ForkJoinWorkerThread - Class in jsr166y
A thread managed by a ForkJoinPool, which executes ForkJoinTasks.
ForkJoinWorkerThread(ForkJoinPool) - Constructor for class jsr166y.ForkJoinWorkerThread
Creates a ForkJoinWorkerThread operating in the given pool.

G

get() - Method in class jsr166y.ForkJoinTask
Waits if necessary for the computation to complete, and then retrieves its result.
get(long, TimeUnit) - Method in class jsr166y.ForkJoinTask
Waits if necessary for at most the given time for the computation to complete, and then retrieves its result, if available.
getActiveThreadCount() - Method in class jsr166y.ForkJoinPool
Returns an estimate of the number of threads that are currently stealing or executing tasks.
getArrivedParties() - Method in class jsr166y.Phaser
Returns the number of registered parties that have arrived at the current phase of this phaser.
getAsyncMode() - Method in class jsr166y.ForkJoinPool
Returns true if this pool uses local first-in-first-out scheduling mode for forked tasks that are never joined.
getException() - Method in class jsr166y.ForkJoinTask
Returns the exception thrown by the base computation, or a CancellationException if cancelled, or null if none or if the method has not yet completed.
getFactory() - Method in class jsr166y.ForkJoinPool
Returns the factory used for constructing new workers.
getParallelism() - Method in class jsr166y.ForkJoinPool
Returns the targeted parallelism level of this pool.
getParent() - Method in class jsr166y.Phaser
Returns the parent of this phaser, or null if none.
getPhase() - Method in class jsr166y.Phaser
Returns the current phase number.
getPool() - Static method in class jsr166y.ForkJoinTask
Returns the pool hosting the current task execution, or null if this task is executing outside of any ForkJoinPool.
getPool() - Method in class jsr166y.ForkJoinWorkerThread
Returns the pool hosting this thread.
getPoolIndex() - Method in class jsr166y.ForkJoinWorkerThread
Returns the index number of this thread in its pool.
getPoolSize() - Method in class jsr166y.ForkJoinPool
Returns the number of worker threads that have started but not yet terminated.
getQueuedSubmissionCount() - Method in class jsr166y.ForkJoinPool
Returns an estimate of the number of tasks submitted to this pool that have not yet begun executing.
getQueuedTaskCount() - Method in class jsr166y.ForkJoinPool
Returns an estimate of the total number of tasks currently held in queues by worker threads (but not including tasks submitted to the pool that have not begun executing).
getQueuedTaskCount() - Static method in class jsr166y.ForkJoinTask
Returns an estimate of the number of tasks that have been forked by the current worker thread but not yet executed.
getRawResult() - Method in class jsr166y.ForkJoinTask
Returns the result that would be returned by ForkJoinTask.join(), even if this task completed abnormally, or null if this task is not known to have been completed.
getRawResult() - Method in class jsr166y.RecursiveAction
Always returns null.
getRawResult() - Method in class jsr166y.RecursiveTask
 
getRegisteredParties() - Method in class jsr166y.Phaser
Returns the number of parties registered at this phaser.
getRoot() - Method in class jsr166y.Phaser
Returns the root ancestor of this phaser, which is the same as this phaser if it has no parent.
getRunningThreadCount() - Method in class jsr166y.ForkJoinPool
Returns an estimate of the number of worker threads that are not blocked waiting to join tasks or for other managed synchronization.
getStealCount() - Method in class jsr166y.ForkJoinPool
Returns an estimate of the total number of tasks stolen from one thread's work queue by another.
getSurplusQueuedTaskCount() - Static method in class jsr166y.ForkJoinTask
Returns an estimate of how many more locally queued tasks are held by the current worker thread than there are other worker threads that might steal them.
getUnarrivedParties() - Method in class jsr166y.Phaser
Returns the number of registered parties that have not yet arrived at the current phase of this phaser.
getUncaughtExceptionHandler() - Method in class jsr166y.ForkJoinPool
Returns the handler for internal worker threads that terminate due to unrecoverable errors encountered while executing tasks.
getWaitingConsumerCount() - Method in class jsr166y.LinkedTransferQueue
 
getWaitingConsumerCount() - Method in interface jsr166y.TransferQueue
Returns an estimate of the number of consumers waiting to receive elements via BlockingQueue.take() or timed poll.

H

hasQueuedSubmissions() - Method in class jsr166y.ForkJoinPool
Returns true if there are any tasks submitted to this pool that have not yet begun executing.
hasWaitingConsumer() - Method in class jsr166y.LinkedTransferQueue
 
hasWaitingConsumer() - Method in interface jsr166y.TransferQueue
Returns true if there is at least one consumer waiting to receive an element via BlockingQueue.take() or timed poll.
helpQuiesce() - Static method in class jsr166y.ForkJoinTask
Possibly executes tasks until the pool hosting the current task is quiescent.

I

inForkJoinPool() - Static method in class jsr166y.ForkJoinTask
Returns true if the current thread is a ForkJoinWorkerThread executing as a ForkJoinPool computation.
invoke(ForkJoinTask<T>) - Method in class jsr166y.ForkJoinPool
Performs the given task, returning its result upon completion.
invoke() - Method in class jsr166y.ForkJoinTask
Commences performing this task, awaits its completion if necessary, and returns its result, or throws an (unchecked) RuntimeException or Error if the underlying computation did so.
invokeAll(Collection<? extends Callable<T>>) - Method in class jsr166y.ForkJoinPool
 
invokeAll(ForkJoinTask<?>, ForkJoinTask<?>) - Static method in class jsr166y.ForkJoinTask
Forks the given tasks, returning when isDone holds for each task or an (unchecked) exception is encountered, in which case the exception is rethrown.
invokeAll(ForkJoinTask<?>...) - Static method in class jsr166y.ForkJoinTask
Forks the given tasks, returning when isDone holds for each task or an (unchecked) exception is encountered, in which case the exception is rethrown.
invokeAll(Collection<T>) - Static method in class jsr166y.ForkJoinTask
Forks all tasks in the specified collection, returning when isDone holds for each task or an (unchecked) exception is encountered, in which case the exception is rethrown.
isCancelled() - Method in class jsr166y.ForkJoinTask
 
isCompletedAbnormally() - Method in class jsr166y.ForkJoinTask
Returns true if this task threw an exception or was cancelled.
isCompletedNormally() - Method in class jsr166y.ForkJoinTask
Returns true if this task completed without throwing an exception and was not cancelled.
isDone() - Method in class jsr166y.ForkJoinTask
 
isEmpty() - Method in class jsr166y.LinkedTransferQueue
Returns true if this queue contains no elements.
isQuiescent() - Method in class jsr166y.ForkJoinPool
Returns true if all worker threads are currently idle.
isReleasable() - Method in interface jsr166y.ForkJoinPool.ManagedBlocker
Returns true if blocking is unnecessary.
isShutdown() - Method in class jsr166y.ForkJoinPool
Returns true if this pool has been shut down.
isTerminated() - Method in class jsr166y.ForkJoinPool
Returns true if all tasks have completed following shut down.
isTerminated() - Method in class jsr166y.Phaser
Returns true if this phaser has been terminated.
isTerminating() - Method in class jsr166y.ForkJoinPool
Returns true if the process of termination has commenced but not yet completed.
iterator() - Method in class jsr166y.LinkedTransferQueue
Returns an iterator over the elements in this queue in proper sequence, from head to tail.

J

join() - Method in class jsr166y.ForkJoinTask
Returns the result of the computation when it is done.
jsr166y - package jsr166y
Preview versions of classes targeted for Java 7.

L

LinkedTransferQueue<E> - Class in jsr166y
An unbounded TransferQueue based on linked nodes.
LinkedTransferQueue() - Constructor for class jsr166y.LinkedTransferQueue
Creates an initially empty LinkedTransferQueue.
LinkedTransferQueue(Collection<? extends E>) - Constructor for class jsr166y.LinkedTransferQueue
Creates a LinkedTransferQueue initially containing the elements of the given collection, added in traversal order of the collection's iterator.

M

managedBlock(ForkJoinPool.ManagedBlocker) - Static method in class jsr166y.ForkJoinPool
Blocks in accord with the given blocker.

N

newTaskFor(Runnable, T) - Method in class jsr166y.ForkJoinPool
 
newTaskFor(Callable<T>) - Method in class jsr166y.ForkJoinPool
 
newThread(ForkJoinPool) - Method in interface jsr166y.ForkJoinPool.ForkJoinWorkerThreadFactory
Returns a new worker thread operating in the given pool.
next(int) - Method in class jsr166y.ThreadLocalRandom
 
nextDouble(double) - Method in class jsr166y.ThreadLocalRandom
Returns a pseudorandom, uniformly distributed double value between 0 (inclusive) and the specified value (exclusive).
nextDouble(double, double) - Method in class jsr166y.ThreadLocalRandom
Returns a pseudorandom, uniformly distributed value between the given least value (inclusive) and bound (exclusive).
nextInt(int, int) - Method in class jsr166y.ThreadLocalRandom
Returns a pseudorandom, uniformly distributed value between the given least value (inclusive) and bound (exclusive).
nextLong(long) - Method in class jsr166y.ThreadLocalRandom
Returns a pseudorandom, uniformly distributed value between 0 (inclusive) and the specified value (exclusive).
nextLong(long, long) - Method in class jsr166y.ThreadLocalRandom
Returns a pseudorandom, uniformly distributed value between the given least value (inclusive) and bound (exclusive).

O

offer(E, long, TimeUnit) - Method in class jsr166y.LinkedTransferQueue
Inserts the specified element at the tail of this queue.
offer(E) - Method in class jsr166y.LinkedTransferQueue
Inserts the specified element at the tail of this queue.
onAdvance(int, int) - Method in class jsr166y.Phaser
Overridable method to perform an action upon impending phase advance, and to control termination.
onStart() - Method in class jsr166y.ForkJoinWorkerThread
Initializes internal state after construction but before processing any tasks.
onTermination(Throwable) - Method in class jsr166y.ForkJoinWorkerThread
Performs cleanup associated with termination of this worker thread.

P

peek() - Method in class jsr166y.LinkedTransferQueue
 
peekNextLocalTask() - Static method in class jsr166y.ForkJoinTask
Returns, but does not unschedule or execute, a task queued by the current thread but not yet executed, if one is immediately available.
Phaser - Class in jsr166y
A reusable synchronization barrier, similar in functionality to CyclicBarrier and CountDownLatch but supporting more flexible usage.
Phaser() - Constructor for class jsr166y.Phaser
Creates a new phaser with no initially registered parties, no parent, and initial phase number 0.
Phaser(int) - Constructor for class jsr166y.Phaser
Creates a new phaser with the given number of registered unarrived parties, no parent, and initial phase number 0.
Phaser(Phaser) - Constructor for class jsr166y.Phaser
Equivalent to Phaser(parent, 0).
Phaser(Phaser, int) - Constructor for class jsr166y.Phaser
Creates a new phaser with the given parent and number of registered unarrived parties.
poll(long, TimeUnit) - Method in class jsr166y.LinkedTransferQueue
 
poll() - Method in class jsr166y.LinkedTransferQueue
 
pollNextLocalTask() - Static method in class jsr166y.ForkJoinTask
Unschedules and returns, without executing, the next task queued by the current thread but not yet executed.
pollSubmission() - Method in class jsr166y.ForkJoinPool
Removes and returns the next unexecuted submission if one is available.
pollTask() - Static method in class jsr166y.ForkJoinTask
Unschedules and returns, without executing, the next task queued by the current thread but not yet executed, if one is available, or if not available, a task that was forked by some other thread, if available.
put(E) - Method in class jsr166y.LinkedTransferQueue
Inserts the specified element at the tail of this queue.

Q

quietlyInvoke() - Method in class jsr166y.ForkJoinTask
Commences performing this task and awaits its completion if necessary, without returning its result or throwing its exception.
quietlyJoin() - Method in class jsr166y.ForkJoinTask
Joins this task, without returning its result or throwing its exception.

R

RecursiveAction - Class in jsr166y
A recursive resultless ForkJoinTask.
RecursiveAction() - Constructor for class jsr166y.RecursiveAction
 
RecursiveTask<V> - Class in jsr166y
A recursive result-bearing ForkJoinTask.
RecursiveTask() - Constructor for class jsr166y.RecursiveTask
 
register() - Method in class jsr166y.Phaser
Adds a new unarrived party to this phaser.
reinitialize() - Method in class jsr166y.ForkJoinTask
Resets the internal bookkeeping state of this task, allowing a subsequent fork.
remainingCapacity() - Method in class jsr166y.LinkedTransferQueue
Always returns Integer.MAX_VALUE because a LinkedTransferQueue is not capacity constrained.
remove(Object) - Method in class jsr166y.LinkedTransferQueue
Removes a single instance of the specified element from this queue, if it is present.
run() - Method in class jsr166y.ForkJoinWorkerThread
This method is required to be public, but should never be called explicitly.

S

setRawResult(V) - Method in class jsr166y.ForkJoinTask
Forces the given value to be returned as a result.
setRawResult(Void) - Method in class jsr166y.RecursiveAction
Requires null completion value.
setRawResult(V) - Method in class jsr166y.RecursiveTask
 
setSeed(long) - Method in class jsr166y.ThreadLocalRandom
Throws UnsupportedOperationException.
shutdown() - Method in class jsr166y.ForkJoinPool
Initiates an orderly shutdown in which previously submitted tasks are executed, but no new tasks will be accepted.
shutdownNow() - Method in class jsr166y.ForkJoinPool
Attempts to cancel and/or stop all tasks, and reject all subsequently submitted tasks.
size() - Method in class jsr166y.LinkedTransferQueue
Returns the number of elements in this queue.
submit(ForkJoinTask<T>) - Method in class jsr166y.ForkJoinPool
Submits a ForkJoinTask for execution.
submit(Callable<T>) - Method in class jsr166y.ForkJoinPool
 
submit(Runnable, T) - Method in class jsr166y.ForkJoinPool
 
submit(Runnable) - Method in class jsr166y.ForkJoinPool
 

T

take() - Method in class jsr166y.LinkedTransferQueue
 
ThreadLocalRandom - Class in jsr166y
A random number generator isolated to the current thread.
toString() - Method in class jsr166y.ForkJoinPool
Returns a string identifying this pool, as well as its state, including indications of run state, parallelism level, and worker and task counts.
toString() - Method in class jsr166y.Phaser
Returns a string identifying this phaser, as well as its state.
transfer(E) - Method in class jsr166y.LinkedTransferQueue
Transfers the element to a consumer, waiting if necessary to do so.
transfer(E) - Method in interface jsr166y.TransferQueue
Transfers the element to a consumer, waiting if necessary to do so.
TransferQueue<E> - Interface in jsr166y
A BlockingQueue in which producers may wait for consumers to receive elements.
tryTransfer(E) - Method in class jsr166y.LinkedTransferQueue
Transfers the element to a waiting consumer immediately, if possible.
tryTransfer(E, long, TimeUnit) - Method in class jsr166y.LinkedTransferQueue
Transfers the element to a consumer if it is possible to do so before the timeout elapses.
tryTransfer(E) - Method in interface jsr166y.TransferQueue
Transfers the element to a waiting consumer immediately, if possible.
tryTransfer(E, long, TimeUnit) - Method in interface jsr166y.TransferQueue
Transfers the element to a consumer if it is possible to do so before the timeout elapses.
tryUnfork() - Method in class jsr166y.ForkJoinTask
Tries to unschedule this task for execution.
A B C D E F G H I J L M N O P Q R S T