Skip navigation links
JBoss Threads 2.2.1.Final
A B C D E F G H I J L N O P Q R S T U V W 

A

abortPolicy() - Static method in class org.jboss.threads.JBossExecutors
Get the abort policy for a ThreadPoolExecutor.
AbstractListener() - Constructor for class org.jboss.threads.AsyncFuture.AbstractListener
 
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
Add a shutdown listener.
addShutdownListener(EventListener<A>, A) - Method in class org.jboss.threads.QueueExecutor
Add a shutdown listener.
addShutdownListener(EventListener<A>, A) - Method in class org.jboss.threads.QueuelessExecutor
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.
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
The possible statuses of an AsyncFuture.
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
 
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.OrderedExecutor
 
awaitTermination(long, TimeUnit) - Method in class org.jboss.threads.QueueExecutor
awaitTermination(long, TimeUnit) - Method in class org.jboss.threads.QueuelessExecutor
 
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.

B

BalancingExecutor - Class in org.jboss.threads
A simple load-balancing executor.
BalancingExecutor() - Constructor for class org.jboss.threads.BalancingExecutor
Construct a new instance.
BalancingExecutor(Executor...) - Constructor for class org.jboss.threads.BalancingExecutor
Construct a new instance.
blockingDirectExecutor() - Static method in class org.jboss.threads.JBossExecutors
Get an executor which executes tasks in the current thread, which implements BlockingExecutor.
blockingDiscardingExecutor() - Static method in class org.jboss.threads.JBossExecutors
Get an executor which discards all tasks, which implements BlockingExecutor.
BlockingExecutor - Interface in org.jboss.threads
An executor which can optionally block or not block on task submission.
BlockingExecutorService - Interface in org.jboss.threads
A blocking executor service.
blockingRejectingExecutor() - Static method in class org.jboss.threads.JBossExecutors
Get an executor which rejects all tasks, which implements BlockingExecutor.
BoundedQueueThreadPoolExecutorMBean - Interface in org.jboss.threads.management
 
BoundedThreadPoolExecutorMBean - Interface in org.jboss.threads.management
 

C

callerRunsPolicy() - Static method in class org.jboss.threads.JBossExecutors
Get the caller-runs policy for a ThreadPoolExecutor.
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.
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.
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
Convenience method to create an instance.
create(AtomicReferenceFieldUpdater<T, V[]>, AtomicArray.Creator<V>) - Static method in class org.jboss.threads.AtomicArray
Convenience method to create an instance.
create(int) - Method in interface org.jboss.threads.AtomicArray.Creator
 
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.

D

Dependency - Class in org.jboss.threads
A task which depends on other tasks, and which may have tasks depending upon it.
DependencyTaskBuilder - Class in org.jboss.threads
A builder for a dependency task.
dependencyTaskBuilder(Executor, Runnable) - Static method in class org.jboss.threads.JBossExecutors
Create a builder for a dependent task.
directBlockingExecutor(DirectExecutor) - Static method in class org.jboss.threads.JBossExecutors
An executor which delegates to the given direct executor, but implements the blocking executor interface.
DirectExecutor - Interface in org.jboss.threads
A direct executor.
directExecutor() - Static method in class org.jboss.threads.JBossExecutors
Get the direct executor.
DirectExecutorService - Interface in org.jboss.threads
A direct executor service.
directExecutorService() - Static method in class org.jboss.threads.JBossExecutors
Get the direct executor service.
discardingExecutor() - Static method in class org.jboss.threads.JBossExecutors
Get the discarding executor.
discardingExecutorService() - Static method in class org.jboss.threads.JBossExecutors
Get the discarding executor service.
discardOldestPolicy() - Static method in class org.jboss.threads.JBossExecutors
Get the discard-oldest policy for a ThreadPoolExecutor.
discardPolicy() - Static method in class org.jboss.threads.JBossExecutors
Get the discard policy for a ThreadPoolExecutor.

E

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
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.JBossThreadPoolExecutor
 
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
Execute a task.
execute(Runnable) - Method in class org.jboss.threads.QueuelessExecutor
 
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
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
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
 
executeBlocking(Runnable, long, TimeUnit) - Method in class org.jboss.threads.JBossThreadPoolExecutor
 
executeBlocking(Runnable) - Method in class org.jboss.threads.OrderedExecutor
 
executeBlocking(Runnable, long, TimeUnit) - Method in class org.jboss.threads.OrderedExecutor
 
executeBlocking(Runnable) - Method in class org.jboss.threads.QueueExecutor
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
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
 
executeBlocking(Runnable, long, TimeUnit) - Method in class org.jboss.threads.QueuelessExecutor
 
executeNonBlocking(Runnable) - Method in interface org.jboss.threads.BlockingExecutor
Execute a task, without blocking.
executeNonBlocking(Runnable) - Method in class org.jboss.threads.JBossThreadPoolExecutor
 
executeNonBlocking(Runnable) - Method in class org.jboss.threads.OrderedExecutor
 
executeNonBlocking(Runnable) - Method in class org.jboss.threads.QueueExecutor
Execute a task, without blocking.
executeNonBlocking(Runnable) - Method in class org.jboss.threads.QueuelessExecutor
 
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.
ExecutionInterruptedException - Exception in org.jboss.threads
Thrown when a Executor.execute(Runnable) submission is interrupted before the task could be accepted.
ExecutionInterruptedException() - Constructor for exception org.jboss.threads.ExecutionInterruptedException
Constructs a ExecutionInterruptedException with no detail message.
ExecutionInterruptedException(String) - Constructor for exception org.jboss.threads.ExecutionInterruptedException
Constructs a ExecutionInterruptedException with the specified detail message.
ExecutionInterruptedException(Throwable) - Constructor for exception org.jboss.threads.ExecutionInterruptedException
Constructs a ExecutionInterruptedException with the specified cause.
ExecutionInterruptedException(String, Throwable) - Constructor for exception org.jboss.threads.ExecutionInterruptedException
Constructs a ExecutionInterruptedException with the specified detail message and cause.
ExecutionTimedOutException - Exception in org.jboss.threads
Thrown when an execute-with-timeout method is called and the timeout elapsed before a task could be accepted.
ExecutionTimedOutException() - Constructor for exception org.jboss.threads.ExecutionTimedOutException
Constructs a ExecutionTimedOutException with no detail message.
ExecutionTimedOutException(String) - Constructor for exception org.jboss.threads.ExecutionTimedOutException
Constructs a ExecutionTimedOutException with the specified detail message.
ExecutionTimedOutException(Throwable) - Constructor for exception org.jboss.threads.ExecutionTimedOutException
Constructs a ExecutionTimedOutException with the specified cause.
ExecutionTimedOutException(String, Throwable) - Constructor for exception org.jboss.threads.ExecutionTimedOutException
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.

F

failed(R, Throwable, A) - Method in interface org.jboss.threads.TaskNotifier
A task has failed.
finished(R, A) - Method in interface org.jboss.threads.TaskNotifier
A task has completed.

G

get() - Method in class org.jboss.threads.AsyncFutureTask
get(long, TimeUnit) - Method in class org.jboss.threads.AsyncFutureTask
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.
getCoreThreads() - Method in class org.jboss.threads.JBossThreadPoolExecutor
 
getCoreThreads() - Method in interface org.jboss.threads.management.BoundedQueueThreadPoolExecutorMBean
 
getCoreThreads() - Method in class org.jboss.threads.QueueExecutor
getCurrentThreadCount() - Method in class org.jboss.threads.JBossScheduledThreadPoolExecutor
 
getCurrentThreadCount() - Method in class org.jboss.threads.JBossThreadPoolExecutor
 
getCurrentThreadCount() - Method in interface org.jboss.threads.management.ThreadExecutorMBean
 
getCurrentThreadCount() - Method in class org.jboss.threads.QueueExecutor
getCurrentThreadCount() - Method in class org.jboss.threads.QueuelessExecutor
 
getHandoffExecutor() - Method in class org.jboss.threads.QueueExecutor
Get the handoff executor which is called when a task cannot be accepted immediately.
getHandoffExecutor() - Method in class org.jboss.threads.QueuelessExecutor
 
getKeepAliveTime() - Method in class org.jboss.threads.JBossScheduledThreadPoolExecutor
 
getKeepAliveTime() - Method in class org.jboss.threads.JBossThreadPoolExecutor
 
getKeepAliveTime() - Method in interface org.jboss.threads.management.ThreadPoolExecutorMBean
 
getKeepAliveTime() - Method in class org.jboss.threads.QueueExecutor
getKeepAliveTime() - Method in class org.jboss.threads.QueuelessExecutor
 
getLargestThreadCount() - Method in class org.jboss.threads.JBossScheduledThreadPoolExecutor
 
getLargestThreadCount() - Method in class org.jboss.threads.JBossThreadPoolExecutor
 
getLargestThreadCount() - Method in interface org.jboss.threads.management.ThreadExecutorMBean
 
getLargestThreadCount() - Method in class org.jboss.threads.QueueExecutor
getLargestThreadCount() - Method in class org.jboss.threads.QueuelessExecutor
 
getMaxThreads() - Method in class org.jboss.threads.JBossScheduledThreadPoolExecutor
 
getMaxThreads() - Method in class org.jboss.threads.JBossThreadPoolExecutor
 
getMaxThreads() - Method in interface org.jboss.threads.management.ThreadPoolExecutorMBean
 
getMaxThreads() - Method in class org.jboss.threads.QueueExecutor
getMaxThreads() - Method in class org.jboss.threads.QueuelessExecutor
 
getQueueSize() - Method in class org.jboss.threads.JBossScheduledThreadPoolExecutor
getQueueSize() - Method in class org.jboss.threads.JBossThreadPoolExecutor
getQueueSize() - Method in interface org.jboss.threads.management.ThreadExecutorMBean
 
getQueueSize() - Method in class org.jboss.threads.QueueExecutor
getQueueSize() - Method in class org.jboss.threads.QueuelessExecutor
getRejectedCount() - Method in class org.jboss.threads.JBossScheduledThreadPoolExecutor
 
getRejectedCount() - Method in class org.jboss.threads.JBossThreadPoolExecutor
 
getRejectedCount() - Method in interface org.jboss.threads.management.ThreadExecutorMBean
 
getRejectedCount() - Method in class org.jboss.threads.QueueExecutor
getRejectedCount() - Method in class org.jboss.threads.QueuelessExecutor
 
getRejectedExecutionHandler() - Method in class org.jboss.threads.JBossScheduledThreadPoolExecutor
 
getRejectedExecutionHandler() - Method in class org.jboss.threads.JBossThreadPoolExecutor
 
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.
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.

H

handleCancelled(AsyncFuture<? extends T>, A) - Method in class org.jboss.threads.AsyncFuture.AbstractListener
Handle a cancellation result.
handleCancelled(AsyncFuture<? extends T>, A) - Method in interface org.jboss.threads.AsyncFuture.Listener
Handle a cancellation result.
handleComplete(AsyncFuture<? extends T>, A) - Method in class org.jboss.threads.AsyncFuture.AbstractListener
Handle a successful computation result.
handleComplete(AsyncFuture<? extends T>, A) - Method in interface org.jboss.threads.AsyncFuture.Listener
Handle a successful computation result.
handleEvent(A) - Method in interface org.jboss.threads.EventListener
Handle the event.
handleFailed(AsyncFuture<? extends T>, Throwable, A) - Method in class org.jboss.threads.AsyncFuture.AbstractListener
Handle a failure result.
handleFailed(AsyncFuture<? extends T>, Throwable, A) - Method in interface org.jboss.threads.AsyncFuture.Listener
Handle a failure result.
handleInterrupt(Thread) - Method in interface org.jboss.threads.InterruptHandler
Handle an interrupt condition on the given thread.
handoffPolicy(Executor) - Static method in class org.jboss.threads.JBossExecutors
Get a handoff policy for a ThreadPoolExecutor.

I

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.
isAllowCoreThreadTimeout() - Method in class org.jboss.threads.JBossThreadPoolExecutor
 
isAllowCoreThreadTimeout() - Method in interface org.jboss.threads.management.BoundedQueueThreadPoolExecutorMBean
 
isAllowCoreThreadTimeout() - Method in class org.jboss.threads.QueueExecutor
isBlocking() - Method in class org.jboss.threads.JBossThreadPoolExecutor
 
isBlocking() - Method in interface org.jboss.threads.management.BoundedThreadPoolExecutorMBean
 
isBlocking() - Method in class org.jboss.threads.QueueExecutor
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
 
isCancelled() - Method in class org.jboss.threads.AsyncFutureTask
isDone() - Method in class org.jboss.threads.AsyncFutureTask
isEmpty() - Method in class org.jboss.threads.ArrayQueue
 
isInterrupted() - Method in class org.jboss.threads.JBossThread
 
isShutdown() - Method in class org.jboss.threads.OrderedExecutor
 
isShutdown() - Method in class org.jboss.threads.QueueExecutor
isShutdown() - Method in class org.jboss.threads.QueuelessExecutor
 
isTerminated() - Method in class org.jboss.threads.OrderedExecutor
 
isTerminated() - Method in class org.jboss.threads.QueueExecutor
isTerminated() - Method in class org.jboss.threads.QueuelessExecutor
 
iterator() - Method in class org.jboss.threads.ArrayQueue
 

J

JBossExecutors - Class in org.jboss.threads
JBoss thread- and executor-related utility and factory methods.
JBossScheduledThreadPoolExecutor - Class in org.jboss.threads
 
JBossScheduledThreadPoolExecutor(int) - Constructor for class org.jboss.threads.JBossScheduledThreadPoolExecutor
 
JBossScheduledThreadPoolExecutor(int, ThreadFactory) - Constructor for class org.jboss.threads.JBossScheduledThreadPoolExecutor
 
JBossScheduledThreadPoolExecutor(int, RejectedExecutionHandler) - Constructor for class org.jboss.threads.JBossScheduledThreadPoolExecutor
 
JBossScheduledThreadPoolExecutor(int, ThreadFactory, RejectedExecutionHandler) - Constructor for class org.jboss.threads.JBossScheduledThreadPoolExecutor
 
JBossThread - Class in org.jboss.threads
A JBoss thread.
JBossThread(Runnable) - Constructor for class org.jboss.threads.JBossThread
Construct a new instance.
JBossThread(Runnable, String) - Constructor for class org.jboss.threads.JBossThread
Construct a new instance.
JBossThread(ThreadGroup, Runnable) - Constructor for class org.jboss.threads.JBossThread
Construct a new instance.
JBossThread(ThreadGroup, Runnable, String) - Constructor for class org.jboss.threads.JBossThread
Construct a new instance.
JBossThread(ThreadGroup, Runnable, String, long) - Constructor for class org.jboss.threads.JBossThread
Construct a new instance.
JBossThreadFactory - Class in org.jboss.threads
A factory for JBossThread instances.
JBossThreadFactory(ThreadGroup, Boolean, Integer, String, Thread.UncaughtExceptionHandler, Long) - Constructor for class org.jboss.threads.JBossThreadFactory
Construct a new instance.
JBossThreadFactory(ThreadGroup, Boolean, Integer, String, Thread.UncaughtExceptionHandler, Long, AccessControlContext) - Constructor for class org.jboss.threads.JBossThreadFactory
Deprecated.
This constructor is unsafe and now just delegates to the other constructor without using the given access control context. It will be removed as of version 2.3.0.Final.
JBossThreadPoolExecutor - Class in org.jboss.threads
 
JBossThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>) - Constructor for class org.jboss.threads.JBossThreadPoolExecutor
 
JBossThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>, ThreadFactory) - Constructor for class org.jboss.threads.JBossThreadPoolExecutor
 
JBossThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>, RejectedExecutionHandler) - Constructor for class org.jboss.threads.JBossThreadPoolExecutor
 
JBossThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>, ThreadFactory, RejectedExecutionHandler) - Constructor for class org.jboss.threads.JBossThreadPoolExecutor
 

L

LimitedExecutor - Class in org.jboss.threads
An executor for long-running tasks which limits the total concurrency over a delegate thread pool.
LimitedExecutor(Executor, Thread.UncaughtExceptionHandler, int) - Constructor for class org.jboss.threads.LimitedExecutor
 
LimitedExecutor(Executor, int) - Constructor for class org.jboss.threads.LimitedExecutor
 
loggingExceptionHandler(Logger) - Static method in class org.jboss.threads.JBossExecutors
Get an uncaught exception handler which logs to the given logger.
loggingExceptionHandler(String) - Static method in class org.jboss.threads.JBossExecutors
Get an uncaught exception handler which logs to the given logger.
loggingExceptionHandler() - Static method in class org.jboss.threads.JBossExecutors
Get an uncaught exception handler which logs to the default error logger.

N

newThread(Runnable) - Method in class org.jboss.threads.JBossThreadFactory
 
notifyingDirectExecutor(DirectExecutor, TaskNotifier<Runnable, ? super A>, A) - Static method in class org.jboss.threads.JBossExecutors
Get a notifying direct executor.
notifyingRunnable(R, TaskNotifier<? super R, ? super A>, A) - Static method in class org.jboss.threads.JBossExecutors
Get a notifying runnable wrapper for a task.
nullRunnable() - Static method in class org.jboss.threads.JBossExecutors
Get the null runnable which does nothing.

O

offer(E) - Method in class org.jboss.threads.ArrayQueue
 
OrderedExecutor - Class in org.jboss.threads
An executor that always runs all tasks in queue order, using a delegate executor to run the tasks.
OrderedExecutor(Executor) - Constructor for class org.jboss.threads.OrderedExecutor
Construct a new instance using an unbounded FIFO queue.
OrderedExecutor(Executor, Queue<Runnable>) - Constructor for class org.jboss.threads.OrderedExecutor
Construct a new instance using the given queue and a blocking reject policy.
OrderedExecutor(Executor, int) - Constructor for class org.jboss.threads.OrderedExecutor
Construct a new instance using a bounded FIFO queue of the given size and a blocking reject policy.
OrderedExecutor(Executor, int, Executor) - Constructor for class org.jboss.threads.OrderedExecutor
Construct a new instance using a bounded FIFO queue of the given size and a handoff reject policy.
OrderedExecutor(Executor, Queue<Runnable>, boolean, Executor) - Constructor for class org.jboss.threads.OrderedExecutor
Construct a new instance.
OrderedExecutor(Executor, int, boolean, Executor) - Constructor for class org.jboss.threads.OrderedExecutor
Construct a new instance using a bounded FIFO queue of the given size and a handoff reject policy.
org.jboss.threads - package org.jboss.threads
 
org.jboss.threads.management - package org.jboss.threads.management
 

P

peek() - Method in class org.jboss.threads.ArrayQueue
 
poll() - Method in class org.jboss.threads.ArrayQueue
 
privilegedExecutor(DirectExecutor, AccessControlContext) - Static method in class org.jboss.threads.JBossExecutors
Create a direct executor which runs with the privileges given by the supplied AccessControlContext instance.
privilegedExecutor(DirectExecutor, Class<?>) - Static method in class org.jboss.threads.JBossExecutors
Create a direct executor which runs with the privileges given by the supplied class' protection domain.
privilegedExecutor(DirectExecutor) - Static method in class org.jboss.threads.JBossExecutors
Create a direct executor which runs with the privileges given by the current access control context.
protectedBlockingExecutor(BlockingExecutor) - Static method in class org.jboss.threads.JBossExecutors
 
protectedBlockingExecutorService(BlockingExecutor) - Static method in class org.jboss.threads.JBossExecutors
Wrap a blocking executor with an BlockingExecutorService instance which supports all the features of BlockingExecutorService except for shutting down the executor.
protectedDirectExecutorService(DirectExecutor) - Static method in class org.jboss.threads.JBossExecutors
Wrap a direct executor with an DirectExecutorService instance which supports all the features of ExecutorService except for shutting down the executor.
protectedExecutorService(Executor) - Static method in class org.jboss.threads.JBossExecutors
Wrap an executor with an ExecutorService instance which supports all the features of ExecutorService except for shutting down the executor.
protectedScheduledExecutorService(ScheduledExecutorService) - Static method in class org.jboss.threads.JBossExecutors
Wrap a scheduled executor with a ScheduledExecutorService instance which supports all the features of ScheduledExecutorService except for shutting down the executor.

Q

QueueExecutor - Class in org.jboss.threads
An executor which uses a regular queue to hold tasks.
QueueExecutor(int, int, long, TimeUnit, Queue<Runnable>, ThreadFactory, boolean, Executor, DirectExecutor) - Constructor for class org.jboss.threads.QueueExecutor
Create a new instance.
QueueExecutor(int, int, long, TimeUnit, Queue<Runnable>, ThreadFactory, boolean, Executor) - Constructor for class org.jboss.threads.QueueExecutor
Create a new instance.
QueueExecutor(int, int, long, TimeUnit, int, ThreadFactory, boolean, Executor) - Constructor for class org.jboss.threads.QueueExecutor
Create a new instance.
QueuelessExecutor - Class in org.jboss.threads
A queueless thread pool.
QueuelessExecutor(ThreadFactory, DirectExecutor, Executor, long) - Constructor for class org.jboss.threads.QueuelessExecutor
 

R

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.

S

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
 
setAllowCoreThreadTimeout(boolean) - Method in interface org.jboss.threads.management.BoundedQueueThreadPoolExecutorMBean
 
setAllowCoreThreadTimeout(boolean) - Method in class org.jboss.threads.QueueExecutor
setBlocking(boolean) - Method in class org.jboss.threads.JBossThreadPoolExecutor
 
setBlocking(boolean) - Method in interface org.jboss.threads.management.BoundedThreadPoolExecutorMBean
 
setBlocking(boolean) - Method in class org.jboss.threads.QueueExecutor
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
 
setCancelled() - Method in class org.jboss.threads.AsyncFutureTask
Set the cancelled result of this operation.
setCoreThreads(int) - Method in class org.jboss.threads.JBossThreadPoolExecutor
 
setCoreThreads(int) - Method in interface org.jboss.threads.management.BoundedQueueThreadPoolExecutorMBean
 
setCoreThreads(int) - Method in class org.jboss.threads.QueueExecutor
setFailed(Throwable) - Method in class org.jboss.threads.AsyncFutureTask
Set the failure result of this operation.
setHandoffExecutor(Executor) - Method in class org.jboss.threads.QueueExecutor
Set the handoff executor which is called when a task cannot be accepted immediately.
setHandoffExecutor(Executor) - Method in class org.jboss.threads.QueuelessExecutor
 
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
 
setKeepAliveTime(long) - Method in interface org.jboss.threads.management.ThreadPoolExecutorMBean
 
setKeepAliveTime(long, TimeUnit) - Method in class org.jboss.threads.QueueExecutor
Set the keep-alive time to the given amount of time.
setKeepAliveTime(long) - Method in class org.jboss.threads.QueueExecutor
setKeepAliveTime(long) - Method in class org.jboss.threads.QueuelessExecutor
 
setMaxThreads(int) - Method in class org.jboss.threads.JBossScheduledThreadPoolExecutor
 
setMaxThreads(int) - Method in class org.jboss.threads.JBossThreadPoolExecutor
 
setMaxThreads(int) - Method in interface org.jboss.threads.management.ThreadPoolExecutorMBean
 
setMaxThreads(int) - Method in class org.jboss.threads.QueueExecutor
setMaxThreads(int) - Method in class org.jboss.threads.QueuelessExecutor
 
setRejectedExecutionHandler(RejectedExecutionHandler) - Method in class org.jboss.threads.JBossScheduledThreadPoolExecutor
 
setRejectedExecutionHandler(RejectedExecutionHandler) - Method in class org.jboss.threads.JBossThreadPoolExecutor
 
setResult(T) - Method in class org.jboss.threads.AsyncFutureTask
Set the successful result of this operation.
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.OrderedExecutor
 
shutdown() - Method in class org.jboss.threads.QueueExecutor
shutdown() - Method in class org.jboss.threads.QueuelessExecutor
 
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.
ShutdownListenable - Interface in org.jboss.threads
An object which can have shutdown listeners registered on it.
shutdownNow() - Method in class org.jboss.threads.OrderedExecutor
 
shutdownNow() - Method in class org.jboss.threads.QueueExecutor
shutdownNow() - Method in class org.jboss.threads.QueuelessExecutor
 
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.
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.

T

TaskNotifier<R extends Runnable,A> - Interface in org.jboss.threads
A notifier which is called when tasks start, stop, or fail.
terminated() - Method in class org.jboss.threads.JBossScheduledThreadPoolExecutor
 
terminated() - Method in class org.jboss.threads.JBossThreadPoolExecutor
 
ThreadCreationException - Exception in org.jboss.threads
Thrown when a thread factory refuses to create a thread for a thread pool.
ThreadCreationException() - Constructor for exception org.jboss.threads.ThreadCreationException
Constructs a ThreadCreationException with no detail message.
ThreadCreationException(String) - Constructor for exception org.jboss.threads.ThreadCreationException
Constructs a ThreadCreationException with the specified detail message.
ThreadCreationException(Throwable) - Constructor for exception org.jboss.threads.ThreadCreationException
Constructs a ThreadCreationException with the specified cause.
ThreadCreationException(String, Throwable) - Constructor for exception org.jboss.threads.ThreadCreationException
Constructs a ThreadCreationException with the specified detail message and cause.
ThreadExecutorMBean - Interface in org.jboss.threads.management
 
threadFactoryExecutor(ThreadFactory) - Static method in class org.jboss.threads.JBossExecutors
Create an executor that executes each task in a new thread.
threadFactoryExecutor(ThreadFactory, int) - Static method in class org.jboss.threads.JBossExecutors
Create an executor that executes each task in a new thread.
threadFactoryExecutor(ThreadFactory, int, boolean) - Static method in class org.jboss.threads.JBossExecutors
Create an executor that executes each task in a new thread.
threadFactoryExecutor(ThreadFactory, int, boolean, DirectExecutor) - Static method in class org.jboss.threads.JBossExecutors
Create an executor that executes each task in a new thread.
threadFormattedNameExecutor(DirectExecutor, String) - Static method in class org.jboss.threads.JBossExecutors
Create a direct executor which changes the thread name for the duration of a task using a formatted name.
threadLocalResetter() - Static method in class org.jboss.threads.JBossExecutors
Get a Runnable which, when executed, clears the thread-local storage of the calling thread.
threadNameExecutor(DirectExecutor, String) - Static method in class org.jboss.threads.JBossExecutors
Create a direct executor which changes the thread name for the duration of a task.
threadNameNotateExecutor(DirectExecutor, String) - Static method in class org.jboss.threads.JBossExecutors
Create a direct executor which adds a note to the thread name for the duration of a task.
ThreadPoolExecutorMBean - Interface in org.jboss.threads.management
 
toString() - Method in class org.jboss.threads.LimitedExecutor
 

U

uninterruptibleExecutor(Executor) - Static method in class org.jboss.threads.JBossExecutors
Get an executor which executes tasks uninterruptibly in the event of blocking.

V

valueOf(String) - Static method in enum org.jboss.threads.AsyncFuture.Status
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.jboss.threads.AsyncFuture.Status
Returns an array containing the constants of this enum type, in the order they are declared.

W

wrappingExecutor(DirectExecutor, Executor) - Static method in class org.jboss.threads.JBossExecutors
An executor which delegates to another executor, wrapping each task in a task wrapper.
wrappingExecutor(Executor) - Static method in class org.jboss.threads.JBossExecutors
Create a wrapping executor for a delegate executor which creates an JBossExecutors.executorTask(DirectExecutor, Runnable) for each task.
WrappingExecutor - Interface in org.jboss.threads
An executor which runs a task within the given direct executor.
wrappingThreadFactory(DirectExecutor, ThreadFactory) - Static method in class org.jboss.threads.JBossExecutors
Creates a thread factory which executes the thread task via the given task wrapping executor.
A B C D E F G H I J L N O P Q R S T U V W 
Skip navigation links
JBoss Threads 2.2.1.Final

Copyright © 2024 JBoss by Red Hat. All rights reserved.