Index

A C D E G H I L N O P R S T U W 
All Classes and Interfaces|All Packages|Serialized Form

A

addCancellationListener(Runnable) - Method in interface org.jtrim2.cancel.CancellationToken
Adds a listener which is to be called when cancellation was requested.
allTokens(CancellationToken...) - Static method in class org.jtrim2.cancel.Cancellation
Returns a CancellationToken which signals cancellation if and only if all of the specified tokens are in canceled state.
anyToken(CancellationToken...) - Static method in class org.jtrim2.cancel.Cancellation
Returns a CancellationToken which signals cancellation if and only if at least one of the specified tokens are in canceled state.
AsyncFunction<R> - Interface in org.jtrim2.concurrent
Represents an asynchronous computation.
AsyncTasks - Class in org.jtrim2.concurrent
Defines utility methods to help with asynchronous tasks relying on CompletableFuture or CompletionStage.
await() - Method in interface org.jtrim2.cancel.InterruptibleWait
Waits until the implementation defined event occurs.
await(long) - Method in interface org.jtrim2.cancel.InterruptibleLimitedWait
Waits until the implementation defined event occurs or the given timeout elapses.
await(CancellationToken, long, TimeUnit, Condition) - Static method in class org.jtrim2.cancel.CancelableWaits
Calls condition.await(long, TimeUnit) with the specified timeout value and waits until it returns or the specified CancellationToken signals that the waiting must be canceled.
await(CancellationToken, long, TimeUnit, InterruptibleLimitedWait) - Static method in class org.jtrim2.cancel.CancelableWaits
Calls wait.await with the specified timeout value and waits until it returns or the specified CancellationToken signals that the waiting must be canceled.
await(CancellationToken, Condition) - Static method in class org.jtrim2.cancel.CancelableWaits
Calls condition.await() and waits until it returns or the specified CancellationToken signals that the waiting must be canceled.
await(CancellationToken, InterruptibleWait) - Static method in class org.jtrim2.cancel.CancelableWaits
Waits until wait.await returns or the specified CancellationToken signals that the waiting must be canceled.
awaitTerminate(CancellationToken, long, TimeUnit, ExecutorService) - Static method in class org.jtrim2.cancel.CancelableWaits
Calls executor.awaitTermination(long, TimeUnit) with the specified timeout value and waits until it returns or the specified CancellationToken signals that the waiting must be canceled.

C

cancel() - Method in interface org.jtrim2.cancel.CancellationController
Requests that the associated task be canceled.
CancelableWaits - Class in org.jtrim2.cancel
Defines static helper methods to wait for a cancellation request instead of thread interruption.
CANCELED_TOKEN - Static variable in class org.jtrim2.cancel.Cancellation
A CancellationToken which is already in the canceled state.
Cancellation - Class in org.jtrim2.cancel
Contains static helper methods and fields related cancellation.
CancellationController - Interface in org.jtrim2.cancel
Defines an interface to cancel an asynchronously executing task.
CancellationSource - Interface in org.jtrim2.cancel
Defines an interface for linked CancellationController and CancellationToken objects.
CancellationToken - Interface in org.jtrim2.cancel
Defines an interface to detect cancellation requests.
checkCanceled() - Method in interface org.jtrim2.cancel.CancellationToken
Checks if cancellation has been requested and throws a OperationCanceledException if so otherwise returns immediately without doing anything.
clear() - Method in interface org.jtrim2.concurrent.collections.TerminableQueue
Removes all the elements from this queue.
combineListenerRefs(Collection<? extends ListenerRef>) - Static method in class org.jtrim2.event.ListenerRefs
Returns a combination of multiple ListenerRef instances.
combineListenerRefs(ListenerRef...) - Static method in class org.jtrim2.event.ListenerRefs
Returns a combination of multiple ListenerRef instances.
complete(V, Throwable, CompletableFuture<? super V>) - Static method in class org.jtrim2.concurrent.AsyncTasks
Completes the passed future exceptionally or normally.
completeForwarder(CompletableFuture<? super V>) - Static method in class org.jtrim2.concurrent.AsyncTasks
Returns a BiConsumer passable to the whenComplete method of CompletionStage completing the passed CompletableFuture.
CopyOnTriggerListenerManager<ListenerType> - Class in org.jtrim2.event
An ListenerManager implementation which creates a copy of the currently registered listeners when dispatching events.
CopyOnTriggerListenerManager() - Constructor for class org.jtrim2.event.CopyOnTriggerListenerManager
Creates a new CopyOnTriggerListenerManager with no listeners registered.
CountDownEvent - Class in org.jtrim2.event
Defines event which triggers after a counter reaches zero.
CountDownEvent(int, Runnable) - Constructor for class org.jtrim2.event.CountDownEvent
Creates a new CountDownEvent with the given initial counter value and event handler.
createCancellationSource() - Static method in class org.jtrim2.cancel.Cancellation
Creates a new CancellationSource whose CancellationToken is not yet in the canceled state.
createChildCancellationSource(CancellationToken) - Static method in class org.jtrim2.cancel.Cancellation
Creates a new CancellationSource which will be notified of the cancellation requests of the specified CancellationToken.

D

dec() - Method in class org.jtrim2.event.CountDownEvent
Decrements the counter by 1.
dispatchRunnable(ListenerManager<? extends Runnable>) - Static method in class org.jtrim2.event.EventListeners
Calls the onEvent method of the passed ListenerManager, causing the run() method of the registered listeners to be called.
dispatchRunnable(OneShotListenerManager<? extends Runnable, Void>) - Static method in class org.jtrim2.event.EventListeners
Calls the onEvent method of the passed OneShotListenerManager, causing the run() method of the registered listeners to be called.
DO_NOTHING_CONTROLLER - Static variable in class org.jtrim2.cancel.Cancellation
A CancellationController which does nothing when calling cancel.
doAsCancelable(CancellationToken, InterruptibleTask<ResultType>) - Static method in class org.jtrim2.cancel.Cancellation
Executes the specified task on the current thread synchronously and interrupts the current thread if the specified CancellationToken signals a cancellation request.

E

errorResultHandler(Consumer<? super Throwable>) - Static method in class org.jtrim2.concurrent.AsyncTasks
Returns a BiConsumer notifying the passed error handler if any of the arguments of the returned BiConsumer is not null.
EventDispatcher<EventListenerType,ArgType> - Interface in org.jtrim2.event
Defines an interface to invoke specific kinds of event handlers.
EventListeners - Class in org.jtrim2.event
Contains static utility methods for listener dispatching.
execute() - Method in class org.jtrim2.concurrent.RepeatingTask
Submits this task to be executed a single time as soon as possible by the ScheduledExecutorService specified at construction time.
execute(CancellationToken) - Method in interface org.jtrim2.cancel.InterruptibleTask
Executes the task defined by this InterruptibleTask.
executeAsync(CancellationToken) - Method in interface org.jtrim2.concurrent.AsyncFunction
Starts executing the task asynchronously and returns a CompletionStage notified after the computation completes (normally or exceptionally).
expectNoError(Throwable) - Static method in class org.jtrim2.concurrent.AsyncTasks
Logs the argument as a SEVERE level issue, if it is not null and does not represent cancellation.

G

getController() - Method in interface org.jtrim2.cancel.CancellationSource
Returns the CancellationController which can be used to signal cancellation to the CancellationToken returned by the getToken() method.
getCounter() - Method in class org.jtrim2.event.CountDownEvent
Returns the current value of the counter.
getListenerCount() - Method in class org.jtrim2.event.CopyOnTriggerListenerManager
Returns the number of currently added but not yet removed listeners.
getListenerCount() - Method in interface org.jtrim2.event.ListenerRegistry
Returns the number of currently added but not yet removed listeners.
getListenerCount() - Method in class org.jtrim2.event.OneShotListenerManager
Returns the number of currently added but not yet removed listeners.
getToken() - Method in interface org.jtrim2.cancel.CancellationSource
Returns the CancellationToken which detects cancellation requests made through the CancellationController returned by the getController() method.

H

handleErrorResult(Throwable, Throwable, Consumer<? super Throwable>) - Static method in class org.jtrim2.concurrent.AsyncTasks
Calls the given error handler if any of the exception arguments is not null.

I

inc() - Method in class org.jtrim2.event.CountDownEvent
Increments the counter by 1.
init(ListenerRef) - Method in class org.jtrim2.event.InitLaterListenerRef
Sets to ListenerRef to which calls are forwarded to.
InitLaterListenerRef - Class in org.jtrim2.event
Defines a ListenerRef forwarding its calls to another ListenerRef which is specified after construction time.
InitLaterListenerRef() - Constructor for class org.jtrim2.event.InitLaterListenerRef
Creates a new InitLaterListenerRef with no underlying ListenerRef.
InterruptibleLimitedWait - Interface in org.jtrim2.cancel
Defines a generic interface to wait for an event to occur or return before the given timeout elapses.
InterruptibleTask<ResultType> - Interface in org.jtrim2.cancel
Defines a generic task which can be canceled by interrupting the thread executing the task.
InterruptibleWait - Interface in org.jtrim2.cancel
Defines a generic interface to wait for an event to occur.
isCanceled() - Method in interface org.jtrim2.cancel.CancellationToken
Returns true if cancellation was requested.
isCanceled(Throwable) - Static method in class org.jtrim2.concurrent.AsyncTasks
Returns true if the given exception represents a cancellation event.
isError(Throwable) - Static method in class org.jtrim2.concurrent.AsyncTasks
Returns true if the given exception represents an error event.
isSignaled() - Method in class org.jtrim2.concurrent.WaitableSignal
Returns true if signal() has been already called on this WaitableSignal object.

L

ListenerManager<ListenerType> - Interface in org.jtrim2.event
Defines a ListenerRegistry which allows events to be dispatched to registered listeners directly.
ListenerRef - Interface in org.jtrim2.event
Defines a reference of an event handler which has been registered to be notified of a certain event.
ListenerRefs - Class in org.jtrim2.event
Defines static utility methods for listener registries.
ListenerRegistry<ListenerType> - Interface in org.jtrim2.event
Defines a collection of event listeners which can be notified of events in an implementation dependent way.
listenForCancellation(CancellationToken, Runnable) - Static method in class org.jtrim2.cancel.Cancellation
Adds a cancellation listener to the specified CancellationToken and returns reference which can be used to remove the listener and wait until it has been removed.
lock(CancellationToken, Lock) - Static method in class org.jtrim2.cancel.CancelableWaits
Calls lock.lockInterruptibly() and waits until it returns or the specified CancellationToken signals that the waiting must be canceled.

N

noOpConsumer() - Static method in class org.jtrim2.concurrent.Tasks
Returns a Consumer whose apply method does nothing but returns immediately to the caller.
noOpTask() - Static method in class org.jtrim2.concurrent.Tasks
Returns a Runnable whose run() method does nothing but returns immediately to the caller.

O

offer(T) - Method in interface org.jtrim2.concurrent.collections.TerminableQueue
Adds an element to this queue if possible, or returns false if the queue does not accept the new element this time.
OneShotListenerManager<ListenerType,ArgType> - Class in org.jtrim2.event
A ListenerRegistry implementation which will automatically unregister listeners once they have been notified by an onEvent call.
OneShotListenerManager() - Constructor for class org.jtrim2.event.OneShotListenerManager
Creates a new OneShotListenerManager with no listeners registered.
onEvent(EventListenerType, ArgType) - Method in interface org.jtrim2.event.EventDispatcher
Invokes the event handler method of the specified listener with the appropriate arguments.
onEvent(EventDispatcher<? super ListenerType, ? super ArgType>, ArgType) - Method in class org.jtrim2.event.CopyOnTriggerListenerManager
Invokes the onEvent method of the specified EventDispatcher with the currently registered listeners and the argument specified.
onEvent(EventDispatcher<? super ListenerType, ? super ArgType>, ArgType) - Method in interface org.jtrim2.event.ListenerManager
Invokes the onEvent method of the specified EventDispatcher with the currently registered listeners and the argument specified.
onEvent(EventDispatcher<? super ListenerType, ? super ArgType>, ArgType) - Method in class org.jtrim2.event.OneShotListenerManager
Invokes the onEvent method of the specified EventDispatcher with the currently registered listeners and the argument specified unless this method has already been called.
onEvent(EventDispatcher<? super ListenerType, ? super ArgType>, ArgType) - Method in class org.jtrim2.event.ProxyListenerRegistry
Invokes the onEvent method of the specified EventDispatcher with the currently registered listeners and the argument specified.
OperationCanceledException - Exception in org.jtrim2.cancel
Thrown by tasks when they detect that they were requested to be canceled.
OperationCanceledException() - Constructor for exception org.jtrim2.cancel.OperationCanceledException
Creates the exception with null as its detail message.
OperationCanceledException(String) - Constructor for exception org.jtrim2.cancel.OperationCanceledException
Creates the exception with a specific detail message.
OperationCanceledException(String, Throwable) - Constructor for exception org.jtrim2.cancel.OperationCanceledException
Creates the exception with a specific detail message and cause.
OperationCanceledException(String, Throwable, boolean) - Constructor for exception org.jtrim2.cancel.OperationCanceledException
Constructs a new runtime exception with the specified detail message, cause, and writable stack trace enabled or disabled.
OperationCanceledException(Throwable) - Constructor for exception org.jtrim2.cancel.OperationCanceledException
Creates the exception with a specific cause.
OperationTimeoutException - Exception in org.jtrim2.cancel
Defines an exception for when an operation was canceled due to timing out.
OperationTimeoutException() - Constructor for exception org.jtrim2.cancel.OperationTimeoutException
Creates the exception with null as its detail message.
OperationTimeoutException(String) - Constructor for exception org.jtrim2.cancel.OperationTimeoutException
Creates the exception with a specific detail message.
OperationTimeoutException(String, Throwable) - Constructor for exception org.jtrim2.cancel.OperationTimeoutException
Creates the exception with a specific detail message and cause.
OperationTimeoutException(String, Throwable, boolean) - Constructor for exception org.jtrim2.cancel.OperationTimeoutException
Constructs a new runtime exception with the specified detail message, cause, and writable stack trace enabled or disabled.
OperationTimeoutException(Throwable) - Constructor for exception org.jtrim2.cancel.OperationTimeoutException
Creates the exception with a specific cause.
org.jtrim2.cancel - package org.jtrim2.cancel
Defines classes and interface related to canceling tasks or other operations.
org.jtrim2.concurrent - package org.jtrim2.concurrent
Defines commonly used concurrency utility classes.
org.jtrim2.concurrent.collections - package org.jtrim2.concurrent.collections
Defines thread-safe collection interfaces and implementations.
org.jtrim2.event - package org.jtrim2.event
Contains classes and interfaces for dispatching and handling event notifications.

P

ProxyListenerRegistry<ListenerType> - Class in org.jtrim2.event
Defines a SimpleListenerRegistry which is backed by another SimpleListenerRegistry.
ProxyListenerRegistry(SimpleListenerRegistry<? super ListenerType>) - Constructor for class org.jtrim2.event.ProxyListenerRegistry
Creates a new ProxyListenerRegistry which is initially backed by the passed ListenerRegistry.
put(CancellationToken, T) - Method in interface org.jtrim2.concurrent.collections.TerminableQueue
Adds an element to this queue waiting if necessary.
put(CancellationToken, T, long, TimeUnit) - Method in interface org.jtrim2.concurrent.collections.TerminableQueue
Adds an element to this queue waiting if necessary.

R

registerListener(ListenerType) - Method in class org.jtrim2.event.CopyOnTriggerListenerManager
Adds an event listener to this container and returns a reference which can later be used to removed the listener added.
registerListener(ListenerType) - Method in interface org.jtrim2.event.ListenerRegistry
Adds an event listener to this container and returns a reference which can later be used to removed the listener added.
registerListener(ListenerType) - Method in class org.jtrim2.event.OneShotListenerManager
Adds an event listener to this container and returns a reference which can later be used to removed the listener added.
registerListener(ListenerType) - Method in class org.jtrim2.event.ProxyListenerRegistry
Adds an event listener to this container and returns a reference which can later be used to removed the listener added.
registerListener(ListenerType) - Method in interface org.jtrim2.event.SimpleListenerRegistry
Adds an event listener to this container and returns a reference which can later be used to removed the listener added.
registerOrNotifyListener(ListenerType) - Method in class org.jtrim2.event.OneShotListenerManager
Adds an event listener to this container or notifies the listener if onEvent has already been called and returns a reference which can later be used to removed the listener added.
RepeatingTask - Class in org.jtrim2.concurrent
Defines a task which can repeatedly be executed by a ScheduledExecutorService and this task controls if it is needed to be rescheduled.
RepeatingTask(ScheduledExecutorService, long, TimeUnit) - Constructor for class org.jtrim2.concurrent.RepeatingTask
Initializes a RepeatingTask with a ScheduledExecutorService and the time to wait between consecutive execution of this task.
RepeatingTask(ScheduledExecutorService, long, TimeUnit, boolean) - Constructor for class org.jtrim2.concurrent.RepeatingTask
Initializes a RepeatingTask with a ScheduledExecutorService, the time to wait between consecutive execution of this task and if it need to be rescheduled in case this task throws an unchecked exception.
replaceRegistry(SimpleListenerRegistry<? super ListenerType>) - Method in class org.jtrim2.event.ProxyListenerRegistry
Unregisters already added listeners from the current backing registry and registers them with the specified listener registry.
rethrowCause() - Method in exception org.jtrim2.concurrent.TaskExecutionException
Throws the cause of this exception if it is an instance of Error or RuntimeException, or throws a RuntimeException exception with the cause of this exception as the cause of the thrown exception.
rethrowCause(Class<? extends T>) - Method in exception org.jtrim2.concurrent.TaskExecutionException
Throws the cause of this exception if it is an instance of Error or RuntimeException or is of the given type, or throws a RuntimeException exception with the cause of this exception as the cause of the thrown exception.
run() - Method in class org.jtrim2.concurrent.RepeatingTask
Invokes the runAndTest() method and reschedules it to the ScheduledExecutorService specified at construction time according to the construction time definitions.
runAndTest() - Method in class org.jtrim2.concurrent.RepeatingTask
Implement this method to actually execute the given task.
runConcurrently(Runnable...) - Static method in class org.jtrim2.concurrent.Tasks
Executes the specified tasks concurrently, each on a separate thread, attempting to execute them as concurrently as possible.
runConcurrently(Collection<? extends Runnable>) - Static method in class org.jtrim2.concurrent.Tasks
Executes the specified tasks concurrently, each on a separate thread, attempting to execute them as concurrently as possible.
runnableDispatcher() - Static method in class org.jtrim2.event.EventListeners
Returns an EventDispatcher which will simply call run() method of the listeners passed to the EventDispatcher.
runOnceTask(Runnable) - Static method in class org.jtrim2.concurrent.Tasks
Returns a Runnable which will execute the specified Runnable but will execute the specified Runnable only once.
runOnceTaskStrict(Runnable) - Static method in class org.jtrim2.concurrent.Tasks
Returns a Runnable which will execute the specified Runnable but will execute the specified Runnable only once, failing on multiple run attempts.

S

schedule(long, TimeUnit) - Method in class org.jtrim2.concurrent.RepeatingTask
Submits this task to be executed a periodically after the given initial delay by the ScheduledExecutorService specified at construction time.
shutdown() - Method in interface org.jtrim2.concurrent.collections.TerminableQueue
Prevents new elements to be added to this queue, but keeps the already added elements.
shutdownAndTryWaitUntilEmpty(CancellationToken, long, TimeUnit) - Method in interface org.jtrim2.concurrent.collections.TerminableQueue
Prevents new elements to be added to this queue, and waits until no more elements are remaining in this queue or the given timeout expires.
shutdownAndWaitUntilEmpty(CancellationToken) - Method in interface org.jtrim2.concurrent.collections.TerminableQueue
Prevents new elements to be added to this queue, and waits until no more elements are remaining in this queue.
signal() - Method in class org.jtrim2.concurrent.WaitableSignal
Sets the state of this WaitableSignal to the signaled state and allows the waitSignal or the tryWaitSignal method to return immediately.
SIGNALING_SIGNAL - Static variable in class org.jtrim2.concurrent.WaitableSignal
A WaitableSignal which is already in the signaling state.
SimpleListenerRegistry<ListenerType> - Interface in org.jtrim2.event
Defines the interface to register event listeners to be notified later in an implementation dependent way.
sleep(CancellationToken, long, TimeUnit) - Static method in class org.jtrim2.cancel.CancelableWaits
Causes the current thread to sleep until the given time elapses or the specified CancellationToken signals a cancellation request.

T

take(CancellationToken) - Method in interface org.jtrim2.concurrent.collections.TerminableQueue
Removes the current head of the queue and returns it waits until it becomes available if the queue is currently empty.
takeButKeepReserved(CancellationToken) - Method in interface org.jtrim2.concurrent.collections.TerminableQueue
Removes the current head of the queue and returns it waits until it becomes available if the queue is currently empty, but keeps reserving the space for the removed element until the returned element is released.
TaskExecutionException - Exception in org.jtrim2.concurrent
Defines that an asynchronously executed task has thrown an unchecked exception.
TaskExecutionException(String, Throwable) - Constructor for exception org.jtrim2.concurrent.TaskExecutionException
Creates a new TaskExecutionException with a given cause and exception message.
TaskExecutionException(Throwable) - Constructor for exception org.jtrim2.concurrent.TaskExecutionException
Creates a new TaskExecutionException with a given cause.
Tasks - Class in org.jtrim2.concurrent
Defines static methods to return simple, convenient task related instances.
TerminableQueue<T> - Interface in org.jtrim2.concurrent.collections
Defines a simple queue which can be stopped from accepting any new elements.
TerminableQueues - Class in org.jtrim2.concurrent.collections
Defines factory methods for TerminableQueue.
TerminatedQueueException - Exception in org.jtrim2.concurrent.collections
Thrown if a queue was shut down, and still trying to add or remove element.
TerminatedQueueException() - Constructor for exception org.jtrim2.concurrent.collections.TerminatedQueueException
Creates the exception with null as its detail message.
TerminatedQueueException(String) - Constructor for exception org.jtrim2.concurrent.collections.TerminatedQueueException
Creates the exception with a specific detail message.
TerminatedQueueException(String, Throwable) - Constructor for exception org.jtrim2.concurrent.collections.TerminatedQueueException
Creates the exception with a specific detail message and cause.
TerminatedQueueException(String, Throwable, boolean) - Constructor for exception org.jtrim2.concurrent.collections.TerminatedQueueException
Constructs a new exception with the specified detail message, cause, and writable stack trace enabled or disabled.
TerminatedQueueException(Throwable) - Constructor for exception org.jtrim2.concurrent.collections.TerminatedQueueException
Creates the exception with a specific cause.
tryLock(CancellationToken, long, TimeUnit, Lock) - Static method in class org.jtrim2.cancel.CancelableWaits
Calls lock.tryLock(long, TimeUnit) with the specified timeout value and waits until it returns or the specified CancellationToken signals that the waiting must be canceled.
tryTake() - Method in interface org.jtrim2.concurrent.collections.TerminableQueue
Removes the current head of the queue and returns it, or returns null if the queue is currently empty.
tryTake(CancellationToken, long, TimeUnit) - Method in interface org.jtrim2.concurrent.collections.TerminableQueue
Removes the current head of the queue and returns it waiting the given timeout if the queue is currently empty.
tryTakeButKeepReserved() - Method in interface org.jtrim2.concurrent.collections.TerminableQueue
Removes the current head of the queue and returns it, but keeps reserving the space for the removed element until the returned element is released; or returns null if the queue is currently empty.
tryTakeButKeepReserved(CancellationToken, long, TimeUnit) - Method in interface org.jtrim2.concurrent.collections.TerminableQueue
Removes the current head of the queue and returns it waiting the given the time if necessary, but keeps reserving the space for the removed element until the returned element is released; or returns null if the timeout elapses before any element could have been retrieved.
tryWaitSignal(CancellationToken, long, TimeUnit) - Method in class org.jtrim2.concurrent.WaitableSignal
Waits until another thread invokes the signal() method or until the specified CancellationToken signals a cancellation request or until the specified timeout elapses.

U

UNCANCELABLE_TOKEN - Static variable in class org.jtrim2.cancel.Cancellation
A CancellationToken which can never be in the canceled state.
unregister() - Method in class org.jtrim2.event.InitLaterListenerRef
Unregisters the listener, so it does not need to be notified of subsequent events.
unregister() - Method in interface org.jtrim2.event.ListenerRef
Unregisters the listener, so it does not need to be notified of subsequent events.
unregisterAndWait(CancellationToken) - Method in interface org.jtrim2.cancel.WaitableListenerRef
Unregisters the associated listener (as the unregister method and waits until it can be ensured that the listener is not going to be notified anymore.
unregistered() - Static method in class org.jtrim2.event.ListenerRefs
Returns a ListenerRef which does nothing when unregistered.
unwrap(Throwable) - Static method in class org.jtrim2.concurrent.AsyncTasks
Returns the actual error represented by the given exception.

W

WaitableListenerRef - Interface in org.jtrim2.cancel
Defines a ListenerRef which can be used to unregister the associated listener and wait until it can be ensured that the listener is not going to be executed anymore.
WaitableSignal - Class in org.jtrim2.concurrent
Defines thread-safe signal for which threads can wait.
WaitableSignal() - Constructor for class org.jtrim2.concurrent.WaitableSignal
Creates a new WaitableSignal in the non-signaled state.
waitSignal(CancellationToken) - Method in class org.jtrim2.concurrent.WaitableSignal
Waits until another thread invokes the signal() method or until the specified CancellationToken signals a cancellation request.
withoutStackTrace() - Static method in exception org.jtrim2.cancel.OperationCanceledException
Returns a new instance of OperationCanceledException without stack trace information.
withoutStackTrace() - Static method in exception org.jtrim2.cancel.OperationTimeoutException
Returns a new instance of OperationTimeoutException without stack trace information.
withoutStackTrace() - Static method in exception org.jtrim2.concurrent.collections.TerminatedQueueException
Returns a new instance of TerminatedQueueException without stack trace information.
withoutStackTrace(String, Throwable) - Static method in exception org.jtrim2.cancel.OperationCanceledException
Returns a new instance of OperationCanceledException without stack trace information.
withoutStackTrace(String, Throwable) - Static method in exception org.jtrim2.cancel.OperationTimeoutException
Returns a new instance of OperationTimeoutException without stack trace information.
withoutStackTrace(String, Throwable) - Static method in exception org.jtrim2.concurrent.collections.TerminatedQueueException
Returns a new instance of TerminatedQueueException without stack trace information.
withWrappedQueue(ReservablePollingQueue<T>) - Static method in class org.jtrim2.concurrent.collections.TerminableQueues
Returns a TerminableQueue using the given ReservablePollingQueue to store elements.
A C D E G H I L N O P R S T U W 
All Classes and Interfaces|All Packages|Serialized Form