Skip navigation links

com.diffplug.durian:durian-concurrent:1.2.0 by DiffPlug

A B C D E F G H I J L M N O P R S T U V W 

A

AbstractCheckedFuture<V,X extends Exception> - Class in com.diffplug.common.util.concurrent
A delegating wrapper around a ListenableFuture that adds support for the AbstractCheckedFuture.checkedGet() and AbstractCheckedFuture.checkedGet(long, TimeUnit) methods.
AbstractCheckedFuture(ListenableFuture<V>) - Constructor for class com.diffplug.common.util.concurrent.AbstractCheckedFuture
Constructs an AbstractCheckedFuture that wraps a delegate.
AbstractExecutionThreadService - Class in com.diffplug.common.util.concurrent
AbstractExecutionThreadService() - Constructor for class com.diffplug.common.util.concurrent.AbstractExecutionThreadService
Constructor for use by subclasses.
AbstractFuture<V> - Class in com.diffplug.common.util.concurrent
An abstract implementation of ListenableFuture, intended for advanced users only.
AbstractFuture() - Constructor for class com.diffplug.common.util.concurrent.AbstractFuture
Constructor for use by subclasses.
AbstractIdleService - Class in com.diffplug.common.util.concurrent
Base class for services that do not need a thread while “running” but may need one during startup and shutdown.
AbstractIdleService() - Constructor for class com.diffplug.common.util.concurrent.AbstractIdleService
Constructor for use by subclasses.
AbstractListeningExecutorService - Class in com.diffplug.common.util.concurrent
Abstract ListeningExecutorService implementation that creates ListenableFuture instances for each Runnable and Callable submitted to it.
AbstractListeningExecutorService() - Constructor for class com.diffplug.common.util.concurrent.AbstractListeningExecutorService
 
AbstractScheduledService - Class in com.diffplug.common.util.concurrent
Base class for services that can implement AbstractScheduledService.startUp() and AbstractScheduledService.shutDown() but while in the “running” state need to perform a periodic task.
AbstractScheduledService() - Constructor for class com.diffplug.common.util.concurrent.AbstractScheduledService
Constructor for use by subclasses.
AbstractScheduledService.CustomScheduler - Class in com.diffplug.common.util.concurrent
A AbstractScheduledService.Scheduler that provides a convenient way for the AbstractScheduledService to use a dynamically changing schedule.
AbstractScheduledService.CustomScheduler.Schedule - Class in com.diffplug.common.util.concurrent
A value object that represents an absolute delay until a task should be invoked.
AbstractScheduledService.Scheduler - Class in com.diffplug.common.util.concurrent
A scheduler defines the policy for how the AbstractScheduledService should run its task.
AbstractService - Class in com.diffplug.common.util.concurrent
Base class for implementing services that can handle AbstractService.doStart() and AbstractService.doStop() requests, responding to them with AbstractService.notifyStarted() and AbstractService.notifyStopped() callbacks.
AbstractService() - Constructor for class com.diffplug.common.util.concurrent.AbstractService
Constructor for use by subclasses.
acquire() - Method in class com.diffplug.common.util.concurrent.RateLimiter
Acquires a single permit from this RateLimiter, blocking until the request can be granted.
acquire(int) - Method in class com.diffplug.common.util.concurrent.RateLimiter
Acquires the given number of permits from this RateLimiter, blocking until the request can be granted.
add(Runnable, Executor) - Method in class com.diffplug.common.util.concurrent.ExecutionList
Adds the Runnable and accompanying Executor to the list of listeners to execute.
addAndGet(double) - Method in class com.diffplug.common.util.concurrent.AtomicDouble
Atomically adds the given value to the current value.
addAndGet(int, double) - Method in class com.diffplug.common.util.concurrent.AtomicDoubleArray
Atomically adds the given value to the element at index i.
addAndGet(K, long) - Method in class com.diffplug.common.util.concurrent.AtomicLongMap
Adds delta to the value currently associated with key, and returns the new value.
addCallback(ListenableFuture<V>, FutureCallback<? super V>) - Static method in class com.diffplug.common.util.concurrent.Futures
Registers separate success and failure callbacks to be run when the Future’s computation is complete or, if the computation is already complete, immediately.
addCallback(ListenableFuture<V>, FutureCallback<? super V>, Executor) - Static method in class com.diffplug.common.util.concurrent.Futures
Registers separate success and failure callbacks to be run when the Future’s computation is complete or, if the computation is already complete, immediately.
addDelayedShutdownHook(ExecutorService, long, TimeUnit) - Static method in class com.diffplug.common.util.concurrent.MoreExecutors
Add a shutdown hook to wait for thread completion in the given service.
addListener(Service.Listener, Executor) - Method in class com.diffplug.common.util.concurrent.AbstractExecutionThreadService
 
addListener(Runnable, Executor) - Method in class com.diffplug.common.util.concurrent.AbstractFuture
Registers a listener to be run on the given executor.
addListener(Service.Listener, Executor) - Method in class com.diffplug.common.util.concurrent.AbstractIdleService
 
addListener(Service.Listener, Executor) - Method in class com.diffplug.common.util.concurrent.AbstractScheduledService
 
addListener(Service.Listener, Executor) - Method in class com.diffplug.common.util.concurrent.AbstractService
 
addListener(Runnable, Executor) - Method in class com.diffplug.common.util.concurrent.ForwardingListenableFuture
 
addListener(Runnable, Executor) - Method in interface com.diffplug.common.util.concurrent.ListenableFuture
Registers a listener to be run on the given executor.
addListener(Runnable, Executor) - Method in class com.diffplug.common.util.concurrent.ListenableFutureTask
 
addListener(Service.Listener, Executor) - Method in interface com.diffplug.common.util.concurrent.Service
Registers a Service.Listener to be executed on the given executor.
addListener(ServiceManager.Listener, Executor) - Method in class com.diffplug.common.util.concurrent.ServiceManager
Registers a ServiceManager.Listener to be executed on the given executor.
addListener(ServiceManager.Listener) - Method in class com.diffplug.common.util.concurrent.ServiceManager
Registers a ServiceManager.Listener to be run when this ServiceManager changes state.
allAsList(ListenableFuture<? extends V>...) - Static method in class com.diffplug.common.util.concurrent.Futures
Creates a new ListenableFuture whose value is a list containing the values of all its input futures, if all succeed.
allAsList(Iterable<? extends ListenableFuture<? extends V>>) - Static method in class com.diffplug.common.util.concurrent.Futures
Creates a new ListenableFuture whose value is a list containing the values of all its input futures, if all succeed.
apply(I) - Method in interface com.diffplug.common.util.concurrent.AsyncFunction
Returns an output Future to use in place of the given input.
asMap() - Method in class com.diffplug.common.util.concurrent.AtomicLongMap
Returns a live, read-only view of the map backing this AtomicLongMap.
AsyncFunction<I,O> - Interface in com.diffplug.common.util.concurrent
Transforms a value, possibly asynchronously.
AtomicDouble - Class in com.diffplug.common.util.concurrent
A double value that may be updated atomically.
AtomicDouble(double) - Constructor for class com.diffplug.common.util.concurrent.AtomicDouble
Creates a new AtomicDouble with the given initial value.
AtomicDouble() - Constructor for class com.diffplug.common.util.concurrent.AtomicDouble
Creates a new AtomicDouble with initial value 0.0.
AtomicDoubleArray - Class in com.diffplug.common.util.concurrent
A double array in which elements may be updated atomically.
AtomicDoubleArray(int) - Constructor for class com.diffplug.common.util.concurrent.AtomicDoubleArray
Creates a new AtomicDoubleArray of the given length, with all elements initially zero.
AtomicDoubleArray(double[]) - Constructor for class com.diffplug.common.util.concurrent.AtomicDoubleArray
Creates a new AtomicDoubleArray with the same length as, and all elements copied from, the given array.
AtomicLongMap<K> - Class in com.diffplug.common.util.concurrent
A map containing long values that can be atomically updated.
Atomics - Class in com.diffplug.common.util.concurrent
Static utility methods pertaining to classes in the java.util.concurrent.atomic package.
awaitHealthy() - Method in class com.diffplug.common.util.concurrent.ServiceManager
Waits for the ServiceManager to become healthy.
awaitHealthy(long, TimeUnit) - Method in class com.diffplug.common.util.concurrent.ServiceManager
Waits for the ServiceManager to become healthy for no more than the given time.
awaitRunning() - Method in class com.diffplug.common.util.concurrent.AbstractExecutionThreadService
 
awaitRunning(long, TimeUnit) - Method in class com.diffplug.common.util.concurrent.AbstractExecutionThreadService
 
awaitRunning() - Method in class com.diffplug.common.util.concurrent.AbstractIdleService
 
awaitRunning(long, TimeUnit) - Method in class com.diffplug.common.util.concurrent.AbstractIdleService
 
awaitRunning() - Method in class com.diffplug.common.util.concurrent.AbstractScheduledService
 
awaitRunning(long, TimeUnit) - Method in class com.diffplug.common.util.concurrent.AbstractScheduledService
 
awaitRunning() - Method in class com.diffplug.common.util.concurrent.AbstractService
 
awaitRunning(long, TimeUnit) - Method in class com.diffplug.common.util.concurrent.AbstractService
 
awaitRunning() - Method in interface com.diffplug.common.util.concurrent.Service
Waits for the Service to reach the running state.
awaitRunning(long, TimeUnit) - Method in interface com.diffplug.common.util.concurrent.Service
Waits for the Service to reach the running state for no more than the given time.
awaitStopped() - Method in class com.diffplug.common.util.concurrent.ServiceManager
Waits for the all the services to reach a terminal state.
awaitStopped(long, TimeUnit) - Method in class com.diffplug.common.util.concurrent.ServiceManager
Waits for the all the services to reach a terminal state for no more than the given time.
awaitTerminated() - Method in class com.diffplug.common.util.concurrent.AbstractExecutionThreadService
 
awaitTerminated(long, TimeUnit) - Method in class com.diffplug.common.util.concurrent.AbstractExecutionThreadService
 
awaitTerminated() - Method in class com.diffplug.common.util.concurrent.AbstractIdleService
 
awaitTerminated(long, TimeUnit) - Method in class com.diffplug.common.util.concurrent.AbstractIdleService
 
awaitTerminated() - Method in class com.diffplug.common.util.concurrent.AbstractScheduledService
 
awaitTerminated(long, TimeUnit) - Method in class com.diffplug.common.util.concurrent.AbstractScheduledService
 
awaitTerminated() - Method in class com.diffplug.common.util.concurrent.AbstractService
 
awaitTerminated(long, TimeUnit) - Method in class com.diffplug.common.util.concurrent.AbstractService
 
awaitTerminated() - Method in interface com.diffplug.common.util.concurrent.Service
Waits for the Service to reach the terminated state.
awaitTerminated(long, TimeUnit) - Method in interface com.diffplug.common.util.concurrent.Service
Waits for the Service to reach a terminal state (either terminated or failed) for no more than the given time.
awaitTermination(long, TimeUnit) - Method in class com.diffplug.common.util.concurrent.ForwardingExecutorService
 
awaitUninterruptibly(CountDownLatch) - Static method in class com.diffplug.common.util.concurrent.Uninterruptibles
Invokes latch.await() uninterruptibly.
awaitUninterruptibly(CountDownLatch, long, TimeUnit) - Static method in class com.diffplug.common.util.concurrent.Uninterruptibles
Invokes latch.await(timeout, unit) uninterruptibly.

B

build() - Method in class com.diffplug.common.util.concurrent.ThreadFactoryBuilder
Returns a new thread factory using the options supplied during the building process.
bulkGet(Iterable<?>) - Method in class com.diffplug.common.util.concurrent.Striped
Returns the stripes that correspond to the passed objects, in ascending (as per Striped.getAt(int)) order.

C

Callables - Class in com.diffplug.common.util.concurrent
Static utility methods pertaining to the Callable interface.
callWithTimeout(Callable<T>, long, TimeUnit, boolean) - Method in class com.diffplug.common.util.concurrent.FakeTimeLimiter
 
callWithTimeout(Callable<T>, long, TimeUnit, boolean) - Method in class com.diffplug.common.util.concurrent.SimpleTimeLimiter
 
callWithTimeout(Callable<T>, long, TimeUnit, boolean) - Method in interface com.diffplug.common.util.concurrent.TimeLimiter
Invokes a specified Callable, timing out after the specified time limit.
cancel(boolean) - Method in class com.diffplug.common.util.concurrent.AbstractFuture
cancel(boolean) - Method in class com.diffplug.common.util.concurrent.ForwardingFuture
 
catching(ListenableFuture<? extends V>, Class<X>, Function<? super X, ? extends V>) - Static method in class com.diffplug.common.util.concurrent.Futures
Returns a Future whose result is taken from the given primary input or, if the primary input fails with the given exceptionType, from the result provided by the fallback.
catching(ListenableFuture<? extends V>, Class<X>, Function<? super X, ? extends V>, Executor) - Static method in class com.diffplug.common.util.concurrent.Futures
Returns a Future whose result is taken from the given primary input or, if the primary input fails with the given exceptionType, from the result provided by the fallback.
catchingAsync(ListenableFuture<? extends V>, Class<X>, AsyncFunction<? super X, ? extends V>) - Static method in class com.diffplug.common.util.concurrent.Futures
Returns a Future whose result is taken from the given primary input or, if the primary input fails with the given exceptionType, from the result provided by the fallback.
catchingAsync(ListenableFuture<? extends V>, Class<X>, AsyncFunction<? super X, ? extends V>, Executor) - Static method in class com.diffplug.common.util.concurrent.Futures
Returns a Future whose result is taken from the given primary input or, if the primary input fails with the given exceptionType, from the result provided by the fallback.
CheckedFuture<V,X extends Exception> - Interface in com.diffplug.common.util.concurrent
A CheckedFuture is a ListenableFuture that includes versions of the get methods that can throw a checked exception.
checkedGet() - Method in class com.diffplug.common.util.concurrent.AbstractCheckedFuture
Exception checking version of Future.get() that will translate InterruptedException, CancellationException and ExecutionException into application-specific exceptions.
checkedGet(long, TimeUnit) - Method in class com.diffplug.common.util.concurrent.AbstractCheckedFuture
Exception checking version of Future.get(long, TimeUnit) that will translate InterruptedException, CancellationException and ExecutionException into application-specific exceptions.
checkedGet() - Method in interface com.diffplug.common.util.concurrent.CheckedFuture
Exception checking version of Future.get() that will translate InterruptedException, CancellationException and ExecutionException into application-specific exceptions.
checkedGet(long, TimeUnit) - Method in interface com.diffplug.common.util.concurrent.CheckedFuture
Exception checking version of Future.get(long, TimeUnit) that will translate InterruptedException, CancellationException and ExecutionException into application-specific exceptions.
checkedGet() - Method in class com.diffplug.common.util.concurrent.ForwardingCheckedFuture
 
checkedGet(long, TimeUnit) - Method in class com.diffplug.common.util.concurrent.ForwardingCheckedFuture
 
clear() - Method in class com.diffplug.common.util.concurrent.AtomicLongMap
Removes all of the mappings from this map.
com.diffplug.common.util.concurrent - package com.diffplug.common.util.concurrent
Concurrency utilities.
compareAndSet(double, double) - Method in class com.diffplug.common.util.concurrent.AtomicDouble
Atomically sets the value to the given updated value if the current value is bitwise equal to the expected value.
compareAndSet(int, double, double) - Method in class com.diffplug.common.util.concurrent.AtomicDoubleArray
Atomically sets the element at position i to the given updated value if the current value is bitwise equal to the expected value.
containsKey(Object) - Method in class com.diffplug.common.util.concurrent.AtomicLongMap
Returns true if this map contains a mapping for the specified key.
create() - Static method in class com.diffplug.common.util.concurrent.AtomicLongMap
Creates an AtomicLongMap.
create(Map<? extends K, ? extends Long>) - Static method in class com.diffplug.common.util.concurrent.AtomicLongMap
Creates an AtomicLongMap with the same mappings as the specified Map.
create(Callable<V>) - Static method in class com.diffplug.common.util.concurrent.ListenableFutureTask
Creates a ListenableFutureTask that will upon running, execute the given Callable.
create(Runnable, V) - Static method in class com.diffplug.common.util.concurrent.ListenableFutureTask
Creates a ListenableFutureTask that will upon running, execute the given Runnable, and arrange that get will return the given result on successful completion.
create(double) - Static method in class com.diffplug.common.util.concurrent.RateLimiter
Creates a RateLimiter with the specified stable throughput, given as “permits per second” (commonly referred to as QPS, queries per second).
create(double, long, TimeUnit) - Static method in class com.diffplug.common.util.concurrent.RateLimiter
Creates a RateLimiter with the specified stable throughput, given as “permits per second” (commonly referred to as QPS, queries per second), and a warmup period, during which the RateLimiter smoothly ramps up its rate, until it reaches its maximum rate at the end of the period (as long as there are enough requests to saturate it).
create() - Static method in class com.diffplug.common.util.concurrent.SettableFuture
Creates a new SettableFuture in the default state.
CustomScheduler() - Constructor for class com.diffplug.common.util.concurrent.AbstractScheduledService.CustomScheduler
 
CycleDetectingLockFactory - Class in com.diffplug.common.util.concurrent
The CycleDetectingLockFactory creates ReentrantLock instances and ReentrantReadWriteLock instances that detect potential deadlock by checking for cycles in lock acquisition order.
CycleDetectingLockFactory.Policies - Enum in com.diffplug.common.util.concurrent
Pre-defined CycleDetectingLockFactory.Policy implementations.
CycleDetectingLockFactory.Policy - Interface in com.diffplug.common.util.concurrent
Encapsulates the action to be taken when a potential deadlock is encountered.
CycleDetectingLockFactory.PotentialDeadlockException - Exception in com.diffplug.common.util.concurrent
Represents a detected cycle in lock acquisition ordering.
CycleDetectingLockFactory.WithExplicitOrdering<E extends Enum<E>> - Class in com.diffplug.common.util.concurrent

D

decrementAndGet(K) - Method in class com.diffplug.common.util.concurrent.AtomicLongMap
Decrements by one the value currently associated with key, and returns the new value.
delegate() - Method in class com.diffplug.common.util.concurrent.ForwardingBlockingQueue
 
delegate() - Method in class com.diffplug.common.util.concurrent.ForwardingCheckedFuture
 
delegate() - Method in class com.diffplug.common.util.concurrent.ForwardingCheckedFuture.SimpleForwardingCheckedFuture
 
delegate() - Method in class com.diffplug.common.util.concurrent.ForwardingExecutorService
 
delegate() - Method in class com.diffplug.common.util.concurrent.ForwardingFuture
 
delegate() - Method in class com.diffplug.common.util.concurrent.ForwardingFuture.SimpleForwardingFuture
 
delegate() - Method in class com.diffplug.common.util.concurrent.ForwardingListenableFuture
 
delegate() - Method in class com.diffplug.common.util.concurrent.ForwardingListenableFuture.SimpleForwardingListenableFuture
 
delegate() - Method in class com.diffplug.common.util.concurrent.ForwardingListeningExecutorService
 
dereference(ListenableFuture<? extends ListenableFuture<? extends V>>) - Static method in class com.diffplug.common.util.concurrent.Futures
Returns a new ListenableFuture whose result is the product of calling get() on the Future nested within the given Future, effectively chaining the futures one after the other.
directExecutor() - Static method in class com.diffplug.common.util.concurrent.MoreExecutors
Returns an Executor that runs each task in the thread that invokes execute, as in ThreadPoolExecutor.CallerRunsPolicy.
done() - Method in class com.diffplug.common.util.concurrent.ListenableFutureTask
Internal implementation detail used to invoke the listeners.
doNothing() - Static method in class com.diffplug.common.util.concurrent.Runnables
Returns a Runnable instance that does nothing when run.
doStart() - Method in class com.diffplug.common.util.concurrent.AbstractService
This method is called by AbstractService.startAsync() to initiate service startup.
doStop() - Method in class com.diffplug.common.util.concurrent.AbstractService
This method should be used to initiate service shutdown.
doubleValue() - Method in class com.diffplug.common.util.concurrent.AtomicDouble
Returns the value of this AtomicDouble as a double.
drainTo(Collection<? super E>, int) - Method in class com.diffplug.common.util.concurrent.ForwardingBlockingQueue
 
drainTo(Collection<? super E>) - Method in class com.diffplug.common.util.concurrent.ForwardingBlockingQueue
 

E

enter() - Method in class com.diffplug.common.util.concurrent.Monitor
Enters this monitor.
enter(long, TimeUnit) - Method in class com.diffplug.common.util.concurrent.Monitor
Enters this monitor.
enterIf(Monitor.Guard) - Method in class com.diffplug.common.util.concurrent.Monitor
Enters this monitor if the guard is satisfied.
enterIf(Monitor.Guard, long, TimeUnit) - Method in class com.diffplug.common.util.concurrent.Monitor
Enters this monitor if the guard is satisfied.
enterIfInterruptibly(Monitor.Guard) - Method in class com.diffplug.common.util.concurrent.Monitor
Enters this monitor if the guard is satisfied.
enterIfInterruptibly(Monitor.Guard, long, TimeUnit) - Method in class com.diffplug.common.util.concurrent.Monitor
Enters this monitor if the guard is satisfied.
enterInterruptibly() - Method in class com.diffplug.common.util.concurrent.Monitor
Enters this monitor.
enterInterruptibly(long, TimeUnit) - Method in class com.diffplug.common.util.concurrent.Monitor
Enters this monitor.
enterWhen(Monitor.Guard) - Method in class com.diffplug.common.util.concurrent.Monitor
Enters this monitor when the guard is satisfied.
enterWhen(Monitor.Guard, long, TimeUnit) - Method in class com.diffplug.common.util.concurrent.Monitor
Enters this monitor when the guard is satisfied.
enterWhenUninterruptibly(Monitor.Guard) - Method in class com.diffplug.common.util.concurrent.Monitor
Enters this monitor when the guard is satisfied.
enterWhenUninterruptibly(Monitor.Guard, long, TimeUnit) - Method in class com.diffplug.common.util.concurrent.Monitor
Enters this monitor when the guard is satisfied.
execute() - Method in class com.diffplug.common.util.concurrent.ExecutionList
Runs this execution list, executing all existing pairs in the order they were added.
execute(Runnable) - Method in class com.diffplug.common.util.concurrent.ForwardingExecutorService
 
ExecutionError - Error in com.diffplug.common.util.concurrent
ExecutionError() - Constructor for error com.diffplug.common.util.concurrent.ExecutionError
Creates a new instance with null as its detail message.
ExecutionError(String) - Constructor for error com.diffplug.common.util.concurrent.ExecutionError
Creates a new instance with the given detail message.
ExecutionError(String, Error) - Constructor for error com.diffplug.common.util.concurrent.ExecutionError
Creates a new instance with the given detail message and cause.
ExecutionError(Error) - Constructor for error com.diffplug.common.util.concurrent.ExecutionError
Creates a new instance with the given cause.
ExecutionList - Class in com.diffplug.common.util.concurrent
A support class for ListenableFuture implementations to manage their listeners.
ExecutionList() - Constructor for class com.diffplug.common.util.concurrent.ExecutionList
Creates a new, empty ExecutionList.
executor() - Method in class com.diffplug.common.util.concurrent.AbstractExecutionThreadService
Returns the Executor that will be used to run this service.
executor() - Method in class com.diffplug.common.util.concurrent.AbstractIdleService
Returns the Executor that will be used to run this service.
executor() - Method in class com.diffplug.common.util.concurrent.AbstractScheduledService

F

failed(Service.State, Throwable) - Method in class com.diffplug.common.util.concurrent.Service.Listener
Called when the service transitions to the FAILED state.
failure(Service) - Method in class com.diffplug.common.util.concurrent.ServiceManager.Listener
Called when a component service has failed.
failureCause() - Method in class com.diffplug.common.util.concurrent.AbstractExecutionThreadService
 
failureCause() - Method in class com.diffplug.common.util.concurrent.AbstractIdleService
 
failureCause() - Method in class com.diffplug.common.util.concurrent.AbstractScheduledService
 
failureCause() - Method in class com.diffplug.common.util.concurrent.AbstractService
 
failureCause() - Method in interface com.diffplug.common.util.concurrent.Service
Returns the Throwable that caused this service to fail.
FakeTimeLimiter - Class in com.diffplug.common.util.concurrent
A TimeLimiter implementation which actually does not attempt to limit time at all.
FakeTimeLimiter() - Constructor for class com.diffplug.common.util.concurrent.FakeTimeLimiter
 
floatValue() - Method in class com.diffplug.common.util.concurrent.AtomicDouble
Returns the value of this AtomicDouble as a float after a narrowing primitive conversion.
ForwardingBlockingQueue<E> - Class in com.diffplug.common.util.concurrent
A BlockingQueue which forwards all its method calls to another BlockingQueue.
ForwardingBlockingQueue() - Constructor for class com.diffplug.common.util.concurrent.ForwardingBlockingQueue
Constructor for use by subclasses.
ForwardingCheckedFuture<V,X extends Exception> - Class in com.diffplug.common.util.concurrent
A future which forwards all its method calls to another future.
ForwardingCheckedFuture() - Constructor for class com.diffplug.common.util.concurrent.ForwardingCheckedFuture
 
ForwardingCheckedFuture.SimpleForwardingCheckedFuture<V,X extends Exception> - Class in com.diffplug.common.util.concurrent
A simplified version of ForwardingCheckedFuture where subclasses can pass in an already constructed CheckedFuture as the delegate.
ForwardingExecutorService - Class in com.diffplug.common.util.concurrent
An executor service which forwards all its method calls to another executor service.
ForwardingExecutorService() - Constructor for class com.diffplug.common.util.concurrent.ForwardingExecutorService
Constructor for use by subclasses.
ForwardingFuture<V> - Class in com.diffplug.common.util.concurrent
A Future which forwards all its method calls to another future.
ForwardingFuture() - Constructor for class com.diffplug.common.util.concurrent.ForwardingFuture
Constructor for use by subclasses.
ForwardingFuture.SimpleForwardingFuture<V> - Class in com.diffplug.common.util.concurrent
A simplified version of ForwardingFuture where subclasses can pass in an already constructed Future as the delegate.
ForwardingListenableFuture<V> - Class in com.diffplug.common.util.concurrent
A ListenableFuture which forwards all its method calls to another future.
ForwardingListenableFuture() - Constructor for class com.diffplug.common.util.concurrent.ForwardingListenableFuture
Constructor for use by subclasses.
ForwardingListenableFuture.SimpleForwardingListenableFuture<V> - Class in com.diffplug.common.util.concurrent
A simplified version of ForwardingListenableFuture where subclasses can pass in an already constructed ListenableFuture as the delegate.
ForwardingListeningExecutorService - Class in com.diffplug.common.util.concurrent
A listening executor service which forwards all its method calls to another listening executor service.
ForwardingListeningExecutorService() - Constructor for class com.diffplug.common.util.concurrent.ForwardingListeningExecutorService
Constructor for use by subclasses.
FutureCallback<V> - Interface in com.diffplug.common.util.concurrent
A callback for accepting the results of a Future computation asynchronously.
Futures - Class in com.diffplug.common.util.concurrent
Static utility methods pertaining to the Future interface.

G

get(long, TimeUnit) - Method in class com.diffplug.common.util.concurrent.AbstractFuture
get() - Method in class com.diffplug.common.util.concurrent.AbstractFuture
get() - Method in class com.diffplug.common.util.concurrent.AtomicDouble
Gets the current value.
get(int) - Method in class com.diffplug.common.util.concurrent.AtomicDoubleArray
Gets the current value at position i.
get(K) - Method in class com.diffplug.common.util.concurrent.AtomicLongMap
Returns the value associated with key, or zero if there is no value associated with key.
get() - Method in class com.diffplug.common.util.concurrent.ForwardingFuture
 
get(long, TimeUnit) - Method in class com.diffplug.common.util.concurrent.ForwardingFuture
 
get(Object) - Method in class com.diffplug.common.util.concurrent.Striped
Returns the stripe that corresponds to the passed key.
getAndAdd(double) - Method in class com.diffplug.common.util.concurrent.AtomicDouble
Atomically adds the given value to the current value.
getAndAdd(int, double) - Method in class com.diffplug.common.util.concurrent.AtomicDoubleArray
Atomically adds the given value to the element at index i.
getAndAdd(K, long) - Method in class com.diffplug.common.util.concurrent.AtomicLongMap
Adds delta to the value currently associated with key, and returns the old value.
getAndDecrement(K) - Method in class com.diffplug.common.util.concurrent.AtomicLongMap
Decrements by one the value currently associated with key, and returns the old value.
getAndIncrement(K) - Method in class com.diffplug.common.util.concurrent.AtomicLongMap
Increments by one the value currently associated with key, and returns the old value.
getAndSet(double) - Method in class com.diffplug.common.util.concurrent.AtomicDouble
Atomically sets to the given value and returns the old value.
getAndSet(int, double) - Method in class com.diffplug.common.util.concurrent.AtomicDoubleArray
Atomically sets the element at position i to the given value and returns the old value.
getAt(int) - Method in class com.diffplug.common.util.concurrent.Striped
Returns the stripe at the specified index.
getChecked(Future<V>, Class<X>) - Static method in class com.diffplug.common.util.concurrent.Futures
Returns the result of Future.get(), converting most exceptions to a new instance of the given checked exception type.
getChecked(Future<V>, Class<X>, long, TimeUnit) - Static method in class com.diffplug.common.util.concurrent.Futures
Returns the result of Future.get(long, TimeUnit), converting most exceptions to a new instance of the given checked exception type.
getConflictingStackTrace() - Method in exception com.diffplug.common.util.concurrent.CycleDetectingLockFactory.PotentialDeadlockException
 
getExitingExecutorService(ThreadPoolExecutor, long, TimeUnit) - Static method in class com.diffplug.common.util.concurrent.MoreExecutors
Converts the given ThreadPoolExecutor into an ExecutorService that exits when the application is complete.
getExitingExecutorService(ThreadPoolExecutor) - Static method in class com.diffplug.common.util.concurrent.MoreExecutors
Converts the given ThreadPoolExecutor into an ExecutorService that exits when the application is complete.
getExitingScheduledExecutorService(ScheduledThreadPoolExecutor, long, TimeUnit) - Static method in class com.diffplug.common.util.concurrent.MoreExecutors
Converts the given ScheduledThreadPoolExecutor into a ScheduledExecutorService that exits when the application is complete.
getExitingScheduledExecutorService(ScheduledThreadPoolExecutor) - Static method in class com.diffplug.common.util.concurrent.MoreExecutors
Converts the given ThreadPoolExecutor into a ScheduledExecutorService that exits when the application is complete.
getMessage() - Method in exception com.diffplug.common.util.concurrent.CycleDetectingLockFactory.PotentialDeadlockException
Appends the chain of messages from the conflictingStackTrace to the original message.
getNextSchedule() - Method in class com.diffplug.common.util.concurrent.AbstractScheduledService.CustomScheduler
Calculates the time at which to next invoke the task.
getOccupiedDepth() - Method in class com.diffplug.common.util.concurrent.Monitor
Returns the number of times the current thread has entered this monitor in excess of the number of times it has left.
getQueueLength() - Method in class com.diffplug.common.util.concurrent.Monitor
Returns an estimate of the number of threads waiting to enter this monitor.
getRate() - Method in class com.diffplug.common.util.concurrent.RateLimiter
Returns the stable rate (as permits per seconds) with which this RateLimiter is configured with.
getUnchecked(Future<V>) - Static method in class com.diffplug.common.util.concurrent.Futures
Returns the result of calling Future.get() uninterruptibly on a task known not to throw a checked exception.
getUninterruptibly(Future<V>) - Static method in class com.diffplug.common.util.concurrent.Uninterruptibles
Invokes future.get() uninterruptibly.
getUninterruptibly(Future<V>, long, TimeUnit) - Static method in class com.diffplug.common.util.concurrent.Uninterruptibles
Invokes future.get(timeout, unit) uninterruptibly.
getWaitQueueLength(Monitor.Guard) - Method in class com.diffplug.common.util.concurrent.Monitor
Returns an estimate of the number of threads waiting for the given guard to become satisfied.
Guard(Monitor) - Constructor for class com.diffplug.common.util.concurrent.Monitor.Guard
 

H

handlePotentialDeadlock(CycleDetectingLockFactory.PotentialDeadlockException) - Method in interface com.diffplug.common.util.concurrent.CycleDetectingLockFactory.Policy
Called when a potential deadlock is encountered.
hasQueuedThread(Thread) - Method in class com.diffplug.common.util.concurrent.Monitor
Queries whether the given thread is waiting to enter this monitor.
hasQueuedThreads() - Method in class com.diffplug.common.util.concurrent.Monitor
Returns whether any threads are waiting to enter this monitor.
hasWaiters(Monitor.Guard) - Method in class com.diffplug.common.util.concurrent.Monitor
Queries whether any threads are waiting for the given guard to become satisfied.
healthy() - Method in class com.diffplug.common.util.concurrent.ServiceManager.Listener
Called when the service initially becomes healthy.

I

immediateCancelledFuture() - Static method in class com.diffplug.common.util.concurrent.Futures
Creates a ListenableFuture which is cancelled immediately upon construction, so that isCancelled() always returns true.
immediateCheckedFuture(V) - Static method in class com.diffplug.common.util.concurrent.Futures
Returns a CheckedFuture which has its value set immediately upon construction.
immediateFailedCheckedFuture(X) - Static method in class com.diffplug.common.util.concurrent.Futures
Returns a CheckedFuture which has an exception set immediately upon construction.
immediateFailedFuture(Throwable) - Static method in class com.diffplug.common.util.concurrent.Futures
Returns a ListenableFuture which has an exception set immediately upon construction.
immediateFuture(V) - Static method in class com.diffplug.common.util.concurrent.Futures
Creates a ListenableFuture which has its value set immediately upon construction.
inCompletionOrder(Iterable<? extends ListenableFuture<? extends T>>) - Static method in class com.diffplug.common.util.concurrent.Futures
Returns a list of delegate futures that correspond to the futures received in the order that they complete.
incrementAndGet(K) - Method in class com.diffplug.common.util.concurrent.AtomicLongMap
Increments by one the value currently associated with key, and returns the new value.
interruptTask() - Method in class com.diffplug.common.util.concurrent.AbstractFuture
Subclasses can override this method to implement interruption of the future’s computation.
intValue() - Method in class com.diffplug.common.util.concurrent.AtomicDouble
Returns the value of this AtomicDouble as an int after a narrowing primitive conversion.
invokeAll(Collection<? extends Callable<T>>) - Method in class com.diffplug.common.util.concurrent.ForwardingExecutorService
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.diffplug.common.util.concurrent.ForwardingExecutorService
 
invokeAll(Collection<? extends Callable<T>>) - Method in interface com.diffplug.common.util.concurrent.ListeningExecutorService
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in interface com.diffplug.common.util.concurrent.ListeningExecutorService
invokeAny(Collection<? extends Callable<T>>) - Method in class com.diffplug.common.util.concurrent.ForwardingExecutorService
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.diffplug.common.util.concurrent.ForwardingExecutorService
 
isCancelled() - Method in class com.diffplug.common.util.concurrent.AbstractFuture
 
isCancelled() - Method in class com.diffplug.common.util.concurrent.ForwardingFuture
 
isDone() - Method in class com.diffplug.common.util.concurrent.AbstractFuture
 
isDone() - Method in class com.diffplug.common.util.concurrent.ForwardingFuture
 
isEmpty() - Method in class com.diffplug.common.util.concurrent.AtomicLongMap
Returns true if this map contains no key-value mappings.
isFair() - Method in class com.diffplug.common.util.concurrent.Monitor
Returns whether this monitor is using a fair ordering policy.
isHealthy() - Method in class com.diffplug.common.util.concurrent.ServiceManager
Returns true if all services are currently in the running state.
isOccupied() - Method in class com.diffplug.common.util.concurrent.Monitor
Returns whether this monitor is occupied by any thread.
isOccupiedByCurrentThread() - Method in class com.diffplug.common.util.concurrent.Monitor
Returns whether the current thread is occupying this monitor (has entered more times than it has left).
isRunning() - Method in class com.diffplug.common.util.concurrent.AbstractExecutionThreadService
 
isRunning() - Method in class com.diffplug.common.util.concurrent.AbstractIdleService
 
isRunning() - Method in class com.diffplug.common.util.concurrent.AbstractScheduledService
 
isRunning() - Method in class com.diffplug.common.util.concurrent.AbstractService
 
isRunning() - Method in interface com.diffplug.common.util.concurrent.Service
Returns true if this service is running.
isSatisfied() - Method in class com.diffplug.common.util.concurrent.Monitor.Guard
Evaluates this guard’s boolean condition.
isShutdown() - Method in class com.diffplug.common.util.concurrent.ForwardingExecutorService
 
isTerminated() - Method in class com.diffplug.common.util.concurrent.ForwardingExecutorService
 

J

JdkFutureAdapters - Class in com.diffplug.common.util.concurrent
Utilities necessary for working with libraries that supply plain Future instances.
joinUninterruptibly(Thread) - Static method in class com.diffplug.common.util.concurrent.Uninterruptibles
Invokes toJoin.join() uninterruptibly.
joinUninterruptibly(Thread, long, TimeUnit) - Static method in class com.diffplug.common.util.concurrent.Uninterruptibles
Invokes unit.timedJoin(toJoin, timeout) uninterruptibly.

L

lazySet(double) - Method in class com.diffplug.common.util.concurrent.AtomicDouble
Eventually sets to the given value.
lazySet(int, double) - Method in class com.diffplug.common.util.concurrent.AtomicDoubleArray
Eventually sets the element at position i to the given value.
lazyTransform(Future<I>, Function<? super I, ? extends O>) - Static method in class com.diffplug.common.util.concurrent.Futures
Like Futures.transform(ListenableFuture, Function) except that the transformation function is invoked on each call to get() on the returned future.
lazyWeakLock(int) - Static method in class com.diffplug.common.util.concurrent.Striped
Creates a Striped<Lock> with lazily initialized, weakly referenced locks.
lazyWeakReadWriteLock(int) - Static method in class com.diffplug.common.util.concurrent.Striped
Creates a Striped<ReadWriteLock> with lazily initialized, weakly referenced read-write locks.
lazyWeakSemaphore(int, int) - Static method in class com.diffplug.common.util.concurrent.Striped
Creates a Striped<Semaphore> with lazily initialized, weakly referenced semaphores, with the specified number of permits.
leave() - Method in class com.diffplug.common.util.concurrent.Monitor
Leaves this monitor.
length() - Method in class com.diffplug.common.util.concurrent.AtomicDoubleArray
Returns the length of the array.
ListenableFuture<V> - Interface in com.diffplug.common.util.concurrent
A Future that accepts completion listeners.
ListenableFutureTask<V> - Class in com.diffplug.common.util.concurrent
A FutureTask that also implements the ListenableFuture interface.
ListenableScheduledFuture<V> - Interface in com.diffplug.common.util.concurrent
Helper interface to implement both ListenableFuture and ScheduledFuture.
Listener() - Constructor for class com.diffplug.common.util.concurrent.Service.Listener
 
Listener() - Constructor for class com.diffplug.common.util.concurrent.ServiceManager.Listener
 
listeningDecorator(ExecutorService) - Static method in class com.diffplug.common.util.concurrent.MoreExecutors
Creates an ExecutorService whose submit and invokeAll methods submit ListenableFutureTask instances to the given delegate executor.
listeningDecorator(ScheduledExecutorService) - Static method in class com.diffplug.common.util.concurrent.MoreExecutors
Creates a ScheduledExecutorService whose submit and invokeAll methods submit ListenableFutureTask instances to the given delegate executor.
ListeningExecutorService - Interface in com.diffplug.common.util.concurrent
An ExecutorService that returns ListenableFuture instances.
ListeningScheduledExecutorService - Interface in com.diffplug.common.util.concurrent
A ScheduledExecutorService that returns ListenableFuture instances from its ExecutorService methods.
listenInPoolThread(Future<V>) - Static method in class com.diffplug.common.util.concurrent.JdkFutureAdapters
Assigns a thread to the given Future to provide ListenableFuture functionality.
listenInPoolThread(Future<V>, Executor) - Static method in class com.diffplug.common.util.concurrent.JdkFutureAdapters
Submits a blocking task for the given Future to provide ListenableFuture functionality.
lock(int) - Static method in class com.diffplug.common.util.concurrent.Striped
Creates a Striped<Lock> with eagerly initialized, strongly referenced locks.
longValue() - Method in class com.diffplug.common.util.concurrent.AtomicDouble
Returns the value of this AtomicDouble as a long after a narrowing primitive conversion.

M

makeChecked(ListenableFuture<V>, Function<? super Exception, X>) - Static method in class com.diffplug.common.util.concurrent.Futures
Creates a CheckedFuture out of a normal ListenableFuture and a Function that maps from Exception instances into the appropriate checked type.
mapException(Exception) - Method in class com.diffplug.common.util.concurrent.AbstractCheckedFuture
Translates from an InterruptedException, CancellationException or ExecutionException thrown by get to an exception of type X to be thrown by checkedGet.
Monitor - Class in com.diffplug.common.util.concurrent
A synchronization abstraction supporting waiting on arbitrary boolean conditions.
Monitor() - Constructor for class com.diffplug.common.util.concurrent.Monitor
Creates a monitor with a non-fair (but fast) ordering policy.
Monitor(boolean) - Constructor for class com.diffplug.common.util.concurrent.Monitor
Creates a monitor with the given ordering policy.
Monitor.Guard - Class in com.diffplug.common.util.concurrent
A boolean condition for which a thread may wait.
MoreExecutors - Class in com.diffplug.common.util.concurrent
Factory and utility methods for Executor, ExecutorService, and ThreadFactory.

N

newDirectExecutorService() - Static method in class com.diffplug.common.util.concurrent.MoreExecutors
Creates an executor service that runs each task in the thread that invokes execute/submit, as in ThreadPoolExecutor.CallerRunsPolicy This applies both to individually submitted tasks and to collections of tasks submitted via invokeAll or invokeAny.
newFixedDelaySchedule(long, long, TimeUnit) - Static method in class com.diffplug.common.util.concurrent.AbstractScheduledService.Scheduler
newFixedRateSchedule(long, long, TimeUnit) - Static method in class com.diffplug.common.util.concurrent.AbstractScheduledService.Scheduler
newInstance(CycleDetectingLockFactory.Policy) - Static method in class com.diffplug.common.util.concurrent.CycleDetectingLockFactory
Creates a new factory with the specified policy.
newInstanceWithExplicitOrdering(Class<E>, CycleDetectingLockFactory.Policy) - Static method in class com.diffplug.common.util.concurrent.CycleDetectingLockFactory
Creates a CycleDetectingLockFactory.WithExplicitOrdering<E>.
newProxy(T, Class<T>, long, TimeUnit) - Method in class com.diffplug.common.util.concurrent.FakeTimeLimiter
 
newProxy(T, Class<T>, long, TimeUnit) - Method in class com.diffplug.common.util.concurrent.SimpleTimeLimiter
 
newProxy(T, Class<T>, long, TimeUnit) - Method in interface com.diffplug.common.util.concurrent.TimeLimiter
Returns an instance of interfaceType that delegates all method calls to the target object, enforcing the specified time limit on each call.
newReentrantLock(String) - Method in class com.diffplug.common.util.concurrent.CycleDetectingLockFactory
Equivalent to newReentrantLock(lockName, false).
newReentrantLock(String, boolean) - Method in class com.diffplug.common.util.concurrent.CycleDetectingLockFactory
Creates a ReentrantLock with the given fairness policy.
newReentrantLock(E) - Method in class com.diffplug.common.util.concurrent.CycleDetectingLockFactory.WithExplicitOrdering
Equivalent to newReentrantLock(rank, false).
newReentrantLock(E, boolean) - Method in class com.diffplug.common.util.concurrent.CycleDetectingLockFactory.WithExplicitOrdering
Creates a ReentrantLock with the given fairness policy and rank.
newReentrantReadWriteLock(String) - Method in class com.diffplug.common.util.concurrent.CycleDetectingLockFactory
Equivalent to newReentrantReadWriteLock(lockName, false).
newReentrantReadWriteLock(String, boolean) - Method in class com.diffplug.common.util.concurrent.CycleDetectingLockFactory
Creates a ReentrantReadWriteLock with the given fairness policy.
newReentrantReadWriteLock(E) - Method in class com.diffplug.common.util.concurrent.CycleDetectingLockFactory.WithExplicitOrdering
Equivalent to newReentrantReadWriteLock(rank, false).
newReentrantReadWriteLock(E, boolean) - Method in class com.diffplug.common.util.concurrent.CycleDetectingLockFactory.WithExplicitOrdering
Creates a ReentrantReadWriteLock with the given fairness policy and rank.
newReference() - Static method in class com.diffplug.common.util.concurrent.Atomics
Creates an AtomicReference instance with no initial value.
newReference(V) - Static method in class com.diffplug.common.util.concurrent.Atomics
Creates an AtomicReference instance with the given initial value.
newReferenceArray(int) - Static method in class com.diffplug.common.util.concurrent.Atomics
Creates an AtomicReferenceArray instance of given length.
newReferenceArray(E[]) - Static method in class com.diffplug.common.util.concurrent.Atomics
Creates an AtomicReferenceArray instance with the same length as, and all elements copied from, the given array.
newTaskFor(Runnable, T) - Method in class com.diffplug.common.util.concurrent.AbstractListeningExecutorService
 
newTaskFor(Callable<T>) - Method in class com.diffplug.common.util.concurrent.AbstractListeningExecutorService
 
nonCancellationPropagating(ListenableFuture<V>) - Static method in class com.diffplug.common.util.concurrent.Futures
Creates a new ListenableFuture whose result is set from the supplied future when it completes.
notifyFailed(Throwable) - Method in class com.diffplug.common.util.concurrent.AbstractService
Invoke this method to transition the service to the Service.State.FAILED.
notifyStarted() - Method in class com.diffplug.common.util.concurrent.AbstractService
Implementing classes should invoke this method once their service has started.
notifyStopped() - Method in class com.diffplug.common.util.concurrent.AbstractService
Implementing classes should invoke this method once their service has stopped.

O

offer(E, long, TimeUnit) - Method in class com.diffplug.common.util.concurrent.ForwardingBlockingQueue
 
onFailure(Throwable) - Method in interface com.diffplug.common.util.concurrent.FutureCallback
Invoked when a Future computation fails or is canceled.
onSuccess(V) - Method in interface com.diffplug.common.util.concurrent.FutureCallback
Invoked with the result of the Future computation when it is successful.

P

platformThreadFactory() - Static method in class com.diffplug.common.util.concurrent.MoreExecutors
Returns a default thread factory used to create new threads.
poll(long, TimeUnit) - Method in class com.diffplug.common.util.concurrent.ForwardingBlockingQueue
 
put(K, long) - Method in class com.diffplug.common.util.concurrent.AtomicLongMap
Associates newValue with key in this map, and returns the value previously associated with key, or zero if there was no such value.
put(E) - Method in class com.diffplug.common.util.concurrent.ForwardingBlockingQueue
 
putAll(Map<? extends K, ? extends Long>) - Method in class com.diffplug.common.util.concurrent.AtomicLongMap
Copies all of the mappings from the specified map to this map.
putUninterruptibly(BlockingQueue<E>, E) - Static method in class com.diffplug.common.util.concurrent.Uninterruptibles
Invokes queue.put(element) uninterruptibly.

R

RateLimiter - Class in com.diffplug.common.util.concurrent
A rate limiter.
readWriteLock(int) - Static method in class com.diffplug.common.util.concurrent.Striped
Creates a Striped<ReadWriteLock> with eagerly initialized, strongly referenced read-write locks.
remainingCapacity() - Method in class com.diffplug.common.util.concurrent.ForwardingBlockingQueue
 
remove(K) - Method in class com.diffplug.common.util.concurrent.AtomicLongMap
Removes and returns the value associated with key.
removeAllZeros() - Method in class com.diffplug.common.util.concurrent.AtomicLongMap
Removes all mappings from this map whose values are zero.
returning(T) - Static method in class com.diffplug.common.util.concurrent.Callables
Creates a Callable which immediately returns a preset value each time it is called.
run() - Method in class com.diffplug.common.util.concurrent.AbstractExecutionThreadService
Run the service.
Runnables - Class in com.diffplug.common.util.concurrent
Static utility methods pertaining to the Runnable interface.
running() - Method in class com.diffplug.common.util.concurrent.Service.Listener
Called when the service transitions from STARTING to RUNNING.
runOneIteration() - Method in class com.diffplug.common.util.concurrent.AbstractScheduledService
Run one iteration of the scheduled task.

S

Schedule(long, TimeUnit) - Constructor for class com.diffplug.common.util.concurrent.AbstractScheduledService.CustomScheduler.Schedule
 
schedule(Runnable, long, TimeUnit) - Method in interface com.diffplug.common.util.concurrent.ListeningScheduledExecutorService
 
schedule(Callable<V>, long, TimeUnit) - Method in interface com.diffplug.common.util.concurrent.ListeningScheduledExecutorService
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in interface com.diffplug.common.util.concurrent.ListeningScheduledExecutorService
 
scheduler() - Method in class com.diffplug.common.util.concurrent.AbstractScheduledService
Returns the AbstractScheduledService.Scheduler object used to configure this service.
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in interface com.diffplug.common.util.concurrent.ListeningScheduledExecutorService
 
semaphore(int, int) - Static method in class com.diffplug.common.util.concurrent.Striped
Creates a Striped<Semaphore> with eagerly initialized, strongly referenced semaphores, with the specified number of permits.
Service - Interface in com.diffplug.common.util.concurrent
An object with an operational state, plus asynchronous Service.startAsync() and Service.stopAsync() lifecycle methods to transition between states.
Service.Listener - Class in com.diffplug.common.util.concurrent
A listener for the various state changes that a Service goes through in its lifecycle.
Service.State - Enum in com.diffplug.common.util.concurrent
The lifecycle states of a service.
ServiceManager - Class in com.diffplug.common.util.concurrent
A manager for monitoring and controlling a set of services.
ServiceManager(Iterable<? extends Service>) - Constructor for class com.diffplug.common.util.concurrent.ServiceManager
Constructs a new instance for managing the given services.
ServiceManager.Listener - Class in com.diffplug.common.util.concurrent
A listener for the aggregate state changes of the services that are under management.
serviceName() - Method in class com.diffplug.common.util.concurrent.AbstractExecutionThreadService
Returns the name of this service.
serviceName() - Method in class com.diffplug.common.util.concurrent.AbstractIdleService
Returns the name of this service.
serviceName() - Method in class com.diffplug.common.util.concurrent.AbstractScheduledService
Returns the name of this service.
servicesByState() - Method in class com.diffplug.common.util.concurrent.ServiceManager
Provides a snapshot of the current state of all the services under management.
set(V) - Method in class com.diffplug.common.util.concurrent.AbstractFuture
Sets the result of this Future unless this Future has already been cancelled or set (including set asynchronously).
set(double) - Method in class com.diffplug.common.util.concurrent.AtomicDouble
Sets to the given value.
set(int, double) - Method in class com.diffplug.common.util.concurrent.AtomicDoubleArray
Sets the element at position i to the given value.
set(V) - Method in class com.diffplug.common.util.concurrent.SettableFuture
 
setDaemon(boolean) - Method in class com.diffplug.common.util.concurrent.ThreadFactoryBuilder
Sets daemon or not for new threads created with this ThreadFactory.
setException(Throwable) - Method in class com.diffplug.common.util.concurrent.AbstractFuture
Sets the failed result of this Future unless this Future has already been cancelled or set (including set asynchronously).
setException(Throwable) - Method in class com.diffplug.common.util.concurrent.SettableFuture
 
setFuture(ListenableFuture<? extends V>) - Method in class com.diffplug.common.util.concurrent.AbstractFuture
Sets the result of this Future to match the supplied input Future once the supplied Future is done, unless this Future has already been cancelled or set (including “set asynchronously,” defined below).
setFuture(ListenableFuture<? extends V>) - Method in class com.diffplug.common.util.concurrent.SettableFuture
 
setNameFormat(String) - Method in class com.diffplug.common.util.concurrent.ThreadFactoryBuilder
Sets the naming format to use when naming threads (Thread.setName(java.lang.String)) which are created with this ThreadFactory.
setPriority(int) - Method in class com.diffplug.common.util.concurrent.ThreadFactoryBuilder
Sets the priority for new threads created with this ThreadFactory.
setRate(double) - Method in class com.diffplug.common.util.concurrent.RateLimiter
Updates the stable rate of this RateLimiter, that is, the permitsPerSecond argument provided in the factory method that constructed the RateLimiter.
SettableFuture<V> - Class in com.diffplug.common.util.concurrent
setThreadFactory(ThreadFactory) - Method in class com.diffplug.common.util.concurrent.ThreadFactoryBuilder
Sets the backing ThreadFactory for new threads created with this ThreadFactory.
setUncaughtExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class com.diffplug.common.util.concurrent.ThreadFactoryBuilder
Sets the Thread.UncaughtExceptionHandler for new threads created with this ThreadFactory.
shutDown() - Method in class com.diffplug.common.util.concurrent.AbstractExecutionThreadService
Stop the service.
shutDown() - Method in class com.diffplug.common.util.concurrent.AbstractIdleService
Stop the service.
shutDown() - Method in class com.diffplug.common.util.concurrent.AbstractScheduledService
Stop the service.
shutdown() - Method in class com.diffplug.common.util.concurrent.ForwardingExecutorService
 
shutdownAndAwaitTermination(ExecutorService, long, TimeUnit) - Static method in class com.diffplug.common.util.concurrent.MoreExecutors
Shuts down the given executor gradually, first disabling new submissions and later cancelling existing tasks.
shutdownNow() - Method in class com.diffplug.common.util.concurrent.ForwardingExecutorService
 
SimpleForwardingCheckedFuture(CheckedFuture<V, X>) - Constructor for class com.diffplug.common.util.concurrent.ForwardingCheckedFuture.SimpleForwardingCheckedFuture
 
SimpleForwardingFuture(Future<V>) - Constructor for class com.diffplug.common.util.concurrent.ForwardingFuture.SimpleForwardingFuture
 
SimpleForwardingListenableFuture(ListenableFuture<V>) - Constructor for class com.diffplug.common.util.concurrent.ForwardingListenableFuture.SimpleForwardingListenableFuture
 
SimpleTimeLimiter - Class in com.diffplug.common.util.concurrent
A TimeLimiter that runs method calls in the background using an ExecutorService.
SimpleTimeLimiter(ExecutorService) - Constructor for class com.diffplug.common.util.concurrent.SimpleTimeLimiter
Constructs a TimeLimiter instance using the given executor service to execute proxied method calls.
SimpleTimeLimiter() - Constructor for class com.diffplug.common.util.concurrent.SimpleTimeLimiter
Constructs a TimeLimiter instance using a Executors.newCachedThreadPool() to execute proxied method calls.
size() - Method in class com.diffplug.common.util.concurrent.AtomicLongMap
Returns the number of key-value mappings in this map.
size() - Method in class com.diffplug.common.util.concurrent.Striped
Returns the total number of stripes in this instance.
sleepUninterruptibly(long, TimeUnit) - Static method in class com.diffplug.common.util.concurrent.Uninterruptibles
Invokes unit.sleep(sleepFor) uninterruptibly.
startAsync() - Method in class com.diffplug.common.util.concurrent.AbstractExecutionThreadService
 
startAsync() - Method in class com.diffplug.common.util.concurrent.AbstractIdleService
 
startAsync() - Method in class com.diffplug.common.util.concurrent.AbstractScheduledService
 
startAsync() - Method in class com.diffplug.common.util.concurrent.AbstractService
 
startAsync() - Method in interface com.diffplug.common.util.concurrent.Service
If the service state is Service.State.NEW, this initiates service startup and returns immediately.
startAsync() - Method in class com.diffplug.common.util.concurrent.ServiceManager
Initiates service startup on all the services being managed.
starting() - Method in class com.diffplug.common.util.concurrent.Service.Listener
Called when the service transitions from NEW to STARTING.
startUp() - Method in class com.diffplug.common.util.concurrent.AbstractExecutionThreadService
Start the service.
startUp() - Method in class com.diffplug.common.util.concurrent.AbstractIdleService
Start the service.
startUp() - Method in class com.diffplug.common.util.concurrent.AbstractScheduledService
Start the service.
startupTimes() - Method in class com.diffplug.common.util.concurrent.ServiceManager
Returns the service load times.
state() - Method in class com.diffplug.common.util.concurrent.AbstractExecutionThreadService
 
state() - Method in class com.diffplug.common.util.concurrent.AbstractIdleService
 
state() - Method in class com.diffplug.common.util.concurrent.AbstractScheduledService
 
state() - Method in class com.diffplug.common.util.concurrent.AbstractService
 
state() - Method in interface com.diffplug.common.util.concurrent.Service
Returns the lifecycle state of the service.
stopAsync() - Method in class com.diffplug.common.util.concurrent.AbstractExecutionThreadService
 
stopAsync() - Method in class com.diffplug.common.util.concurrent.AbstractIdleService
 
stopAsync() - Method in class com.diffplug.common.util.concurrent.AbstractScheduledService
 
stopAsync() - Method in class com.diffplug.common.util.concurrent.AbstractService
 
stopAsync() - Method in interface com.diffplug.common.util.concurrent.Service
If the service is starting or running, this initiates service shutdown and returns immediately.
stopAsync() - Method in class com.diffplug.common.util.concurrent.ServiceManager
Initiates service shutdown if necessary on all the services being managed.
stopped() - Method in class com.diffplug.common.util.concurrent.ServiceManager.Listener
Called when the all of the component services have reached a terminal state, either terminated or failed.
stopping(Service.State) - Method in class com.diffplug.common.util.concurrent.Service.Listener
Called when the service transitions to the STOPPING state.
Striped<L> - Class in com.diffplug.common.util.concurrent
A striped Lock/Semaphore/ReadWriteLock.
submit(Runnable) - Method in class com.diffplug.common.util.concurrent.AbstractListeningExecutorService
 
submit(Runnable, T) - Method in class com.diffplug.common.util.concurrent.AbstractListeningExecutorService
 
submit(Callable<T>) - Method in class com.diffplug.common.util.concurrent.AbstractListeningExecutorService
 
submit(Callable<T>) - Method in class com.diffplug.common.util.concurrent.ForwardingExecutorService
 
submit(Runnable) - Method in class com.diffplug.common.util.concurrent.ForwardingExecutorService
 
submit(Runnable, T) - Method in class com.diffplug.common.util.concurrent.ForwardingExecutorService
 
submit(Callable<T>) - Method in class com.diffplug.common.util.concurrent.ForwardingListeningExecutorService
 
submit(Runnable) - Method in class com.diffplug.common.util.concurrent.ForwardingListeningExecutorService
 
submit(Runnable, T) - Method in class com.diffplug.common.util.concurrent.ForwardingListeningExecutorService
 
submit(Callable<T>) - Method in interface com.diffplug.common.util.concurrent.ListeningExecutorService
 
submit(Runnable) - Method in interface com.diffplug.common.util.concurrent.ListeningExecutorService
 
submit(Runnable, T) - Method in interface com.diffplug.common.util.concurrent.ListeningExecutorService
 
successfulAsList(ListenableFuture<? extends V>...) - Static method in class com.diffplug.common.util.concurrent.Futures
Creates a new ListenableFuture whose value is a list containing the values of all its successful input futures.
successfulAsList(Iterable<? extends ListenableFuture<? extends V>>) - Static method in class com.diffplug.common.util.concurrent.Futures
Creates a new ListenableFuture whose value is a list containing the values of all its successful input futures.
sum() - Method in class com.diffplug.common.util.concurrent.AtomicLongMap
Returns the sum of all values in this map.
systemExit() - Static method in class com.diffplug.common.util.concurrent.UncaughtExceptionHandlers
Returns an exception handler that exits the system.

T

take() - Method in class com.diffplug.common.util.concurrent.ForwardingBlockingQueue
 
takeUninterruptibly(BlockingQueue<E>) - Static method in class com.diffplug.common.util.concurrent.Uninterruptibles
Invokes queue.take() uninterruptibly.
terminated(Service.State) - Method in class com.diffplug.common.util.concurrent.Service.Listener
Called when the service transitions to the TERMINATED state.
ThreadFactoryBuilder - Class in com.diffplug.common.util.concurrent
A ThreadFactory builder, providing any combination of these features: whether threads should be marked as daemon threads a naming format a thread priority an uncaught exception handler a backing thread factory
ThreadFactoryBuilder() - Constructor for class com.diffplug.common.util.concurrent.ThreadFactoryBuilder
Creates a new ThreadFactory builder.
TimeLimiter - Interface in com.diffplug.common.util.concurrent
Produces proxies that impose a time limit on method calls to the proxied object.
toString() - Method in class com.diffplug.common.util.concurrent.AbstractExecutionThreadService
 
toString() - Method in class com.diffplug.common.util.concurrent.AbstractIdleService
 
toString() - Method in class com.diffplug.common.util.concurrent.AbstractScheduledService
 
toString() - Method in class com.diffplug.common.util.concurrent.AbstractService
 
toString() - Method in class com.diffplug.common.util.concurrent.AtomicDouble
Returns the String representation of the current value.
toString() - Method in class com.diffplug.common.util.concurrent.AtomicDoubleArray
Returns the String representation of the current values of array.
toString() - Method in class com.diffplug.common.util.concurrent.AtomicLongMap
 
toString() - Method in class com.diffplug.common.util.concurrent.RateLimiter
 
toString() - Method in class com.diffplug.common.util.concurrent.ServiceManager
 
transform(ListenableFuture<I>, Function<? super I, ? extends O>) - Static method in class com.diffplug.common.util.concurrent.Futures
Returns a new ListenableFuture whose result is the product of applying the given Function to the result of the given Future.
transform(ListenableFuture<I>, Function<? super I, ? extends O>, Executor) - Static method in class com.diffplug.common.util.concurrent.Futures
Returns a new ListenableFuture whose result is the product of applying the given Function to the result of the given Future.
transformAsync(ListenableFuture<I>, AsyncFunction<? super I, ? extends O>) - Static method in class com.diffplug.common.util.concurrent.Futures
Returns a new ListenableFuture whose result is asynchronously derived from the result of the given Future.
transformAsync(ListenableFuture<I>, AsyncFunction<? super I, ? extends O>, Executor) - Static method in class com.diffplug.common.util.concurrent.Futures
Returns a new ListenableFuture whose result is asynchronously derived from the result of the given Future.
triggerShutdown() - Method in class com.diffplug.common.util.concurrent.AbstractExecutionThreadService
Invoked to request the service to stop.
tryAcquire(long, TimeUnit) - Method in class com.diffplug.common.util.concurrent.RateLimiter
Acquires a permit from this RateLimiter if it can be obtained without exceeding the specified timeout, or returns false immediately (without waiting) if the permit would not have been granted before the timeout expired.
tryAcquire(int) - Method in class com.diffplug.common.util.concurrent.RateLimiter
Acquires permits from this RateLimiter if it can be acquired immediately without delay.
tryAcquire() - Method in class com.diffplug.common.util.concurrent.RateLimiter
Acquires a permit from this RateLimiter if it can be acquired immediately without delay.
tryAcquire(int, long, TimeUnit) - Method in class com.diffplug.common.util.concurrent.RateLimiter
Acquires the given number of permits from this RateLimiter if it can be obtained without exceeding the specified timeout, or returns false immediately (without waiting) if the permits would not have been granted before the timeout expired.
tryAcquireUninterruptibly(Semaphore, long, TimeUnit) - Static method in class com.diffplug.common.util.concurrent.Uninterruptibles
Invokes semaphore.tryAcquire(1, timeout, unit) uninterruptibly.
tryAcquireUninterruptibly(Semaphore, int, long, TimeUnit) - Static method in class com.diffplug.common.util.concurrent.Uninterruptibles
Invokes semaphore.tryAcquire(permits, timeout, unit) uninterruptibly.
tryEnter() - Method in class com.diffplug.common.util.concurrent.Monitor
Enters this monitor if it is possible to do so immediately.
tryEnterIf(Monitor.Guard) - Method in class com.diffplug.common.util.concurrent.Monitor
Enters this monitor if it is possible to do so immediately and the guard is satisfied.

U

UncaughtExceptionHandlers - Class in com.diffplug.common.util.concurrent
Factories for Thread.UncaughtExceptionHandler instances.
UncheckedExecutionException - Exception in com.diffplug.common.util.concurrent
Unchecked variant of ExecutionException.
UncheckedExecutionException() - Constructor for exception com.diffplug.common.util.concurrent.UncheckedExecutionException
Creates a new instance with null as its detail message.
UncheckedExecutionException(String) - Constructor for exception com.diffplug.common.util.concurrent.UncheckedExecutionException
Creates a new instance with the given detail message.
UncheckedExecutionException(String, Throwable) - Constructor for exception com.diffplug.common.util.concurrent.UncheckedExecutionException
Creates a new instance with the given detail message and cause.
UncheckedExecutionException(Throwable) - Constructor for exception com.diffplug.common.util.concurrent.UncheckedExecutionException
Creates a new instance with the given cause.
UncheckedTimeoutException - Exception in com.diffplug.common.util.concurrent
Unchecked version of TimeoutException.
UncheckedTimeoutException() - Constructor for exception com.diffplug.common.util.concurrent.UncheckedTimeoutException
 
UncheckedTimeoutException(String) - Constructor for exception com.diffplug.common.util.concurrent.UncheckedTimeoutException
 
UncheckedTimeoutException(Throwable) - Constructor for exception com.diffplug.common.util.concurrent.UncheckedTimeoutException
 
UncheckedTimeoutException(String, Throwable) - Constructor for exception com.diffplug.common.util.concurrent.UncheckedTimeoutException
 
Uninterruptibles - Class in com.diffplug.common.util.concurrent
Utilities for treating interruptible operations as uninterruptible.

V

valueOf(String) - Static method in enum com.diffplug.common.util.concurrent.CycleDetectingLockFactory.Policies
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.diffplug.common.util.concurrent.Service.State
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.diffplug.common.util.concurrent.CycleDetectingLockFactory.Policies
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.diffplug.common.util.concurrent.Service.State
Returns an array containing the constants of this enum type, in the order they are declared.

W

waitFor(Monitor.Guard) - Method in class com.diffplug.common.util.concurrent.Monitor
Waits for the guard to be satisfied.
waitFor(Monitor.Guard, long, TimeUnit) - Method in class com.diffplug.common.util.concurrent.Monitor
Waits for the guard to be satisfied.
waitForUninterruptibly(Monitor.Guard) - Method in class com.diffplug.common.util.concurrent.Monitor
Waits for the guard to be satisfied.
waitForUninterruptibly(Monitor.Guard, long, TimeUnit) - Method in class com.diffplug.common.util.concurrent.Monitor
Waits for the guard to be satisfied.
wasInterrupted() - Method in class com.diffplug.common.util.concurrent.AbstractFuture
Returns true if this future was cancelled with mayInterruptIfRunning set to true.
weakCompareAndSet(double, double) - Method in class com.diffplug.common.util.concurrent.AtomicDouble
Atomically sets the value to the given updated value if the current value is bitwise equal to the expected value.
weakCompareAndSet(int, double, double) - Method in class com.diffplug.common.util.concurrent.AtomicDoubleArray
Atomically sets the element at position i to the given updated value if the current value is bitwise equal to the expected value.
withTimeout(ListenableFuture<V>, long, TimeUnit, ScheduledExecutorService) - Static method in class com.diffplug.common.util.concurrent.Futures
Returns a future that delegates to another but will finish early (via a TimeoutException wrapped in an ExecutionException) if the specified duration expires.
A B C D E F G H I J L M N O P R S T U V W 
Skip navigation links

com.diffplug.durian:durian-concurrent:1.2.0 by DiffPlug