RecursiveAction

public abstract class RecursiveAction
extends ForkJoinTask<Void>

java.lang.Object
   ↳ java.util.concurrent.ForkJoinTask<java.lang.Void>
     ↳ java.util.concurrent.RecursiveAction


A recursive resultless ForkJoinTask. This class establishes conventions to parameterize resultless actions as Void ForkJoinTasks. Because null is the only valid value of type Void, methods such as join always return null upon completion.

Sample Usages. Here is a simple but complete ForkJoin sort that sorts a given long[] array:

 static class SortTask extends RecursiveAction {
   final long[] array; final int lo, hi;
   SortTask(long[] array, int lo, int hi) {
     this.array = array; this.lo = lo; this.hi = hi;
   }
   SortTask(long[] array) { this(array, 0, array.length); }
   protected void compute() {
     if (hi - lo < THRESHOLD)
       sortSequentially(lo, hi);
     else {
       int mid = (lo + hi) >>> 1;
       invokeAll(new SortTask(array, lo, mid),
                 new SortTask(array, mid, hi));
       merge(lo, mid, hi);
     }
   }
   // implementation details follow:
   static final int THRESHOLD = 1000;
   void sortSequentially(int lo, int hi) {
     Arrays.sort(array, lo, hi);
   }
   void merge(int lo, int mid, int hi) {
     long[] buf = Arrays.copyOfRange(array, lo, mid);
     for (int i = 0, j = lo, k = mid; i < buf.length; j++)
       array[j] = (k == hi || buf[i] < array[k]) ?
         buf[i++] : array[k++];
   }
 }
You could then sort anArray by creating new SortTask(anArray) and invoking it in a ForkJoinPool. As a more concrete simple example, the following task increments each element of an array:
 class IncrementTask extends RecursiveAction {
   final long[] array; final int lo, hi;
   IncrementTask(long[] array, int lo, int hi) {
     this.array = array; this.lo = lo; this.hi = hi;
   }
   protected void compute() {
     if (hi - lo < THRESHOLD) {
       for (int i = lo; i < hi; ++i)
         array[i]++;
     }
     else {
       int mid = (lo + hi) >>> 1;
       invokeAll(new IncrementTask(array, lo, mid),
                 new IncrementTask(array, mid, hi));
     }
   }
 }

The following example illustrates some refinements and idioms that may lead to better performance: RecursiveActions need not be fully recursive, so long as they maintain the basic divide-and-conquer approach. Here is a class that sums the squares of each element of a double array, by subdividing out only the right-hand-sides of repeated divisions by two, and keeping track of them with a chain of next references. It uses a dynamic threshold based on method getSurplusQueuedTaskCount, but counterbalances potential excess partitioning by directly performing leaf actions on unstolen tasks rather than further subdividing.

 double sumOfSquares(ForkJoinPool pool, double[] array) {
   int n = array.length;
   Applyer a = new Applyer(array, 0, n, null);
   pool.invoke(a);
   return a.result;
 }

 class Applyer extends RecursiveAction {
   final double[] array;
   final int lo, hi;
   double result;
   Applyer next; // keeps track of right-hand-side tasks
   Applyer(double[] array, int lo, int hi, Applyer next) {
     this.array = array; this.lo = lo; this.hi = hi;
     this.next = next;
   }

   double atLeaf(int l, int h) {
     double sum = 0;
     for (int i = l; i < h; ++i) // perform leftmost base step
       sum += array[i] * array[i];
     return sum;
   }

   protected void compute() {
     int l = lo;
     int h = hi;
     Applyer right = null;
     while (h - l > 1 && getSurplusQueuedTaskCount() <= 3) {
       int mid = (l + h) >>> 1;
       right = new Applyer(array, mid, h, right);
       right.fork();
       h = mid;
     }
     double sum = atLeaf(l, h);
     while (right != null) {
       if (right.tryUnfork()) // directly calculate if not stolen
         sum += right.atLeaf(right.lo, right.hi);
       else {
         right.join();
         sum += right.result;
       }
       right = right.next;
     }
     result = sum;
   }
 }

Summary

Public constructors

RecursiveAction()

Constructor for subclasses to call.

Public methods

final Void getRawResult()

Always returns null.

Protected methods

abstract void compute()

The main computation performed by this task.

final boolean exec()

Implements execution conventions for RecursiveActions.

final void setRawResult(Void mustBeNull)

Requires null completion value.

Inherited methods

static <T> ForkJoinTask<T> adapt(Runnable runnable, T result)

Returns a new ForkJoinTask that performs the run method of the given Runnable as its action, and returns the given result upon join().

static ForkJoinTask<?> adapt(Runnable runnable)

Returns a new ForkJoinTask that performs the run method of the given Runnable as its action, and returns a null result upon join().

static <T> ForkJoinTask<T> adapt(Callable<? extends T> callable)

Returns a new ForkJoinTask that performs the call method of the given Callable as its action, and returns its result upon join(), translating any checked exceptions encountered into RuntimeException.

static <T> ForkJoinTask<T> adaptInterruptible(Callable<? extends T> callable)

Returns a new ForkJoinTask that performs the call method of the given Callable as its action, and returns its result upon join(), translating any checked exceptions encountered into RuntimeException.

boolean cancel(boolean mayInterruptIfRunning)

Attempts to cancel execution of this task.

final boolean compareAndSetForkJoinTaskTag(short expect, short update)

Atomically conditionally sets the tag value for this task.

void complete(Void value)

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.

void completeExceptionally(Throwable ex)

Completes this task abnormally, and if not already aborted or cancelled, causes it to throw the given exception upon join and related operations.

Throwable exceptionNow()

Returns the exception thrown by the task, without waiting.

abstract boolean exec()

Immediately performs the base action of this task and returns true if, upon return from this method, this task is guaranteed to have completed.

final ForkJoinTask<Void> fork()

Arranges to asynchronously execute this task in the pool the current task is running in, if applicable, or using the ForkJoinPool.commonPool() if not inForkJoinPool().

final Void get(long timeout, TimeUnit unit)

Waits if necessary for at most the given time for the computation to complete, and then retrieves its result, if available.

final Void get()

Waits if necessary for the computation to complete, and then retrieves its result.

final Throwable getException()

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.

final short getForkJoinTaskTag()

Returns the tag for this task.

static ForkJoinPool getPool()

Returns the pool hosting the current thread, or null if the current thread is executing outside of any ForkJoinPool.

static int getQueuedTaskCount()

Returns an estimate of the number of tasks that have been forked by the current worker thread but not yet executed.

abstract Void getRawResult()

Returns the result that would be returned by join(), even if this task completed abnormally, or null if this task is not known to have been completed.

static int getSurplusQueuedTaskCount()

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, or zero if this thread is not operating in a ForkJoinPool.

static void helpQuiesce()

Possibly executes tasks until the pool hosting the current task is quiescent.

static boolean inForkJoinPool()

Returns true if the current thread is a ForkJoinWorkerThread executing as a ForkJoinPool computation.

final Void invoke()

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.

static void invokeAll(ForkJoinTask<?> t1, ForkJoinTask<?> t2)

Forks the given tasks, returning when isDone holds for each task or an (unchecked) exception is encountered, in which case the exception is rethrown.

static <T extends ForkJoinTask<?>> Collection<T> invokeAll(Collection<T> tasks)

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.

static void invokeAll(ForkJoinTask...<?> tasks)

Forks the given tasks, returning when isDone holds for each task or an (unchecked) exception is encountered, in which case the exception is rethrown.

final boolean isCancelled()

Returns true if this task was cancelled before it completed normally.

final boolean isCompletedAbnormally()

Returns true if this task threw an exception or was cancelled.

final boolean isCompletedNormally()

Returns true if this task completed without throwing an exception and was not cancelled.

final boolean isDone()

Returns true if this task completed.

final Void join()

Returns the result of the computation when it is done.

static ForkJoinTask<?> peekNextLocalTask()

Returns, but does not unschedule or execute, a task queued by the current thread but not yet executed, if one is immediately available.

static ForkJoinTask<?> pollNextLocalTask()

Unschedules and returns, without executing, the next task queued by the current thread but not yet executed, if the current thread is operating in a ForkJoinPool.

static ForkJoinTask<?> pollTask()

If the current thread is operating in a ForkJoinPool, 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.

final void quietlyComplete()

Completes this task normally without setting a value.

final void quietlyInvoke()

Commences performing this task and awaits its completion if necessary, without returning its result or throwing its exception.

final boolean quietlyJoin(long timeout, TimeUnit unit)

Tries to join this task, returning true if it completed (possibly exceptionally) before the given timeout and the current thread has not been interrupted.

final void quietlyJoin()

Joins this task, without returning its result or throwing its exception.

final boolean quietlyJoinUninterruptibly(long timeout, TimeUnit unit)

Tries to join this task, returning true if it completed (possibly exceptionally) before the given timeout.

void reinitialize()

Resets the internal bookkeeping state of this task, allowing a subsequent fork.

Void resultNow()

Returns the computed result, without waiting.

final short setForkJoinTaskTag(short newValue)

Atomically sets the tag value for this task and returns the old value.

abstract void setRawResult(Void value)

Forces the given value to be returned as a result.

Future.State state()

boolean tryUnfork()

Tries to unschedule this task for execution.

Object clone()

Creates and returns a copy of this object.

boolean equals(Object obj)

Indicates whether some other object is "equal to" this one.

void finalize()

Called by the garbage collector on an object when garbage collection determines that there are no more references to the object.

final Class<?> getClass()

Returns the runtime class of this Object.

int hashCode()

Returns a hash code value for the object.

final void notify()

Wakes up a single thread that is waiting on this object's monitor.

final void notifyAll()

Wakes up all threads that are waiting on this object's monitor.

String toString()

Returns a string representation of the object.

final void wait(long timeoutMillis, int nanos)

Causes the current thread to wait until it is awakened, typically by being notified or interrupted, or until a certain amount of real time has elapsed.

final void wait(long timeoutMillis)

Causes the current thread to wait until it is awakened, typically by being notified or interrupted, or until a certain amount of real time has elapsed.

final void wait()

Causes the current thread to wait until it is awakened, typically by being notified or interrupted.

abstract boolean cancel(boolean mayInterruptIfRunning)

Attempts to cancel execution of this task.

default Throwable exceptionNow()

Returns the exception thrown by the task, without waiting.

abstract Void get(long timeout, TimeUnit unit)

Waits if necessary for at most the given time for the computation to complete, and then retrieves its result, if available.

abstract Void get()

Waits if necessary for the computation to complete, and then retrieves its result.

abstract boolean isCancelled()

Returns true if this task was cancelled before it completed normally.

abstract boolean isDone()

Returns true if this task completed.

default Void resultNow()

Returns the computed result, without waiting.

default Future.State state()

Public constructors

RecursiveAction

Added in API level 21
public RecursiveAction ()

Constructor for subclasses to call.

Public methods

getRawResult

Added in API level 21
public final Void getRawResult ()

Always returns null.

Returns
Void null always

Protected methods

compute

Added in API level 21
protected abstract void compute ()

The main computation performed by this task.

exec

Added in API level 21
protected final boolean exec ()

Implements execution conventions for RecursiveActions.

Returns
boolean true if this task is known to have completed normally

setRawResult

Added in API level 21
protected final void setRawResult (Void mustBeNull)

Requires null completion value.

Parameters
mustBeNull Void: the value