Package | Description |
---|---|
com.google.common.cache |
This package contains caching utilities.
|
com.google.common.util.concurrent |
Concurrency utilities.
|
com.google.common.util.concurrent.testing |
Class and Description |
---|
ListenableFuture
A
Future that accepts completion listeners. |
SettableFuture
A
ListenableFuture whose result can be set by a SettableFuture.set(Object) , SettableFuture.setException(Throwable) or SettableFuture.setFuture(ListenableFuture) call. |
Class and Description |
---|
AbstractCatchingFuture
Implementations of
Futures.catching* . |
AbstractFuture
An abstract implementation of
ListenableFuture , intended for advanced users only. |
AbstractFuture.AtomicHelper |
AbstractFuture.Cancellation
A special value to represent cancellation and the 'wasInterrupted' bit.
|
AbstractFuture.Failure
A special value to represent failure, when
AbstractFuture.setException(java.lang.Throwable) is called successfully. |
AbstractFuture.Listener
Listeners also form a stack through the
AbstractFuture.listeners field. |
AbstractFuture.Trusted
Tag interface marking trusted subclasses.
|
AbstractFuture.TrustedFuture
A less abstract subclass of AbstractFuture.
|
AbstractFuture.Waiter
Waiter links form a Treiber stack, in the
AbstractFuture.waiters field. |
AbstractListeningExecutorService
Abstract
ListeningExecutorService implementation that creates ListenableFuture
instances for each Runnable and Callable submitted to it. |
AbstractScheduledService.CustomScheduler.Schedule
A value object that represents an absolute delay until a task should be invoked.
|
AbstractScheduledService.Scheduler
A scheduler defines the policy for how the
AbstractScheduledService should run its
task. |
AbstractService
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.StateSnapshot
An immutable snapshot of the current state of the service.
|
AbstractTransformFuture
Implementations of
Futures.transform* . |
AggregateFuture
A future whose value is derived from a collection of input futures.
|
AggregateFuture.ReleaseResourcesReason |
AggregateFutureState
A helper which does some thread-safe operations for aggregate futures, which must be implemented
differently in GWT.
|
AggregateFutureState.AtomicHelper |
AsyncCallable
Computes a value, possibly asynchronously.
|
AsyncFunction
Transforms a value, possibly asynchronously.
|
AtomicDouble
A
double value that may be updated atomically. |
AtomicLongMap
A map containing
long values that can be atomically updated. |
ClosingFuture
A step in a pipeline of an asynchronous computation.
|
ClosingFuture.AsyncClosingCallable
An operation that computes a
ClosingFuture of a result. |
ClosingFuture.AsyncClosingFunction
A function from an input to a
ClosingFuture of a result. |
ClosingFuture.CloseableList |
ClosingFuture.ClosingCallable
An operation that computes a result.
|
ClosingFuture.ClosingFunction
A function from an input to a result.
|
ClosingFuture.Combiner
A builder of a
ClosingFuture step that is derived from more than one input step. |
ClosingFuture.Combiner.AsyncCombiningCallable
An operation that returns a
ClosingFuture result and may throw an exception. |
ClosingFuture.Combiner.CombiningCallable
An operation that returns a result and may throw an exception.
|
ClosingFuture.Combiner2
A generic
ClosingFuture.Combiner that lets you use a lambda or method reference to combine two ClosingFuture s. |
ClosingFuture.Combiner2.AsyncClosingFunction2
A function that returns a
ClosingFuture when applied to the values of the two futures
passed to ClosingFuture.whenAllSucceed(ClosingFuture, ClosingFuture) . |
ClosingFuture.Combiner2.ClosingFunction2
A function that returns a value when applied to the values of the two futures passed to
ClosingFuture.whenAllSucceed(ClosingFuture, ClosingFuture) . |
ClosingFuture.Combiner3
A generic
ClosingFuture.Combiner that lets you use a lambda or method reference to combine three
ClosingFuture s. |
ClosingFuture.Combiner3.AsyncClosingFunction3
A function that returns a
ClosingFuture when applied to the values of the three
futures passed to ClosingFuture.whenAllSucceed(ClosingFuture, ClosingFuture, ClosingFuture) . |
ClosingFuture.Combiner3.ClosingFunction3
A function that returns a value when applied to the values of the three futures passed to
ClosingFuture.whenAllSucceed(ClosingFuture, ClosingFuture, ClosingFuture) . |
ClosingFuture.Combiner4
A generic
ClosingFuture.Combiner that lets you use a lambda or method reference to combine four
ClosingFuture s. |
ClosingFuture.Combiner4.AsyncClosingFunction4
A function that returns a
ClosingFuture when applied to the values of the four
futures passed to ClosingFuture.whenAllSucceed(ClosingFuture, ClosingFuture, ClosingFuture,
ClosingFuture) . |
ClosingFuture.Combiner4.ClosingFunction4
A function that returns a value when applied to the values of the four futures passed to
ClosingFuture.whenAllSucceed(ClosingFuture, ClosingFuture, ClosingFuture, ClosingFuture) . |
ClosingFuture.Combiner5
A generic
ClosingFuture.Combiner that lets you use a lambda or method reference to combine five
ClosingFuture s. |
ClosingFuture.Combiner5.AsyncClosingFunction5
A function that returns a
ClosingFuture when applied to the values of the five
futures passed to ClosingFuture.whenAllSucceed(ClosingFuture, ClosingFuture, ClosingFuture,
ClosingFuture, ClosingFuture) . |
ClosingFuture.Combiner5.ClosingFunction5
A function that returns a value when applied to the values of the five futures passed to
ClosingFuture.whenAllSucceed(ClosingFuture, ClosingFuture, ClosingFuture, ClosingFuture,
ClosingFuture) . |
ClosingFuture.DeferredCloser
An object that can capture objects to be closed later, when a
ClosingFuture pipeline is
done. |
ClosingFuture.Peeker
An object that can return the value of the
ClosingFuture s that are passed to ClosingFuture.whenAllComplete(Iterable) or ClosingFuture.whenAllSucceed(Iterable) . |
ClosingFuture.State
The state of a
ClosingFuture.CloseableList . |
ClosingFuture.ValueAndCloser
An object that holds the final result of an asynchronous
ClosingFuture operation and
allows the user to close all the closeable objects that were captured during it for later
closing. |
ClosingFuture.ValueAndCloserConsumer
Represents an operation that accepts a
ClosingFuture.ValueAndCloser for the last step in a ClosingFuture pipeline. |
CollectionFuture
Aggregate future that collects (stores) results of each future.
|
CollectionFuture.Present
The result of a successful
Future . |
CombinedFuture.CombinedFutureInterruptibleTask |
CycleDetectingLockFactory
The
CycleDetectingLockFactory creates ReentrantLock instances and ReentrantReadWriteLock instances that detect potential deadlock by checking for cycles in lock
acquisition order. |
CycleDetectingLockFactory.CycleDetectingLock
Internal Lock implementations implement the
CycleDetectingLock interface, allowing the
detection logic to treat all locks in the same manner. |
CycleDetectingLockFactory.CycleDetectingReentrantReadLock |
CycleDetectingLockFactory.CycleDetectingReentrantReadWriteLock |
CycleDetectingLockFactory.CycleDetectingReentrantWriteLock |
CycleDetectingLockFactory.ExampleStackTrace
A Throwable used to record a stack trace that illustrates an example of a specific lock
acquisition ordering.
|
CycleDetectingLockFactory.LockGraphNode
A
LockGraphNode associated with each lock instance keeps track of the directed edges in
the lock acquisition graph. |
CycleDetectingLockFactory.Policies
Pre-defined
CycleDetectingLockFactory.Policy implementations. |
CycleDetectingLockFactory.Policy
Encapsulates the action to be taken when a potential deadlock is encountered.
|
CycleDetectingLockFactory.PotentialDeadlockException
Represents a detected cycle in lock acquisition ordering.
|
CycleDetectingLockFactory.WithExplicitOrdering
A
CycleDetectingLockFactory.WithExplicitOrdering provides the additional enforcement of
an application-specified ordering of lock acquisitions. |
DirectExecutor
An
Executor that runs each task in the thread that invokes execute . |
ExecutionList
A support class for
ListenableFuture implementations to manage their listeners. |
ExecutionList.RunnableExecutorPair |
ExecutionSequencer
Serializes execution of tasks, somewhat like an "asynchronous
synchronized block." Each
enqueued callable will not be submitted to its associated executor until the
previous callable has returned -- and, if the previous callable was an AsyncCallable , not
until the Future it returned is done (successful, failed, or
cancelled). |
ExecutionSequencer.RunningState |
ExecutionSequencer.ThreadConfinedTaskQueue
This object is unsafely published, but avoids problematic races by relying exclusively on the
identity equality of its Thread field so that the task field is only accessed by a single
thread.
|
FluentFuture
A
ListenableFuture that supports fluent chains of operations. |
FluentFuture.TrustedFuture
A less abstract subclass of AbstractFuture.
|
ForwardingCondition
Forwarding wrapper around a
Condition . |
ForwardingExecutorService
An executor service which forwards all its method calls to another executor service.
|
ForwardingFuture
A
Future which forwards all its method calls to another future. |
ForwardingListenableFuture
A
ListenableFuture which forwards all its method calls to another future. |
ForwardingListenableFuture.SimpleForwardingListenableFuture
A simplified version of
ForwardingListenableFuture where subclasses can pass in an
already constructed ListenableFuture as the delegate. |
ForwardingLock
Forwarding wrapper around a
Lock . |
FutureCallback
A callback for accepting the results of a
Future computation
asynchronously. |
Futures.FutureCombiner
A helper to create a new
ListenableFuture whose result is generated from a combination
of input futures. |
Futures.InCompletionOrderState |
FuturesGetChecked.GetCheckedTypeValidator |
FuturesGetChecked.GetCheckedTypeValidatorHolder.ClassValueValidator |
FuturesGetChecked.GetCheckedTypeValidatorHolder.WeakSetValidator |
GwtFluentFutureCatchingSpecialization
Hidden superclass of
FluentFuture that provides us a place to declare special GWT
versions of the FluentFuture.catching family of methods. |
GwtFuturesCatchingSpecialization
Hidden superclass of
Futures that provides us a place to declare special GWT versions of
the Futures.catching family of methods. |
IgnoreJRERequirement |
InterruptibleTask |
ListenableFuture
A
Future that accepts completion listeners. |
ListenableFutureTask
A
FutureTask that also implements the ListenableFuture interface. |
ListenableScheduledFuture
Helper interface to implement both
ListenableFuture and ScheduledFuture . |
ListenerCallQueue
A list of listeners for implementing a concurrency friendly observable object.
|
ListenerCallQueue.Event
Method reference-compatible listener event.
|
ListenerCallQueue.PerListenerQueue
A special purpose queue/executor that dispatches listener events serially on a configured
executor.
|
ListeningExecutorService
An
ExecutorService that returns ListenableFuture instances. |
ListeningScheduledExecutorService
A
ScheduledExecutorService that returns ListenableFuture instances from its
ExecutorService methods. |
Monitor
A synchronization abstraction supporting waiting on arbitrary boolean conditions.
|
Monitor.Guard
A boolean condition for which a thread may wait.
|
MoreExecutors.ListeningDecorator |
Partially.GwtIncompatible
The presence of this annotation on an API indicates that the method may be used with the
Google Web Toolkit (GWT) but that it has some
restrictions.
|
RateLimiter
A rate limiter.
|
RateLimiter.SleepingStopwatch |
SequentialExecutor.QueueWorker
Worker that runs tasks from
SequentialExecutor.queue until it is empty. |
SequentialExecutor.WorkerRunningState |
Service
An object with an operational state, plus asynchronous
Service.startAsync() and Service.stopAsync() lifecycle methods to transition between states. |
Service.Listener
A listener for the various state changes that a
Service goes through in its lifecycle. |
Service.State
The lifecycle states of a service.
|
ServiceManager
A manager for monitoring and controlling a set of services.
|
ServiceManager.Listener
A listener for the aggregate state changes of the services that are under management.
|
ServiceManager.ServiceManagerState
An encapsulation of all the mutable state of the
ServiceManager that needs to be
accessed by instances of ServiceManager.ServiceListener . |
ServiceManagerBridge
Superinterface of
ServiceManager to introduce a bridge method for servicesByState() , to ensure binary compatibility with older Guava versions that specified
servicesByState() to return ImmutableMultimap . |
SettableFuture
A
ListenableFuture whose result can be set by a SettableFuture.set(Object) , SettableFuture.setException(Throwable) or SettableFuture.setFuture(ListenableFuture) call. |
SimpleTimeLimiter
A TimeLimiter that runs method calls in the background using an
ExecutorService . |
SmoothRateLimiter |
Striped
A striped
Lock/Semaphore/ReadWriteLock . |
Striped.PowerOfTwoStriped |
Striped.SmallLazyStriped.ArrayReference |
Striped.WeakSafeReadWriteLock
ReadWriteLock implementation whose read and write locks retain a reference back to this lock.
|
ThreadFactoryBuilder
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
|
TimeLimiter
Imposes a time limit on method calls.
|
TimeoutFuture
Implementation of
Futures#withTimeout . |
TrustedListenableFutureTask
A
RunnableFuture that also implements the ListenableFuture interface. |
WrappingExecutorService
An abstract
ExecutorService that allows subclasses to wrap tasks before they are submitted to the underlying executor. |
Class and Description |
---|
AbstractFuture
An abstract implementation of
ListenableFuture , intended for advanced users only. |
AbstractListeningExecutorService
Abstract
ListeningExecutorService implementation that creates ListenableFuture
instances for each Runnable and Callable submitted to it. |
ForwardingFuture
A
Future which forwards all its method calls to another future. |
ForwardingListenableFuture
A
ListenableFuture which forwards all its method calls to another future. |
ForwardingListenableFuture.SimpleForwardingListenableFuture
A simplified version of
ForwardingListenableFuture where subclasses can pass in an
already constructed ListenableFuture as the delegate. |
ListenableFuture
A
Future that accepts completion listeners. |
ListenableScheduledFuture
Helper interface to implement both
ListenableFuture and ScheduledFuture . |
ListeningExecutorService
An
ExecutorService that returns ListenableFuture instances. |
ListeningScheduledExecutorService
A
ScheduledExecutorService that returns ListenableFuture instances from its
ExecutorService methods. |