Uses of Annotation Type
com.google.common.annotations.J2ktIncompatible
Package
Description
Basic utility libraries and interfaces.
Collection interfaces and implementations, and other utilities for collections.
Utility methods and classes for I/O; for example input streams, output streams, readers, writers,
and files.
Arithmetic functions operating on primitive values and on
BigInteger
and BigDecimal
instances.Utility methods and classes for networking (such as IP addresses and domain names).
Static utilities for the eight primitive types and
void
, and value types for treating
them as unsigned or storing them in immutable arrays.Concurrency utilities.
-
Uses of J2ktIncompatible in com.google.common.base
Modifier and TypeClassDescriptionfinal class
This class provides default values for all Java types, as defined by the JLS.final class
Utility methods for working withEnum
instances.class
Phantom reference with afinalizeReferent()
method which a background thread invokes after the garbage collector reclaims the referent.interface
Implemented by references that have code to run after garbage collection of their referents.class
A reference queue with an associated background thread that dequeues references and invokesFinalizableReference.finalizeReferent()
on them.class
Soft reference with afinalizeReferent()
method which a background thread invokes after the garbage collector reclaims the referent.class
Weak reference with afinalizeReferent()
method which a background thread invokes after the garbage collector reclaims the referent.enum
Represents a standard system property.Modifier and TypeFieldDescriptionstatic final Charset
Charsets.US_ASCII
Deprecated.static final Charset
Charsets.UTF_16
Deprecated.UseStandardCharsets.UTF_16
instead.static final Charset
Charsets.UTF_16BE
Deprecated.UseStandardCharsets.UTF_16BE
instead.static final Charset
Charsets.UTF_16LE
Deprecated.UseStandardCharsets.UTF_16LE
instead.Modifier and TypeMethodDescriptionStopwatch.elapsed()
Returns the current elapsed time shown on this stopwatch as aDuration
.static List
<StackTraceElement> Throwables.lazyStackTrace
(Throwable throwable) Deprecated.This method is equivalent toThrowable.getStackTrace()
on JDK versions past JDK 8 and on all Android versions.static boolean
Throwables.lazyStackTraceIsLazy()
Deprecated.This method always returns false on JDK versions past JDK 8 and on all Android versions.Suppliers.memoizeWithExpiration
(Supplier<T> delegate, Duration duration) Returns a supplier that caches the instance supplied by the delegate and removes the cached value after the specified time has passed.static RuntimeException
Deprecated.To preserve behavior, usethrow e
orthrow new RuntimeException(e)
directly, or use a combination ofThrowables.throwIfUnchecked(java.lang.Throwable)
andthrow new RuntimeException(e)
.static <X extends Throwable>
voidThrowables.propagateIfInstanceOf
(@Nullable Throwable throwable, Class<X> declaredType) Deprecated.UseThrowables.throwIfInstanceOf(java.lang.Throwable, java.lang.Class<X>)
, which has the same behavior but rejectsnull
.static void
Throwables.propagateIfPossible
(@Nullable Throwable throwable) Deprecated.UseThrowables.throwIfUnchecked(java.lang.Throwable)
, which has the same behavior but rejectsnull
.static <X extends Throwable>
voidThrowables.propagateIfPossible
(@Nullable Throwable throwable, Class<X> declaredType) Deprecated.Use a combination ofThrowables.throwIfInstanceOf(java.lang.Throwable, java.lang.Class<X>)
andThrowables.throwIfUnchecked(java.lang.Throwable)
, which togther provide the same behavior except that they rejectnull
.Throwables.propagateIfPossible
(@Nullable Throwable throwable, Class<X1> declaredType1, Class<X2> declaredType2) Deprecated.Use a combination of two calls toThrowables.throwIfInstanceOf(java.lang.Throwable, java.lang.Class<X>)
and one call toThrowables.throwIfUnchecked(java.lang.Throwable)
, which togther provide the same behavior except that they rejectnull
.Returns a predicate that evaluates totrue
if the class being tested is assignable to (is a subtype of)clazz
.Suppliers.synchronizedSupplier
(Supplier<T> delegate) Returns a supplier whoseget()
method synchronizes ondelegate
before calling it, making it thread-safe. -
Uses of J2ktIncompatible in com.google.common.collect
Modifier and TypeClassDescriptionfinal class
A multiset that supports concurrent modifications and that provides atomic versions of mostMultiset
operations (exceptions where noted).final class
ABiMap
backed by twoEnumMap
instances.final class
EnumHashBiMap<K extends Enum<K>,
V extends @Nullable Object> ABiMap
backed by anEnumMap
instance for keys-to-values, and aHashMap
instance for values-to-keys.final class
EnumMultiset<E extends Enum<E>>
Multiset implementation specialized for enum elements, supporting all single-element operations in O(1).class
Deprecated.This class has moved tocom.google.common.util.concurrent
.class
ForwardingDeque<E extends @Nullable Object>
A deque which forwards all its method calls to another deque.interface
Interner<E>
Provides similar behavior toString.intern()
for any immutable type.final class
Contains static methods pertaining to instances ofInterner
.final class
A builder ofConcurrentMap
instances that can have keys or values automatically wrapped in weak references.final class
MutableClassToInstanceMap<B extends @Nullable Object>
A mutable class-to-instance map backed by an arbitrary user-provided map.Modifier and TypeMethodDescriptionOrdering.arbitrary()
Returns an arbitrary ordering over all objects, for whichcompare(a, b) == 0
impliesa == b
(identity equality).Sets.complementOf
(Collection<E> collection) Creates anEnumSet
consisting of all enum values that are not in the specified collection.Sets.complementOf
(Collection<E> collection, Class<E> type) Creates anEnumSet
consisting of all enum values that are not in the specified collection.static <E> int
Queues.drain
(BlockingQueue<E> q, Collection<? super E> buffer, int numElements, long timeout, TimeUnit unit) Drains the queue asBlockingQueue.drainTo(Collection, int)
, but if the requestednumElements
elements are not available, it will wait for them up to the specified timeout.static <E> int
Queues.drain
(BlockingQueue<E> q, Collection<? super E> buffer, int numElements, Duration timeout) Drains the queue asBlockingQueue.drainTo(Collection, int)
, but if the requestednumElements
elements are not available, it will wait for them up to the specified timeout.static <E> int
Queues.drainUninterruptibly
(BlockingQueue<E> q, Collection<? super E> buffer, int numElements, long timeout, TimeUnit unit) Drains the queue as Queues.drain(BlockingQueue, Collection, int, long, TimeUnit), but with a different behavior in case it is interrupted while waiting.static <E> int
Queues.drainUninterruptibly
(BlockingQueue<E> q, Collection<? super E> buffer, int numElements, Duration timeout) Drains the queue as Queues.drain(BlockingQueue, Collection, int, Duration), but with a different behavior in case it is interrupted while waiting.static ImmutableMap
<String, String> Maps.fromProperties
(Properties properties) Creates anImmutableMap<String, String>
from aProperties
instance.static <E> ArrayBlockingQueue
<E> Queues.newArrayBlockingQueue
(int capacity) Creates an emptyArrayBlockingQueue
with the given (fixed) capacity and nonfair access policy.static <E> ConcurrentLinkedQueue
<E> Queues.newConcurrentLinkedQueue()
Creates an emptyConcurrentLinkedQueue
.static <E> ConcurrentLinkedQueue
<E> Queues.newConcurrentLinkedQueue
(Iterable<? extends E> elements) Creates aConcurrentLinkedQueue
containing the elements of the specified iterable, in the order they are returned by the iterable's iterator.static <E extends @Nullable Object>
CopyOnWriteArrayList<E> Lists.newCopyOnWriteArrayList()
Creates an emptyCopyOnWriteArrayList
instance.static <E extends @Nullable Object>
CopyOnWriteArrayList<E> Lists.newCopyOnWriteArrayList
(Iterable<? extends E> elements) Creates aCopyOnWriteArrayList
instance containing the given elements.static <E extends @Nullable Object>
CopyOnWriteArraySet<E> Sets.newCopyOnWriteArraySet()
Creates an emptyCopyOnWriteArraySet
instance.static <E extends @Nullable Object>
CopyOnWriteArraySet<E> Sets.newCopyOnWriteArraySet
(Iterable<? extends E> elements) Creates aCopyOnWriteArraySet
instance containing the given elements.static <E> LinkedBlockingDeque
<E> Queues.newLinkedBlockingDeque()
Creates an emptyLinkedBlockingDeque
with a capacity ofInteger.MAX_VALUE
.static <E> LinkedBlockingDeque
<E> Queues.newLinkedBlockingDeque
(int capacity) Creates an emptyLinkedBlockingDeque
with the given (fixed) capacity.static <E> LinkedBlockingDeque
<E> Queues.newLinkedBlockingDeque
(Iterable<? extends E> elements) Creates aLinkedBlockingDeque
with a capacity ofInteger.MAX_VALUE
, containing the elements of the specified iterable, in the order they are returned by the iterable's iterator.static <E> LinkedBlockingQueue
<E> Queues.newLinkedBlockingQueue()
Creates an emptyLinkedBlockingQueue
with a capacity ofInteger.MAX_VALUE
.static <E> LinkedBlockingQueue
<E> Queues.newLinkedBlockingQueue
(int capacity) Creates an emptyLinkedBlockingQueue
with the given (fixed) capacity.static <E> LinkedBlockingQueue
<E> Queues.newLinkedBlockingQueue
(Iterable<? extends E> elements) Creates aLinkedBlockingQueue
with a capacity ofInteger.MAX_VALUE
, containing the elements of the specified iterable, in the order they are returned by the iterable's iterator.static <E extends Comparable>
PriorityBlockingQueue<E> Queues.newPriorityBlockingQueue()
Creates an emptyPriorityBlockingQueue
with the ordering given by its elements' natural ordering.static <E extends Comparable>
PriorityBlockingQueue<E> Queues.newPriorityBlockingQueue
(Iterable<? extends E> elements) Creates aPriorityBlockingQueue
containing the given elements.static <E> SynchronousQueue
<E> Queues.newSynchronousQueue()
Creates an emptySynchronousQueue
with nonfair access policy.Maps.synchronizedBiMap
(BiMap<K, V> bimap) Returns a synchronized (thread-safe) bimap backed by the specified bimap.Queues.synchronizedDeque
(Deque<E> deque) Returns a synchronized (thread-safe) deque backed by the specified deque.static <K extends @Nullable Object,
V extends @Nullable Object>
ListMultimap<K, V> Multimaps.synchronizedListMultimap
(ListMultimap<K, V> multimap) Returns a synchronized (thread-safe)ListMultimap
backed by the specified multimap.Multimaps.synchronizedMultimap
(Multimap<K, V> multimap) Returns a synchronized (thread-safe) multimap backed by the specified multimap.static <K extends @Nullable Object,
V extends @Nullable Object>
NavigableMap<K, V> Maps.synchronizedNavigableMap
(NavigableMap<K, V> navigableMap) Returns a synchronized (thread-safe) navigable map backed by the specified navigable map.static <E extends @Nullable Object>
NavigableSet<E> Sets.synchronizedNavigableSet
(NavigableSet<E> navigableSet) Returns a synchronized (thread-safe) navigable set backed by the specified navigable set.Queues.synchronizedQueue
(Queue<E> queue) Returns a synchronized (thread-safe) queue backed by the specified queue.static <K extends @Nullable Object,
V extends @Nullable Object>
SetMultimap<K, V> Multimaps.synchronizedSetMultimap
(SetMultimap<K, V> multimap) Returns a synchronized (thread-safe)SetMultimap
backed by the specified multimap.static <K extends @Nullable Object,
V extends @Nullable Object>
SortedSetMultimap<K, V> Multimaps.synchronizedSortedSetMultimap
(SortedSetMultimap<K, V> multimap) Returns a synchronized (thread-safe)SortedSetMultimap
backed by the specified multimap.static <R extends @Nullable Object,
C extends @Nullable Object, V extends @Nullable Object>
Table<R, C, V> Tables.synchronizedTable
(Table<R, C, V> table) Returns a synchronized (thread-safe) table backed by the specified table.Object[]
EvictingQueue.toArray()
final Object[]
ImmutableCollection.toArray()
Object[]
MinMaxPriorityQueue.toArray()
-
Uses of J2ktIncompatible in com.google.common.io
Modifier and TypeInterfaceDescriptioninterface
An extension ofDataInput
for reading from in-memory byte arrays; its methods offer identical functionality but do not throwIOException
.interface
An extension ofDataOutput
for writing to in-memory byte arrays; its methods offer identical functionality but do not throwIOException
.interface
ByteProcessor<T extends @Nullable Object>
A callback interface to process bytes from a stream.class
A destination to which bytes can be written, such as a file.class
A readable source of bytes, such as a file.final class
Provides utility methods for working with byte arrays and I/O streams.class
A destination to which characters can be written, such as a text file.class
A readable source of characters, such as a text file.final class
Provides utility methods for working with character streams.final class
Utility methods for working withCloseable
objects.final class
final class
AnInputStream
that counts the number of bytes read.final class
An OutputStream that counts the number of bytes written.final class
AnOutputStream
that starts buffering to a byte array, but switches to file buffering once the data reaches a configurable size.final class
Provides utility methods for working with files.enum
Modes for opening a file for writing.final class
Utility methods for working withFlushable
objects.final class
Exception indicating that a recursive delete can't be performed because the file system does not have the support necessary to guarantee that it is not vulnerable to race conditions that would allow it to delete files and directories outside of the directory being deleted (i.e.,SecureDirectoryStream
is not supported).interface
LineProcessor<T extends @Nullable Object>
A callback to be used with the streamingreadLines
methods.final class
A class for reading lines of text.final class
An implementation ofDataInput
that uses little-endian byte ordering for readingshort
,int
,float
,double
, andlong
values.final class
An implementation ofDataOutput
that uses little-endian byte ordering for writingchar
,short
,int
,float
,double
, andlong
values.final class
final class
File name filter that only accepts files matching a regular expression.enum
Options for use with recursive delete methods (MoreFiles.deleteRecursively(java.nio.file.Path, com.google.common.io.RecursiveDeleteOption...)
andMoreFiles.deleteDirectoryContents(java.nio.file.Path, com.google.common.io.RecursiveDeleteOption...)
).final class
Provides utility methods for working with resources in the classpath.Modifier and TypeMethodDescriptionfinal ByteSource
BaseEncoding.decodingSource
(CharSource encodedSource) Returns aByteSource
that reads base-encoded bytes from the specifiedCharSource
.abstract InputStream
BaseEncoding.decodingStream
(Reader reader) Returns anInputStream
that decodes base-encoded input from the specifiedReader
.final ByteSink
BaseEncoding.encodingSink
(CharSink encodedSink) Returns aByteSink
that writes base-encoded bytes to the specifiedCharSink
.abstract OutputStream
BaseEncoding.encodingStream
(Writer writer) Returns anOutputStream
that encodes bytes using this encoding into the specifiedWriter
. -
Uses of J2ktIncompatible in com.google.common.math
Modifier and TypeClassDescriptionclass
A class for arithmetic onBigDecimal
that is not covered by its built-in methods.class
The representation of a linear transformation between real numbersx
andy
.final class
An immutable value object capturing some basic statistics about a collection of paired double values (e.g. points on a plane).final class
A mutable object which accumulates paired double values (e.g. points on a plane) and tracks some basic statistics over all the values added so far.final class
Provides a fluent API for calculating quantiles.final class
A bundle of statistical summary values -- sum, count, mean/average, min and max, and several forms of variance -- that were computed from a single set of zero or more floating-point values.final class
A mutable object which accumulates double values and tracks some basic statistics over all the values added so far. -
Uses of J2ktIncompatible in com.google.common.net
Modifier and TypeClassDescriptionfinal class
A syntactically valid host specifier, suitable for use in a URI.final class
Static utility methods pertaining toInetAddress
instances. -
Uses of J2ktIncompatible in com.google.common.primitives
Modifier and TypeClassDescriptionfinal class
Static utility methods pertaining tobyte
primitives that interpret values as unsigned (that is, any negative valueb
is treated as the positive value256 + b
).Modifier and TypeMethodDescriptionUnsignedInteger.times
(UnsignedInteger val) Returns the result of multiplying this andval
. -
Uses of J2ktIncompatible in com.google.common.util.concurrent
Modifier and TypeClassDescriptionclass
Base class for services that can implementAbstractExecutionThreadService.startUp()
,AbstractExecutionThreadService.run()
andAbstractExecutionThreadService.shutDown()
methods.class
Base class for services that do not need a thread while "running" but may need one during startup and shutdown.class
AbstractListeningExecutorService
implementation that createsListenableFuture
instances for eachRunnable
andCallable
submitted to it.class
Base class for services that can implementAbstractScheduledService.startUp()
andAbstractScheduledService.shutDown()
but while in the "running" state need to perform a periodic task.class
Base class for implementing services that can handleAbstractService.doStart()
andAbstractService.doStop()
requests, responding to them withAbstractService.notifyStarted()
andAbstractService.notifyStopped()
callbacks.class
Adouble
value that may be updated atomically.class
Adouble
array in which elements may be updated atomically.final class
A map containinglong
values that can be atomically updated.final class
ClosingFuture<V extends @Nullable Object>
A step in a pipeline of an asynchronous computation.class
TheCycleDetectingLockFactory
createsReentrantLock
instances andReentrantReadWriteLock
instances that detect potential deadlock by checking for cycles in lock acquisition order.final class
A support class forListenableFuture
implementations to manage their listeners.final class
Serializes execution of tasks, somewhat like an "asynchronoussynchronized
block."final class
A TimeLimiter implementation which actually does not attempt to limit time at all.class
ABlockingDeque
which forwards all its method calls to anotherBlockingDeque
.class
ABlockingQueue
which forwards all its method calls to anotherBlockingQueue
.class
An executor service which forwards all its method calls to another executor service.class
A listening executor service which forwards all its method calls to another listening executor service.final class
Utilities necessary for working with libraries that supply plainFuture
instances.class
ListenableFutureTask<V extends @Nullable Object>
AFutureTask
that also implements theListenableFuture
interface.interface
AScheduledExecutorService
that returnsListenableFuture
instances from itsExecutorService
methods.final class
A synchronization abstraction supporting waiting on arbitrary boolean conditions.class
A rate limiter.interface
An object with an operational state, plus asynchronousService.startAsync()
andService.stopAsync()
lifecycle methods to transition between states.final class
A manager for monitoring and controlling a set of services.final class
A TimeLimiter that runs method calls in the background using anExecutorService
.class
Striped<L>
A stripedLock/Semaphore/ReadWriteLock
.final class
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 factoryinterface
Imposes a time limit on method calls.final class
Factories forThread.UncaughtExceptionHandler
instances.class
Unchecked version ofTimeoutException
.Modifier and TypeMethodDescriptionstatic void
MoreExecutors.addDelayedShutdownHook
(ExecutorService service, long terminationTimeout, TimeUnit timeUnit) Add a shutdown hook to wait for thread completion in the givenservice
.static void
MoreExecutors.addDelayedShutdownHook
(ExecutorService service, Duration terminationTimeout) Add a shutdown hook to wait for thread completion in the givenservice
.static <T extends @Nullable Object>
AsyncCallable<T> Callables.asAsyncCallable
(Callable<T> callable, ListeningExecutorService listeningExecutorService) Creates anAsyncCallable
from aCallable
.default boolean
ListeningExecutorService.awaitTermination
(Duration timeout) Duration-based overload ofExecutorService.awaitTermination(long, TimeUnit)
.static void
Uninterruptibles.awaitTerminationUninterruptibly
(ExecutorService executor) Invokesexecutor.
awaitTermination(long, TimeUnit)
uninterruptibly with no timeout.static boolean
Uninterruptibles.awaitTerminationUninterruptibly
(ExecutorService executor, long timeout, TimeUnit unit) Invokesexecutor.
awaitTermination(long, TimeUnit)
uninterruptibly.static boolean
Uninterruptibles.awaitTerminationUninterruptibly
(ExecutorService executor, Duration timeout) Invokesexecutor.
awaitTermination(long, TimeUnit)
uninterruptibly.static void
Uninterruptibles.awaitUninterruptibly
(CountDownLatch latch) Invokeslatch.
await()
uninterruptibly.static boolean
Uninterruptibles.awaitUninterruptibly
(CountDownLatch latch, long timeout, TimeUnit unit) Invokeslatch.
await(timeout, unit)
uninterruptibly.static boolean
Uninterruptibles.awaitUninterruptibly
(CountDownLatch latch, Duration timeout) Invokeslatch.
await(timeout, unit)
uninterruptibly.static boolean
Uninterruptibles.awaitUninterruptibly
(Condition condition, long timeout, TimeUnit unit) Invokescondition.
await(timeout, unit)
uninterruptibly.static boolean
Uninterruptibles.awaitUninterruptibly
(Condition condition, Duration timeout) Invokescondition.
await(timeout, unit)
uninterruptibly.final <X extends Throwable>
FluentFuture<V> FluentFuture.catching
(Class<X> exceptionType, Function<? super X, ? extends V> fallback, Executor executor) Returns aFuture
whose result is taken from thisFuture
or, if thisFuture
fails with the givenexceptionType
, from the result provided by thefallback
.static <V extends @Nullable Object,
X extends Throwable>
ListenableFuture<V> Futures.catching
(ListenableFuture<? extends V> input, Class<X> exceptionType, Function<? super X, ? extends V> fallback, Executor executor) Returns aFuture
whose result is taken from the given primaryinput
or, if the primary input fails with the givenexceptionType
, from the result provided by thefallback
.final <X extends Throwable>
FluentFuture<V> FluentFuture.catchingAsync
(Class<X> exceptionType, AsyncFunction<? super X, ? extends V> fallback, Executor executor) Returns aFuture
whose result is taken from thisFuture
or, if thisFuture
fails with the givenexceptionType
, from the result provided by thefallback
.static <V extends @Nullable Object,
X extends Throwable>
ListenableFuture<V> Futures.catchingAsync
(ListenableFuture<? extends V> input, Class<X> exceptionType, AsyncFunction<? super X, ? extends V> fallback, Executor executor) Returns aFuture
whose result is taken from the given primaryinput
or, if the primary input fails with the givenexceptionType
, from the result provided by thefallback
.Futures.getChecked
(Future<V> future, Class<X> exceptionClass) Returns the result ofFuture.get()
, converting most exceptions to a new instance of the given checked exception type.Futures.getChecked
(Future<V> future, Class<X> exceptionClass, long timeout, TimeUnit unit) Returns the result ofFuture.get(long, TimeUnit)
, converting most exceptions to a new instance of the given checked exception type.Futures.getChecked
(Future<V> future, Class<X> exceptionClass, Duration timeout) Returns the result ofFuture.get(long, TimeUnit)
, converting most exceptions to a new instance of the given checked exception type.static ExecutorService
MoreExecutors.getExitingExecutorService
(ThreadPoolExecutor executor) Converts the given ThreadPoolExecutor into an ExecutorService that exits when the application is complete.static ExecutorService
MoreExecutors.getExitingExecutorService
(ThreadPoolExecutor executor, long terminationTimeout, TimeUnit timeUnit) Converts the given ThreadPoolExecutor into an ExecutorService that exits when the application is complete.static ExecutorService
MoreExecutors.getExitingExecutorService
(ThreadPoolExecutor executor, Duration terminationTimeout) Converts the given ThreadPoolExecutor into an ExecutorService that exits when the application is complete.static ScheduledExecutorService
MoreExecutors.getExitingScheduledExecutorService
(ScheduledThreadPoolExecutor executor) Converts the given ScheduledThreadPoolExecutor into a ScheduledExecutorService that exits when the application is complete.static ScheduledExecutorService
MoreExecutors.getExitingScheduledExecutorService
(ScheduledThreadPoolExecutor executor, long terminationTimeout, TimeUnit timeUnit) Converts the given ScheduledThreadPoolExecutor into a ScheduledExecutorService that exits when the application is complete.static ScheduledExecutorService
MoreExecutors.getExitingScheduledExecutorService
(ScheduledThreadPoolExecutor executor, Duration terminationTimeout) Converts the given ScheduledThreadPoolExecutor into a ScheduledExecutorService that exits when the application is complete.Uninterruptibles.getUninterruptibly
(Future<V> future, long timeout, TimeUnit unit) Invokesfuture.
get(timeout, unit)
uninterruptibly.Uninterruptibles.getUninterruptibly
(Future<V> future, Duration timeout) Invokesfuture.
get(timeout, unit)
uninterruptibly.ListeningExecutorService.invokeAll
(Collection<? extends Callable<T>> tasks, Duration timeout) Duration-based overload ofListeningExecutorService.invokeAll(Collection, long, TimeUnit)
.ListeningExecutorService.invokeAny
(Collection<? extends Callable<T>> tasks, Duration timeout) Duration-based overload ofExecutorService.invokeAny(Collection, long, TimeUnit)
.static void
Uninterruptibles.joinUninterruptibly
(Thread toJoin) InvokestoJoin.
join()
uninterruptibly.static void
Uninterruptibles.joinUninterruptibly
(Thread toJoin, long timeout, TimeUnit unit) Invokesunit.
timedJoin(toJoin, timeout)
uninterruptibly.static void
Uninterruptibles.joinUninterruptibly
(Thread toJoin, Duration timeout) Invokesunit.
timedJoin(toJoin, timeout)
uninterruptibly.Futures.lazyTransform
(Future<I> input, Function<? super I, ? extends O> function) LikeFutures.transform(ListenableFuture, Function, Executor)
except that the transformationfunction
is invoked on each call toget()
on the returned future.static ListeningExecutorService
MoreExecutors.listeningDecorator
(ExecutorService delegate) Creates anExecutorService
whosesubmit
andinvokeAll
methods submitListenableFutureTask
instances to the given delegate executor.MoreExecutors.listeningDecorator
(ScheduledExecutorService delegate) Creates aScheduledExecutorService
whosesubmit
andinvokeAll
methods submitListenableFutureTask
instances to the given delegate executor.static ThreadFactory
MoreExecutors.platformThreadFactory()
Returns a default thread factory used to create new threads.static <E> void
Uninterruptibles.putUninterruptibly
(BlockingQueue<E> queue, E element) Invokesqueue.
put(element)
uninterruptibly.static <O extends @Nullable Object>
ListenableFuture<O> Futures.scheduleAsync
(AsyncCallable<O> callable, long delay, TimeUnit timeUnit, ScheduledExecutorService executorService) Schedulescallable
on the specifiedexecutor
, returning aFuture
.static <O extends @Nullable Object>
ListenableFuture<O> Futures.scheduleAsync
(AsyncCallable<O> callable, Duration delay, ScheduledExecutorService executorService) Schedulescallable
on the specifiedexecutor
, returning aFuture
.static boolean
MoreExecutors.shutdownAndAwaitTermination
(ExecutorService service, long timeout, TimeUnit unit) Shuts down the given executor service gradually, first disabling new submissions and later, if necessary, cancelling remaining tasks.static boolean
MoreExecutors.shutdownAndAwaitTermination
(ExecutorService service, Duration timeout) Shuts down the given executor service gradually, first disabling new submissions and later, if necessary, cancelling remaining tasks.static void
Uninterruptibles.sleepUninterruptibly
(long sleepFor, TimeUnit unit) Invokesunit.
sleep(sleepFor)
uninterruptibly.static void
Uninterruptibles.sleepUninterruptibly
(Duration sleepFor) Invokesunit.
sleep(sleepFor)
uninterruptibly.static <E> E
Uninterruptibles.takeUninterruptibly
(BlockingQueue<E> queue) Invokesqueue.
take()
uninterruptibly.static boolean
Uninterruptibles.tryAcquireUninterruptibly
(Semaphore semaphore, int permits, long timeout, TimeUnit unit) Invokessemaphore.
tryAcquire(permits, timeout, unit)
uninterruptibly.static boolean
Uninterruptibles.tryAcquireUninterruptibly
(Semaphore semaphore, int permits, Duration timeout) Invokessemaphore.
tryAcquire(permits, timeout, unit)
uninterruptibly.static boolean
Uninterruptibles.tryAcquireUninterruptibly
(Semaphore semaphore, long timeout, TimeUnit unit) Invokessemaphore.
tryAcquire(1, timeout, unit)
uninterruptibly.static boolean
Uninterruptibles.tryAcquireUninterruptibly
(Semaphore semaphore, Duration timeout) Invokessemaphore.
tryAcquire(1, timeout, unit)
uninterruptibly.static boolean
Uninterruptibles.tryLockUninterruptibly
(Lock lock, long timeout, TimeUnit unit) Invokeslock.
tryLock(timeout, unit)
uninterruptibly.static boolean
Uninterruptibles.tryLockUninterruptibly
(Lock lock, Duration timeout) Invokeslock.
tryLock(timeout, unit)
uninterruptibly.final FluentFuture
<V> FluentFuture.withTimeout
(long timeout, TimeUnit unit, ScheduledExecutorService scheduledExecutor) Returns a future that delegates to this future but will finish early (via aTimeoutException
wrapped in anExecutionException
) if the specified timeout expires.final FluentFuture
<V> FluentFuture.withTimeout
(Duration timeout, ScheduledExecutorService scheduledExecutor) Returns a future that delegates to this future but will finish early (via aTimeoutException
wrapped in anExecutionException
) if the specified timeout expires.static <V extends @Nullable Object>
ListenableFuture<V> Futures.withTimeout
(ListenableFuture<V> delegate, long time, TimeUnit unit, ScheduledExecutorService scheduledExecutor) Returns a future that delegates to another but will finish early (via aTimeoutException
wrapped in anExecutionException
) if the specified duration expires.static <V extends @Nullable Object>
ListenableFuture<V> Futures.withTimeout
(ListenableFuture<V> delegate, Duration time, ScheduledExecutorService scheduledExecutor) Returns a future that delegates to another but will finish early (via aTimeoutException
wrapped in anExecutionException
) if the specified duration expires.
StandardCharsets.US_ASCII
instead.