- abortPolicy() - Static method in class org.jboss.threads.JBossExecutors
-
- AbstractListener() - Constructor for class org.jboss.threads.AsyncFuture.AbstractListener
-
- acceptInterruptDeferredEx(ExceptionObjLongConsumer<T, E>, T, long) - Static method in class org.jboss.threads.JBossThread
-
- acceptInterruptDeferredEx(ExceptionObjIntConsumer<T, E>, T, int) - Static method in class org.jboss.threads.JBossThread
-
- acceptInterruptDeferredEx(ExceptionBiConsumer<T, U, E>, T, U) - Static method in class org.jboss.threads.JBossThread
-
- acceptInterruptDeferredEx(ExceptionConsumer<T, E>, T) - Static method in class org.jboss.threads.JBossThread
-
- acceptInterruptResumedEx(ExceptionObjLongConsumer<T, E>, T, long) - Static method in class org.jboss.threads.JBossThread
-
- acceptInterruptResumedEx(ExceptionObjIntConsumer<T, E>, T, int) - Static method in class org.jboss.threads.JBossThread
-
- acceptInterruptResumedEx(ExceptionBiConsumer<T, U, E>, T, U) - Static method in class org.jboss.threads.JBossThread
-
- acceptInterruptResumedEx(ExceptionConsumer<T, E>, T) - Static method in class org.jboss.threads.JBossThread
-
- acceptWithInterruptHandler(InterruptHandler, ExceptionObjLongConsumer<T, E>, T, long) - Static method in class org.jboss.threads.JBossThread
-
- acceptWithInterruptHandler(InterruptHandler, ExceptionObjIntConsumer<T, E>, T, int) - Static method in class org.jboss.threads.JBossThread
-
- acceptWithInterruptHandler(InterruptHandler, ExceptionBiConsumer<T, U, E>, T, U) - Static method in class org.jboss.threads.JBossThread
-
- acceptWithInterruptHandler(InterruptHandler, ExceptionConsumer<T, E>, T) - Static method in class org.jboss.threads.JBossThread
-
- add(T, V) - Method in class org.jboss.threads.AtomicArray
-
Atomically replace the array with a new array which is one element longer, and which includes the given value.
- add(T, V, Comparator<? super V>) - Method in class org.jboss.threads.AtomicArray
-
Add a value to a sorted array.
- add(Dependency) - Method in class org.jboss.threads.DependencyTaskBuilder
-
Add a dependency.
- add(Collection<Dependency>) - Method in class org.jboss.threads.DependencyTaskBuilder
-
Add many dependencies.
- add(Dependency...) - Method in class org.jboss.threads.DependencyTaskBuilder
-
Add many dependencies.
- addExecutor(Executor) - Method in class org.jboss.threads.BalancingExecutor
-
Add a delegate executor.
- addIfAbsent(T, V, boolean) - Method in class org.jboss.threads.AtomicArray
-
Atomically replace the array with a new array which is one element longer, and which includes the given value,
if the value is not already present within the array.
- addIfAbsent(T, V, Comparator<? super V>) - Method in class org.jboss.threads.AtomicArray
-
Add a value to a sorted array if it is not already present.
- addListener(AsyncFuture.Listener<? super T, A>, A) - Method in interface org.jboss.threads.AsyncFuture
-
Add an asynchronous listener to be called when this operation completes.
- addListener(AsyncFuture.Listener<? super T, A>, A) - Method in class org.jboss.threads.AsyncFutureTask
-
Add an asynchronous listener to be called when this operation completes.
- addShutdownListener(EventListener<A>, A) - Method in class org.jboss.threads.JBossScheduledThreadPoolExecutor
-
Add a shutdown listener.
- addShutdownListener(EventListener<A>, A) - Method in class org.jboss.threads.JBossThreadPoolExecutor
-
Deprecated.
Add a shutdown listener.
- addShutdownListener(EventListener<A>, A) - Method in class org.jboss.threads.QueueExecutor
-
Deprecated.
Add a shutdown listener.
- addShutdownListener(EventListener<A>, A) - Method in class org.jboss.threads.QueuelessExecutor
-
Deprecated.
Add a shutdown listener.
- addShutdownListener(EventListener<A>, A) - Method in interface org.jboss.threads.ShutdownListenable
-
Add a shutdown listener.
- addShutdownListener(EventListener<A>, A) - Method in class org.jboss.threads.SimpleShutdownListenable
-
Add a shutdown listener.
- allowCoreThreadTimeOut(boolean) - Method in class org.jboss.threads.EnhancedQueueExecutor
-
Establish whether core threads are allowed to time out.
- allowCoreThreadTimeOut(boolean) - Method in class org.jboss.threads.EnhancedQueueExecutor.Builder
-
Establish whether core threads are allowed to time out.
- allowsCoreThreadTimeOut() - Method in class org.jboss.threads.EnhancedQueueExecutor
-
Determine whether core threads are allowed to time out.
- allowsCoreThreadTimeOut() - Method in class org.jboss.threads.EnhancedQueueExecutor.Builder
-
Determine whether core threads are allowed to time out.
- applyInterruptDeferredEx(ExceptionBiFunction<T, U, R, E>, T, U) - Static method in class org.jboss.threads.JBossThread
-
- applyInterruptDeferredEx(ExceptionFunction<T, R, E>, T) - Static method in class org.jboss.threads.JBossThread
-
- applyInterruptResumedEx(ExceptionBiFunction<T, U, R, E>, T, U) - Static method in class org.jboss.threads.JBossThread
-
- applyInterruptResumedEx(ExceptionFunction<T, R, E>, T) - Static method in class org.jboss.threads.JBossThread
-
- applyWithInterruptHandler(InterruptHandler, ExceptionBiFunction<T, U, R, E>, T, U) - Static method in class org.jboss.threads.JBossThread
-
- applyWithInterruptHandler(InterruptHandler, ExceptionFunction<T, R, E>, T) - Static method in class org.jboss.threads.JBossThread
-
- arrayNotEmpty() - Method in class org.jboss.threads.Messages_$logger
-
- arrayNotEmpty$str() - Method in class org.jboss.threads.Messages_$logger
-
- ArrayQueue<E> - Class in org.jboss.threads
-
A simple array-backed queue with a fixed size.
- ArrayQueue(int) - Constructor for class org.jboss.threads.ArrayQueue
-
- asyncCancel(boolean) - Method in interface org.jboss.threads.AsyncCancellable
-
Handle an asynchronous cancellation.
- asyncCancel(boolean) - Method in interface org.jboss.threads.AsyncFuture
-
Handle an asynchronous cancellation.
- asyncCancel(boolean) - Method in class org.jboss.threads.AsyncFutureTask
-
Cancel this task.
- AsyncCancellable - Interface in org.jboss.threads
-
An interface which supports asynchronous cancellation.
- AsyncFuture<T> - Interface in org.jboss.threads
-
This interface represents the result of an asynchronous future task, which provides all the features
of
Future
while also adding several additional convenience methods and the ability to add asynchronous
callbacks.
- AsyncFuture.AbstractListener<T,A> - Class in org.jboss.threads
-
An abstract base class for an implementation of the Listener
interface.
- AsyncFuture.Listener<T,A> - Interface in org.jboss.threads
-
A listener for an asynchronous future computation result.
- AsyncFuture.Status - Enum in org.jboss.threads
-
- AsyncFutureTask<T> - Class in org.jboss.threads
-
A base class for implementing asynchronous tasks.
- AsyncFutureTask(Executor) - Constructor for class org.jboss.threads.AsyncFutureTask
-
Construct a new instance.
- AtomicArray<T,V> - Class in org.jboss.threads
-
Utility for snapshot/copy-on-write arrays.
- AtomicArray.Creator<V> - Interface in org.jboss.threads
-
Deprecated.
- await() - Method in interface org.jboss.threads.AsyncFuture
-
Wait if necessary for this operation to complete, returning the outcome.
- await(long, TimeUnit) - Method in interface org.jboss.threads.AsyncFuture
-
Wait if necessary for this operation to complete, returning the outcome, which may include
AsyncFuture.Status.WAITING
if
the timeout expires before the operation completes.
- await() - Method in class org.jboss.threads.AsyncFutureTask
-
Wait if necessary for this operation to complete, returning the outcome.
- await(long, TimeUnit) - Method in class org.jboss.threads.AsyncFutureTask
-
Wait if necessary for this operation to complete, returning the outcome, which may include
AsyncFuture.Status.WAITING
if
the timeout expires before the operation completes.
- awaitTermination(long, TimeUnit) - Method in class org.jboss.threads.EnhancedQueueExecutor
-
Wait for the thread pool to complete termination.
- awaitTermination(long, TimeUnit) - Method in class org.jboss.threads.OrderedExecutor
-
- awaitTermination(long, TimeUnit) - Method in class org.jboss.threads.QueueExecutor
-
Deprecated.
- awaitTermination(long, TimeUnit) - Method in class org.jboss.threads.QueuelessExecutor
-
Deprecated.
- awaitUninterruptibly() - Method in interface org.jboss.threads.AsyncFuture
-
Wait (uninterruptibly) if necessary for this operation to complete, returning the outcome.
- awaitUninterruptibly(long, TimeUnit) - Method in interface org.jboss.threads.AsyncFuture
-
Wait if necessary for this operation to complete, returning the outcome, which may include
AsyncFuture.Status.WAITING
if
the timeout expires before the operation completes.
- awaitUninterruptibly() - Method in class org.jboss.threads.AsyncFutureTask
-
Wait (uninterruptibly) if necessary for this operation to complete, returning the outcome.
- awaitUninterruptibly(long, TimeUnit) - Method in class org.jboss.threads.AsyncFutureTask
-
Wait if necessary for this operation to complete, returning the outcome, which may include
AsyncFuture.Status.WAITING
if
the timeout expires before the operation completes.
- callerRunsPolicy() - Static method in class org.jboss.threads.JBossExecutors
-
- cancel(boolean) - Method in interface org.jboss.threads.AsyncFuture
-
Synchronously cancel a task, blocking uninterruptibly until it is known whether such cancellation was
successful.
- cancel(boolean) - Method in class org.jboss.threads.AsyncFutureTask
-
Synchronously cancel a task, blocking uninterruptibly until it is known whether such cancellation was
successful.
- cannotAddThread() - Method in class org.jboss.threads.Messages_$logger
-
- cannotAddThread$str() - Method in class org.jboss.threads.Messages_$logger
-
- cannotAwaitWithin() - Method in class org.jboss.threads.Messages_$logger
-
- cannotAwaitWithin$str() - Method in class org.jboss.threads.Messages_$logger
-
- cannotReduceMaxBelowCurrent() - Method in class org.jboss.threads.Messages_$logger
-
- cannotReduceMaxBelowCurrent$str() - Method in class org.jboss.threads.Messages_$logger
-
- classLoaderPreservingTask(Runnable) - Static method in class org.jboss.threads.JBossExecutors
-
Create a task that delegates to the given task, preserving the context classloader which was in effect when
this method was invoked.
- cleanupExecutor(DirectExecutor, Runnable) - Static method in class org.jboss.threads.JBossExecutors
-
Create an executor which runs the given cleanup task after running its given task.
- clear() - Method in class org.jboss.threads.ArrayQueue
-
- clear(T) - Method in class org.jboss.threads.AtomicArray
-
Convenience method to set the field value to the empty array.
- clear() - Method in class org.jboss.threads.BalancingExecutor
-
Clear out all delegate executors at once.
- compositeTask(Runnable...) - Static method in class org.jboss.threads.JBossExecutors
-
Create a task that is a composite of several other tasks.
- compositeTask(Collection<Runnable>) - Static method in class org.jboss.threads.JBossExecutors
-
Create a task that is a composite of several other tasks.
- concurrentModification() - Method in class org.jboss.threads.Messages_$logger
-
- concurrentModification$str() - Method in class org.jboss.threads.Messages_$logger
-
- contextClassLoaderExecutor(DirectExecutor, ClassLoader) - Static method in class org.jboss.threads.JBossExecutors
-
Create a direct executor which runs tasks with the given context class loader.
- contextClassLoaderResetter() - Static method in class org.jboss.threads.JBossExecutors
-
Get a Runnable
which, when executed, clears the thread context class loader (if the caller has sufficient
privileges).
- create(AtomicReferenceFieldUpdater<T, V[]>, Class<V>) - Static method in class org.jboss.threads.AtomicArray
-
Construct a new instance.
- create(AtomicReferenceFieldUpdater<T, V[]>, AtomicArray.Creator<V>) - Static method in class org.jboss.threads.AtomicArray
-
- create(AtomicReferenceFieldUpdater<T, V[]>, V[]) - Static method in class org.jboss.threads.AtomicArray
-
Construct a new instance.
- create(int) - Method in interface org.jboss.threads.AtomicArray.Creator
-
Deprecated.
- create() - Method in class org.jboss.threads.DependencyTaskBuilder
-
Create, and possibly execute, a dependent task from this builder.
- currentTask() - Static method in class org.jboss.threads.Dependency
-
Get the dependency task which this thread is currently running.
- currentThread() - Static method in class org.jboss.threads.JBossThread
-
Get the current JBossThread
, or null
if the current thread is not a JBossThread
.
- EnhancedQueueExecutor - Class in org.jboss.threads
-
A task-or-thread queue backed thread pool executor service.
- EnhancedQueueExecutor.Builder - Class in org.jboss.threads
-
The builder class for an EnhancedQueueExecutor
.
- EventListener<A> - Interface in org.jboss.threads
-
An event listener which handles a single event and accepts an attachment of some type.
- exceptionLoggingExecutor(DirectExecutor, Logger) - Static method in class org.jboss.threads.JBossExecutors
-
Create a direct executor which consumes and logs errors that are thrown.
- exceptionLoggingExecutor(DirectExecutor, Logger, Logger.Level) - Static method in class org.jboss.threads.JBossExecutors
-
Create a direct executor which consumes and logs errors that are thrown.
- exceptionLoggingExecutor(DirectExecutor) - Static method in class org.jboss.threads.JBossExecutors
-
Create a direct executor which consumes and logs errors that are thrown to the default thread error category
"org.jboss.threads.errors"
.
- execute(Runnable) - Method in class org.jboss.threads.BalancingExecutor
-
Execute a task.
- execute(Runnable) - Method in interface org.jboss.threads.BlockingExecutor
-
Deprecated.
Executes the given command at some time in the future.
- execute(Runnable) - Method in interface org.jboss.threads.DirectExecutor
-
Executes the given command in the calling thread.
- execute(Runnable) - Method in class org.jboss.threads.EnhancedQueueExecutor
-
Execute a task.
- execute(Runnable) - Method in class org.jboss.threads.JBossThreadPoolExecutor
-
Deprecated.
- execute(Runnable) - Method in class org.jboss.threads.LimitedExecutor
-
- execute(Runnable) - Method in class org.jboss.threads.OrderedExecutor
-
Run a task.
- execute(Runnable) - Method in class org.jboss.threads.QueueExecutor
-
Deprecated.
Execute a task.
- execute(Runnable) - Method in class org.jboss.threads.QueuelessExecutor
-
Deprecated.
- execute(Runnable) - Method in interface org.jboss.threads.WrappingExecutor
-
Run the given task directly, without a wrapper.
- execute(DirectExecutor, Runnable) - Method in interface org.jboss.threads.WrappingExecutor
-
Run the given task within the given wrapper.
- executeBlocking(Runnable) - Method in interface org.jboss.threads.BlockingExecutor
-
Deprecated.
Execute a task, blocking until it can be accepted, or until the calling thread is interrupted.
- executeBlocking(Runnable, long, TimeUnit) - Method in interface org.jboss.threads.BlockingExecutor
-
Deprecated.
Execute a task, blocking until it can be accepted, a timeout elapses, or the calling thread is interrupted.
- executeBlocking(Runnable) - Method in class org.jboss.threads.JBossThreadPoolExecutor
-
Deprecated.
- executeBlocking(Runnable, long, TimeUnit) - Method in class org.jboss.threads.JBossThreadPoolExecutor
-
Deprecated.
- executeBlocking(Runnable) - Method in class org.jboss.threads.OrderedExecutor
-
Deprecated.
- executeBlocking(Runnable, long, TimeUnit) - Method in class org.jboss.threads.OrderedExecutor
-
Deprecated.
- executeBlocking(Runnable) - Method in class org.jboss.threads.QueueExecutor
-
Deprecated.
Execute a task, blocking until it can be accepted, or until the calling thread is interrupted.
- executeBlocking(Runnable, long, TimeUnit) - Method in class org.jboss.threads.QueueExecutor
-
Deprecated.
Execute a task, blocking until it can be accepted, a timeout elapses, or the calling thread is interrupted.
- executeBlocking(Runnable) - Method in class org.jboss.threads.QueuelessExecutor
-
Deprecated.
- executeBlocking(Runnable, long, TimeUnit) - Method in class org.jboss.threads.QueuelessExecutor
-
Deprecated.
- executeNonBlocking(Runnable) - Method in interface org.jboss.threads.BlockingExecutor
-
Deprecated.
Execute a task, without blocking.
- executeNonBlocking(Runnable) - Method in class org.jboss.threads.JBossThreadPoolExecutor
-
Deprecated.
- executeNonBlocking(Runnable) - Method in class org.jboss.threads.OrderedExecutor
-
Deprecated.
- executeNonBlocking(Runnable) - Method in class org.jboss.threads.QueueExecutor
-
Deprecated.
Execute a task, without blocking.
- executeNonBlocking(Runnable) - Method in class org.jboss.threads.QueuelessExecutor
-
Deprecated.
- executeUninterruptibly(Executor, Runnable) - Static method in class org.jboss.threads.JBossExecutors
-
Execute a task uninterruptibly.
- executeWithInterruptDeferred(Runnable) - Static method in class org.jboss.threads.JBossThread
-
Defer interrupts for the duration of some task.
- executeWithInterruptDeferred(DirectExecutor, Runnable) - Static method in class org.jboss.threads.JBossThread
-
Defer interrupts for the duration of some task.
- executeWithInterruptDeferred(Callable<T>) - Static method in class org.jboss.threads.JBossThread
-
Defer interrupts for the duration of some task.
- executeWithInterruptDeferred(PrivilegedAction<T>) - Static method in class org.jboss.threads.JBossThread
-
Defer interrupts for the duration of some task.
- executeWithInterruptDeferred(PrivilegedExceptionAction<T>) - Static method in class org.jboss.threads.JBossThread
-
Defer interrupts for the duration of some task.
- executionFailed(Throwable, Runnable) - Method in class org.jboss.threads.Messages_$logger
-
- executionFailed$str() - Method in class org.jboss.threads.Messages_$logger
-
- executionInterrupted() - Method in class org.jboss.threads.Messages_$logger
-
- executionInterrupted$str() - Method in class org.jboss.threads.Messages_$logger
-
- ExecutionInterruptedException - Exception in org.jboss.threads
-
Deprecated.
- ExecutionInterruptedException() - Constructor for exception org.jboss.threads.ExecutionInterruptedException
-
Deprecated.
Constructs a ExecutionInterruptedException
with no detail message.
- ExecutionInterruptedException(String) - Constructor for exception org.jboss.threads.ExecutionInterruptedException
-
Deprecated.
Constructs a ExecutionInterruptedException
with the specified detail message.
- ExecutionInterruptedException(Throwable) - Constructor for exception org.jboss.threads.ExecutionInterruptedException
-
Deprecated.
Constructs a ExecutionInterruptedException
with the specified cause.
- ExecutionInterruptedException(String, Throwable) - Constructor for exception org.jboss.threads.ExecutionInterruptedException
-
Deprecated.
Constructs a ExecutionInterruptedException
with the specified detail message and cause.
- executionRejected() - Method in class org.jboss.threads.Messages_$logger
-
- executionRejected$str() - Method in class org.jboss.threads.Messages_$logger
-
- executionTimedOut() - Method in class org.jboss.threads.Messages_$logger
-
- executionTimedOut$str() - Method in class org.jboss.threads.Messages_$logger
-
- ExecutionTimedOutException - Exception in org.jboss.threads
-
Deprecated.
- ExecutionTimedOutException() - Constructor for exception org.jboss.threads.ExecutionTimedOutException
-
Deprecated.
Constructs a ExecutionTimedOutException
with no detail message.
- ExecutionTimedOutException(String) - Constructor for exception org.jboss.threads.ExecutionTimedOutException
-
Deprecated.
Constructs a ExecutionTimedOutException
with the specified detail message.
- ExecutionTimedOutException(Throwable) - Constructor for exception org.jboss.threads.ExecutionTimedOutException
-
Deprecated.
Constructs a ExecutionTimedOutException
with the specified cause.
- ExecutionTimedOutException(String, Throwable) - Constructor for exception org.jboss.threads.ExecutionTimedOutException
-
Deprecated.
Constructs a ExecutionTimedOutException
with the specified detail message and cause.
- executor(WrappingExecutor, DirectExecutor) - Static method in class org.jboss.threads.JBossExecutors
-
An executor which delegates to a wrapping executor, wrapping each task in a task wrapper.
- executorTask(DirectExecutor, Runnable) - Static method in class org.jboss.threads.JBossExecutors
-
Get a task that runs the given task through the given direct executor.
- get() - Method in class org.jboss.threads.AsyncFutureTask
- get(long, TimeUnit) - Method in class org.jboss.threads.AsyncFutureTask
- getActiveCount() - Method in class org.jboss.threads.EnhancedQueueExecutor
-
Get an estimate of the number of threads which are currently doing work on behalf of the thread pool.
- getActiveCount() - Method in interface org.jboss.threads.management.StandardThreadPoolMXBean
-
Get an estimate of the current number of active (busy) threads.
- getAndSet(T, V[]) - Method in class org.jboss.threads.AtomicArray
-
Atomically get and update the value of this array.
- getAndSetInterruptHandler(InterruptHandler) - Static method in class org.jboss.threads.JBossThread
-
Swap the current thread's active interrupt handler.
- getCompletedTaskCount() - Method in class org.jboss.threads.EnhancedQueueExecutor
-
Get an estimate of the number of tasks completed by this thread pool.
- getCompletedTaskCount() - Method in interface org.jboss.threads.management.StandardThreadPoolMXBean
-
Get an estimate of the number of tasks completed by this thread pool.
- getCorePoolSize() - Method in class org.jboss.threads.EnhancedQueueExecutor.Builder
-
Get the core pool size.
- getCorePoolSize() - Method in class org.jboss.threads.EnhancedQueueExecutor
-
Get the core pool size.
- getCorePoolSize() - Method in interface org.jboss.threads.management.StandardThreadPoolMXBean
-
Get the core pool size.
- getCoreThreads() - Method in class org.jboss.threads.JBossThreadPoolExecutor
-
Deprecated.
- getCoreThreads() - Method in interface org.jboss.threads.management.BoundedQueueThreadPoolExecutorMBean
-
Deprecated.
- getCoreThreads() - Method in class org.jboss.threads.QueueExecutor
-
Deprecated.
- getCurrentThreadCount() - Method in class org.jboss.threads.JBossScheduledThreadPoolExecutor
-
- getCurrentThreadCount() - Method in class org.jboss.threads.JBossThreadPoolExecutor
-
Deprecated.
- getCurrentThreadCount() - Method in interface org.jboss.threads.management.ThreadExecutorMBean
-
Deprecated.
- getCurrentThreadCount() - Method in class org.jboss.threads.QueueExecutor
-
Deprecated.
- getCurrentThreadCount() - Method in class org.jboss.threads.QueuelessExecutor
-
Deprecated.
- getExceptionHandler() - Method in class org.jboss.threads.EnhancedQueueExecutor.Builder
-
Get the uncaught exception handler.
- getExceptionHandler() - Method in class org.jboss.threads.EnhancedQueueExecutor
-
Get the exception handler to use for uncaught exceptions.
- getGrowthResistance() - Method in class org.jboss.threads.EnhancedQueueExecutor.Builder
-
Get the thread pool growth resistance.
- getGrowthResistance() - Method in class org.jboss.threads.EnhancedQueueExecutor
-
Get the thread pool growth resistance.
- getGrowthResistance() - Method in interface org.jboss.threads.management.StandardThreadPoolMXBean
-
Get the pool size growth resistance factor.
- getHandoffExecutor() - Method in class org.jboss.threads.EnhancedQueueExecutor.Builder
-
Get the handoff executor.
- getHandoffExecutor() - Method in class org.jboss.threads.EnhancedQueueExecutor
-
Get the executor to delegate to in the event of task rejection.
- getHandoffExecutor() - Method in class org.jboss.threads.ManagedThreadPoolExecutor
-
- getHandoffExecutor() - Method in class org.jboss.threads.QueueExecutor
-
Deprecated.
Get the handoff executor which is called when a task cannot be accepted immediately.
- getHandoffExecutor() - Method in class org.jboss.threads.QueuelessExecutor
-
Deprecated.
- getInterruptDeferredEx(ExceptionSupplier<T, E>) - Static method in class org.jboss.threads.JBossThread
-
- getInterruptResumedEx(ExceptionSupplier<T, E>) - Static method in class org.jboss.threads.JBossThread
-
- getJarName() - Static method in class org.jboss.threads.Version
-
Get the name of the JBoss Modules JAR.
- getKeepAliveTime(TimeUnit) - Method in class org.jboss.threads.EnhancedQueueExecutor.Builder
-
Get the thread keep-alive time.
- getKeepAliveTime(TimeUnit) - Method in class org.jboss.threads.EnhancedQueueExecutor
-
Get the thread keep-alive time.
- getKeepAliveTime() - Method in class org.jboss.threads.JBossScheduledThreadPoolExecutor
-
- getKeepAliveTime() - Method in class org.jboss.threads.JBossThreadPoolExecutor
-
Deprecated.
- getKeepAliveTime() - Method in interface org.jboss.threads.management.ThreadPoolExecutorMBean
-
Deprecated.
- getKeepAliveTime() - Method in class org.jboss.threads.QueueExecutor
-
Deprecated.
- getKeepAliveTime() - Method in class org.jboss.threads.QueuelessExecutor
-
Deprecated.
- getKeepAliveTimeSeconds() - Method in interface org.jboss.threads.management.StandardThreadPoolMXBean
-
Get the thread keep-alive time, in seconds.
- getLargestPoolSize() - Method in class org.jboss.threads.EnhancedQueueExecutor
-
Get an estimate of the peak number of threads that the pool has ever held.
- getLargestPoolSize() - Method in interface org.jboss.threads.management.StandardThreadPoolMXBean
-
Get an estimate of the peak number of threads that the pool has ever held.
- getLargestQueueSize() - Method in class org.jboss.threads.EnhancedQueueExecutor
-
Get an estimate of the peak size of the queue.
- getLargestQueueSize() - Method in interface org.jboss.threads.management.StandardThreadPoolMXBean
-
Get an estimate of the peak size of the queue, if any.
- getLargestThreadCount() - Method in class org.jboss.threads.JBossScheduledThreadPoolExecutor
-
- getLargestThreadCount() - Method in class org.jboss.threads.JBossThreadPoolExecutor
-
Deprecated.
- getLargestThreadCount() - Method in interface org.jboss.threads.management.ThreadExecutorMBean
-
Deprecated.
- getLargestThreadCount() - Method in class org.jboss.threads.QueueExecutor
-
Deprecated.
- getLargestThreadCount() - Method in class org.jboss.threads.QueuelessExecutor
-
Deprecated.
- getMaximumPoolSize() - Method in class org.jboss.threads.EnhancedQueueExecutor.Builder
-
Get the maximum pool size.
- getMaximumPoolSize() - Method in class org.jboss.threads.EnhancedQueueExecutor
-
Get the maximum pool size.
- getMaximumPoolSize() - Method in interface org.jboss.threads.management.StandardThreadPoolMXBean
-
Get the maximum pool size.
- getMaximumQueueSize() - Method in class org.jboss.threads.EnhancedQueueExecutor.Builder
-
Get the maximum queue size.
- getMaximumQueueSize() - Method in class org.jboss.threads.EnhancedQueueExecutor
-
Get the maximum queue size.
- getMaximumQueueSize() - Method in interface org.jboss.threads.management.StandardThreadPoolMXBean
-
Get the maximum queue size for this thread pool.
- getMaxThreads() - Method in class org.jboss.threads.JBossScheduledThreadPoolExecutor
-
- getMaxThreads() - Method in class org.jboss.threads.JBossThreadPoolExecutor
-
Deprecated.
- getMaxThreads() - Method in interface org.jboss.threads.management.ThreadPoolExecutorMBean
-
Deprecated.
- getMaxThreads() - Method in class org.jboss.threads.QueueExecutor
-
Deprecated.
- getMaxThreads() - Method in class org.jboss.threads.QueuelessExecutor
-
Deprecated.
- getMBeanName() - Method in class org.jboss.threads.EnhancedQueueExecutor.Builder
-
Get the overridden MBean name.
- getPoolSize() - Method in class org.jboss.threads.EnhancedQueueExecutor
-
Get an estimate of the current number of active threads in the pool.
- getPoolSize() - Method in interface org.jboss.threads.management.StandardThreadPoolMXBean
-
Get an estimate of the current number of active threads in the pool.
- getQueueSize() - Method in class org.jboss.threads.EnhancedQueueExecutor
-
Get an estimate of the current queue size.
- getQueueSize() - Method in class org.jboss.threads.JBossScheduledThreadPoolExecutor
- getQueueSize() - Method in class org.jboss.threads.JBossThreadPoolExecutor
-
Deprecated.
- getQueueSize() - Method in interface org.jboss.threads.management.StandardThreadPoolMXBean
-
Get an estimate of the current queue size, if any.
- getQueueSize() - Method in interface org.jboss.threads.management.ThreadExecutorMBean
-
Deprecated.
- getQueueSize() - Method in class org.jboss.threads.QueueExecutor
-
Deprecated.
- getQueueSize() - Method in class org.jboss.threads.QueuelessExecutor
-
Deprecated.
- getRejectedCount() - Method in class org.jboss.threads.JBossScheduledThreadPoolExecutor
-
- getRejectedCount() - Method in class org.jboss.threads.JBossThreadPoolExecutor
-
Deprecated.
- getRejectedCount() - Method in interface org.jboss.threads.management.ThreadExecutorMBean
-
Deprecated.
- getRejectedCount() - Method in class org.jboss.threads.QueueExecutor
-
Deprecated.
- getRejectedCount() - Method in class org.jboss.threads.QueuelessExecutor
-
Deprecated.
- getRejectedExecutionHandler() - Method in class org.jboss.threads.JBossScheduledThreadPoolExecutor
-
- getRejectedExecutionHandler() - Method in class org.jboss.threads.JBossThreadPoolExecutor
-
Deprecated.
- getRejectedTaskCount() - Method in class org.jboss.threads.EnhancedQueueExecutor
-
Get an estimate of the total number of tasks ever rejected by this thread pool for any reason.
- getRejectedTaskCount() - Method in interface org.jboss.threads.management.StandardThreadPoolMXBean
-
Get an estimate of the total number of tasks ever rejected by this thread pool for any reason.
- getSpinMissCount() - Method in interface org.jboss.threads.management.StandardThreadPoolMXBean
-
Get the number of spin misses that have occurred.
- getStatus() - Method in interface org.jboss.threads.AsyncFuture
-
Get (poll) the current status of the asynchronous operation.
- getStatus() - Method in class org.jboss.threads.AsyncFutureTask
-
Get (poll) the current status of the asynchronous operation.
- getSubmittedTaskCount() - Method in class org.jboss.threads.EnhancedQueueExecutor
-
Get an estimate of the total number of tasks ever submitted to this thread pool.
- getSubmittedTaskCount() - Method in interface org.jboss.threads.management.StandardThreadPoolMXBean
-
Get an estimate of the total number of tasks ever submitted to this thread pool.
- getTerminationTask() - Method in class org.jboss.threads.EnhancedQueueExecutor.Builder
-
Get the termination task.
- getThreadFactory() - Method in class org.jboss.threads.EnhancedQueueExecutor.Builder
-
Get the configured thread factory.
- getThreadPoolMXBean() - Method in class org.jboss.threads.EnhancedQueueExecutor
-
- getThreadPoolMXBean() - Method in class org.jboss.threads.ManagedThreadPoolExecutor
-
- getThreadPoolMXBean() - Method in interface org.jboss.threads.management.ManageableThreadPoolExecutorService
-
Create or acquire an MXBean instance for this thread pool.
- getUninterruptibly() - Method in interface org.jboss.threads.AsyncFuture
-
Waits (uninterruptibly) if necessary for the computation to complete, and then retrieves the result.
- getUninterruptibly(long, TimeUnit) - Method in interface org.jboss.threads.AsyncFuture
-
Waits (uninterruptibly) if necessary for at most the given time for the computation to complete, and then
retrieves the result, if available.
- getUninterruptibly() - Method in class org.jboss.threads.AsyncFutureTask
-
Waits (uninterruptibly) if necessary for the computation to complete, and then retrieves the result.
- getUninterruptibly(long, TimeUnit) - Method in class org.jboss.threads.AsyncFutureTask
-
Waits (uninterruptibly) if necessary for at most the given time for the computation to complete, and then
retrieves the result, if available.
- getVersionString() - Static method in class org.jboss.threads.Version
-
Get the version string of JBoss Modules.
- getWithInterruptHandler(InterruptHandler, ExceptionSupplier<R, E>) - Static method in class org.jboss.threads.JBossThread
-
- initializingExecutor(DirectExecutor, Runnable) - Static method in class org.jboss.threads.JBossExecutors
-
Create an executor which runs the given initialization task before running its given task.
- interrupt() - Method in class org.jboss.threads.JBossThread
-
Interrupt this thread.
- InterruptHandler - Interface in org.jboss.threads
-
A thread interrupt handler.
- interruptHandlerThrew(Throwable, InterruptHandler) - Method in class org.jboss.threads.Messages_$logger
-
- interruptHandlerThrew$str() - Method in class org.jboss.threads.Messages_$logger
-
- isAllowCoreThreadTimeout() - Method in class org.jboss.threads.JBossThreadPoolExecutor
-
Deprecated.
- isAllowCoreThreadTimeout() - Method in interface org.jboss.threads.management.BoundedQueueThreadPoolExecutorMBean
-
Deprecated.
- isAllowCoreThreadTimeOut() - Method in interface org.jboss.threads.management.StandardThreadPoolMXBean
-
Determine whether core threads are allowed to time out.
- isAllowCoreThreadTimeout() - Method in class org.jboss.threads.QueueExecutor
-
Deprecated.
- isBlocking() - Method in class org.jboss.threads.JBossThreadPoolExecutor
-
Deprecated.
- isBlocking() - Method in interface org.jboss.threads.management.BoundedThreadPoolExecutorMBean
-
Deprecated.
- isBlocking() - Method in class org.jboss.threads.QueueExecutor
-
Deprecated.
Determine whether this thread pool executor is set to block when a task cannot be accepted immediately.
- isBlocking() - Method in class org.jboss.threads.QueuelessExecutor
-
Deprecated.
- isCancelled() - Method in class org.jboss.threads.AsyncFutureTask
- isCorePoolSizeSupported() - Method in interface org.jboss.threads.management.StandardThreadPoolMXBean
-
Determine whether this implementation supports a separate core pool size.
- isCoreThreadPrestartSupported() - Method in interface org.jboss.threads.management.StandardThreadPoolMXBean
-
Determine whether this thread pool allows manual pre-start of core threads.
- isDone() - Method in class org.jboss.threads.AsyncFutureTask
- isEmpty() - Method in class org.jboss.threads.ArrayQueue
-
- isGrowthResistanceSupported() - Method in interface org.jboss.threads.management.StandardThreadPoolMXBean
-
Determine whether the thread pool supports a growth resistance factor.
- isInterrupted() - Method in class org.jboss.threads.JBossThread
-
- isQueueBounded() - Method in interface org.jboss.threads.management.StandardThreadPoolMXBean
-
Determine whether there is a bounded queue backing this thread pool.
- isQueueSizeModifiable() - Method in interface org.jboss.threads.management.StandardThreadPoolMXBean
-
Determine whether the maximum queue size is modifiable.
- isRegisterMBean() - Method in class org.jboss.threads.EnhancedQueueExecutor.Builder
-
Determine whether an MBean should automatically be registered for this pool.
- isShutdown() - Method in class org.jboss.threads.EnhancedQueueExecutor
-
Determine whether shutdown was requested on this thread pool.
- isShutdown() - Method in interface org.jboss.threads.management.StandardThreadPoolMXBean
-
Determine whether shutdown was requested.
- isShutdown() - Method in class org.jboss.threads.OrderedExecutor
-
- isShutdown() - Method in class org.jboss.threads.QueueExecutor
-
Deprecated.
- isShutdown() - Method in class org.jboss.threads.QueuelessExecutor
-
Deprecated.
- isTerminated() - Method in class org.jboss.threads.EnhancedQueueExecutor
-
Determine whether shutdown has completed on this thread pool.
- isTerminated() - Method in interface org.jboss.threads.management.StandardThreadPoolMXBean
-
Determine whether shutdown is complete.
- isTerminated() - Method in class org.jboss.threads.OrderedExecutor
-
- isTerminated() - Method in class org.jboss.threads.QueueExecutor
-
Deprecated.
- isTerminated() - Method in class org.jboss.threads.QueuelessExecutor
-
Deprecated.
- isTerminating() - Method in class org.jboss.threads.EnhancedQueueExecutor
-
Determine if this thread pool is in the process of terminating but has not yet completed.
- isTerminating() - Method in interface org.jboss.threads.management.StandardThreadPoolMXBean
-
Determine whether shutdown is in progress.
- iterator() - Method in class org.jboss.threads.ArrayQueue
-
- rejectingExecutor() - Static method in class org.jboss.threads.JBossExecutors
-
Get the rejecting executor.
- rejectingExecutor(String) - Static method in class org.jboss.threads.JBossExecutors
-
Get a rejecting executor.
- rejectingExecutorService() - Static method in class org.jboss.threads.JBossExecutors
-
Get the rejecting executor service.
- rejectingExecutorService(String) - Static method in class org.jboss.threads.JBossExecutors
-
Get the rejecting executor service.
- remove(T, V, boolean) - Method in class org.jboss.threads.AtomicArray
-
Atomically replace the array with a new array which does not include the first occurrance of the given value, if
the value is present in the array.
- remove(T, V, Comparator<? super V>) - Method in class org.jboss.threads.AtomicArray
-
Remove a value to a sorted array.
- removeAll(T, V, boolean) - Method in class org.jboss.threads.AtomicArray
-
Atomically replace the array with a new array which does not include any occurrances of the given value, if
the value is present in the array.
- removeExecutor(Executor) - Method in class org.jboss.threads.BalancingExecutor
-
Remove a delegate executor.
- resettingExecutor(DirectExecutor) - Static method in class org.jboss.threads.JBossExecutors
-
Create a direct executor which delegates tasks to the given executor, and then clears all thread-local
data after each task completes (regardless of outcome).
- resettingThreadFactory(ThreadFactory) - Static method in class org.jboss.threads.JBossExecutors
-
Create a thread factory which resets all thread-local storage and delegates to the given thread factory.
- run(R, DirectExecutor, TaskNotifier<? super R, ? super A>, A) - Static method in class org.jboss.threads.JBossExecutors
-
Run a task through the given direct executor, invoking the given notifier with the given attachment.
- run(R, TaskNotifier<? super R, ? super A>, A) - Static method in class org.jboss.threads.JBossExecutors
-
Run a task, invoking the given notifier with the given attachment.
- run() - Method in class org.jboss.threads.JBossThread
-
Execute the thread's Runnable
.
- run() - Method in class org.jboss.threads.ThreadOnExitAction
-
- runInterruptDeferredEx(ExceptionRunnable<E>) - Static method in class org.jboss.threads.JBossThread
-
- runInterruptResumedEx(ExceptionRunnable<E>) - Static method in class org.jboss.threads.JBossThread
-
- runWithInterruptHandler(InterruptHandler, ExceptionRunnable<E>) - Static method in class org.jboss.threads.JBossThread
-
- set(T, V[]) - Method in class org.jboss.threads.AtomicArray
-
Update the value of this array.
- setAllowCoreThreadTimeout(boolean) - Method in class org.jboss.threads.JBossThreadPoolExecutor
-
Deprecated.
- setAllowCoreThreadTimeout(boolean) - Method in interface org.jboss.threads.management.BoundedQueueThreadPoolExecutorMBean
-
Deprecated.
- setAllowCoreThreadTimeOut(boolean) - Method in interface org.jboss.threads.management.StandardThreadPoolMXBean
-
Establish whether core threads are allowed to time out.
- setAllowCoreThreadTimeout(boolean) - Method in class org.jboss.threads.QueueExecutor
-
Deprecated.
- setBlocking(boolean) - Method in class org.jboss.threads.JBossThreadPoolExecutor
-
Deprecated.
- setBlocking(boolean) - Method in interface org.jboss.threads.management.BoundedThreadPoolExecutorMBean
-
Deprecated.
- setBlocking(boolean) - Method in class org.jboss.threads.QueueExecutor
-
Deprecated.
Set whether this thread pool executor should be set to block when a task cannot be accepted immediately.
- setBlocking(boolean) - Method in class org.jboss.threads.QueuelessExecutor
-
Deprecated.
- setCancelled() - Method in class org.jboss.threads.AsyncFutureTask
-
Set the cancelled result of this operation.
- setCorePoolSize(int) - Method in class org.jboss.threads.EnhancedQueueExecutor.Builder
-
Set the core pool size.
- setCorePoolSize(int) - Method in class org.jboss.threads.EnhancedQueueExecutor
-
Set the core pool size.
- setCorePoolSize(int) - Method in interface org.jboss.threads.management.StandardThreadPoolMXBean
-
Set the core pool size.
- setCoreThreads(int) - Method in class org.jboss.threads.JBossThreadPoolExecutor
-
Deprecated.
- setCoreThreads(int) - Method in interface org.jboss.threads.management.BoundedQueueThreadPoolExecutorMBean
-
Deprecated.
- setCoreThreads(int) - Method in class org.jboss.threads.QueueExecutor
-
Deprecated.
- setExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class org.jboss.threads.EnhancedQueueExecutor.Builder
-
Set the uncaught exception handler.
- setExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class org.jboss.threads.EnhancedQueueExecutor
-
Set the exception handler to use for uncaught exceptions.
- setFailed(Throwable) - Method in class org.jboss.threads.AsyncFutureTask
-
Set the failure result of this operation.
- setGrowthResistance(float) - Method in class org.jboss.threads.EnhancedQueueExecutor.Builder
-
Set the thread pool growth resistance.
- setGrowthResistance(float) - Method in class org.jboss.threads.EnhancedQueueExecutor
-
Set the growth resistance factor.
- setGrowthResistance(float) - Method in interface org.jboss.threads.management.StandardThreadPoolMXBean
-
Set the pool size growth resistance factor, if supported.
- setHandoffExecutor(Executor) - Method in class org.jboss.threads.EnhancedQueueExecutor.Builder
-
Set the handoff executor.
- setHandoffExecutor(Executor) - Method in class org.jboss.threads.EnhancedQueueExecutor
-
Set the executor to delegate to in the event of task rejection.
- setHandoffExecutor(Executor) - Method in class org.jboss.threads.ManagedThreadPoolExecutor
-
- setHandoffExecutor(Executor) - Method in class org.jboss.threads.QueueExecutor
-
Deprecated.
Set the handoff executor which is called when a task cannot be accepted immediately.
- setHandoffExecutor(Executor) - Method in class org.jboss.threads.QueuelessExecutor
-
Deprecated.
- setKeepAliveTime(long, TimeUnit) - Method in class org.jboss.threads.EnhancedQueueExecutor.Builder
-
Set the thread keep-alive time.
- setKeepAliveTime(long, TimeUnit) - Method in class org.jboss.threads.EnhancedQueueExecutor
-
Set the thread keep-alive time.
- setKeepAliveTime(long) - Method in class org.jboss.threads.JBossScheduledThreadPoolExecutor
-
- setKeepAliveTime(long, TimeUnit) - Method in class org.jboss.threads.JBossScheduledThreadPoolExecutor
-
- setKeepAliveTime(long) - Method in class org.jboss.threads.JBossThreadPoolExecutor
-
Deprecated.
- setKeepAliveTime(long) - Method in interface org.jboss.threads.management.ThreadPoolExecutorMBean
-
Deprecated.
- setKeepAliveTime(long, TimeUnit) - Method in class org.jboss.threads.QueueExecutor
-
Deprecated.
Set the keep-alive time to the given amount of time.
- setKeepAliveTime(long) - Method in class org.jboss.threads.QueueExecutor
-
Deprecated.
- setKeepAliveTime(long) - Method in class org.jboss.threads.QueuelessExecutor
-
Deprecated.
- setKeepAliveTimeSeconds(long) - Method in interface org.jboss.threads.management.StandardThreadPoolMXBean
-
Set the thread keep-alive time, in seconds.
- setMaximumPoolSize(int) - Method in class org.jboss.threads.EnhancedQueueExecutor.Builder
-
Set the maximum pool size.
- setMaximumPoolSize(int) - Method in class org.jboss.threads.EnhancedQueueExecutor
-
Set the maximum pool size.
- setMaximumPoolSize(int) - Method in interface org.jboss.threads.management.StandardThreadPoolMXBean
-
Set the maximum pool size.
- setMaximumQueueSize(int) - Method in class org.jboss.threads.EnhancedQueueExecutor.Builder
-
Set the maximum queue size.
- setMaximumQueueSize(int) - Method in class org.jboss.threads.EnhancedQueueExecutor
-
Set the maximum queue size.
- setMaximumQueueSize(int) - Method in interface org.jboss.threads.management.StandardThreadPoolMXBean
-
Set the maximum queue size for this thread pool.
- setMaxThreads(int) - Method in class org.jboss.threads.JBossScheduledThreadPoolExecutor
-
- setMaxThreads(int) - Method in class org.jboss.threads.JBossThreadPoolExecutor
-
Deprecated.
- setMaxThreads(int) - Method in interface org.jboss.threads.management.ThreadPoolExecutorMBean
-
Deprecated.
- setMaxThreads(int) - Method in class org.jboss.threads.QueueExecutor
-
Deprecated.
- setMaxThreads(int) - Method in class org.jboss.threads.QueuelessExecutor
-
Deprecated.
- setMBeanName(String) - Method in class org.jboss.threads.EnhancedQueueExecutor.Builder
-
Set the overridden MBean name.
- setRegisterMBean(boolean) - Method in class org.jboss.threads.EnhancedQueueExecutor.Builder
-
Establish whether an MBean should automatically be registered for this pool.
- setRejectedExecutionHandler(RejectedExecutionHandler) - Method in class org.jboss.threads.JBossScheduledThreadPoolExecutor
-
- setRejectedExecutionHandler(RejectedExecutionHandler) - Method in class org.jboss.threads.JBossThreadPoolExecutor
-
Deprecated.
- setResult(T) - Method in class org.jboss.threads.AsyncFutureTask
-
Set the successful result of this operation.
- setTerminationTask(Runnable) - Method in class org.jboss.threads.EnhancedQueueExecutor.Builder
-
Set the termination task.
- setTerminationTask(Runnable) - Method in class org.jboss.threads.EnhancedQueueExecutor
-
Set the termination task, overwriting any previous setting.
- setThreadFactory(ThreadFactory) - Method in class org.jboss.threads.EnhancedQueueExecutor.Builder
-
Set the configured thread factory.
- setUncaughtExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class org.jboss.threads.JBossThread
-
Change the uncaught exception handler for this thread.
- shutdown() - Method in class org.jboss.threads.EnhancedQueueExecutor
-
Request that shutdown be initiated for this thread pool.
- shutdown(boolean) - Method in class org.jboss.threads.EnhancedQueueExecutor
-
Initiate shutdown of this thread pool.
- shutdown() - Method in class org.jboss.threads.OrderedExecutor
-
- shutdown() - Method in class org.jboss.threads.QueueExecutor
-
Deprecated.
- shutdown() - Method in class org.jboss.threads.QueuelessExecutor
-
Deprecated.
- shutdown() - Method in class org.jboss.threads.SimpleShutdownListenable
-
Run and remove all registered listeners, and mark this object as having been shut down so that
future listeners are invoked immediately.
- shutDownInitiated() - Method in class org.jboss.threads.Messages_$logger
-
- shutDownInitiated$str() - Method in class org.jboss.threads.Messages_$logger
-
- ShutdownListenable - Interface in org.jboss.threads
-
An object which can have shutdown listeners registered on it.
- shutdownNow() - Method in class org.jboss.threads.EnhancedQueueExecutor
-
Attempt to stop the thread pool immediately by interrupting all running threads and de-queueing all pending
tasks.
- shutdownNow() - Method in class org.jboss.threads.OrderedExecutor
-
- shutdownNow() - Method in class org.jboss.threads.QueueExecutor
-
Deprecated.
- shutdownNow() - Method in class org.jboss.threads.QueuelessExecutor
-
Deprecated.
- SimpleShutdownListenable - Class in org.jboss.threads
-
A simple shutdown-listenable registry.
- SimpleShutdownListenable() - Constructor for class org.jboss.threads.SimpleShutdownListenable
-
- size() - Method in class org.jboss.threads.ArrayQueue
-
- sort(T, Comparator<? super V>) - Method in class org.jboss.threads.AtomicArray
-
Sort an array.
- StandardThreadPoolMXBean - Interface in org.jboss.threads.management
-
An MXBean which contains the attributes and operations found on all standard thread pools.
- start() - Method in class org.jboss.threads.JBossThread
-
Start the thread.
- started(R, A) - Method in interface org.jboss.threads.TaskNotifier
-
A task was started.
- StoppedExecutorException - Exception in org.jboss.threads
-
Thrown when a task is submitted to an executor which is in the process of, or has completed shutting down.
- StoppedExecutorException() - Constructor for exception org.jboss.threads.StoppedExecutorException
-
Constructs a StoppedExecutorException
with no detail message.
- StoppedExecutorException(String) - Constructor for exception org.jboss.threads.StoppedExecutorException
-
Constructs a StoppedExecutorException
with the specified detail message.
- StoppedExecutorException(Throwable) - Constructor for exception org.jboss.threads.StoppedExecutorException
-
Constructs a StoppedExecutorException
with the specified cause.
- StoppedExecutorException(String, Throwable) - Constructor for exception org.jboss.threads.StoppedExecutorException
-
Constructs a StoppedExecutorException
with the specified detail message and cause.