ForkJoinPool
open class ForkJoinPool : AbstractExecutorService
An ExecutorService
for running ForkJoinTask
s. A ForkJoinPool
provides the entry point for submissions from non-ForkJoinTask
clients, as well as management and monitoring operations.
A ForkJoinPool
differs from other kinds of ExecutorService
mainly by virtue of employing work-stealing: all threads in the pool attempt to find and execute tasks submitted to the pool and/or created by other active tasks (eventually blocking waiting for work if none exist). This enables efficient processing when most tasks spawn other subtasks (as do most ForkJoinTask
s), as well as when many small tasks are submitted to the pool from external clients. Especially when setting asyncMode to true in constructors, ForkJoinPool
s may also be appropriate for use with event-style tasks that are never joined. All worker threads are initialized with Thread.isDaemon
set true
.
A static commonPool()
is available and appropriate for most applications. The common pool is used by any ForkJoinTask that is not explicitly submitted to a specified pool. Using the common pool normally reduces resource usage (its threads are slowly reclaimed during periods of non-use, and reinstated upon subsequent use).
For applications that require separate or custom pools, a ForkJoinPool
may be constructed with a given target parallelism level; by default, equal to the number of available processors. The pool attempts to maintain enough active (or available) threads by dynamically adding, suspending, or resuming internal worker threads, even if some tasks are stalled waiting to join others. However, no such adjustments are guaranteed in the face of blocked I/O or other unmanaged synchronization. The nested ManagedBlocker
interface enables extension of the kinds of synchronization accommodated. The default policies may be overridden using a constructor with parameters corresponding to those documented in class ThreadPoolExecutor
.
In addition to execution and lifecycle control methods, this class provides status check methods (for example getStealCount
) that are intended to aid in developing, tuning, and monitoring fork/join applications. Also, method toString
returns indications of pool state in a convenient form for informal monitoring.
As is the case with other ExecutorServices, there are three main task execution methods summarized in the following table. These are designed to be used primarily by clients not already engaged in fork/join computations in the current pool. The main forms of these methods accept instances of ForkJoinTask
, but overloaded forms also allow mixed execution of plain Runnable
- or Callable
- based activities as well. However, tasks that are already executing in a pool should normally instead use the within-computation forms listed in the table unless using async event-style tasks that are not usually joined, in which case there is little difference among choice of methods.
The parameters used to construct the common pool may be controlled by setting the following java.lang.System#getProperty:
java.util.concurrent.ForkJoinPool.common.parallelism
- the parallelism level, a non-negative integer
java.util.concurrent.ForkJoinPool.common.threadFactory
- the class name of a ForkJoinWorkerThreadFactory
. The system class loader is used to load this class.
java.util.concurrent.ForkJoinPool.common.exceptionHandler
- the class name of a UncaughtExceptionHandler
. The system class loader is used to load this class.
java.util.concurrent.ForkJoinPool.common.maximumSpares
- the maximum number of allowed extra threads to maintain target parallelism (default 256).
If no thread factory is supplied via a system property, then the common pool uses a factory that uses the system class loader as the
thread context class loader. In addition, if a
SecurityManager
is present, then the common pool uses a factory supplying threads that have no
Permissions
enabled, and are not guaranteed to preserve the values of
java.lang.ThreadLocal
variables across tasks. Upon any error in establishing these settings, default parameters are used. It is possible to disable or limit the use of threads in the common pool by setting the parallelism property to zero, and/or using a factory that may return
null
. However doing so may cause unjoined tasks to never be executed.
Summary
Nested classes |
abstract |
Factory for creating new ForkJoinWorkerThread s.
|
abstract |
Interface for extending managed parallelism for tasks running in ForkJoinPool s.
|
Public constructors |
Creates a ForkJoinPool with parallelism equal to java.lang.Runtime#availableProcessors , using defaults for all other parameters (see ForkJoinPool(int,java.util.concurrent.ForkJoinPool.ForkJoinWorkerThreadFactory,java.lang.Thread.UncaughtExceptionHandler,boolean,int,int,int,java.util.function.Predicate,long,java.util.concurrent.TimeUnit) ).
|
Creates a ForkJoinPool with the indicated parallelism level, using defaults for all other parameters (see ForkJoinPool(int,java.util.concurrent.ForkJoinPool.ForkJoinWorkerThreadFactory,java.lang.Thread.UncaughtExceptionHandler,boolean,int,int,int,java.util.function.Predicate,long,java.util.concurrent.TimeUnit) ).
|
Creates a ForkJoinPool with the given parameters (using defaults for others -- see ForkJoinPool(int,java.util.concurrent.ForkJoinPool.ForkJoinWorkerThreadFactory,java.lang.Thread.UncaughtExceptionHandler,boolean,int,int,int,java.util.function.Predicate,long,java.util.concurrent.TimeUnit) ).
|
Creates a ForkJoinPool with the given parameters.
|
Public methods |
open Boolean |
If called by a ForkJoinTask operating in this pool, equivalent in effect to ForkJoinTask.helpQuiesce .
|
open Boolean |
Blocks until all tasks have completed execution after a shutdown request, or the timeout occurs, or the current thread is interrupted, whichever happens first.
|
open Unit |
Unless this is the commonPool() , initiates an orderly shutdown in which previously submitted tasks are executed, but no new tasks will be accepted, and waits until all tasks have completed execution and the executor has terminated.
|
open static ForkJoinPool! |
Returns the common pool instance.
|
open Unit |
|
open Unit |
Arranges for (asynchronous) execution of the given task.
|
open ForkJoinTask<T>! |
Submits the given task as if submitted from a non-ForkJoinTask client.
|
open Int |
Returns an estimate of the number of threads that are currently stealing or executing tasks.
|
open Boolean |
Returns true if this pool uses local first-in-first-out scheduling mode for forked tasks that are never joined.
|
open static Int |
Returns the targeted parallelism level of the common pool.
|
open ForkJoinPool.ForkJoinWorkerThreadFactory! |
Returns the factory used for constructing new workers.
|
open Int |
Returns the targeted parallelism level of this pool.
|
open Int |
Returns the number of worker threads that have started but not yet terminated.
|
open Int |
Returns an estimate of the number of tasks submitted to this pool that have not yet begun executing.
|
open Long |
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).
|
open Int |
Returns an estimate of the number of worker threads that are not blocked waiting to join tasks or for other managed synchronization.
|
open Long |
Returns an estimate of the total number of completed tasks that were executed by a thread other than their submitter.
|
open Thread.UncaughtExceptionHandler! |
Returns the handler for internal worker threads that terminate due to unrecoverable errors encountered while executing tasks.
|
open Boolean |
Returns true if there are any tasks submitted to this pool that have not yet begun executing.
|
open T |
Performs the given task, returning its result upon completion.
|
open MutableList<Future<T>!>! |
|
open MutableList<Future<T>!>! |
|
open T |
|
open T |
|
open Boolean |
Returns true if all worker threads are currently idle.
|
open Boolean |
Returns true if this pool has been shut down.
|
open Boolean |
Returns true if all tasks have completed following shut down.
|
open Boolean |
Returns true if the process of termination has commenced but not yet completed.
|
open ForkJoinTask<T>! |
Submits the given task without guaranteeing that it will eventually execute in the absence of available active threads.
|
open static Unit |
Runs the given possibly blocking task.
|
open Int |
Changes the target parallelism of this pool, controlling the future creation, use, and termination of worker threads.
|
open Unit |
Possibly initiates an orderly shutdown in which previously submitted tasks are executed, but no new tasks will be accepted.
|
open MutableList<Runnable!>! |
Possibly attempts to cancel and/or stop all tasks, and reject all subsequently submitted tasks.
|
open ForkJoinTask<*>! |
|
open ForkJoinTask<T>! |
|
open ForkJoinTask<T>! |
|
open ForkJoinTask<T>! |
Submits a ForkJoinTask for execution.
|
open String |
Returns a string identifying this pool, as well as its state, including indications of run state, parallelism level, and worker and task counts.
|
Protected methods |
open Int |
Removes all available unexecuted submitted and forked tasks from scheduling queues and adds them to the given collection, without altering their execution status.
|
open RunnableFuture<T>! |
|
open RunnableFuture<T>! |
|
open ForkJoinTask<*>! |
Removes and returns the next unexecuted submission if one is available.
|
Public constructors
ForkJoinPool
ForkJoinPool()
Creates a ForkJoinPool
with parallelism equal to java.lang.Runtime#availableProcessors
, using defaults for all other parameters (see ForkJoinPool(int,java.util.concurrent.ForkJoinPool.ForkJoinWorkerThreadFactory,java.lang.Thread.UncaughtExceptionHandler,boolean,int,int,int,java.util.function.Predicate,long,java.util.concurrent.TimeUnit)
).
Exceptions |
java.lang.SecurityException |
if a security manager exists and the caller is not permitted to modify threads because it does not hold ("modifyThread") |
ForkJoinPool
ForkJoinPool(parallelism: Int)
Creates a ForkJoinPool
with the indicated parallelism level, using defaults for all other parameters (see ForkJoinPool(int,java.util.concurrent.ForkJoinPool.ForkJoinWorkerThreadFactory,java.lang.Thread.UncaughtExceptionHandler,boolean,int,int,int,java.util.function.Predicate,long,java.util.concurrent.TimeUnit)
).
Parameters |
parallelism |
Int: the parallelism level |
Exceptions |
java.lang.IllegalArgumentException |
if parallelism less than or equal to zero, or greater than implementation limit |
java.lang.SecurityException |
if a security manager exists and the caller is not permitted to modify threads because it does not hold ("modifyThread") |
ForkJoinPool
ForkJoinPool(
parallelism: Int,
factory: ForkJoinPool.ForkJoinWorkerThreadFactory!,
handler: Thread.UncaughtExceptionHandler!,
asyncMode: Boolean)
Creates a ForkJoinPool
with the given parameters (using defaults for others -- see ForkJoinPool(int,java.util.concurrent.ForkJoinPool.ForkJoinWorkerThreadFactory,java.lang.Thread.UncaughtExceptionHandler,boolean,int,int,int,java.util.function.Predicate,long,java.util.concurrent.TimeUnit)
).
Exceptions |
java.lang.IllegalArgumentException |
if parallelism less than or equal to zero, or greater than implementation limit |
java.lang.NullPointerException |
if the factory is null |
java.lang.SecurityException |
if a security manager exists and the caller is not permitted to modify threads because it does not hold ("modifyThread") |
ForkJoinPool
ForkJoinPool(
parallelism: Int,
factory: ForkJoinPool.ForkJoinWorkerThreadFactory!,
handler: Thread.UncaughtExceptionHandler!,
asyncMode: Boolean,
corePoolSize: Int,
maximumPoolSize: Int,
minimumRunnable: Int,
saturate: Predicate<in ForkJoinPool!>!,
keepAliveTime: Long,
unit: TimeUnit!)
Creates a ForkJoinPool
with the given parameters.
Parameters |
parallelism |
Int: the parallelism level. For default value, use java.lang.Runtime#availableProcessors . |
factory |
ForkJoinPool.ForkJoinWorkerThreadFactory!: the factory for creating new threads. For default value, use defaultForkJoinWorkerThreadFactory . |
handler |
Thread.UncaughtExceptionHandler!: the handler for internal worker threads that terminate due to unrecoverable errors encountered while executing tasks. For default value, use null . |
asyncMode |
Boolean: if true, establishes local first-in-first-out scheduling mode for forked tasks that are never joined. This mode may be more appropriate than default locally stack-based mode in applications in which worker threads only process event-style asynchronous tasks. For default value, use false . |
corePoolSize |
Int: the number of threads to keep in the pool (unless timed out after an elapsed keep-alive). Normally (and by default) this is the same value as the parallelism level, but may be set to a larger value to reduce dynamic overhead if tasks regularly block. Using a smaller value (for example 0 ) has the same effect as the default. |
maximumPoolSize |
Int: the maximum number of threads allowed. When the maximum is reached, attempts to replace blocked threads fail. (However, because creation and termination of different threads may overlap, and may be managed by the given thread factory, this value may be transiently exceeded.) To arrange the same value as is used by default for the common pool, use 256 plus the parallelism level. (By default, the common pool allows a maximum of 256 spare threads.) Using a value (for example Integer.MAX_VALUE ) larger than the implementation's total thread limit has the same effect as using this limit (which is the default). |
minimumRunnable |
Int: the minimum allowed number of core threads not blocked by a join or ManagedBlocker . To ensure progress, when too few unblocked threads exist and unexecuted tasks may exist, new threads are constructed, up to the given maximumPoolSize. For the default value, use 1 , that ensures liveness. A larger value might improve throughput in the presence of blocked activities, but might not, due to increased overhead. A value of zero may be acceptable when submitted tasks cannot have dependencies requiring additional threads. |
saturate |
Predicate<in ForkJoinPool!>!: if non-null, a predicate invoked upon attempts to create more than the maximum total allowed threads. By default, when a thread is about to block on a join or ManagedBlocker , but cannot be replaced because the maximumPoolSize would be exceeded, a RejectedExecutionException is thrown. But if this predicate returns true , then no exception is thrown, so the pool continues to operate with fewer than the target number of runnable threads, which might not ensure progress. |
keepAliveTime |
Long: the elapsed time since last use before a thread is terminated (and then later replaced if needed). For the default value, use 60, TimeUnit.SECONDS . |
unit |
TimeUnit!: the time unit for the keepAliveTime argument |
Exceptions |
java.lang.IllegalArgumentException |
if parallelism is less than or equal to zero, or is greater than implementation limit, or if maximumPoolSize is less than parallelism, of if the keepAliveTime is less than or equal to zero. |
java.lang.NullPointerException |
if the factory is null |
java.lang.SecurityException |
if a security manager exists and the caller is not permitted to modify threads because it does not hold ("modifyThread") |
Public methods
awaitQuiescence
open fun awaitQuiescence(
timeout: Long,
unit: TimeUnit!
): Boolean
If called by a ForkJoinTask operating in this pool, equivalent in effect to ForkJoinTask.helpQuiesce
. Otherwise, waits and/or attempts to assist performing tasks until this pool isQuiescent
or the indicated timeout elapses.
Parameters |
timeout |
Long: the maximum time to wait |
unit |
TimeUnit!: the time unit of the timeout argument |
Return |
Boolean |
true if quiescent; false if the timeout elapsed. |
awaitTermination
open fun awaitTermination(
timeout: Long,
unit: TimeUnit!
): Boolean
Blocks until all tasks have completed execution after a shutdown request, or the timeout occurs, or the current thread is interrupted, whichever happens first. Because the commonPool()
never terminates until program shutdown, when applied to the common pool, this method is equivalent to awaitQuiescence(long,java.util.concurrent.TimeUnit)
but always returns false
.
Parameters |
timeout |
Long: the maximum time to wait |
unit |
TimeUnit!: the time unit of the timeout argument |
Return |
Boolean |
true if this executor terminated and false if the timeout elapsed before termination |
Exceptions |
java.lang.InterruptedException |
if interrupted while waiting |
close
open fun close(): Unit
Unless this is the commonPool()
, initiates an orderly shutdown in which previously submitted tasks are executed, but no new tasks will be accepted, and waits until all tasks have completed execution and the executor has terminated.
If already terminated, or this is the commonPool()
, this method has no effect on execution, and does not wait. Otherwise, if interrupted while waiting, this method stops all executing tasks as if by invoking shutdownNow()
. It then continues to wait until all actively executing tasks have completed. Tasks that were awaiting execution are not executed. The interrupt status will be re-asserted before this method returns.
Exceptions |
java.lang.Exception |
if this resource cannot be closed |
java.lang.SecurityException |
if a security manager exists and shutting down this ExecutorService may manipulate threads that the caller is not permitted to modify because it does not hold ("modifyThread") , or the security manager's checkAccess method denies access. |
commonPool
open static fun commonPool(): ForkJoinPool!
Returns the common pool instance. This pool is statically constructed; its run state is unaffected by attempts to shutdown
or shutdownNow
. However this pool and any ongoing processing are automatically terminated upon program System.exit
. Any program that relies on asynchronous task processing to complete before program termination should invoke commonPool().
awaitQuiescence
, before exit.
execute
open fun execute(task: Runnable!): Unit
Parameters |
command |
the runnable task |
Exceptions |
java.util.concurrent.RejectedExecutionException |
if the task cannot be scheduled for execution |
java.lang.NullPointerException |
if the task is null |
execute
open fun execute(task: ForkJoinTask<*>!): Unit
Arranges for (asynchronous) execution of the given task.
Exceptions |
java.lang.NullPointerException |
if the task is null |
java.util.concurrent.RejectedExecutionException |
if the task cannot be scheduled for execution |
externalSubmit
open fun <T : Any!> externalSubmit(task: ForkJoinTask<T>!): ForkJoinTask<T>!
Submits the given task as if submitted from a non-ForkJoinTask
client. The task is added to a scheduling queue for submissions to the pool even when called from a thread in the pool.
Parameters |
task |
ForkJoinTask<T>!: the task to submit |
<T> |
the type of the task's result |
Exceptions |
java.lang.NullPointerException |
if the task is null |
java.util.concurrent.RejectedExecutionException |
if the task cannot be scheduled for execution |
getActiveThreadCount
open fun getActiveThreadCount(): Int
Returns an estimate of the number of threads that are currently stealing or executing tasks. This method may overestimate the number of active threads.
Return |
Int |
the number of active threads |
getAsyncMode
open fun getAsyncMode(): Boolean
Returns true
if this pool uses local first-in-first-out scheduling mode for forked tasks that are never joined.
Return |
Boolean |
true if this pool uses async mode |
getCommonPoolParallelism
open static fun getCommonPoolParallelism(): Int
Returns the targeted parallelism level of the common pool.
Return |
Int |
the targeted parallelism level of the common pool |
getParallelism
open fun getParallelism(): Int
Returns the targeted parallelism level of this pool.
Return |
Int |
the targeted parallelism level of this pool |
getPoolSize
open fun getPoolSize(): Int
Returns the number of worker threads that have started but not yet terminated. The result returned by this method may differ from getParallelism
when threads are created to maintain parallelism when others are cooperatively blocked.
Return |
Int |
the number of worker threads |
getQueuedSubmissionCount
open fun getQueuedSubmissionCount(): Int
Returns an estimate of the number of tasks submitted to this pool that have not yet begun executing. This method may take time proportional to the number of submissions.
Return |
Int |
the number of queued submissions |
getQueuedTaskCount
open fun getQueuedTaskCount(): Long
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). This value is only an approximation, obtained by iterating across all threads in the pool. This method may be useful for tuning task granularities.
Return |
Long |
the number of queued tasks |
getRunningThreadCount
open fun getRunningThreadCount(): Int
Returns an estimate of the number of worker threads that are not blocked waiting to join tasks or for other managed synchronization. This method may overestimate the number of running threads.
Return |
Int |
the number of worker threads |
getStealCount
open fun getStealCount(): Long
Returns an estimate of the total number of completed tasks that were executed by a thread other than their submitter. The reported value underestimates the actual total number of steals when the pool is not quiescent. This value may be useful for monitoring and tuning fork/join programs: in general, steal counts should be high enough to keep threads busy, but low enough to avoid overhead and contention across threads.
Return |
Long |
the number of steals |
getUncaughtExceptionHandler
open fun getUncaughtExceptionHandler(): Thread.UncaughtExceptionHandler!
Returns the handler for internal worker threads that terminate due to unrecoverable errors encountered while executing tasks.
hasQueuedSubmissions
open fun hasQueuedSubmissions(): Boolean
Returns true
if there are any tasks submitted to this pool that have not yet begun executing.
Return |
Boolean |
true if there are any queued submissions |
invoke
open fun <T : Any!> invoke(task: ForkJoinTask<T>!): T
Performs the given task, returning its result upon completion. If the computation encounters an unchecked Exception or Error, it is rethrown as the outcome of this invocation. Rethrown exceptions behave in the same way as regular exceptions, but, when possible, contain stack traces (as displayed for example using ex.printStackTrace()
) of both the current thread as well as the thread actually encountering the exception; minimally only the latter.
Parameters |
task |
ForkJoinTask<T>!: the task |
<T> |
the type of the task's result |
Return |
T |
the task's result |
Exceptions |
java.lang.NullPointerException |
if the task is null |
java.util.concurrent.RejectedExecutionException |
if the task cannot be scheduled for execution |
invokeAll
open fun <T : Any!> invokeAll(tasks: MutableCollection<out Callable<T>!>!): MutableList<Future<T>!>!
Parameters |
tasks |
MutableCollection<out Callable<T>!>!: the collection of tasks |
<T> |
the type of the values returned from the tasks |
Return |
MutableList<Future<T>!>! |
a list of Futures representing the tasks, in the same sequential order as produced by the iterator for the given task list, each of which has completed |
Exceptions |
java.lang.InterruptedException |
if interrupted while waiting, in which case unfinished tasks are cancelled |
java.lang.NullPointerException |
if tasks or any of its elements are null |
java.util.concurrent.RejectedExecutionException |
if any task cannot be scheduled for execution |
invokeAll
open fun <T : Any!> invokeAll(
tasks: MutableCollection<out Callable<T>!>!,
timeout: Long,
unit: TimeUnit!
): MutableList<Future<T>!>!
Parameters |
tasks |
MutableCollection<out Callable<T>!>!: the collection of tasks |
timeout |
Long: the maximum time to wait |
unit |
TimeUnit!: the time unit of the timeout argument |
<T> |
the type of the values returned from the tasks |
Return |
MutableList<Future<T>!>! |
a list of Futures representing the tasks, in the same sequential order as produced by the iterator for the given task list. If the operation did not time out, each task will have completed. If it did time out, some of these tasks will not have completed. |
Exceptions |
java.lang.InterruptedException |
if interrupted while waiting, in which case unfinished tasks are cancelled |
java.lang.NullPointerException |
if tasks, any of its elements, or unit are null |
java.util.concurrent.RejectedExecutionException |
if any task cannot be scheduled for execution |
invokeAny
open fun <T : Any!> invokeAny(tasks: MutableCollection<out Callable<T>!>!): T
Parameters |
tasks |
MutableCollection<out Callable<T>!>!: the collection of tasks |
<T> |
the type of the values returned from the tasks |
Return |
T |
the result returned by one of the tasks |
Exceptions |
java.lang.InterruptedException |
if interrupted while waiting |
java.lang.NullPointerException |
if tasks or any element task subject to execution is null |
java.lang.IllegalArgumentException |
if tasks is empty |
java.util.concurrent.ExecutionException |
if no task successfully completes |
java.util.concurrent.RejectedExecutionException |
if tasks cannot be scheduled for execution |
invokeAny
open fun <T : Any!> invokeAny(
tasks: MutableCollection<out Callable<T>!>!,
timeout: Long,
unit: TimeUnit!
): T
Parameters |
tasks |
MutableCollection<out Callable<T>!>!: the collection of tasks |
timeout |
Long: the maximum time to wait |
unit |
TimeUnit!: the time unit of the timeout argument |
<T> |
the type of the values returned from the tasks |
Return |
T |
the result returned by one of the tasks |
Exceptions |
java.lang.InterruptedException |
if interrupted while waiting |
java.lang.NullPointerException |
if tasks, or unit, or any element task subject to execution is null |
java.util.concurrent.TimeoutException |
if the given timeout elapses before any task successfully completes |
java.util.concurrent.ExecutionException |
if no task successfully completes |
java.util.concurrent.RejectedExecutionException |
if tasks cannot be scheduled for execution |
isQuiescent
open fun isQuiescent(): Boolean
Returns true
if all worker threads are currently idle. An idle worker is one that cannot obtain a task to execute because none are available to steal from other threads, and there are no pending submissions to the pool. This method is conservative; it might not return true
immediately upon idleness of all threads, but will eventually become true if threads remain inactive.
Return |
Boolean |
true if all threads are currently idle |
isShutdown
open fun isShutdown(): Boolean
Returns true
if this pool has been shut down.
Return |
Boolean |
true if this pool has been shut down |
isTerminated
open fun isTerminated(): Boolean
Returns true
if all tasks have completed following shut down.
Return |
Boolean |
true if all tasks have completed following shut down |
isTerminating
open fun isTerminating(): Boolean
Returns true
if the process of termination has commenced but not yet completed. This method may be useful for debugging. A return of true
reported a sufficient period after shutdown may indicate that submitted tasks have ignored or suppressed interruption, or are waiting for I/O, causing this executor not to properly terminate. (See the advisory notes for class ForkJoinTask
stating that tasks should not normally entail blocking operations. But if they do, they must abort them on interrupt.)
Return |
Boolean |
true if terminating but not yet terminated |
lazySubmit
open fun <T : Any!> lazySubmit(task: ForkJoinTask<T>!): ForkJoinTask<T>!
Submits the given task without guaranteeing that it will eventually execute in the absence of available active threads. In some contexts, this method may reduce contention and overhead by relying on context-specific knowledge that existing threads (possibly including the calling thread if operating in this pool) will eventually be available to execute the task.
Parameters |
task |
ForkJoinTask<T>!: the task |
<T> |
the type of the task's result |
Exceptions |
java.lang.NullPointerException |
if the task is null |
java.util.concurrent.RejectedExecutionException |
if the task cannot be scheduled for execution |
managedBlock
open static fun managedBlock(blocker: ForkJoinPool.ManagedBlocker!): Unit
Runs the given possibly blocking task. When running in a ForkJoinPool, this method possibly arranges for a spare thread to be activated if necessary to ensure sufficient parallelism while the current thread is blocked in blocker.block()
.
This method repeatedly calls blocker.isReleasable()
and blocker.block()
until either method returns true
. Every call to blocker.block()
is preceded by a call to blocker.isReleasable()
that returned false
.
If not running in a ForkJoinPool, this method is behaviorally equivalent to
<code>while (!blocker.isReleasable())
if (blocker.block())
break;</code>
If running in a ForkJoinPool, the pool may first be expanded to ensure sufficient parallelism available during the call to
blocker.block()
.
Exceptions |
java.lang.InterruptedException |
if blocker.block() did so |
setParallelism
open fun setParallelism(size: Int): Int
Changes the target parallelism of this pool, controlling the future creation, use, and termination of worker threads. Applications include contexts in which the number of available processors changes over time.
Parameters |
size |
Int: the target parallelism level |
Return |
Int |
the previous parallelism level. |
Exceptions |
java.lang.IllegalArgumentException |
if size is less than 1 or greater than the maximum supported by this pool. |
java.lang.UnsupportedOperationException |
this is thecommonPool() and parallelism level was set by System property {@systemProperty * java.util.concurrent.ForkJoinPool.common.parallelism}. |
java.lang.SecurityException |
if a security manager exists and the caller is not permitted to modify threads because it does not hold ("modifyThread") |
shutdown
open fun shutdown(): Unit
Possibly initiates an orderly shutdown in which previously submitted tasks are executed, but no new tasks will be accepted. Invocation has no effect on execution state if this is the commonPool()
, and no additional effect if already shut down. Tasks that are in the process of being submitted concurrently during the course of this method may or may not be rejected.
Exceptions |
java.lang.SecurityException |
if a security manager exists and the caller is not permitted to modify threads because it does not hold ("modifyThread") |
shutdownNow
open fun shutdownNow(): MutableList<Runnable!>!
Possibly attempts to cancel and/or stop all tasks, and reject all subsequently submitted tasks. Invocation has no effect on execution state if this is the commonPool()
, and no additional effect if already shut down. Otherwise, tasks that are in the process of being submitted or executed concurrently during the course of this method may or may not be rejected. This method cancels both existing and unexecuted tasks, in order to permit termination in the presence of task dependencies. So the method always returns an empty list (unlike the case for some other Executors).
Exceptions |
java.lang.SecurityException |
if a security manager exists and the caller is not permitted to modify threads because it does not hold ("modifyThread") |
submit
open fun submit(task: Runnable!): ForkJoinTask<*>!
Parameters |
task |
Runnable!: the task to submit |
Return |
ForkJoinTask<*>! |
a Future representing pending completion of the task |
Exceptions |
java.util.concurrent.RejectedExecutionException |
if the task cannot be scheduled for execution |
java.lang.NullPointerException |
if the task is null |
submit
open fun <T : Any!> submit(
task: Runnable!,
result: T
): ForkJoinTask<T>!
Parameters |
task |
Runnable!: the task to submit |
result |
T: the result to return |
<T> |
the type of the result |
Return |
ForkJoinTask<T>! |
a Future representing pending completion of the task |
Exceptions |
java.util.concurrent.RejectedExecutionException |
if the task cannot be scheduled for execution |
java.lang.NullPointerException |
if the task is null |
submit
open fun <T : Any!> submit(task: Callable<T>!): ForkJoinTask<T>!
Parameters |
task |
Callable<T>!: the task to submit |
<T> |
the type of the task's result |
Return |
ForkJoinTask<T>! |
a Future representing pending completion of the task |
Exceptions |
java.util.concurrent.RejectedExecutionException |
if the task cannot be scheduled for execution |
java.lang.NullPointerException |
if the task is null |
submit
open fun <T : Any!> submit(task: ForkJoinTask<T>!): ForkJoinTask<T>!
Submits a ForkJoinTask for execution.
Parameters |
task |
ForkJoinTask<T>!: the task to submit |
<T> |
the type of the task's result |
Exceptions |
java.lang.NullPointerException |
if the task is null |
java.util.concurrent.RejectedExecutionException |
if the task cannot be scheduled for execution |
toString
open fun toString(): String
Returns a string identifying this pool, as well as its state, including indications of run state, parallelism level, and worker and task counts.
Return |
String |
a string identifying this pool, as well as its state |
Protected methods
drainTasksTo
protected open fun drainTasksTo(c: MutableCollection<in ForkJoinTask<*>!>!): Int
Removes all available unexecuted submitted and forked tasks from scheduling queues and adds them to the given collection, without altering their execution status. These may include artificially generated or wrapped tasks. This method is designed to be invoked only when the pool is known to be quiescent. Invocations at other times may not remove all tasks. A failure encountered while attempting to add elements to collection c
may result in elements being in neither, either or both collections when the associated exception is thrown. The behavior of this operation is undefined if the specified collection is modified while the operation is in progress.
Return |
Int |
the number of elements transferred |
newTaskFor
protected open fun <T : Any!> newTaskFor(
runnable: Runnable!,
value: T
): RunnableFuture<T>!
Parameters |
runnable |
Runnable!: the runnable task being wrapped |
value |
T: the default value for the returned future |
<T> |
the type of the given value |
Return |
RunnableFuture<T>! |
a RunnableFuture which, when run, will run the underlying runnable and which, as a Future , will yield the given value as its result and provide for cancellation of the underlying task |
newTaskFor
protected open fun <T : Any!> newTaskFor(callable: Callable<T>!): RunnableFuture<T>!
Parameters |
callable |
Callable<T>!: the callable task being wrapped |
<T> |
the type of the callable's result |
Return |
RunnableFuture<T>! |
a RunnableFuture which, when run, will call the underlying callable and which, as a Future , will yield the callable's result as its result and provide for cancellation of the underlying task |
pollSubmission
protected open fun pollSubmission(): ForkJoinTask<*>!
Removes and returns the next unexecuted submission if one is available. This method may be useful in extensions to this class that re-assign work in systems with multiple pools.
Return |
ForkJoinTask<*>! |
the next submission, or null if none |
Properties
defaultForkJoinWorkerThreadFactory
static val defaultForkJoinWorkerThreadFactory: ForkJoinPool.ForkJoinWorkerThreadFactory!
Creates a new ForkJoinWorkerThread. This factory is used unless overridden in ForkJoinPool constructors.