- AbstractFutureCallbackFailureHandler - Class in org.threadly.concurrent.future
-
An abstract implementation of
FutureCallback
where the result is ignored.
- AbstractFutureCallbackFailureHandler() - Constructor for class org.threadly.concurrent.future.AbstractFutureCallbackFailureHandler
-
- AbstractFutureCallbackResultHandler<T> - Class in org.threadly.concurrent.future
-
An abstract implementation of
FutureCallback
where failures are ignored.
- AbstractFutureCallbackResultHandler() - Constructor for class org.threadly.concurrent.future.AbstractFutureCallbackResultHandler
-
- AbstractPriorityScheduler - Class in org.threadly.concurrent
-
- AbstractService - Class in org.threadly.util
-
An abstract implementation of the
Service
interface.
- AbstractService() - Constructor for class org.threadly.util.AbstractService
-
- AbstractSubmitterExecutor - Class in org.threadly.concurrent
-
- AbstractSubmitterExecutor() - Constructor for class org.threadly.concurrent.AbstractSubmitterExecutor
-
- AbstractSubmitterScheduler - Class in org.threadly.concurrent
-
Similar to the
AbstractSubmitterExecutor
this abstract class is designed to reduce code
duplication for the multiple schedule functions.
- AbstractSubmitterScheduler() - Constructor for class org.threadly.concurrent.AbstractSubmitterScheduler
-
- acceptConsumedItem(T) - Method in interface org.threadly.concurrent.BlockingQueueConsumer.ConsumerAcceptor
-
Called when ever the queue consumer has removed an item from the queue.
- accurateForwardProgressingMillis() - Static method in class org.threadly.util.Clock
-
Returns an accurate amount of time in milliseconds since this class has loaded (starting at
0
).
- accurateTimeMillis() - Static method in class org.threadly.util.Clock
-
- accurateTimeNanos() - Static method in class org.threadly.util.Clock
-
This directly returns the result of System.nanoTime()
.
- add(T) - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
- add(int, T) - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
- addAll(Collection<? extends T>) - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
- addAll(int, Collection<? extends T>) - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
- addCallback(FutureCallback<? super T>) - Method in class org.threadly.concurrent.future.ImmediateFailureListenableFuture
-
- addCallback(FutureCallback<? super T>, Executor) - Method in class org.threadly.concurrent.future.ImmediateFailureListenableFuture
-
- addCallback(FutureCallback<? super T>) - Method in class org.threadly.concurrent.future.ImmediateResultListenableFuture
-
- addCallback(FutureCallback<? super T>, Executor) - Method in class org.threadly.concurrent.future.ImmediateResultListenableFuture
-
- addCallback(FutureCallback<? super T>) - Method in interface org.threadly.concurrent.future.ListenableFuture
-
- addCallback(FutureCallback<? super T>, Executor) - Method in interface org.threadly.concurrent.future.ListenableFuture
-
- addCallback(FutureCallback<? super T>) - Method in class org.threadly.concurrent.future.ScheduledFutureDelegate
-
- addCallback(FutureCallback<? super T>, Executor) - Method in class org.threadly.concurrent.future.ScheduledFutureDelegate
-
- addFirst(T) - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
- addLast(T) - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
- addListener(T, Executor) - Method in class org.threadly.concurrent.event.DefaultExecutorListenerHelper
-
- addListener(Runnable, Executor) - Method in class org.threadly.concurrent.event.DefaultExecutorRunnableListenerHelper
-
- addListener(T) - Method in class org.threadly.concurrent.event.ListenerHelper
-
- addListener(T, Executor) - Method in class org.threadly.concurrent.event.ListenerHelper
-
- addListener(Runnable) - Method in class org.threadly.concurrent.event.RunnableListenerHelper
-
Adds a listener to be called.
- addListener(Runnable, Executor) - Method in class org.threadly.concurrent.event.RunnableListenerHelper
-
Adds a listener to be called.
- addListener(Runnable) - Method in interface org.threadly.concurrent.future.ListenableFuture
-
Add a listener to be called once the future has completed.
- addListener(Runnable, Executor) - Method in interface org.threadly.concurrent.future.ListenableFuture
-
Add a listener to be called once the future has completed.
- addListener(Runnable) - Method in class org.threadly.concurrent.future.ListenableFutureTask
-
- addListener(Runnable, Executor) - Method in class org.threadly.concurrent.future.ListenableFutureTask
-
- addListener(Runnable) - Method in class org.threadly.concurrent.future.ScheduledFutureDelegate
-
- addListener(Runnable, Executor) - Method in class org.threadly.concurrent.future.ScheduledFutureDelegate
-
- addListener(Runnable) - Method in class org.threadly.concurrent.future.SettableListenableFuture
-
- addListener(Runnable, Executor) - Method in class org.threadly.concurrent.future.SettableListenableFuture
-
- addProfiledThread(Thread) - Method in class org.threadly.util.debug.ControlledThreadProfiler
-
Adds a thread to be checked by the running profiler.
- adjustPoolSize(int) - Method in class org.threadly.concurrent.PriorityScheduler
-
Adjust the pools size by a given delta.
- advance(long) - Method in class org.threadly.test.concurrent.TestableScheduler
-
This is to provide a convince when advancing the scheduler forward an explicit amount of time.
- advance(long, ExceptionHandler) - Method in class org.threadly.test.concurrent.TestableScheduler
-
This is to provide a convince when advancing the scheduler forward an explicit amount of time.
- append(char) - Method in class org.threadly.util.StringBufferWriter
-
- append(CharSequence) - Method in class org.threadly.util.StringBufferWriter
-
- append(CharSequence, int, int) - Method in class org.threadly.util.StringBufferWriter
-
- append(char) - Method in class org.threadly.util.StringBuilderWriter
-
- append(CharSequence) - Method in class org.threadly.util.StringBuilderWriter
-
- append(CharSequence, int, int) - Method in class org.threadly.util.StringBuilderWriter
-
- applyToLeft(Iterable<? extends Pair<? extends L, ?>>, Consumer<? super L>) - Static method in class org.threadly.util.Pair
-
Goes through source Iterable
and provides all left entries to a given consumer.
- applyToRight(Iterable<? extends Pair<?, ? extends R>>, Consumer<? super R>) - Static method in class org.threadly.util.Pair
-
Goes through source Iterable
and provides all right entries to a given consumer.
- assertEquals(Object, Object) - Method in class org.threadly.test.concurrent.AsyncVerifier
-
Verifies that the passed in values are equal using the o1.equals(o2) relationship.
- assertFalse(boolean) - Method in class org.threadly.test.concurrent.AsyncVerifier
-
Verifies that the passed in condition is false.
- assertNotNull(Object) - Method in class org.threadly.test.concurrent.AsyncVerifier
-
Verifies that the passed in object is not null.
- assertNull(Object) - Method in class org.threadly.test.concurrent.AsyncVerifier
-
Verifies that the passed in object is null.
- assertTrue(boolean) - Method in class org.threadly.test.concurrent.AsyncVerifier
-
Verifies that the passed in condition is true.
- AsyncCallListenerHelper<T> - Class in org.threadly.concurrent.event
-
This class changes the behavior of how listeners are called from the parent class
ListenerHelper
.
- AsyncCallListenerHelper(Class<? super T>, Executor) - Constructor for class org.threadly.concurrent.event.AsyncCallListenerHelper
-
- AsyncCallRunnableListenerHelper - Class in org.threadly.concurrent.event
-
- AsyncCallRunnableListenerHelper(boolean, Executor) - Constructor for class org.threadly.concurrent.event.AsyncCallRunnableListenerHelper
-
- AsyncVerifier - Class in org.threadly.test.concurrent
-
A simple class for verifying multi-threaded unit tests.
- AsyncVerifier() - Constructor for class org.threadly.test.concurrent.AsyncVerifier
-
- AUTOMATIC_UPDATE_FREQUENCY_IN_MS - Static variable in class org.threadly.util.Clock
-
This is the frequency at which the thread which regularly updates the clock wakes up and
updates the time.
- awaitTermination() - Method in class org.threadly.concurrent.PriorityScheduler
-
Block until the thread pool has shutdown and all threads have been stopped.
- awaitTermination(long) - Method in class org.threadly.concurrent.PriorityScheduler
-
Block until the thread pool has shutdown and all threads have been stopped.
- awaitTermination() - Method in class org.threadly.concurrent.SingleThreadScheduler
-
Block until the thread pool has shutdown and all threads have been stopped.
- awaitTermination(long) - Method in class org.threadly.concurrent.SingleThreadScheduler
-
Block until the thread pool has shutdown and all threads have been stopped.
- awaitTermination() - Method in class org.threadly.concurrent.UnfairExecutor
-
Block until the thread pool has shutdown and all threads have been stopped.
- awaitTermination(long) - Method in class org.threadly.concurrent.UnfairExecutor
-
Block until the thread pool has shutdown and all threads have been stopped.
- awaitTermination(long, TimeUnit) - Method in class org.threadly.concurrent.wrapper.compatibility.PrioritySchedulerServiceWrapper
-
- awaitTermination(long, TimeUnit) - Method in class org.threadly.concurrent.wrapper.compatibility.SingleThreadSchedulerServiceWrapper
-
- binarySearch(List<Long>, long, boolean) - Static method in class org.threadly.util.SortUtils
-
A faster binary search algorithm for sorting a list.
- binarySearch(Function<Integer, Long>, int, long, boolean) - Static method in class org.threadly.util.SortUtils
-
A faster binary search algorithm for sorting a list.
- BlockingQueueConsumer<T> - Class in org.threadly.concurrent
-
Producer consumer problems are very frequent within multi-threaded code.
- BlockingQueueConsumer(ThreadFactory, BlockingQueue<? extends T>, BlockingQueueConsumer.ConsumerAcceptor<? super T>) - Constructor for class org.threadly.concurrent.BlockingQueueConsumer
-
Constructs a new consumer, with a provided queue to consume from, and an acceptor to accept
items.
- BlockingQueueConsumer(ThreadFactory, String, BlockingQueue<? extends T>, BlockingQueueConsumer.ConsumerAcceptor<? super T>) - Constructor for class org.threadly.concurrent.BlockingQueueConsumer
-
Constructs a new consumer, with a provided queue to consume from, and an acceptor to accept
items.
- BlockingQueueConsumer.ConsumerAcceptor<T> - Interface in org.threadly.concurrent
-
Interface for an implementation which can accept consumed tasks.
- blockingTick(ExceptionHandler) - Method in class org.threadly.concurrent.NoThreadScheduler
-
- blockTillAllComplete(Iterable<? extends Future<?>>) - Static method in class org.threadly.concurrent.future.FutureUtils
-
This call blocks till all futures in the list have completed.
- blockTillAllComplete(Iterable<? extends Future<?>>, long) - Static method in class org.threadly.concurrent.future.FutureUtils
-
This call blocks till all futures in the list have completed.
- blockTillAllCompleteOrFirstError(Iterable<? extends Future<?>>) - Static method in class org.threadly.concurrent.future.FutureUtils
-
This call blocks till all futures in the list have completed.
- blockTillAllCompleteOrFirstError(Iterable<? extends Future<?>>, long) - Static method in class org.threadly.concurrent.future.FutureUtils
-
This call blocks till all futures in the list have completed.
- blockTillClockAdvances() - Static method in class org.threadly.test.concurrent.TestUtils
-
Blocks until the System clock advances at least 1 millisecond.
- blockTillFinished() - Method in class org.threadly.test.concurrent.TestRunnable
-
Blocks until run has completed at least once.
- blockTillFinished(int) - Method in class org.threadly.test.concurrent.TestRunnable
-
Blocks until run has completed at least once.
- blockTillFinished(int, int) - Method in class org.threadly.test.concurrent.TestRunnable
-
Blocks until run completed been called the provided quantity of times.
- blockTillStarted() - Method in class org.threadly.test.concurrent.TestRunnable
-
Blocks until run has been called at least once.
- blockTillStarted(int) - Method in class org.threadly.test.concurrent.TestRunnable
-
Blocks until run has been called at least once.
- blockTillTrue() - Method in class org.threadly.test.concurrent.TestCondition
-
Blocks till condition is true, useful for asynchronism operations, waiting for them to
complete in other threads during unit tests.
- blockTillTrue(int) - Method in class org.threadly.test.concurrent.TestCondition
-
Blocks till condition is true, useful for asynchronism operations, waiting for them to
complete in other threads during unit tests.
- blockTillTrue(int, int) - Method in class org.threadly.test.concurrent.TestCondition
-
Blocks till condition is true, useful for asynchronism operations, waiting for them to
complete in other threads during unit tests.
- BOOLEAN_FALSE_RESULT - Static variable in class org.threadly.concurrent.future.ImmediateResultListenableFuture
-
- BOOLEAN_TRUE_RESULT - Static variable in class org.threadly.concurrent.future.ImmediateResultListenableFuture
-
- call() - Method in class org.threadly.concurrent.event.ListenerHelper
-
Calls to notify the subscribed listeners with the given call.
- call() - Method in class org.threadly.concurrent.RunnableCallableAdapter
-
- CallableContainer<T> - Interface in org.threadly.concurrent
-
Interface to implement if any classes are containing a callable.
- callListeners() - Method in class org.threadly.concurrent.event.RunnableListenerHelper
-
Will call all listeners that are registered with this helper.
- cancel(boolean) - Method in class org.threadly.concurrent.future.ScheduledFutureDelegate
-
- cancel(boolean) - Method in class org.threadly.concurrent.future.SettableListenableFuture
-
- cancelIncompleteFutures(Iterable<? extends Future<?>>, boolean) - Static method in class org.threadly.concurrent.future.FutureUtils
-
Invoked Future.cancel(boolean)
for every future in this collection.
- cancelIncompleteFuturesIfAnyFail(boolean, Iterable<? extends ListenableFuture<?>>, boolean) - Static method in class org.threadly.concurrent.future.FutureUtils
-
Provide a group of futures and cancel all of them if any of them are canceled or fail.
- cancelTick() - Method in class org.threadly.concurrent.NoThreadScheduler
-
Call to cancel current or the next tick call.
- CentralThreadlyPool - Class in org.threadly.concurrent
-
Threadly's centrally provided pool manager.
- CentralThreadlyPool() - Constructor for class org.threadly.concurrent.CentralThreadlyPool
-
- charAt(int) - Method in class org.threadly.util.StringBufferWriter
-
- charAt(int) - Method in class org.threadly.util.StringBuilderWriter
-
- clear() - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
- clearListeners() - Method in class org.threadly.concurrent.event.ListenerHelper
-
Removes all listener currently registered.
- clearListeners() - Method in class org.threadly.concurrent.event.RunnableListenerHelper
-
Removes all listeners currently registered.
- clearResult() - Method in class org.threadly.concurrent.future.SettableListenableFuture
-
Clears the stored result from this set future.
- clearTasks() - Method in class org.threadly.concurrent.NoThreadScheduler
-
Removes any tasks waiting to be run.
- clearTasks() - Method in class org.threadly.test.concurrent.TestableScheduler
-
Removes any tasks waiting to be run.
- Clock - Class in org.threadly.util
-
This is a utility class for low-resolution timing which avoids frequent
System.currentTimeMillis()
calls (which perform poorly because they require system
calls).
- Clock() - Constructor for class org.threadly.util.Clock
-
- close() - Method in class org.threadly.util.StringBufferWriter
-
- close() - Method in class org.threadly.util.StringBuilderWriter
-
- collectLeft(Collection<? extends Pair<? extends T, ?>>) - Static method in class org.threadly.util.Pair
-
Collect all the non-null left references into a new List.
- collectRight(Collection<? extends Pair<?, ? extends T>>) - Static method in class org.threadly.util.Pair
-
Collect all the non-null right references into a new List.
- compareTo(Delayed) - Method in class org.threadly.concurrent.future.ScheduledFutureDelegate
-
- computationPool() - Static method in class org.threadly.concurrent.CentralThreadlyPool
-
Thread pool well suited for running CPU intensive computations on the tasks thread.
- computationPool(String) - Static method in class org.threadly.concurrent.CentralThreadlyPool
-
Thread pool well suited for running CPU intensive computations on the tasks thread.
- ConcurrentArrayList<T> - Class in org.threadly.concurrent.collections
-
A thread safe list implementation with an array back end.
- ConcurrentArrayList() - Constructor for class org.threadly.concurrent.collections.ConcurrentArrayList
-
- ConcurrentArrayList(int, int) - Constructor for class org.threadly.concurrent.collections.ConcurrentArrayList
-
- ConditionTimeoutException() - Constructor for exception org.threadly.test.concurrent.TestCondition.ConditionTimeoutException
-
Constructor for new TimeoutException.
- ConditionTimeoutException(String) - Constructor for exception org.threadly.test.concurrent.TestCondition.ConditionTimeoutException
-
Constructor for new TimeoutException.
- ConfigurableThreadFactory - Class in org.threadly.concurrent
-
Implementation of ThreadFactory
which is configurable for the most common use cases.
- ConfigurableThreadFactory() - Constructor for class org.threadly.concurrent.ConfigurableThreadFactory
-
- ConfigurableThreadFactory(String, boolean) - Constructor for class org.threadly.concurrent.ConfigurableThreadFactory
-
- ConfigurableThreadFactory(boolean) - Constructor for class org.threadly.concurrent.ConfigurableThreadFactory
-
- ConfigurableThreadFactory(int) - Constructor for class org.threadly.concurrent.ConfigurableThreadFactory
-
- ConfigurableThreadFactory(Thread.UncaughtExceptionHandler) - Constructor for class org.threadly.concurrent.ConfigurableThreadFactory
-
Constructs a new
ConfigurableThreadFactory
specifying an
Thread.UncaughtExceptionHandler
that will be provided to all newly created threads.
- ConfigurableThreadFactory(ExceptionHandler) - Constructor for class org.threadly.concurrent.ConfigurableThreadFactory
-
- ConfigurableThreadFactory(String, boolean, boolean, int, Thread.UncaughtExceptionHandler, ExceptionHandler) - Constructor for class org.threadly.concurrent.ConfigurableThreadFactory
-
Constructs a new
ConfigurableThreadFactory
allowing you to provide specific values
for everything which this class allows to be configured.
- ContainerHelper - Class in org.threadly.concurrent
-
- ContainerHelper() - Constructor for class org.threadly.concurrent.ContainerHelper
-
- contains(Object) - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
- containsAll(Collection<?>) - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
- containsLeft(Iterable<? extends Pair<?, ?>>, Object) - Static method in class org.threadly.util.Pair
-
Simple search to see if a collection of pairs contains a given left value.
- containsRight(Iterable<? extends Pair<?, ?>>, Object) - Static method in class org.threadly.util.Pair
-
Simple search to see if a collection of pairs contains a given right value.
- ControlledThreadProfiler - Class in org.threadly.util.debug
-
This class functions very similar to the
Profiler
.
- ControlledThreadProfiler() - Constructor for class org.threadly.util.debug.ControlledThreadProfiler
-
Constructs a new profiler instance.
- ControlledThreadProfiler(int) - Constructor for class org.threadly.util.debug.ControlledThreadProfiler
-
Constructs a new profiler instance.
- convertMap(Map<? extends L, ? extends R>) - Static method in class org.threadly.util.Pair
-
Convert a map into a list of Pair's where the left side of the pair contains the value and
the right side is the corresponding value.
- countFuturesWithResult(Iterable<? extends Future<?>>, T) - Static method in class org.threadly.concurrent.future.FutureUtils
-
Counts how many futures provided completed with a result that matches the one provided here.
- countFuturesWithResult(Iterable<? extends Future<?>>, T, long) - Static method in class org.threadly.concurrent.future.FutureUtils
-
Counts how many futures provided completed with a result that matches the one provided here.
- get(int) - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
- get() - Method in class org.threadly.concurrent.future.ExecuteOnGetFutureTask
-
- get() - Method in class org.threadly.concurrent.future.ImmediateFailureListenableFuture
-
- get(long, TimeUnit) - Method in class org.threadly.concurrent.future.ImmediateFailureListenableFuture
-
- get() - Method in class org.threadly.concurrent.future.ImmediateResultListenableFuture
-
- get(long, TimeUnit) - Method in class org.threadly.concurrent.future.ImmediateResultListenableFuture
-
- get() - Method in class org.threadly.concurrent.future.ScheduledFutureDelegate
-
- get(long, TimeUnit) - Method in class org.threadly.concurrent.future.ScheduledFutureDelegate
-
- get() - Method in class org.threadly.concurrent.future.SettableListenableFuture
-
- get(long, TimeUnit) - Method in class org.threadly.concurrent.future.SettableListenableFuture
-
- get() - Method in class org.threadly.test.concurrent.TestCondition
-
Getter for the conditions current state.
- getActiveTaskCount() - Method in class org.threadly.concurrent.NoThreadScheduler
-
- getActiveTaskCount() - Method in class org.threadly.concurrent.PriorityScheduler
-
Call to check how many tasks are currently being executed in this thread pool.
- getActiveTaskCount() - Method in interface org.threadly.concurrent.SchedulerService
-
Call to check how many tasks are currently being executed in this scheduler.
- getActiveTaskCount() - Method in class org.threadly.concurrent.SingleThreadScheduler
-
- getActiveTaskCount() - Method in class org.threadly.concurrent.wrapper.interceptor.SchedulerServiceTaskInterceptor
-
- getActiveTaskCount() - Method in class org.threadly.concurrent.wrapper.limiter.KeyedSchedulerServiceLimiter
-
Call to check how many tasks are currently being executed in this scheduler.
- getActiveTaskCount() - Method in class org.threadly.concurrent.wrapper.limiter.SchedulerServiceLimiter
-
- getActiveTaskCount() - Method in class org.threadly.concurrent.wrapper.limiter.SchedulerServiceQueueLimitRejector
-
- getActiveTaskCount() - Method in class org.threadly.concurrent.wrapper.limiter.SingleThreadSchedulerSubPool
-
- getActiveTaskCount() - Method in class org.threadly.concurrent.wrapper.PrioritySchedulerDefaultPriorityWrapper
-
- getActiveTaskCount() - Method in class org.threadly.concurrent.wrapper.traceability.ThreadRenamingPriorityScheduler
-
- getActiveTaskCount() - Method in class org.threadly.concurrent.wrapper.traceability.ThreadRenamingSchedulerService
-
- getActiveTaskCount() - Method in class org.threadly.test.concurrent.TestableScheduler
-
- getAllStoredMessages() - Static method in class org.threadly.util.debug.DebugLogger
-
Request to get and clear all currently stored log messages.
- getAllStoredMessages(boolean) - Static method in class org.threadly.util.debug.DebugLogger
-
Request to get and clear all currently stored log messages.
- getAverage(Collection<? extends Number>) - Static method in class org.threadly.util.StatisticsUtils
-
Calculates the average from a collection of numeric values.
- getAverageExecutionDelay() - Method in class org.threadly.concurrent.statistics.NoThreadSchedulerStatisticTracker
-
- getAverageExecutionDelay(TaskPriority) - Method in class org.threadly.concurrent.statistics.NoThreadSchedulerStatisticTracker
-
- getAverageExecutionDelay() - Method in class org.threadly.concurrent.statistics.PrioritySchedulerStatisticTracker
-
- getAverageExecutionDelay(TaskPriority) - Method in class org.threadly.concurrent.statistics.PrioritySchedulerStatisticTracker
-
- getAverageExecutionDelay() - Method in class org.threadly.concurrent.statistics.SingleThreadSchedulerStatisticTracker
-
- getAverageExecutionDelay(TaskPriority) - Method in class org.threadly.concurrent.statistics.SingleThreadSchedulerStatisticTracker
-
- getAverageExecutionDelay() - Method in interface org.threadly.concurrent.statistics.StatisticExecutor
-
This reports the rolling average delay from when a task was expected to run, till when the
executor actually started the task.
- getAverageExecutionDelay() - Method in interface org.threadly.concurrent.statistics.StatisticPriorityScheduler
-
This reports the rolling average delay from when a task was expected to run, till when the
executor actually started the task.
- getAverageExecutionDelay(TaskPriority) - Method in interface org.threadly.concurrent.statistics.StatisticPriorityScheduler
-
Gets the average delay from when the task is ready, to when it is actually executed.
- getAverageExecutionDelay() - Method in class org.threadly.concurrent.wrapper.statistics.ExecutorStatisticWrapper
-
- getAverageExecutionDuration() - Method in class org.threadly.concurrent.statistics.NoThreadSchedulerStatisticTracker
-
- getAverageExecutionDuration(TaskPriority) - Method in class org.threadly.concurrent.statistics.NoThreadSchedulerStatisticTracker
-
- getAverageExecutionDuration() - Method in class org.threadly.concurrent.statistics.PrioritySchedulerStatisticTracker
-
- getAverageExecutionDuration(TaskPriority) - Method in class org.threadly.concurrent.statistics.PrioritySchedulerStatisticTracker
-
- getAverageExecutionDuration() - Method in class org.threadly.concurrent.statistics.SingleThreadSchedulerStatisticTracker
-
- getAverageExecutionDuration(TaskPriority) - Method in class org.threadly.concurrent.statistics.SingleThreadSchedulerStatisticTracker
-
- getAverageExecutionDuration() - Method in interface org.threadly.concurrent.statistics.StatisticExecutor
-
Get the average duration that tasks submitted through this executor have spent executing.
- getAverageExecutionDuration() - Method in interface org.threadly.concurrent.statistics.StatisticPriorityScheduler
-
Get the average duration that tasks submitted through this executor have spent executing.
- getAverageExecutionDuration(TaskPriority) - Method in interface org.threadly.concurrent.statistics.StatisticPriorityScheduler
-
Get the average duration that tasks submitted through this executor have spent executing.
- getAverageExecutionDuration() - Method in class org.threadly.concurrent.wrapper.statistics.ExecutorStatisticWrapper
-
- getCauseOfType(Throwable, Class<? extends T>) - Static method in class org.threadly.util.ExceptionUtils
-
Checks to see if the provided error, or any causes in the provided error matching the
provided type.
- getCauseOfTypes(Throwable, Iterable<? extends Class<? extends Throwable>>) - Static method in class org.threadly.util.ExceptionUtils
-
Checks to see if the provided error, or any causes in the provided error matching the
provided type.
- getCollectedSampleQty() - Method in class org.threadly.util.debug.Profiler
-
Call to get an estimate on how many times the profiler has collected a sample of the thread
stacks.
- getContainedCallable() - Method in interface org.threadly.concurrent.CallableContainer
-
Call to get the contained callable held within the wrapper.
- getContainedCallable() - Method in class org.threadly.concurrent.future.ListenableFutureTask
-
- getContainedRunnable() - Method in class org.threadly.concurrent.RunnableCallableAdapter
-
- getContainedRunnable() - Method in interface org.threadly.concurrent.RunnableContainer
-
Call to get the contained runnable within the wrapper.
- getContainedRunnable() - Method in class org.threadly.concurrent.wrapper.ThrowableSuppressingRunnable
-
- getContainedRunnable() - Method in class org.threadly.concurrent.wrapper.traceability.ThreadRenamingRunnable
-
- getContainedRunnables(List<? extends RunnableContainer>) - Static method in class org.threadly.concurrent.ContainerHelper
-
Takes in a list of runnable containers, and instead makes a list of the runnables which are
contained in each item of the list.
- getCreationTime() - Method in class org.threadly.test.concurrent.TestRunnable
-
- getCurrentMessageQty() - Static method in class org.threadly.util.debug.DebugLogger
-
This call checks how many messages are waiting in the stored map.
- getCurrentPoolSize() - Method in class org.threadly.concurrent.PriorityScheduler
-
Getter for the current quantity of threads running in this pool (either active or idle).
- getDefaultPriority() - Method in class org.threadly.concurrent.AbstractPriorityScheduler
-
- getDefaultPriority() - Method in interface org.threadly.concurrent.PrioritySchedulerService
-
Get the default priority for the scheduler.
- getDefaultPriority() - Method in class org.threadly.concurrent.wrapper.interceptor.PrioritySchedulerTaskInterceptor
-
- getDefaultPriority() - Method in class org.threadly.concurrent.wrapper.limiter.PrioritySchedulerServiceQueueLimitRejector
-
- getDefaultPriority() - Method in class org.threadly.concurrent.wrapper.PrioritySchedulerDefaultPriorityWrapper
-
- getDefaultPriority() - Method in class org.threadly.concurrent.wrapper.traceability.ThreadRenamingPriorityScheduler
-
- getDelay(TimeUnit) - Method in class org.threadly.concurrent.future.ScheduledFutureDelegate
-
- getDelayTillFirstRun() - Method in class org.threadly.test.concurrent.TestRunnable
-
This function blocks till the first run completes then will return the time until the first
run started it's call.
- getDelayTillHour(int, int) - Static method in class org.threadly.concurrent.SchedulingUtils
-
Call to calculate how many milliseconds until the provided time.
- getDelayTillMinute(int) - Static method in class org.threadly.concurrent.SchedulingUtils
-
Call to calculate how many milliseconds until the provided minute.
- getDelayTillNextTask() - Method in class org.threadly.concurrent.NoThreadScheduler
-
Checks how long till the next task will be ready to execute.
- getDelayTillNextTask() - Method in class org.threadly.test.concurrent.TestableScheduler
-
Checks how long till the next task will be ready to execute.
- getDelayTillRun(int) - Method in class org.threadly.test.concurrent.TestRunnable
-
This function blocks till the run provided, and then gets the time between creation and a
given run.
- getDelayTillRun(int, int) - Method in class org.threadly.test.concurrent.TestRunnable
-
This function blocks till the run provided, and
then gets the time between creation and a given run.
- getExceptionHandler() - Static method in class org.threadly.util.ExceptionUtils
-
- getExecutionDelayPercentiles(double...) - Method in class org.threadly.concurrent.statistics.NoThreadSchedulerStatisticTracker
-
- getExecutionDelayPercentiles(TaskPriority, double...) - Method in class org.threadly.concurrent.statistics.NoThreadSchedulerStatisticTracker
-
- getExecutionDelayPercentiles(double...) - Method in class org.threadly.concurrent.statistics.PrioritySchedulerStatisticTracker
-
- getExecutionDelayPercentiles(TaskPriority, double...) - Method in class org.threadly.concurrent.statistics.PrioritySchedulerStatisticTracker
-
- getExecutionDelayPercentiles(double...) - Method in class org.threadly.concurrent.statistics.SingleThreadSchedulerStatisticTracker
-
- getExecutionDelayPercentiles(TaskPriority, double...) - Method in class org.threadly.concurrent.statistics.SingleThreadSchedulerStatisticTracker
-
- getExecutionDelayPercentiles(double...) - Method in interface org.threadly.concurrent.statistics.StatisticExecutor
-
Gets percentile values for execution delays.
- getExecutionDelayPercentiles(double...) - Method in interface org.threadly.concurrent.statistics.StatisticPriorityScheduler
-
Gets percentile values for execution delays.
- getExecutionDelayPercentiles(TaskPriority, double...) - Method in interface org.threadly.concurrent.statistics.StatisticPriorityScheduler
-
Gets percentile values for execution delays.
- getExecutionDelayPercentiles(double...) - Method in class org.threadly.concurrent.wrapper.statistics.ExecutorStatisticWrapper
-
- getExecutionDelaySamples() - Method in class org.threadly.concurrent.statistics.NoThreadSchedulerStatisticTracker
-
- getExecutionDelaySamples(TaskPriority) - Method in class org.threadly.concurrent.statistics.NoThreadSchedulerStatisticTracker
-
- getExecutionDelaySamples() - Method in class org.threadly.concurrent.statistics.PrioritySchedulerStatisticTracker
-
- getExecutionDelaySamples(TaskPriority) - Method in class org.threadly.concurrent.statistics.PrioritySchedulerStatisticTracker
-
- getExecutionDelaySamples() - Method in class org.threadly.concurrent.statistics.SingleThreadSchedulerStatisticTracker
-
- getExecutionDelaySamples(TaskPriority) - Method in class org.threadly.concurrent.statistics.SingleThreadSchedulerStatisticTracker
-
- getExecutionDelaySamples() - Method in interface org.threadly.concurrent.statistics.StatisticExecutor
-
Get raw sample data for task execution delays.
- getExecutionDelaySamples() - Method in interface org.threadly.concurrent.statistics.StatisticPriorityScheduler
-
Get raw sample data for task execution delays.
- getExecutionDelaySamples(TaskPriority) - Method in interface org.threadly.concurrent.statistics.StatisticPriorityScheduler
-
Call to get a list of all currently recorded times for execution delays.
- getExecutionDelaySamples() - Method in class org.threadly.concurrent.wrapper.statistics.ExecutorStatisticWrapper
-
- getExecutionDurationPercentiles(double...) - Method in class org.threadly.concurrent.statistics.NoThreadSchedulerStatisticTracker
-
- getExecutionDurationPercentiles(TaskPriority, double...) - Method in class org.threadly.concurrent.statistics.NoThreadSchedulerStatisticTracker
-
- getExecutionDurationPercentiles(double...) - Method in class org.threadly.concurrent.statistics.PrioritySchedulerStatisticTracker
-
- getExecutionDurationPercentiles(TaskPriority, double...) - Method in class org.threadly.concurrent.statistics.PrioritySchedulerStatisticTracker
-
- getExecutionDurationPercentiles(double...) - Method in class org.threadly.concurrent.statistics.SingleThreadSchedulerStatisticTracker
-
- getExecutionDurationPercentiles(TaskPriority, double...) - Method in class org.threadly.concurrent.statistics.SingleThreadSchedulerStatisticTracker
-
- getExecutionDurationPercentiles(double...) - Method in interface org.threadly.concurrent.statistics.StatisticExecutor
-
Gets percentile values for execution duration.
- getExecutionDurationPercentiles(double...) - Method in interface org.threadly.concurrent.statistics.StatisticPriorityScheduler
-
Gets percentile values for execution duration.
- getExecutionDurationPercentiles(TaskPriority, double...) - Method in interface org.threadly.concurrent.statistics.StatisticPriorityScheduler
-
Gets percentile values for execution duration.
- getExecutionDurationPercentiles(double...) - Method in class org.threadly.concurrent.wrapper.statistics.ExecutorStatisticWrapper
-
- getExecutionDurationSamples() - Method in class org.threadly.concurrent.statistics.NoThreadSchedulerStatisticTracker
-
- getExecutionDurationSamples(TaskPriority) - Method in class org.threadly.concurrent.statistics.NoThreadSchedulerStatisticTracker
-
- getExecutionDurationSamples() - Method in class org.threadly.concurrent.statistics.PrioritySchedulerStatisticTracker
-
- getExecutionDurationSamples(TaskPriority) - Method in class org.threadly.concurrent.statistics.PrioritySchedulerStatisticTracker
-
- getExecutionDurationSamples() - Method in class org.threadly.concurrent.statistics.SingleThreadSchedulerStatisticTracker
-
- getExecutionDurationSamples(TaskPriority) - Method in class org.threadly.concurrent.statistics.SingleThreadSchedulerStatisticTracker
-
- getExecutionDurationSamples() - Method in interface org.threadly.concurrent.statistics.StatisticExecutor
-
Get raw sample data for task run durations.
- getExecutionDurationSamples() - Method in interface org.threadly.concurrent.statistics.StatisticPriorityScheduler
-
Get raw sample data for task run durations.
- getExecutionDurationSamples(TaskPriority) - Method in interface org.threadly.concurrent.statistics.StatisticPriorityScheduler
-
Get raw sample data for task run durations.
- getExecutionDurationSamples() - Method in class org.threadly.concurrent.wrapper.statistics.ExecutorStatisticWrapper
-
- getExecutor() - Method in class org.threadly.concurrent.wrapper.KeyDistributedExecutor
-
Getter for the executor being used behind the scenes.
- getExecutorForKey(Object) - Method in class org.threadly.concurrent.wrapper.KeyDistributedExecutor
-
Returns a
SubmitterExecutor
implementation where all tasks submitted on this executor
will run on the provided key.
- getExpectedConcurrencyLevel() - Method in class org.threadly.concurrent.lock.StripedLock
-
Getter for the expected concurrency level this class was constructed with.
- getFirst() - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
- getFrontPadding() - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
Getter for current amount to added padding to the front of new buffers.
- getFutureTillDelay(Object, long) - Method in class org.threadly.concurrent.wrapper.limiter.KeyedRateLimiterExecutor
-
In order to help assist with avoiding to schedule too much on the scheduler at any given
time, this call returns a future that will block until the delay for the next task falls
below the maximum delay provided into this call.
- getFutureTillDelay(long) - Method in class org.threadly.concurrent.wrapper.limiter.RateLimiterExecutor
-
In order to help assist with avoiding to schedule too much on the scheduler at any given
time, this call returns a future that will block until the delay for the next task falls
below the maximum delay provided into this call.
- getGenericThreadCount() - Static method in class org.threadly.concurrent.CentralThreadlyPool
-
This reports the number of threads currently available for processing across all pools where
the max thread count is >
the guaranteed thread count.
- getInsertionEndIndex(List<Long>, long, boolean) - Static method in class org.threadly.util.SortUtils
-
This function uses the binary search and adds a small amount of logic such that it determines
the placement index for a given item.
- getInsertionEndIndex(Function<Integer, Long>, int, long, boolean) - Static method in class org.threadly.util.SortUtils
-
This function uses the binary search and adds a small amount of logic such that it determines
the placement index for a given value.
- getLast() - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
- getLastTickTime() - Method in class org.threadly.test.concurrent.TestableScheduler
-
Returns the last provided time to the tick call.
- getLeft() - Method in class org.threadly.util.Pair
-
Getter to get the left reference stored in the pair.
- getLeftFromRight(Iterable<? extends Pair<? extends T, ?>>, Object) - Static method in class org.threadly.util.Pair
-
Get the left side of a pair by searching for a matching right side.
- getLock(Object) - Method in class org.threadly.concurrent.lock.StripedLock
-
Call to get a lock object for a given key.
- getLock(int) - Method in class org.threadly.concurrent.lock.StripedLock
-
Call to get a lock object for a given hash code.
- getLongRunningTasks(long) - Method in class org.threadly.concurrent.statistics.NoThreadSchedulerStatisticTracker
-
- getLongRunningTasks(long) - Method in class org.threadly.concurrent.statistics.PrioritySchedulerStatisticTracker
-
- getLongRunningTasks(long) - Method in class org.threadly.concurrent.statistics.SingleThreadSchedulerStatisticTracker
-
- getLongRunningTasks(long) - Method in interface org.threadly.concurrent.statistics.StatisticExecutor
-
Call to get a list of runnables and stack traces from tasks which have been actively
executing for a longer duration than the one provided.
- getLongRunningTasks(long) - Method in class org.threadly.concurrent.wrapper.statistics.ExecutorStatisticWrapper
-
- getLongRunningTasksQty(long) - Method in class org.threadly.concurrent.statistics.NoThreadSchedulerStatisticTracker
-
- getLongRunningTasksQty(long) - Method in class org.threadly.concurrent.statistics.PrioritySchedulerStatisticTracker
-
- getLongRunningTasksQty(long) - Method in class org.threadly.concurrent.statistics.SingleThreadSchedulerStatisticTracker
-
- getLongRunningTasksQty(long) - Method in interface org.threadly.concurrent.statistics.StatisticExecutor
-
Call to return the number of tasks which have been running longer than the provided duration
in milliseconds.
- getLongRunningTasksQty(long) - Method in class org.threadly.concurrent.wrapper.statistics.ExecutorStatisticWrapper
-
- getMaxConcurrency() - Method in class org.threadly.concurrent.wrapper.limiter.ExecutorLimiter
-
Call to check what the maximum concurrency this limiter will allow.
- getMaxPoolSize() - Method in class org.threadly.concurrent.PriorityScheduler
-
Getter for the currently set max thread pool size.
- getMaxWaitForLowPriority() - Method in class org.threadly.concurrent.AbstractPriorityScheduler
-
- getMaxWaitForLowPriority() - Method in interface org.threadly.concurrent.PrioritySchedulerService
-
Getter for the amount of time a low priority task will wait during thread contention before
it is eligible for execution.
- getMaxWaitForLowPriority() - Method in class org.threadly.concurrent.wrapper.interceptor.PrioritySchedulerTaskInterceptor
-
- getMaxWaitForLowPriority() - Method in class org.threadly.concurrent.wrapper.limiter.PrioritySchedulerServiceQueueLimitRejector
-
- getMaxWaitForLowPriority() - Method in class org.threadly.concurrent.wrapper.PrioritySchedulerDefaultPriorityWrapper
-
- getMaxWaitForLowPriority() - Method in class org.threadly.concurrent.wrapper.traceability.ThreadRenamingPriorityScheduler
-
- getMinimumDelay(Object) - Method in class org.threadly.concurrent.wrapper.limiter.KeyedRateLimiterExecutor
-
This call will check how far out we have already scheduled tasks to be run.
- getMinimumDelay() - Method in class org.threadly.concurrent.wrapper.limiter.RateLimiterExecutor
-
This call will check how far out we have already scheduled tasks to be run.
- getModificationLock() - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
If you want to chain multiple calls together and ensure that no threads modify the structure
during that time you can get the lock to prevent additional modifications.
- getOldestLogMessages(int) - Static method in class org.threadly.util.debug.DebugLogger
-
This call retrieves and removes the oldest stored log messages.
- getOldestLogMessages(int, boolean) - Static method in class org.threadly.util.debug.DebugLogger
-
This call retrieves and removes the oldest stored log messages.
- getPercentiles(Collection<? extends T>, double...) - Static method in class org.threadly.util.StatisticsUtils
-
Gets percentile values from a collection of numeric values.
- getPollInterval() - Method in class org.threadly.util.debug.Profiler
-
Call to get the currently set profile interval.
- getProfiledThreadCount() - Method in class org.threadly.util.debug.ControlledThreadProfiler
-
Call to check how many threads are currently being checked by the profiler.
- getQueuedTaskCount() - Method in class org.threadly.concurrent.AbstractPriorityScheduler
-
- getQueuedTaskCount(TaskPriority) - Method in class org.threadly.concurrent.AbstractPriorityScheduler
-
- getQueuedTaskCount() - Method in class org.threadly.concurrent.PriorityScheduler
-
- getQueuedTaskCount(TaskPriority) - Method in class org.threadly.concurrent.PriorityScheduler
-
- getQueuedTaskCount(TaskPriority) - Method in interface org.threadly.concurrent.PrioritySchedulerService
-
Returns a count of how many tasks are either waiting to be executed, or are scheduled to be
executed at a future point for a specific priority.
- getQueuedTaskCount() - Method in interface org.threadly.concurrent.SchedulerService
-
Returns how many tasks are either waiting to be executed, or are scheduled to be executed at
a future point.
- getQueuedTaskCount() - Method in interface org.threadly.concurrent.statistics.StatisticExecutor
-
Returns how many tasks are either waiting to be executed, or are scheduled to be executed at
a future point.
- getQueuedTaskCount(TaskPriority) - Method in class org.threadly.concurrent.wrapper.interceptor.PrioritySchedulerTaskInterceptor
-
- getQueuedTaskCount() - Method in class org.threadly.concurrent.wrapper.interceptor.SchedulerServiceTaskInterceptor
-
- getQueuedTaskCount() - Method in class org.threadly.concurrent.wrapper.limiter.ExecutorQueueLimitRejector
-
Invoked to check how many tasks are currently being tracked as queued by this limiter.
- getQueuedTaskCount() - Method in class org.threadly.concurrent.wrapper.limiter.KeyedSchedulerServiceLimiter
-
Returns how many tasks are either waiting to be executed, or are scheduled to be executed at
a future point.
- getQueuedTaskCount(TaskPriority) - Method in class org.threadly.concurrent.wrapper.limiter.PrioritySchedulerServiceQueueLimitRejector
-
- getQueuedTaskCount() - Method in class org.threadly.concurrent.wrapper.limiter.SchedulerServiceLimiter
-
- getQueuedTaskCount() - Method in class org.threadly.concurrent.wrapper.limiter.SubmitterSchedulerQueueLimitRejector
-
Invoked to check how many tasks are currently being tracked as queued by this limiter.
- getQueuedTaskCount() - Method in class org.threadly.concurrent.wrapper.PrioritySchedulerDefaultPriorityWrapper
-
- getQueuedTaskCount(TaskPriority) - Method in class org.threadly.concurrent.wrapper.PrioritySchedulerDefaultPriorityWrapper
-
- getQueuedTaskCount() - Method in class org.threadly.concurrent.wrapper.statistics.ExecutorStatisticWrapper
-
Call to check how many tasks are queued waiting for execution.
- getQueuedTaskCount() - Method in class org.threadly.concurrent.wrapper.traceability.ThreadRenamingPriorityScheduler
-
- getQueuedTaskCount(TaskPriority) - Method in class org.threadly.concurrent.wrapper.traceability.ThreadRenamingPriorityScheduler
-
- getQueuedTaskCount() - Method in class org.threadly.concurrent.wrapper.traceability.ThreadRenamingSchedulerService
-
- getQueueLimit() - Method in class org.threadly.concurrent.wrapper.limiter.ExecutorQueueLimitRejector
-
Invoked to check the currently set queue limit.
- getQueueLimit() - Method in class org.threadly.concurrent.wrapper.limiter.SubmitterSchedulerQueueLimitRejector
-
Invoked to check the currently set queue limit.
- getRearPadding() - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
Getter for current amount to added padding to the rear of new buffers.
- getRight() - Method in class org.threadly.util.Pair
-
Getter to get the right reference stored in the pair.
- getRightFromLeft(Iterable<? extends Pair<?, ? extends T>>, Object) - Static method in class org.threadly.util.Pair
-
Get the right side of a pair by searching for a matching left side.
- getRootCause(Throwable) - Static method in class org.threadly.util.ExceptionUtils
-
Gets the root cause of a provided Throwable
.
- getRunCount() - Method in class org.threadly.test.concurrent.TestRunnable
-
Getter for the number of times the run function has completed.
- getRunDelayInMillis() - Method in class org.threadly.test.concurrent.TestRunnable
-
- getSchedulerForKey(Object) - Method in class org.threadly.concurrent.wrapper.KeyDistributedScheduler
-
Returns a scheduler implementation where all tasks submitted on this scheduler will run on
the provided key.
- getStripe(Runnable) - Method in class org.threadly.concurrent.UnfairExecutor.AtomicStripeGenerator
-
- getStripe(Runnable) - Method in class org.threadly.concurrent.UnfairExecutor.TaskHashXorTimeStripeGenerator
-
- getStripe(Runnable) - Method in interface org.threadly.concurrent.UnfairExecutor.TaskStripeGenerator
-
Generate an identifier for the stripe to distribute the task on to.
- getSubmitterExecutorForKey(Object) - Method in class org.threadly.concurrent.wrapper.limiter.KeyedRateLimiterExecutor
-
Returns an executor implementation where all tasks submitted on this executor will run on the
provided key.
- getSubmitterExecutorForKey(double, Object) - Method in class org.threadly.concurrent.wrapper.limiter.KeyedRateLimiterExecutor
-
Returns an executor implementation where all tasks submitted on this executor will run on the
provided key.
- getSubscribedListeners() - Method in class org.threadly.concurrent.event.ListenerHelper
-
Return a collection of the currently subscribed listener instances.
- getSubscribedListeners() - Method in class org.threadly.concurrent.event.RunnableListenerHelper
-
Return a collection of the currently subscribed listener instances.
- getTaskQueueSize(Object) - Method in class org.threadly.concurrent.wrapper.KeyDistributedExecutor
-
Call to check how many tasks have been queued up for a given key.
- getTaskQueueSizeMap() - Method in class org.threadly.concurrent.wrapper.KeyDistributedExecutor
-
Get a map of all the keys and how many tasks are queued per key.
- getThreadLocalExceptionHandler() - Static method in class org.threadly.util.ExceptionUtils
-
- getTimeoutInMillis() - Method in class org.threadly.concurrent.future.Watchdog
-
Request the timeout in milliseconds until futures that have not completed are canceled.
- getTotalExecutionCount() - Method in class org.threadly.concurrent.statistics.NoThreadSchedulerStatisticTracker
-
- getTotalExecutionCount(TaskPriority) - Method in class org.threadly.concurrent.statistics.NoThreadSchedulerStatisticTracker
-
- getTotalExecutionCount() - Method in class org.threadly.concurrent.statistics.PrioritySchedulerStatisticTracker
-
- getTotalExecutionCount(TaskPriority) - Method in class org.threadly.concurrent.statistics.PrioritySchedulerStatisticTracker
-
- getTotalExecutionCount() - Method in class org.threadly.concurrent.statistics.SingleThreadSchedulerStatisticTracker
-
- getTotalExecutionCount(TaskPriority) - Method in class org.threadly.concurrent.statistics.SingleThreadSchedulerStatisticTracker
-
- getTotalExecutionCount() - Method in interface org.threadly.concurrent.statistics.StatisticExecutor
-
Call to get the total quantity of tasks this executor has handled.
- getTotalExecutionCount(TaskPriority) - Method in interface org.threadly.concurrent.statistics.StatisticPriorityScheduler
-
Call to get the total quantity of tasks this executor has handled for a specific priority.
- getTotalExecutionCount() - Method in class org.threadly.concurrent.wrapper.statistics.ExecutorStatisticWrapper
-
- getTrackedKeyCount() - Method in class org.threadly.concurrent.wrapper.limiter.KeyedRateLimiterExecutor
-
Check how many keys are currently being restricted or monitored.
- getUnsubmittedTaskCount() - Method in class org.threadly.concurrent.wrapper.limiter.ExecutorLimiter
-
Returns how many tasks are currently being "limited" and thus are in queue to run from this
limiter.
- getWaitingForExecutionTaskCount() - Method in class org.threadly.concurrent.AbstractPriorityScheduler
-
- getWaitingForExecutionTaskCount(TaskPriority) - Method in class org.threadly.concurrent.AbstractPriorityScheduler
-
- getWaitingForExecutionTaskCount(TaskPriority) - Method in interface org.threadly.concurrent.PrioritySchedulerService
-
Returns a count of how many tasks are either waiting to be executed for a specific priority.
- getWaitingForExecutionTaskCount() - Method in interface org.threadly.concurrent.SchedulerService
-
Returns how many tasks are either waiting to be executed.
- getWaitingForExecutionTaskCount(TaskPriority) - Method in class org.threadly.concurrent.wrapper.interceptor.PrioritySchedulerTaskInterceptor
-
- getWaitingForExecutionTaskCount() - Method in class org.threadly.concurrent.wrapper.interceptor.SchedulerServiceTaskInterceptor
-
- getWaitingForExecutionTaskCount(TaskPriority) - Method in class org.threadly.concurrent.wrapper.limiter.PrioritySchedulerServiceQueueLimitRejector
-
- getWaitingForExecutionTaskCount() - Method in class org.threadly.concurrent.wrapper.limiter.SchedulerServiceLimiter
-
- getWaitingForExecutionTaskCount() - Method in class org.threadly.concurrent.wrapper.limiter.SchedulerServiceQueueLimitRejector
-
- getWaitingForExecutionTaskCount() - Method in class org.threadly.concurrent.wrapper.PrioritySchedulerDefaultPriorityWrapper
-
- getWaitingForExecutionTaskCount(TaskPriority) - Method in class org.threadly.concurrent.wrapper.PrioritySchedulerDefaultPriorityWrapper
-
- getWaitingForExecutionTaskCount() - Method in class org.threadly.concurrent.wrapper.traceability.ThreadRenamingPriorityScheduler
-
- getWaitingForExecutionTaskCount(TaskPriority) - Method in class org.threadly.concurrent.wrapper.traceability.ThreadRenamingPriorityScheduler
-
- getWaitingForExecutionTaskCount() - Method in class org.threadly.concurrent.wrapper.traceability.ThreadRenamingSchedulerService
-
- padEnd(String, int, char) - Static method in class org.threadly.util.StringUtils
-
Pads the end of the provided string with the provided character until a minimum length is
reached.
- padStart(String, int, char) - Static method in class org.threadly.util.StringUtils
-
Pads the start of the provided string with the provided character until a minimum length is
reached.
- Pair<L,R> - Class in org.threadly.util
-
A simple tuple implementation (every library needs one, right?).
- Pair(L, R) - Constructor for class org.threadly.util.Pair
-
Constructs a new pair, providing the left and right objects to be held.
- peek() - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
- peekFirst() - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
- peekLast() - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
- poll() - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
- Poller - Class in org.threadly.concurrent
-
Simple class for watching a condition and getting notified when a state has changed.
- Poller(SchedulerService, long) - Constructor for class org.threadly.concurrent.Poller
-
Construct a new poller which will run on the provided scheduler, and run at the specified
frequency.
- Poller(SchedulerService, long, long) - Constructor for class org.threadly.concurrent.Poller
-
Construct a new poller which will run on the provided scheduler, and run at the specified
frequency.
- pollFirst() - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
- pollLast() - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
- pop() - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
- prestartAllThreads() - Method in class org.threadly.concurrent.PriorityScheduler
-
- prestartExecutionThread() - Method in class org.threadly.concurrent.SingleThreadScheduler
-
Start thread for execution if not already started.
- prestartExecutionThread(boolean) - Method in class org.threadly.concurrent.SingleThreadScheduler
-
Start thread for execution if not already started.
- PRINT_STACKTRACE_HANDLER - Static variable in interface org.threadly.util.ExceptionHandler
-
Default
ExceptionHandler
implementation which will invoke
Throwable.printStackTrace()
.
- PriorityScheduler - Class in org.threadly.concurrent
-
Executor to run tasks, schedule tasks.
- PriorityScheduler(int) - Constructor for class org.threadly.concurrent.PriorityScheduler
-
Constructs a new thread pool, though threads will be lazily started as it has tasks ready to
run.
- PriorityScheduler(int, boolean) - Constructor for class org.threadly.concurrent.PriorityScheduler
-
Constructs a new thread pool, though threads will be lazily started as it has tasks ready to
run.
- PriorityScheduler(int, TaskPriority, long) - Constructor for class org.threadly.concurrent.PriorityScheduler
-
Constructs a new thread pool, though threads will be lazily started as it has tasks ready to
run.
- PriorityScheduler(int, TaskPriority, long, boolean) - Constructor for class org.threadly.concurrent.PriorityScheduler
-
Constructs a new thread pool, though threads will be lazily started as it has tasks ready to
run.
- PriorityScheduler(int, TaskPriority, long, ThreadFactory) - Constructor for class org.threadly.concurrent.PriorityScheduler
-
Constructs a new thread pool, though threads will be lazily started as it has tasks ready to
run.
- PrioritySchedulerDefaultPriorityWrapper - Class in org.threadly.concurrent.wrapper
-
- PrioritySchedulerDefaultPriorityWrapper(PrioritySchedulerService, TaskPriority) - Constructor for class org.threadly.concurrent.wrapper.PrioritySchedulerDefaultPriorityWrapper
-
Constructs a new priority wrapper with a new default priority to use.
- PrioritySchedulerService - Interface in org.threadly.concurrent
-
This interface represents schedulers which can not only execute and schedule tasks, but run
based off a given priority as well.
- PrioritySchedulerServiceQueueLimitRejector - Class in org.threadly.concurrent.wrapper.limiter
-
- PrioritySchedulerServiceQueueLimitRejector(PrioritySchedulerService, int) - Constructor for class org.threadly.concurrent.wrapper.limiter.PrioritySchedulerServiceQueueLimitRejector
-
- PrioritySchedulerServiceQueueLimitRejector(PrioritySchedulerService, int, RejectedExecutionHandler) - Constructor for class org.threadly.concurrent.wrapper.limiter.PrioritySchedulerServiceQueueLimitRejector
-
- PrioritySchedulerServiceQueueLimitRejector(PrioritySchedulerService, int, boolean) - Constructor for class org.threadly.concurrent.wrapper.limiter.PrioritySchedulerServiceQueueLimitRejector
-
- PrioritySchedulerServiceQueueLimitRejector(PrioritySchedulerService, int, boolean, RejectedExecutionHandler) - Constructor for class org.threadly.concurrent.wrapper.limiter.PrioritySchedulerServiceQueueLimitRejector
-
- PrioritySchedulerServiceWrapper - Class in org.threadly.concurrent.wrapper.compatibility
-
This is a wrapper for
PriorityScheduler
to be a drop in replacement for any
ScheduledExecutorService
(AKA the
ScheduledThreadPoolExecutor
interface).
- PrioritySchedulerServiceWrapper(PriorityScheduler) - Constructor for class org.threadly.concurrent.wrapper.compatibility.PrioritySchedulerServiceWrapper
-
Constructs a new wrapper to adhere to the
ScheduledExecutorService
interface.
- PrioritySchedulerServiceWrapper(PriorityScheduler, TaskPriority) - Constructor for class org.threadly.concurrent.wrapper.compatibility.PrioritySchedulerServiceWrapper
-
Constructs a new wrapper to adhere to the
ScheduledExecutorService
interface.
- PrioritySchedulerStatisticTracker - Class in org.threadly.concurrent.statistics
-
- PrioritySchedulerStatisticTracker(int) - Constructor for class org.threadly.concurrent.statistics.PrioritySchedulerStatisticTracker
-
Constructs a new thread pool, though no threads will be started till it accepts it's first
request.
- PrioritySchedulerStatisticTracker(int, boolean) - Constructor for class org.threadly.concurrent.statistics.PrioritySchedulerStatisticTracker
-
Constructs a new thread pool, though no threads will be started till it accepts it's first
request.
- PrioritySchedulerStatisticTracker(int, TaskPriority, long) - Constructor for class org.threadly.concurrent.statistics.PrioritySchedulerStatisticTracker
-
Constructs a new thread pool, though no threads will be started till it accepts it's first
request.
- PrioritySchedulerStatisticTracker(int, TaskPriority, long, boolean) - Constructor for class org.threadly.concurrent.statistics.PrioritySchedulerStatisticTracker
-
Constructs a new thread pool, though no threads will be started till it accepts it's first
request.
- PrioritySchedulerStatisticTracker(int, TaskPriority, long, ThreadFactory) - Constructor for class org.threadly.concurrent.statistics.PrioritySchedulerStatisticTracker
-
Constructs a new thread pool, though no threads will be started till it accepts it's first
request.
- PrioritySchedulerStatisticTracker(int, int) - Constructor for class org.threadly.concurrent.statistics.PrioritySchedulerStatisticTracker
-
Constructs a new thread pool, though no threads will be started till it accepts it's first
request.
- PrioritySchedulerStatisticTracker(int, boolean, int) - Constructor for class org.threadly.concurrent.statistics.PrioritySchedulerStatisticTracker
-
Constructs a new thread pool, though no threads will be started till it accepts it's first
request.
- PrioritySchedulerStatisticTracker(int, TaskPriority, long, int) - Constructor for class org.threadly.concurrent.statistics.PrioritySchedulerStatisticTracker
-
Constructs a new thread pool, though no threads will be started till it accepts it's first
request.
- PrioritySchedulerStatisticTracker(int, TaskPriority, long, boolean, int) - Constructor for class org.threadly.concurrent.statistics.PrioritySchedulerStatisticTracker
-
Constructs a new thread pool, though no threads will be started till it accepts it's first
request.
- PrioritySchedulerStatisticTracker(int, TaskPriority, long, ThreadFactory, int) - Constructor for class org.threadly.concurrent.statistics.PrioritySchedulerStatisticTracker
-
Constructs a new thread pool, though no threads will be started till it accepts it's first
request.
- PrioritySchedulerStatisticTracker(int, int, boolean) - Constructor for class org.threadly.concurrent.statistics.PrioritySchedulerStatisticTracker
-
Constructs a new thread pool, though no threads will be started till it accepts it's first
request.
- PrioritySchedulerStatisticTracker(int, boolean, int, boolean) - Constructor for class org.threadly.concurrent.statistics.PrioritySchedulerStatisticTracker
-
Constructs a new thread pool, though no threads will be started till it accepts it's first
request.
- PrioritySchedulerStatisticTracker(int, TaskPriority, long, int, boolean) - Constructor for class org.threadly.concurrent.statistics.PrioritySchedulerStatisticTracker
-
Constructs a new thread pool, though no threads will be started till it accepts it's first
request.
- PrioritySchedulerStatisticTracker(int, TaskPriority, long, boolean, int, boolean) - Constructor for class org.threadly.concurrent.statistics.PrioritySchedulerStatisticTracker
-
Constructs a new thread pool, though no threads will be started till it accepts it's first
request.
- PrioritySchedulerStatisticTracker(int, TaskPriority, long, ThreadFactory, int, boolean) - Constructor for class org.threadly.concurrent.statistics.PrioritySchedulerStatisticTracker
-
Constructs a new thread pool, though no threads will be started till it accepts it's first
request.
- PrioritySchedulerTaskInterceptor - Class in org.threadly.concurrent.wrapper.interceptor
-
Class to wrap
PrioritySchedulerService
pool so that tasks can be intercepted and either
wrapped, or modified, before being submitted to the pool.
- PrioritySchedulerTaskInterceptor(PrioritySchedulerService, BiFunction<Runnable, Boolean, Runnable>) - Constructor for class org.threadly.concurrent.wrapper.interceptor.PrioritySchedulerTaskInterceptor
-
Constructs a wrapper for
PrioritySchedulerService
pool so that tasks can be intercepted
and modified, before being submitted to the pool.
- Profiler - Class in org.threadly.util.debug
-
Tool for profiling a running java application to get an idea of where the slow points
(either because of lock contention, or because of high computational demand).
- Profiler() - Constructor for class org.threadly.util.debug.Profiler
-
Constructs a new profiler instance.
- Profiler(int) - Constructor for class org.threadly.util.debug.Profiler
-
Constructs a new profiler instance.
- push(T) - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
- ranConcurrently() - Method in class org.threadly.test.concurrent.TestRunnable
-
Check if this instance has ever been detected to run concurrently.
- rangedThreadPool(int, int) - Static method in class org.threadly.concurrent.CentralThreadlyPool
-
Requests a pool with a given range of threads.
- rangedThreadPool(int, int, String) - Static method in class org.threadly.concurrent.CentralThreadlyPool
-
Requests a pool with a given range of threads.
- rangedThreadPool(TaskPriority, int, int) - Static method in class org.threadly.concurrent.CentralThreadlyPool
-
Requests a pool with a given range of threads.
- rangedThreadPool(TaskPriority, int, int, String) - Static method in class org.threadly.concurrent.CentralThreadlyPool
-
Requests a pool with a given range of threads.
- ranOnce() - Method in class org.threadly.test.concurrent.TestRunnable
-
Getter to check if the runnable has run exactly once.
- RateLimiterExecutor - Class in org.threadly.concurrent.wrapper.limiter
-
Another way to limit executions on a scheduler.
- RateLimiterExecutor(SubmitterScheduler, double) - Constructor for class org.threadly.concurrent.wrapper.limiter.RateLimiterExecutor
-
- RateLimiterExecutor(SubmitterScheduler, double, long) - Constructor for class org.threadly.concurrent.wrapper.limiter.RateLimiterExecutor
-
- RateLimiterExecutor(SubmitterScheduler, double, long, RejectedExecutionHandler) - Constructor for class org.threadly.concurrent.wrapper.limiter.RateLimiterExecutor
-
- registeredListenerCount() - Method in class org.threadly.concurrent.event.ListenerHelper
-
- registeredListenerCount() - Method in class org.threadly.concurrent.event.RunnableListenerHelper
-
Returns how many listeners were added, and will be ran on the next call to
callListeners
.
- RejectedExecutionHandler - Interface in org.threadly.concurrent.wrapper.limiter
-
Interface to be invoked when a limiter can not accept a task for any reason.
- remove(Runnable) - Method in class org.threadly.concurrent.AbstractPriorityScheduler
-
- remove(Callable<?>) - Method in class org.threadly.concurrent.AbstractPriorityScheduler
-
- remove(Object) - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
- remove(int) - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
- remove() - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
- remove(Collection<? extends RunnableContainer>, Runnable) - Static method in class org.threadly.concurrent.ContainerHelper
-
Attempts to remove the provided runnable from the source collection.
- remove(Collection<? extends RunnableContainer>, Callable<?>) - Static method in class org.threadly.concurrent.ContainerHelper
-
Attempts to remove the provided callable from the source collection.
- remove(Runnable) - Method in interface org.threadly.concurrent.SchedulerService
-
Removes the runnable task from the execution queue.
- remove(Callable<?>) - Method in interface org.threadly.concurrent.SchedulerService
-
Removes the callable task from the execution queue.
- remove(Runnable) - Method in class org.threadly.concurrent.wrapper.interceptor.SchedulerServiceTaskInterceptor
-
- remove(Callable<?>) - Method in class org.threadly.concurrent.wrapper.interceptor.SchedulerServiceTaskInterceptor
-
- remove(Runnable) - Method in class org.threadly.concurrent.wrapper.limiter.KeyedSchedulerServiceLimiter
-
Removes the runnable task from the execution queue.
- remove(Callable<?>) - Method in class org.threadly.concurrent.wrapper.limiter.KeyedSchedulerServiceLimiter
-
Removes the runnable task from the execution queue.
- remove(Runnable) - Method in class org.threadly.concurrent.wrapper.limiter.SchedulerServiceLimiter
-
- remove(Callable<?>) - Method in class org.threadly.concurrent.wrapper.limiter.SchedulerServiceLimiter
-
- remove(Runnable) - Method in class org.threadly.concurrent.wrapper.limiter.SchedulerServiceQueueLimitRejector
-
- remove(Callable<?>) - Method in class org.threadly.concurrent.wrapper.limiter.SchedulerServiceQueueLimitRejector
-
- remove(Runnable) - Method in class org.threadly.concurrent.wrapper.PrioritySchedulerDefaultPriorityWrapper
-
- remove(Callable<?>) - Method in class org.threadly.concurrent.wrapper.PrioritySchedulerDefaultPriorityWrapper
-
- remove(Runnable) - Method in class org.threadly.concurrent.wrapper.traceability.ThreadRenamingPriorityScheduler
-
- remove(Callable<?>) - Method in class org.threadly.concurrent.wrapper.traceability.ThreadRenamingPriorityScheduler
-
- remove(Runnable) - Method in class org.threadly.concurrent.wrapper.traceability.ThreadRenamingSchedulerService
-
- remove(Callable<?>) - Method in class org.threadly.concurrent.wrapper.traceability.ThreadRenamingSchedulerService
-
- removeAll(Collection<?>) - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
- removedProfiledThread(Thread) - Method in class org.threadly.util.debug.ControlledThreadProfiler
-
Removed a thread from the set of tracked threads.
- removeFirst() - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
- removeFirstOccurrence(Object) - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
- removeLast() - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
- removeLastOccurrence(Object) - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
- removeListener(T) - Method in class org.threadly.concurrent.event.ListenerHelper
-
Attempts to remove a listener waiting to be called.
- removeListener(Runnable) - Method in class org.threadly.concurrent.event.RunnableListenerHelper
-
Attempts to remove a listener waiting to be called.
- reposition(T, int) - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
Move a stored item to a new index.
- reposition(T, int, boolean) - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
Move a stored item to a new index.
- reposition(int, int) - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
Move a stored item located at an index to a new index.
- ReschedulingOperation - Class in org.threadly.concurrent
-
Abstract implementation for more complicated recurring behavior.
- reset() - Method in class org.threadly.util.debug.Profiler
-
Reset the current stored statistics.
- resetCollectedStats() - Method in class org.threadly.concurrent.statistics.NoThreadSchedulerStatisticTracker
-
- resetCollectedStats() - Method in class org.threadly.concurrent.statistics.PrioritySchedulerStatisticTracker
-
- resetCollectedStats() - Method in class org.threadly.concurrent.statistics.SingleThreadSchedulerStatisticTracker
-
- resetCollectedStats() - Method in interface org.threadly.concurrent.statistics.StatisticExecutor
-
Clears all collected rolling statistics.
- resetCollectedStats() - Method in class org.threadly.concurrent.wrapper.statistics.ExecutorStatisticWrapper
-
- retainAll(Collection<?>) - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
- run() - Method in class org.threadly.concurrent.DoNothingRunnable
-
- run() - Method in class org.threadly.concurrent.future.ExecuteOnGetFutureTask
-
- run() - Method in class org.threadly.concurrent.future.ListenableFutureAdapterTask
-
- run() - Method in class org.threadly.concurrent.future.ListenableFutureTask
-
- run() - Method in class org.threadly.concurrent.future.RunnableFutureCallbackAdapter
-
- run() - Method in class org.threadly.concurrent.RunnableChain
-
- run() - Method in class org.threadly.concurrent.wrapper.ThrowableSuppressingRunnable
-
- run() - Method in class org.threadly.concurrent.wrapper.traceability.ThreadRenamingRunnable
-
- run() - Method in class org.threadly.test.concurrent.TestRunnable
-
- RunnableCallableAdapter<T> - Class in org.threadly.concurrent
-
Converts a Runnable
with a result into a Callable
.
- RunnableCallableAdapter(Runnable) - Constructor for class org.threadly.concurrent.RunnableCallableAdapter
-
Constructs a new adapter with a provided runnable to execute.
- RunnableCallableAdapter(Runnable, T) - Constructor for class org.threadly.concurrent.RunnableCallableAdapter
-
Constructs a new adapter with a provided runnable to execute, and an optional result.
- RunnableChain - Class in org.threadly.concurrent
-
A class to chain multiple runnables to later be run together, within the same thread.
- RunnableChain(boolean, Iterable<? extends Runnable>) - Constructor for class org.threadly.concurrent.RunnableChain
-
Constructs a runnable chain with a provided list of runnables to iterate over.
- RunnableContainer - Interface in org.threadly.concurrent
-
Interface to implement if any classes are containing a runnable.
- RunnableFutureCallbackAdapter<T> - Class in org.threadly.concurrent.future
-
- RunnableFutureCallbackAdapter(Future<T>, FutureCallback<? super T>) - Constructor for class org.threadly.concurrent.future.RunnableFutureCallbackAdapter
-
- RunnableListenerHelper - Class in org.threadly.concurrent.event
-
Class which assist with holding and calling to Runnable listeners.
- RunnableListenerHelper(boolean) - Constructor for class org.threadly.concurrent.event.RunnableListenerHelper
-
- runRunnable(Runnable) - Static method in class org.threadly.util.ExceptionUtils
-
Invokes Runnable.run()
on the provided runnable on this thread, ensuring that no
throwables are thrown out of this invocation.
- SameThreadSubmitterExecutor - Class in org.threadly.concurrent
-
A
SubmitterExecutor
that will run all provided tasks immediately in the same thread
that is calling into it.
- SameThreadSubmitterExecutor() - Constructor for class org.threadly.concurrent.SameThreadSubmitterExecutor
-
- schedule(Runnable, long, TaskPriority) - Method in class org.threadly.concurrent.AbstractPriorityScheduler
-
- schedule(Runnable, long) - Method in class org.threadly.concurrent.AbstractSubmitterScheduler
-
- schedule(Runnable, long, TaskPriority) - Method in interface org.threadly.concurrent.PrioritySchedulerService
-
Schedule a task with a given delay and a specified priority.
- schedule(Runnable, long) - Method in interface org.threadly.concurrent.SubmitterScheduler
-
Schedule a one time task with a given delay.
- schedule(Runnable, long, TaskPriority) - Method in class org.threadly.concurrent.wrapper.interceptor.PrioritySchedulerTaskInterceptor
-
- schedule(Runnable, long) - Method in class org.threadly.concurrent.wrapper.interceptor.SubmitterSchedulerTaskInterceptor
-
- schedule(Object, Runnable, long) - Method in class org.threadly.concurrent.wrapper.KeyDistributedScheduler
-
Schedule a one time task with a given delay that will not run concurrently based off the
thread key.
- schedule(Runnable, long, TaskPriority) - Method in class org.threadly.concurrent.wrapper.limiter.PrioritySchedulerServiceQueueLimitRejector
-
- schedule(Runnable, long) - Method in class org.threadly.concurrent.wrapper.limiter.SubmitterSchedulerLimiter
-
- schedule(Runnable, long) - Method in class org.threadly.concurrent.wrapper.PrioritySchedulerDefaultPriorityWrapper
-
- schedule(Runnable, long, TaskPriority) - Method in class org.threadly.concurrent.wrapper.PrioritySchedulerDefaultPriorityWrapper
-
- schedule(Runnable, long, TaskPriority) - Method in class org.threadly.concurrent.wrapper.traceability.ThreadRenamingPriorityScheduler
-
- scheduleAtFixedRate(Runnable, long, long) - Method in class org.threadly.concurrent.AbstractPriorityScheduler
-
- scheduleAtFixedRate(Runnable, long, long, TaskPriority) - Method in class org.threadly.concurrent.NoThreadScheduler
-
- scheduleAtFixedRate(Runnable, long, long, TaskPriority) - Method in class org.threadly.concurrent.PriorityScheduler
-
- scheduleAtFixedRate(Runnable, long, long, TaskPriority) - Method in interface org.threadly.concurrent.PrioritySchedulerService
-
Schedule a fixed rate recurring task to run.
- scheduleAtFixedRate(Runnable, long, long, TaskPriority) - Method in class org.threadly.concurrent.SingleThreadScheduler
-
- scheduleAtFixedRate(Runnable, long, long, TaskPriority) - Method in class org.threadly.concurrent.statistics.NoThreadSchedulerStatisticTracker
-
- scheduleAtFixedRate(Runnable, long, long, TaskPriority) - Method in class org.threadly.concurrent.statistics.PrioritySchedulerStatisticTracker
-
- scheduleAtFixedRate(Runnable, long, long) - Method in interface org.threadly.concurrent.SubmitterScheduler
-
Schedule a fixed rate recurring task to run.
- scheduleAtFixedRate(Runnable, long, long) - Method in class org.threadly.concurrent.wrapper.compatibility.ScheduledExecutorServiceWrapper
-
- scheduleAtFixedRate(Runnable, long, long, TaskPriority) - Method in class org.threadly.concurrent.wrapper.interceptor.PrioritySchedulerTaskInterceptor
-
- scheduleAtFixedRate(Runnable, long, long) - Method in class org.threadly.concurrent.wrapper.interceptor.SubmitterSchedulerTaskInterceptor
-
- scheduleAtFixedRate(Runnable, long, long, TaskPriority) - Method in class org.threadly.concurrent.wrapper.limiter.PrioritySchedulerServiceQueueLimitRejector
-
- scheduleAtFixedRate(Runnable, long, long, TaskPriority) - Method in class org.threadly.concurrent.wrapper.limiter.SingleThreadSchedulerSubPool
-
- scheduleAtFixedRate(Runnable, long, long) - Method in class org.threadly.concurrent.wrapper.limiter.SubmitterSchedulerLimiter
-
- scheduleAtFixedRate(Runnable, long, long) - Method in class org.threadly.concurrent.wrapper.limiter.SubmitterSchedulerQueueLimitRejector
-
- scheduleAtFixedRate(Runnable, long, long) - Method in class org.threadly.concurrent.wrapper.PrioritySchedulerDefaultPriorityWrapper
-
- scheduleAtFixedRate(Runnable, long, long, TaskPriority) - Method in class org.threadly.concurrent.wrapper.PrioritySchedulerDefaultPriorityWrapper
-
- scheduleAtFixedRate(Runnable, long, long) - Method in class org.threadly.concurrent.wrapper.SchedulerExecutorDelegator
-
- scheduleAtFixedRate(Runnable, long, long) - Method in class org.threadly.concurrent.wrapper.traceability.ThreadRenamingPriorityScheduler
-
- scheduleAtFixedRate(Runnable, long, long, TaskPriority) - Method in class org.threadly.concurrent.wrapper.traceability.ThreadRenamingPriorityScheduler
-
- scheduleAtFixedRate(Runnable, long, long) - Method in class org.threadly.concurrent.wrapper.traceability.ThreadRenamingSubmitterScheduler
-
- scheduleAtFixedRate(Runnable, long, long, TaskPriority) - Method in class org.threadly.test.concurrent.TestableScheduler
-
- ScheduledExecutorServiceWrapper - Class in org.threadly.concurrent.wrapper.compatibility
-
This is a wrapper for the
ScheduledThreadPoolExecutor
to use that
implementation with the
SubmitterScheduler
.
- ScheduledExecutorServiceWrapper(ScheduledExecutorService) - Constructor for class org.threadly.concurrent.wrapper.compatibility.ScheduledExecutorServiceWrapper
-
Constructs a new wrapper with the provided scheduler implementation.
- ScheduledFutureDelegate<T> - Class in org.threadly.concurrent.future
-
- ScheduledFutureDelegate(ListenableFuture<? extends T>, Delayed) - Constructor for class org.threadly.concurrent.future.ScheduledFutureDelegate
-
- SchedulerExecutorDelegator - Class in org.threadly.concurrent.wrapper
-
Class which takes in both an executor and a scheduler.
- SchedulerExecutorDelegator(SubmitterExecutor, SubmitterScheduler) - Constructor for class org.threadly.concurrent.wrapper.SchedulerExecutorDelegator
-
Constructs a new delegator with the provided pools to defer executions to.
- SchedulerService - Interface in org.threadly.concurrent
-
This interface adds some more advanced features to a scheduler that are more service oriented.
- SchedulerServiceLimiter - Class in org.threadly.concurrent.wrapper.limiter
-
This class is designed to limit how much parallel execution happens on a provided
SchedulerService
.
- SchedulerServiceLimiter(SchedulerService, int) - Constructor for class org.threadly.concurrent.wrapper.limiter.SchedulerServiceLimiter
-
- SchedulerServiceLimiter(SchedulerService, int, boolean) - Constructor for class org.threadly.concurrent.wrapper.limiter.SchedulerServiceLimiter
-
- SchedulerServiceQueueLimitRejector - Class in org.threadly.concurrent.wrapper.limiter
-
- SchedulerServiceQueueLimitRejector(SchedulerService, int) - Constructor for class org.threadly.concurrent.wrapper.limiter.SchedulerServiceQueueLimitRejector
-
- SchedulerServiceQueueLimitRejector(SchedulerService, int, RejectedExecutionHandler) - Constructor for class org.threadly.concurrent.wrapper.limiter.SchedulerServiceQueueLimitRejector
-
- SchedulerServiceTaskInterceptor - Class in org.threadly.concurrent.wrapper.interceptor
-
Class to wrap
SchedulerService
pool so that tasks can be intercepted and either
wrapped, or modified, before being submitted to the pool.
- SchedulerServiceTaskInterceptor(SchedulerService, BiFunction<Runnable, Boolean, Runnable>) - Constructor for class org.threadly.concurrent.wrapper.interceptor.SchedulerServiceTaskInterceptor
-
Constructs a wrapper for
SchedulerService
pool so that tasks can be intercepted and modified,
before being submitted to the pool.
- scheduleTaskAtFixedRate(Object, Runnable, long, long) - Method in class org.threadly.concurrent.wrapper.KeyDistributedScheduler
-
Schedule a fixed rate recurring task to run.
- scheduleTaskWithFixedDelay(Object, Runnable, long, long) - Method in class org.threadly.concurrent.wrapper.KeyDistributedScheduler
-
Schedule a fixed delay recurring task to run.
- scheduleWhile(SubmitterScheduler, long, boolean, Callable<? extends T>, Predicate<? super T>) - Static method in class org.threadly.concurrent.future.FutureUtils
-
Executes a task, checking the result from the task to see if it needs to reschedule the task
again.
- scheduleWhile(SubmitterScheduler, long, boolean, Callable<? extends T>, Predicate<? super T>, long, boolean) - Static method in class org.threadly.concurrent.future.FutureUtils
-
Executes a task, checking the result from the task to see if it needs to reschedule the task
again.
- scheduleWhile(SubmitterScheduler, long, ListenableFuture<? extends T>, Callable<? extends T>, Predicate<? super T>) - Static method in class org.threadly.concurrent.future.FutureUtils
-
Executes a task, checking the result from the task to see if it needs to reschedule the task
again.
- scheduleWhile(SubmitterScheduler, long, ListenableFuture<? extends T>, Callable<? extends T>, Predicate<? super T>, long, boolean) - Static method in class org.threadly.concurrent.future.FutureUtils
-
Executes a task, checking the result from the task to see if it needs to reschedule the task
again.
- scheduleWhile(SubmitterScheduler, long, boolean, Runnable, Supplier<Boolean>) - Static method in class org.threadly.concurrent.future.FutureUtils
-
Executes a task until the provided supplier returns false
.
- scheduleWhile(SubmitterScheduler, long, boolean, Runnable, Supplier<Boolean>, long) - Static method in class org.threadly.concurrent.future.FutureUtils
-
Executes a task, checking the result from the task to see if it needs to reschedule the task
again.
- scheduleWhileTaskResultNull(SubmitterScheduler, long, boolean, Callable<? extends T>) - Static method in class org.threadly.concurrent.future.FutureUtils
-
Will continue to schedule the provided task as long as the task is returning a null
result.
- scheduleWhileTaskResultNull(SubmitterScheduler, long, boolean, Callable<? extends T>, long) - Static method in class org.threadly.concurrent.future.FutureUtils
-
Will continue to schedule the provided task as long as the task is returning a null
result.
- scheduleWithFixedDelay(Runnable, long, long) - Method in class org.threadly.concurrent.AbstractPriorityScheduler
-
- scheduleWithFixedDelay(Runnable, long, long, TaskPriority) - Method in class org.threadly.concurrent.NoThreadScheduler
-
- scheduleWithFixedDelay(Runnable, long, long, TaskPriority) - Method in class org.threadly.concurrent.PriorityScheduler
-
- scheduleWithFixedDelay(Runnable, long, long, TaskPriority) - Method in interface org.threadly.concurrent.PrioritySchedulerService
-
Schedule a fixed delay recurring task to run.
- scheduleWithFixedDelay(Runnable, long, long, TaskPriority) - Method in class org.threadly.concurrent.SingleThreadScheduler
-
- scheduleWithFixedDelay(Runnable, long, long, TaskPriority) - Method in class org.threadly.concurrent.statistics.NoThreadSchedulerStatisticTracker
-
- scheduleWithFixedDelay(Runnable, long, long, TaskPriority) - Method in class org.threadly.concurrent.statistics.PrioritySchedulerStatisticTracker
-
- scheduleWithFixedDelay(Runnable, long, long) - Method in interface org.threadly.concurrent.SubmitterScheduler
-
Schedule a fixed delay recurring task to run.
- scheduleWithFixedDelay(Runnable, long, long) - Method in class org.threadly.concurrent.wrapper.compatibility.ScheduledExecutorServiceWrapper
-
- scheduleWithFixedDelay(Runnable, long, long, TaskPriority) - Method in class org.threadly.concurrent.wrapper.interceptor.PrioritySchedulerTaskInterceptor
-
- scheduleWithFixedDelay(Runnable, long, long) - Method in class org.threadly.concurrent.wrapper.interceptor.SubmitterSchedulerTaskInterceptor
-
- scheduleWithFixedDelay(Runnable, long, long, TaskPriority) - Method in class org.threadly.concurrent.wrapper.limiter.PrioritySchedulerServiceQueueLimitRejector
-
- scheduleWithFixedDelay(Runnable, long, long, TaskPriority) - Method in class org.threadly.concurrent.wrapper.limiter.SingleThreadSchedulerSubPool
-
- scheduleWithFixedDelay(Runnable, long, long) - Method in class org.threadly.concurrent.wrapper.limiter.SubmitterSchedulerLimiter
-
- scheduleWithFixedDelay(Runnable, long, long) - Method in class org.threadly.concurrent.wrapper.limiter.SubmitterSchedulerQueueLimitRejector
-
- scheduleWithFixedDelay(Runnable, long, long) - Method in class org.threadly.concurrent.wrapper.PrioritySchedulerDefaultPriorityWrapper
-
- scheduleWithFixedDelay(Runnable, long, long, TaskPriority) - Method in class org.threadly.concurrent.wrapper.PrioritySchedulerDefaultPriorityWrapper
-
- scheduleWithFixedDelay(Runnable, long, long) - Method in class org.threadly.concurrent.wrapper.SchedulerExecutorDelegator
-
- scheduleWithFixedDelay(Runnable, long, long) - Method in class org.threadly.concurrent.wrapper.traceability.ThreadRenamingPriorityScheduler
-
- scheduleWithFixedDelay(Runnable, long, long, TaskPriority) - Method in class org.threadly.concurrent.wrapper.traceability.ThreadRenamingPriorityScheduler
-
- scheduleWithFixedDelay(Runnable, long, long) - Method in class org.threadly.concurrent.wrapper.traceability.ThreadRenamingSubmitterScheduler
-
- scheduleWithFixedDelay(Runnable, long, long, TaskPriority) - Method in class org.threadly.test.concurrent.TestableScheduler
-
- SchedulingUtils - Class in org.threadly.concurrent
-
Class for helping calculate the offset for scheduling tasks.
- SchedulingUtils() - Constructor for class org.threadly.concurrent.SchedulingUtils
-
- Service - Interface in org.threadly.util
-
A service is defined as something which is constructed in a stopped state (unless the
constructor starts the service automatically).
- set(int, T) - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
- setDefaultExceptionHandler(ExceptionHandler) - Static method in class org.threadly.util.ExceptionUtils
-
- setFailure(Throwable) - Method in class org.threadly.concurrent.future.SettableListenableFuture
-
Call to indicate this future is done, and provide the occurred failure.
- setFrontPadding(int) - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
This changes the configuration for the front padding amount for future modification
operations.
- setInheritableExceptionHandler(ExceptionHandler) - Static method in class org.threadly.util.ExceptionUtils
-
Sets the
ExceptionHandler
for this thread, and any threads that spawn off of this
thread.
- setLeft(L) - Method in class org.threadly.util.MutablePair
-
Update the left reference with the provided object.
- setMaxConcurrency(int) - Method in class org.threadly.concurrent.wrapper.limiter.ExecutorLimiter
-
Updates the concurrency limit for this wrapper.
- setMaxScheduleDelayMillis(long) - Method in class org.threadly.concurrent.wrapper.limiter.RateLimiterExecutor
-
At runtime adjust the maximum amount that this rate limiter will be willing to schedule out
tasks in order to maintain the rate.
- setMaxWaitForLowPriority(long) - Method in class org.threadly.concurrent.AbstractPriorityScheduler
-
Changes the max wait time for low priority tasks.
- setPermitsPerSecond(double) - Method in class org.threadly.concurrent.wrapper.limiter.RateLimiterExecutor
-
Sets the allowed permits per second.
- setPollInterval(int) - Method in class org.threadly.util.debug.Profiler
-
Change how long the profiler waits before getting additional thread stacks.
- setPoolSize(int) - Method in class org.threadly.concurrent.PriorityScheduler
-
Change the set thread pool size.
- setQueueLimit(int) - Method in class org.threadly.concurrent.wrapper.limiter.ExecutorQueueLimitRejector
-
Invoked to change the set limit.
- setQueueLimit(int) - Method in class org.threadly.concurrent.wrapper.limiter.SubmitterSchedulerQueueLimitRejector
-
Invoked to change the set limit.
- setRearPadding(int) - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
This changes the configuration for the rear padding amount for future modification operations.
- setResult(T) - Method in class org.threadly.concurrent.future.SettableListenableFuture
-
Call to indicate this future is done, and provide the given result.
- setRight(R) - Method in class org.threadly.util.MutablePair
-
Update the right reference with the provided object.
- setRunDelayInMillis(int) - Method in class org.threadly.test.concurrent.TestRunnable
-
Changes the amount of time the runnable will sleep/block when called.
- setRunningThread(Thread) - Method in class org.threadly.concurrent.future.SettableListenableFuture
-
Optional call to set the thread internally that will be generating the result for this
future.
- setScheduleDelay(long) - Method in class org.threadly.concurrent.ReschedulingOperation
-
Adjusts the delay at which this task is scheduled or rescheduled.
- SettableListenableFuture<T> - Class in org.threadly.concurrent.future
-
This class is designed to be a helper when returning a single result asynchronously.
- SettableListenableFuture() - Constructor for class org.threadly.concurrent.future.SettableListenableFuture
-
- SettableListenableFuture(boolean) - Constructor for class org.threadly.concurrent.future.SettableListenableFuture
-
- setThreadExceptionHandler(ExceptionHandler) - Static method in class org.threadly.util.ExceptionUtils
-
- shiftLocalHourToUTC(int) - Static method in class org.threadly.concurrent.SchedulingUtils
-
This will shift an hour from the local time zone to UTC.
- shutdown() - Method in class org.threadly.concurrent.PriorityScheduler
-
Stops any new tasks from being submitted to the pool.
- shutdown() - Method in class org.threadly.concurrent.SingleThreadScheduler
-
Stops any new tasks from being submitted to the pool.
- shutdown() - Method in class org.threadly.concurrent.UnfairExecutor
-
Stops any new tasks from being submitted to the pool.
- shutdown() - Method in class org.threadly.concurrent.wrapper.compatibility.PrioritySchedulerServiceWrapper
-
- shutdown() - Method in class org.threadly.concurrent.wrapper.compatibility.SingleThreadSchedulerServiceWrapper
-
- shutdownNow() - Method in class org.threadly.concurrent.PriorityScheduler
-
Stops any new tasks from being able to be executed and removes workers from the pool.
- shutdownNow() - Method in class org.threadly.concurrent.SingleThreadScheduler
-
Stops any new tasks from being submitted to the pool.
- shutdownNow() - Method in class org.threadly.concurrent.statistics.PrioritySchedulerStatisticTracker
-
- shutdownNow() - Method in class org.threadly.concurrent.statistics.SingleThreadSchedulerStatisticTracker
-
- shutdownNow() - Method in class org.threadly.concurrent.UnfairExecutor
-
Stops any new tasks from being submitted to the pool.
- shutdownNow() - Method in class org.threadly.concurrent.wrapper.compatibility.PrioritySchedulerServiceWrapper
-
This call will stop the processor as quick as possible.
- shutdownNow() - Method in class org.threadly.concurrent.wrapper.compatibility.SingleThreadSchedulerServiceWrapper
-
- signalComplete() - Method in class org.threadly.test.concurrent.AsyncVerifier
-
Call to indicate that this thread has finished, and should notify the waiting main test
thread that the test may be complete.
- signalToRun() - Method in class org.threadly.concurrent.ReschedulingOperation
-
Invoke to indicate that this operation has stuff to do.
- signalToRunImmediately(boolean) - Method in class org.threadly.concurrent.ReschedulingOperation
-
- singleThreadPool() - Static method in class org.threadly.concurrent.CentralThreadlyPool
-
Return a single threaded pool.
- singleThreadPool(String) - Static method in class org.threadly.concurrent.CentralThreadlyPool
-
Return a single threaded pool.
- singleThreadPool(boolean) - Static method in class org.threadly.concurrent.CentralThreadlyPool
-
Return a single threaded pool.
- singleThreadPool(boolean, String) - Static method in class org.threadly.concurrent.CentralThreadlyPool
-
Return a single threaded pool.
- SingleThreadScheduler - Class in org.threadly.concurrent
-
- SingleThreadScheduler() - Constructor for class org.threadly.concurrent.SingleThreadScheduler
-
- SingleThreadScheduler(TaskPriority, long) - Constructor for class org.threadly.concurrent.SingleThreadScheduler
-
- SingleThreadScheduler(boolean) - Constructor for class org.threadly.concurrent.SingleThreadScheduler
-
- SingleThreadScheduler(TaskPriority, long, boolean) - Constructor for class org.threadly.concurrent.SingleThreadScheduler
-
- SingleThreadScheduler(ThreadFactory) - Constructor for class org.threadly.concurrent.SingleThreadScheduler
-
- SingleThreadScheduler(TaskPriority, long, ThreadFactory) - Constructor for class org.threadly.concurrent.SingleThreadScheduler
-
- SingleThreadSchedulerServiceWrapper - Class in org.threadly.concurrent.wrapper.compatibility
-
This is a wrapper for
SingleThreadScheduler
to be a drop in replacement for any
ScheduledExecutorService
(AKA the
ScheduledThreadPoolExecutor
interface).
- SingleThreadSchedulerServiceWrapper(SingleThreadScheduler) - Constructor for class org.threadly.concurrent.wrapper.compatibility.SingleThreadSchedulerServiceWrapper
-
Constructs a new wrapper to adhere to the
ScheduledExecutorService
interface.
- SingleThreadSchedulerServiceWrapper(SingleThreadScheduler, TaskPriority) - Constructor for class org.threadly.concurrent.wrapper.compatibility.SingleThreadSchedulerServiceWrapper
-
Constructs a new wrapper to adhere to the
ScheduledExecutorService
interface.
- SingleThreadSchedulerStatisticTracker - Class in org.threadly.concurrent.statistics
-
- SingleThreadSchedulerStatisticTracker() - Constructor for class org.threadly.concurrent.statistics.SingleThreadSchedulerStatisticTracker
-
- SingleThreadSchedulerStatisticTracker(TaskPriority, long) - Constructor for class org.threadly.concurrent.statistics.SingleThreadSchedulerStatisticTracker
-
- SingleThreadSchedulerStatisticTracker(boolean) - Constructor for class org.threadly.concurrent.statistics.SingleThreadSchedulerStatisticTracker
-
- SingleThreadSchedulerStatisticTracker(TaskPriority, long, boolean) - Constructor for class org.threadly.concurrent.statistics.SingleThreadSchedulerStatisticTracker
-
- SingleThreadSchedulerStatisticTracker(ThreadFactory) - Constructor for class org.threadly.concurrent.statistics.SingleThreadSchedulerStatisticTracker
-
- SingleThreadSchedulerStatisticTracker(TaskPriority, long, ThreadFactory) - Constructor for class org.threadly.concurrent.statistics.SingleThreadSchedulerStatisticTracker
-
- SingleThreadSchedulerStatisticTracker(int) - Constructor for class org.threadly.concurrent.statistics.SingleThreadSchedulerStatisticTracker
-
- SingleThreadSchedulerStatisticTracker(TaskPriority, long, int) - Constructor for class org.threadly.concurrent.statistics.SingleThreadSchedulerStatisticTracker
-
- SingleThreadSchedulerStatisticTracker(boolean, int) - Constructor for class org.threadly.concurrent.statistics.SingleThreadSchedulerStatisticTracker
-
- SingleThreadSchedulerStatisticTracker(TaskPriority, long, boolean, int) - Constructor for class org.threadly.concurrent.statistics.SingleThreadSchedulerStatisticTracker
-
- SingleThreadSchedulerStatisticTracker(ThreadFactory, int) - Constructor for class org.threadly.concurrent.statistics.SingleThreadSchedulerStatisticTracker
-
- SingleThreadSchedulerStatisticTracker(TaskPriority, long, ThreadFactory, int) - Constructor for class org.threadly.concurrent.statistics.SingleThreadSchedulerStatisticTracker
-
- SingleThreadSchedulerStatisticTracker(int, boolean) - Constructor for class org.threadly.concurrent.statistics.SingleThreadSchedulerStatisticTracker
-
- SingleThreadSchedulerStatisticTracker(TaskPriority, long, int, boolean) - Constructor for class org.threadly.concurrent.statistics.SingleThreadSchedulerStatisticTracker
-
- SingleThreadSchedulerStatisticTracker(boolean, int, boolean) - Constructor for class org.threadly.concurrent.statistics.SingleThreadSchedulerStatisticTracker
-
- SingleThreadSchedulerStatisticTracker(TaskPriority, long, boolean, int, boolean) - Constructor for class org.threadly.concurrent.statistics.SingleThreadSchedulerStatisticTracker
-
- SingleThreadSchedulerStatisticTracker(ThreadFactory, int, boolean) - Constructor for class org.threadly.concurrent.statistics.SingleThreadSchedulerStatisticTracker
-
- SingleThreadSchedulerStatisticTracker(TaskPriority, long, ThreadFactory, int, boolean) - Constructor for class org.threadly.concurrent.statistics.SingleThreadSchedulerStatisticTracker
-
- SingleThreadSchedulerSubPool - Class in org.threadly.concurrent.wrapper.limiter
-
This sub-pool is a special time of limiter.
- SingleThreadSchedulerSubPool(SchedulerService) - Constructor for class org.threadly.concurrent.wrapper.limiter.SingleThreadSchedulerSubPool
-
Construct a new single threaded sub-pool.
- SingleThreadSchedulerSubPool(SchedulerService, TaskPriority, long) - Constructor for class org.threadly.concurrent.wrapper.limiter.SingleThreadSchedulerSubPool
-
Construct a new single threaded sub-pool with default task priority behaviors.
- size() - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
- sleep(long) - Static method in class org.threadly.test.concurrent.TestUtils
-
Since sleeps are sometimes necessary, this makes an easy way to ignore InterruptedException's.
- SortUtils - Class in org.threadly.util
-
A collection of utilities for searching and sorting against collections and other data
providers.
- SortUtils() - Constructor for class org.threadly.util.SortUtils
-
- split(Collection<? extends Pair<? extends L, ? extends R>>) - Static method in class org.threadly.util.Pair
-
Split a collection of pair's into a pair of two collections.
- stackToString(Throwable) - Static method in class org.threadly.util.ExceptionUtils
-
Convert throwable's stack and message into a simple string.
- stackToString(StackTraceElement[]) - Static method in class org.threadly.util.ExceptionUtils
-
Writes the stack trace array out to a string.
- start() - Method in class org.threadly.util.AbstractService
-
- start() - Method in class org.threadly.util.debug.Profiler
-
Starts the profiler running in a new thread.
- start(Executor) - Method in class org.threadly.util.debug.Profiler
-
Starts the profiler running in a new thread.
- start(long) - Method in class org.threadly.util.debug.Profiler
-
Starts the profiler running in a new thread.
- start(Executor, long) - Method in class org.threadly.util.debug.Profiler
-
Starts the profiler running in a new thread.
- start() - Method in interface org.threadly.util.Service
-
Starts the service, blocking until the service is running.
- startClockUpdateThread() - Static method in class org.threadly.util.Clock
-
Starts a thread to regularly updated the clock automatically.
- startIfNotStarted() - Method in class org.threadly.util.AbstractService
-
- startIfNotStarted() - Method in interface org.threadly.util.Service
-
Starts the service if it has not already been started.
- StatisticExecutor - Interface in org.threadly.concurrent.statistics
-
Interface for some basic statistic elements provided by any statistic executor/scheduler or any
executor/scheduler wrappers.
- StatisticPriorityScheduler - Interface in org.threadly.concurrent.statistics
-
An extension of
StatisticExecutor
, defining specific behavior when the statistic
tracker is implementing for a scheduler which has a concept of task priorities.
- StatisticsUtils - Class in org.threadly.util
-
Utilities for getting some basic statistics out of numerical data collections.
- StatisticsUtils() - Constructor for class org.threadly.util.StatisticsUtils
-
- stop() - Method in class org.threadly.util.AbstractService
-
- stop() - Method in class org.threadly.util.debug.Profiler
-
Stops the profiler from collecting more statistics.
- stop() - Method in interface org.threadly.util.Service
-
Stops the service, blocking until the service is shutdown.
- stopClockUpdateThread() - Static method in class org.threadly.util.Clock
-
Stops the clock from updating automatically.
- stopIfRunning() - Method in class org.threadly.util.AbstractService
-
- stopIfRunning() - Method in interface org.threadly.util.Service
-
Stops the service if it currently running.
- StringBufferWriter - Class in org.threadly.util
-
Class to wrap a StringBuffer
to implement the Writer
interface.
- StringBufferWriter(StringBuffer) - Constructor for class org.threadly.util.StringBufferWriter
-
Constructs a new writer with the provided StringBuffer
to write to.
- StringBuilderWriter - Class in org.threadly.util
-
Class to wrap a StringBuilder
to implement the Writer
interface.
- StringBuilderWriter(StringBuilder) - Constructor for class org.threadly.util.StringBuilderWriter
-
Constructs a new writer with the provided StringBuilder
to write to.
- StringUtils - Class in org.threadly.util
-
Some small utilities and constants around handling strings.
- StringUtils() - Constructor for class org.threadly.util.StringUtils
-
- StripedLock - Class in org.threadly.concurrent.lock
-
This structure allows for more controlled levels of parallelism.
- StripedLock(int) - Constructor for class org.threadly.concurrent.lock.StripedLock
-
Constructs a new
StripedLock
with a given expected concurrency level.
- subList(int, int) - Method in class org.threadly.concurrent.collections.ConcurrentArrayList
-
This returns a sub list from the current list.
- submit(Runnable, T, TaskPriority) - Method in class org.threadly.concurrent.AbstractPriorityScheduler
-
- submit(Callable<T>, TaskPriority) - Method in class org.threadly.concurrent.AbstractPriorityScheduler
-
- submit(Runnable, T) - Method in class org.threadly.concurrent.AbstractSubmitterExecutor
-
- submit(Callable<T>) - Method in class org.threadly.concurrent.AbstractSubmitterExecutor
-
- submit(Runnable, TaskPriority) - Method in interface org.threadly.concurrent.PrioritySchedulerService
-
Submit a task to run as soon as possible for the given priority.
- submit(Runnable, T, TaskPriority) - Method in interface org.threadly.concurrent.PrioritySchedulerService
-
Submit a task to run as soon as possible for the given priority.
- submit(Callable<T>, TaskPriority) - Method in interface org.threadly.concurrent.PrioritySchedulerService
-
Submit a Callable
to run as soon as possible for the given priority.
- submit(Runnable, T) - Method in class org.threadly.concurrent.SameThreadSubmitterExecutor
-
- submit(Callable<T>) - Method in class org.threadly.concurrent.SameThreadSubmitterExecutor
-
- submit(Runnable) - Method in interface org.threadly.concurrent.SubmitterExecutor
-
Submit a task to run as soon as possible.
- submit(Runnable, T) - Method in interface org.threadly.concurrent.SubmitterExecutor
-
Submit a task to run as soon as possible.
- submit(Callable<T>) - Method in interface org.threadly.concurrent.SubmitterExecutor
-
Submit a Callable
to run as soon as possible.
- submit(Runnable, T) - Method in class org.threadly.concurrent.wrapper.interceptor.ExecutorTaskInterceptor
-
- submit(Callable<T>) - Method in class org.threadly.concurrent.wrapper.interceptor.ExecutorTaskInterceptor
-
- submit(Runnable, T, TaskPriority) - Method in class org.threadly.concurrent.wrapper.interceptor.PrioritySchedulerTaskInterceptor
-
- submit(Callable<T>, TaskPriority) - Method in class org.threadly.concurrent.wrapper.interceptor.PrioritySchedulerTaskInterceptor
-
- submit(Object, Runnable) - Method in class org.threadly.concurrent.wrapper.KeyDistributedExecutor
-
Submit a task to be run with a given thread key.
- submit(Object, Runnable, T) - Method in class org.threadly.concurrent.wrapper.KeyDistributedExecutor
-
Submit a task to be run with a given thread key.
- submit(Object, Callable<T>) - Method in class org.threadly.concurrent.wrapper.KeyDistributedExecutor
-
Submit a callable to be run with a given thread key.
- submit(Runnable, T) - Method in class org.threadly.concurrent.wrapper.limiter.ExecutorLimiter
-
- submit(Callable<T>) - Method in class org.threadly.concurrent.wrapper.limiter.ExecutorLimiter
-
- submit(Object, Runnable) - Method in class org.threadly.concurrent.wrapper.limiter.KeyedRateLimiterExecutor
-
Submit a task to be run with a given thread key.
- submit(double, Object, Runnable) - Method in class org.threadly.concurrent.wrapper.limiter.KeyedRateLimiterExecutor
-
Submit a task to be run with a given thread key.
- submit(Object, Runnable, T) - Method in class org.threadly.concurrent.wrapper.limiter.KeyedRateLimiterExecutor
-
Submit a task to be run with a given thread key.
- submit(double, Object, Runnable, T) - Method in class org.threadly.concurrent.wrapper.limiter.KeyedRateLimiterExecutor
-
Submit a task to be run with a given thread key.
- submit(Object, Callable<T>) - Method in class org.threadly.concurrent.wrapper.limiter.KeyedRateLimiterExecutor
-
Submit a callable to be run with a given thread key.
- submit(double, Object, Callable<T>) - Method in class org.threadly.concurrent.wrapper.limiter.KeyedRateLimiterExecutor
-
Submit a callable to be run with a given thread key.
- submit(Runnable, TaskPriority) - Method in class org.threadly.concurrent.wrapper.limiter.PrioritySchedulerServiceQueueLimitRejector
-
- submit(Runnable, T, TaskPriority) - Method in class org.threadly.concurrent.wrapper.limiter.PrioritySchedulerServiceQueueLimitRejector
-
- submit(Callable<T>, TaskPriority) - Method in class org.threadly.concurrent.wrapper.limiter.PrioritySchedulerServiceQueueLimitRejector
-
- submit(double, Runnable) - Method in class org.threadly.concurrent.wrapper.limiter.RateLimiterExecutor
-
Exact same as the submit counter part, except you can specify how many permits this task will
require/use (instead of defaulting to 1).
- submit(double, Runnable, T) - Method in class org.threadly.concurrent.wrapper.limiter.RateLimiterExecutor
-
Exact same as the submit counter part, except you can specify how many permits this task will
require/use (instead of defaulting to 1).
- submit(double, Callable<T>) - Method in class org.threadly.concurrent.wrapper.limiter.RateLimiterExecutor
-
Exact same as the submit counter part, except you can specify how many permits this task will
require/use (instead of defaulting to 1).
- submit(Runnable) - Method in class org.threadly.concurrent.wrapper.PrioritySchedulerDefaultPriorityWrapper
-
- submit(Runnable, T) - Method in class org.threadly.concurrent.wrapper.PrioritySchedulerDefaultPriorityWrapper
-
- submit(Runnable, TaskPriority) - Method in class org.threadly.concurrent.wrapper.PrioritySchedulerDefaultPriorityWrapper
-
- submit(Runnable, T, TaskPriority) - Method in class org.threadly.concurrent.wrapper.PrioritySchedulerDefaultPriorityWrapper
-
- submit(Callable<T>) - Method in class org.threadly.concurrent.wrapper.PrioritySchedulerDefaultPriorityWrapper
-
- submit(Callable<T>, TaskPriority) - Method in class org.threadly.concurrent.wrapper.PrioritySchedulerDefaultPriorityWrapper
-
- submit(Runnable, T, TaskPriority) - Method in class org.threadly.concurrent.wrapper.traceability.ThreadRenamingPriorityScheduler
-
- submit(Callable<T>, TaskPriority) - Method in class org.threadly.concurrent.wrapper.traceability.ThreadRenamingPriorityScheduler
-
- submitScheduled(Runnable, T, long, TaskPriority) - Method in class org.threadly.concurrent.AbstractPriorityScheduler
-
- submitScheduled(Callable<T>, long, TaskPriority) - Method in class org.threadly.concurrent.AbstractPriorityScheduler
-
- submitScheduled(Runnable, T, long) - Method in class org.threadly.concurrent.AbstractSubmitterScheduler
-
- submitScheduled(Callable<T>, long) - Method in class org.threadly.concurrent.AbstractSubmitterScheduler
-
- submitScheduled(Runnable, long, TaskPriority) - Method in interface org.threadly.concurrent.PrioritySchedulerService
-
Schedule a task with a given delay and a specified priority.
- submitScheduled(Runnable, T, long, TaskPriority) - Method in interface org.threadly.concurrent.PrioritySchedulerService
-
Schedule a task with a given delay and a specified priority.
- submitScheduled(Callable<T>, long, TaskPriority) - Method in interface org.threadly.concurrent.PrioritySchedulerService
-
Schedule a Callable
with a given delay.
- submitScheduled(Runnable, long) - Method in interface org.threadly.concurrent.SubmitterScheduler
-
Schedule a task with a given delay.
- submitScheduled(Runnable, T, long) - Method in interface org.threadly.concurrent.SubmitterScheduler
-
Schedule a task with a given delay.
- submitScheduled(Callable<T>, long) - Method in interface org.threadly.concurrent.SubmitterScheduler
-
Schedule a Callable
with a given delay.
- submitScheduled(Runnable, T, long, TaskPriority) - Method in class org.threadly.concurrent.wrapper.interceptor.PrioritySchedulerTaskInterceptor
-
- submitScheduled(Callable<T>, long, TaskPriority) - Method in class org.threadly.concurrent.wrapper.interceptor.PrioritySchedulerTaskInterceptor
-
- submitScheduled(Runnable, T, long) - Method in class org.threadly.concurrent.wrapper.interceptor.SubmitterSchedulerTaskInterceptor
-
- submitScheduled(Callable<T>, long) - Method in class org.threadly.concurrent.wrapper.interceptor.SubmitterSchedulerTaskInterceptor
-
- submitScheduled(Object, Runnable, long) - Method in class org.threadly.concurrent.wrapper.KeyDistributedScheduler
-
Schedule a task with a given delay.
- submitScheduled(Object, Runnable, T, long) - Method in class org.threadly.concurrent.wrapper.KeyDistributedScheduler
-
Schedule a task with a given delay.
- submitScheduled(Object, Callable<T>, long) - Method in class org.threadly.concurrent.wrapper.KeyDistributedScheduler
-
Schedule a Callable
with a given delay.
- submitScheduled(Runnable, long, TaskPriority) - Method in class org.threadly.concurrent.wrapper.limiter.PrioritySchedulerServiceQueueLimitRejector
-
- submitScheduled(Runnable, T, long, TaskPriority) - Method in class org.threadly.concurrent.wrapper.limiter.PrioritySchedulerServiceQueueLimitRejector
-
- submitScheduled(Callable<T>, long, TaskPriority) - Method in class org.threadly.concurrent.wrapper.limiter.PrioritySchedulerServiceQueueLimitRejector
-
- submitScheduled(Runnable, long) - Method in class org.threadly.concurrent.wrapper.limiter.SubmitterSchedulerLimiter
-
- submitScheduled(Runnable, T, long) - Method in class org.threadly.concurrent.wrapper.limiter.SubmitterSchedulerLimiter
-
- submitScheduled(Callable<T>, long) - Method in class org.threadly.concurrent.wrapper.limiter.SubmitterSchedulerLimiter
-
- submitScheduled(Runnable, long) - Method in class org.threadly.concurrent.wrapper.PrioritySchedulerDefaultPriorityWrapper
-
- submitScheduled(Runnable, T, long) - Method in class org.threadly.concurrent.wrapper.PrioritySchedulerDefaultPriorityWrapper
-
- submitScheduled(Runnable, long, TaskPriority) - Method in class org.threadly.concurrent.wrapper.PrioritySchedulerDefaultPriorityWrapper
-
- submitScheduled(Runnable, T, long, TaskPriority) - Method in class org.threadly.concurrent.wrapper.PrioritySchedulerDefaultPriorityWrapper
-
- submitScheduled(Callable<T>, long) - Method in class org.threadly.concurrent.wrapper.PrioritySchedulerDefaultPriorityWrapper
-
- submitScheduled(Callable<T>, long, TaskPriority) - Method in class org.threadly.concurrent.wrapper.PrioritySchedulerDefaultPriorityWrapper
-
- submitScheduled(Runnable, T, long, TaskPriority) - Method in class org.threadly.concurrent.wrapper.traceability.ThreadRenamingPriorityScheduler
-
- submitScheduled(Callable<T>, long, TaskPriority) - Method in class org.threadly.concurrent.wrapper.traceability.ThreadRenamingPriorityScheduler
-
- SubmitterExecutor - Interface in org.threadly.concurrent
-
A thread pool for executing tasks with provided futures.
- SubmitterExecutorAdapter - Class in org.threadly.concurrent.wrapper
-
A simple wrapper class for
Executor
implementations to provide
SubmitterExecutor
capabilities.
- SubmitterExecutorAdapter(Executor) - Constructor for class org.threadly.concurrent.wrapper.SubmitterExecutorAdapter
-
Constructors a new wrapper instance with the provided executor to defer calls to.
- SubmitterScheduler - Interface in org.threadly.concurrent
-
A thread pool for scheduling tasks with provided futures.
- SubmitterSchedulerLimiter - Class in org.threadly.concurrent.wrapper.limiter
-
This class is designed to limit how much parallel execution happens on a provided
SubmitterScheduler
.
- SubmitterSchedulerLimiter(SubmitterScheduler, int) - Constructor for class org.threadly.concurrent.wrapper.limiter.SubmitterSchedulerLimiter
-
- SubmitterSchedulerLimiter(SubmitterScheduler, int, boolean) - Constructor for class org.threadly.concurrent.wrapper.limiter.SubmitterSchedulerLimiter
-
- SubmitterSchedulerQueueLimitRejector - Class in org.threadly.concurrent.wrapper.limiter
-
- SubmitterSchedulerQueueLimitRejector(SubmitterScheduler, int) - Constructor for class org.threadly.concurrent.wrapper.limiter.SubmitterSchedulerQueueLimitRejector
-
- SubmitterSchedulerQueueLimitRejector(SubmitterScheduler, int, RejectedExecutionHandler) - Constructor for class org.threadly.concurrent.wrapper.limiter.SubmitterSchedulerQueueLimitRejector
-
- SubmitterSchedulerTaskInterceptor - Class in org.threadly.concurrent.wrapper.interceptor
-
Class to wrap
SubmitterScheduler
pool so that tasks can be intercepted and either
wrapped, or modified, before being submitted to the pool.
- SubmitterSchedulerTaskInterceptor(SubmitterScheduler, BiFunction<Runnable, Boolean, Runnable>) - Constructor for class org.threadly.concurrent.wrapper.interceptor.SubmitterSchedulerTaskInterceptor
-
Constructs a wrapper for
SubmitterScheduler
pool so that tasks can be intercepted
and modified, before being submitted to the pool.
- subSequence(int, int) - Method in class org.threadly.util.StringBufferWriter
-
- subSequence(int, int) - Method in class org.threadly.util.StringBuilderWriter
-
- SuppressedStackRuntimeException - Exception in org.threadly.util
-
Type of RuntimeException
which does not generate a stack at it's point of creation.
- SuppressedStackRuntimeException() - Constructor for exception org.threadly.util.SuppressedStackRuntimeException
-
Construct a new exception with no message or cause.
- SuppressedStackRuntimeException(String) - Constructor for exception org.threadly.util.SuppressedStackRuntimeException
-
Construct a new exception with a provided message and no cause.
- SuppressedStackRuntimeException(Throwable) - Constructor for exception org.threadly.util.SuppressedStackRuntimeException
-
Construct a new exception with a provided cause.
- SuppressedStackRuntimeException(String, Throwable) - Constructor for exception org.threadly.util.SuppressedStackRuntimeException
-
Construct a new exception providing both a unique message and cause.