All Classes Interface Summary Class Summary Enum Summary Exception Summary Error Summary Annotation Types Summary
Class |
Description |
AbstractCache<K,V> |
This class provides a skeletal implementation of the Cache interface to minimize the
effort required to implement this interface.
|
AbstractCache.SimpleStatsCounter |
|
AbstractCache.StatsCounter |
|
AbstractCheckedFuture<V,X extends java.lang.Exception> |
|
AbstractExecutionThreadService |
|
AbstractFuture<V> |
An abstract implementation of ListenableFuture , intended for advanced users only.
|
AbstractIdleService |
Base class for services that do not need a thread while "running"
but may need one during startup and shutdown.
|
AbstractInvocationHandler |
Abstract implementation of InvocationHandler that handles Object.equals(java.lang.Object) ,
Object.hashCode() and Object.toString() .
|
AbstractIterator<T> |
This class provides a skeletal implementation of the Iterator
interface, to make this interface easier to implement for certain types of
data sources.
|
AbstractListeningExecutorService |
|
AbstractLoadingCache<K,V> |
This class provides a skeletal implementation of the Cache interface to minimize the
effort required to implement this interface.
|
AbstractScheduledService |
|
AbstractScheduledService.CustomScheduler |
|
AbstractScheduledService.CustomScheduler.Schedule |
A value object that represents an absolute delay until a task should be invoked.
|
AbstractScheduledService.Scheduler |
|
AbstractSequentialIterator<T> |
This class provides a skeletal implementation of the Iterator
interface for sequences whose next element can always be derived from the
previous element.
|
AbstractService |
|
AllowConcurrentEvents |
Marks an event subscriber method as being thread-safe.
|
ArrayBasedCharEscaper |
A CharEscaper that uses an array to quickly look up replacement
characters for a given char value.
|
ArrayBasedEscaperMap |
|
ArrayBasedUnicodeEscaper |
A UnicodeEscaper that uses an array to quickly look up replacement
characters for a given code point.
|
ArrayListMultimap<K,V> |
Implementation of Multimap that uses an ArrayList to store
the values for a given key.
|
ArrayTable<R,C,V> |
Fixed-size Table implementation backed by a two-dimensional array.
|
Ascii |
Static methods pertaining to ASCII characters (those in the range of values
0x00 through 0x7F ), and to strings containing such
characters.
|
AsyncEventBus |
An EventBus that takes the Executor of your choice and uses it to
dispatch events, allowing dispatch to occur asynchronously.
|
AsyncFunction<I,O> |
Transforms a value, possibly asynchronously.
|
AtomicDouble |
A double value that may be updated atomically.
|
AtomicDoubleArray |
A double array in which elements may be updated atomically.
|
AtomicLongMap<K> |
A map containing long values that can be atomically updated.
|
Atomics |
Static utility methods pertaining to classes in the
java.util.concurrent.atomic package.
|
BaseEncoding |
A binary encoding scheme for reversibly translating between byte sequences and printable ASCII
strings.
|
BaseEncoding.DecodingException |
Exception indicating invalid base-encoded input encountered while decoding.
|
Beta |
Signifies that a public API (public class, method or field) is subject to
incompatible changes, or even removal, in a future release.
|
BigIntegerMath |
A class for arithmetic on values of type BigInteger .
|
BiMap<K,V> |
A bimap (or "bidirectional map") is a map that preserves the uniqueness of
its values as well as that of its keys.
|
BinaryTreeTraverser<T> |
A variant of TreeTraverser for binary trees, providing additional traversals specific to
binary trees.
|
BloomFilter<T> |
A Bloom filter for instances of T .
|
Booleans |
Static utility methods pertaining to boolean primitives, that are not
already found in either Boolean or Arrays .
|
BoundType |
Indicates whether an endpoint of some range is contained in the range itself ("closed") or not
("open").
|
ByteArrayDataInput |
An extension of DataInput for reading from in-memory byte arrays; its
methods offer identical functionality but do not throw IOException .
|
ByteArrayDataOutput |
An extension of DataOutput for writing to in-memory byte arrays; its
methods offer identical functionality but do not throw IOException .
|
ByteProcessor<T> |
A callback interface to process bytes from a stream.
|
Bytes |
Static utility methods pertaining to byte primitives, that are not
already found in either Byte or Arrays , and interpret
bytes as neither signed nor unsigned.
|
ByteSink |
A destination to which bytes can be written, such as a file.
|
ByteSource |
A readable source of bytes, such as a file.
|
ByteStreams |
Provides utility methods for working with byte arrays and I/O streams.
|
Cache<K,V> |
A semi-persistent mapping from keys to values.
|
CacheBuilder<K,V> |
A builder of LoadingCache and Cache instances having any combination of the
following features:
automatic loading of entries into the cache
least-recently-used eviction when a maximum size is exceeded
time-based expiration of entries, measured since last access or last write
keys automatically wrapped in weak references
values automatically wrapped in weak or
soft references
notification of evicted (or otherwise removed) entries
accumulation of cache access statistics
|
CacheBuilderSpec |
|
CacheLoader<K,V> |
Computes or retrieves values, based on a key, for use in populating a LoadingCache .
|
CacheLoader.InvalidCacheLoadException |
Thrown to indicate that an invalid response was returned from a call to CacheLoader .
|
CacheLoader.UnsupportedLoadingOperationException |
Exception thrown by loadAll() to indicate that it is not supported.
|
CacheStats |
Statistics about the performance of a Cache .
|
Callables |
Static utility methods pertaining to the Callable interface.
|
CaseFormat |
Utility class for converting between various ASCII case formats.
|
CharEscaper |
An object that converts literal text into a format safe for inclusion in a particular context
(such as an XML document).
|
CharEscaperBuilder |
Simple helper class to build a "sparse" array of objects based on the indexes that were added to
it.
|
CharMatcher |
Determines a true or false value for any Java char value, just as Predicate does
for any Object .
|
Chars |
Static utility methods pertaining to char primitives, that are not
already found in either Character or Arrays .
|
Charsets |
Contains constant definitions for the six standard Charset instances, which are
guaranteed to be supported by all Java platform implementations.
|
CharSink |
A destination to which characters can be written, such as a text file.
|
CharSource |
A readable source of characters, such as a text file.
|
CharStreams |
Provides utility methods for working with character streams.
|
CheckedFuture<V,X extends java.lang.Exception> |
A CheckedFuture is a ListenableFuture that includes versions
of the get methods that can throw a checked exception.
|
ClassPath |
Scans the source of a ClassLoader and finds all loadable classes and resources.
|
ClassPath.ClassInfo |
|
ClassPath.ResourceInfo |
Represents a class path resource that can be either a class file or any other resource file
loadable from the class path.
|
ClassToInstanceMap<B> |
A map, each entry of which maps a Java
raw type to an instance of that type.
|
Closeables |
Utility methods for working with Closeable objects.
|
Closer |
A Closeable that collects Closeable resources and closes them all when it is
closed.
|
Collections2 |
Provides static methods for working with Collection instances.
|
ComparisonChain |
A utility for performing a chained comparison statement.
|
ComputationException |
Wraps an exception that occurred during a computation.
|
ConcurrentHashMultiset<E> |
A multiset that supports concurrent modifications and that provides atomic versions of most
Multiset operations (exceptions where noted).
|
ContiguousSet<C extends java.lang.Comparable> |
|
Converter<A,B> |
A function from A to B with an associated reverse function from B
to A ; used for converting back and forth between different representations of the same
information.
|
CountingInputStream |
An InputStream that counts the number of bytes read.
|
CountingOutputStream |
An OutputStream that counts the number of bytes written.
|
CycleDetectingLockFactory |
The CycleDetectingLockFactory creates ReentrantLock instances and
ReentrantReadWriteLock instances that detect potential deadlock by checking
for cycles in lock acquisition order.
|
CycleDetectingLockFactory.Policies |
|
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<E extends java.lang.Enum<E>> |
A CycleDetectingLockFactory.WithExplicitOrdering provides the
additional enforcement of an application-specified ordering of lock
acquisitions.
|
DeadEvent |
Wraps an event that was posted, but which had no subscribers and thus could
not be delivered.
|
Defaults |
This class provides default values for all Java types, as defined by the JLS.
|
DiscreteDomain<C extends java.lang.Comparable> |
A descriptor for a discrete Comparable domain such as all
Integer instances.
|
DoubleMath |
A class for arithmetic on doubles that is not covered by Math .
|
Doubles |
Static utility methods pertaining to double primitives, that are not
already found in either Double or Arrays .
|
EnumBiMap<K extends java.lang.Enum<K>,V extends java.lang.Enum<V>> |
A BiMap backed by two EnumMap instances.
|
EnumHashBiMap<K extends java.lang.Enum<K>,V> |
A BiMap backed by an EnumMap instance for keys-to-values, and
a HashMap instance for values-to-keys.
|
EnumMultiset<E extends java.lang.Enum<E>> |
Multiset implementation backed by an EnumMap .
|
Enums |
Utility methods for working with Enum instances.
|
Equivalence<T> |
A strategy for determining whether two instances are considered equivalent.
|
Equivalence.Wrapper<T> |
|
Escaper |
An object that converts literal text into a format safe for inclusion in a particular context
(such as an XML document).
|
Escapers |
Static utility methods pertaining to Escaper instances.
|
Escapers.Builder |
A builder for simple, fast escapers.
|
EventBus |
Dispatches events to listeners, and provides ways for listeners to register
themselves.
|
EvictingQueue<E> |
A non-blocking queue which automatically evicts elements from the head of the queue when
attempting to add new elements onto the queue and it is full.
|
ExecutionError |
Error variant of ExecutionException .
|
ExecutionList |
A support class for ListenableFuture implementations to manage their listeners.
|
FakeTimeLimiter |
A TimeLimiter implementation which actually does not attempt to limit time
at all.
|
FileBackedOutputStream |
An OutputStream that starts buffering to a byte array, but
switches to file buffering once the data reaches a configurable size.
|
Files |
Provides utility methods for working with files.
|
FileWriteMode |
Modes for opening a file for writing.
|
FinalizablePhantomReference<T> |
Phantom reference with a finalizeReferent() method which a background thread invokes
after the garbage collector reclaims the referent.
|
FinalizableReference |
Implemented by references that have code to run after garbage collection of their referents.
|
FinalizableReferenceQueue |
|
FinalizableSoftReference<T> |
Soft reference with a finalizeReferent() method which a background thread invokes after
the garbage collector reclaims the referent.
|
FinalizableWeakReference<T> |
Weak reference with a finalizeReferent() method which a background thread invokes after
the garbage collector reclaims the referent.
|
Floats |
Static utility methods pertaining to float primitives, that are not
already found in either Float or Arrays .
|
FluentIterable<E> |
An expanded Iterable API, providing functionality similar to Java 8's powerful streams library in a slightly different way.
|
Flushables |
Utility methods for working with Flushable objects.
|
ForwardingBlockingDeque<E> |
A BlockingDeque which forwards all its method calls to another BlockingDeque .
|
ForwardingBlockingQueue<E> |
A BlockingQueue which forwards all its method calls to another
BlockingQueue .
|
ForwardingCache<K,V> |
A cache which forwards all its method calls to another cache.
|
ForwardingCache.SimpleForwardingCache<K,V> |
A simplified version of ForwardingCache where subclasses can pass in an already
constructed Cache as the delegate.
|
ForwardingCheckedFuture<V,X extends java.lang.Exception> |
A future which forwards all its method calls to another future.
|
ForwardingCheckedFuture.SimpleForwardingCheckedFuture<V,X extends java.lang.Exception> |
|
ForwardingCollection<E> |
A collection which forwards all its method calls to another collection.
|
ForwardingConcurrentMap<K,V> |
A concurrent map which forwards all its method calls to another concurrent
map.
|
ForwardingDeque<E> |
A deque which forwards all its method calls to another deque.
|
ForwardingExecutorService |
An executor service which forwards all its method calls to another executor
service.
|
ForwardingFuture<V> |
A Future which forwards all its method calls to another future.
|
ForwardingFuture.SimpleForwardingFuture<V> |
A simplified version of ForwardingFuture where subclasses
can pass in an already constructed Future as the delegate.
|
ForwardingIterator<T> |
An iterator which forwards all its method calls to another iterator.
|
ForwardingList<E> |
A list which forwards all its method calls to another list.
|
ForwardingListenableFuture<V> |
|
ForwardingListenableFuture.SimpleForwardingListenableFuture<V> |
|
ForwardingListeningExecutorService |
A listening executor service which forwards all its method calls to another
listening executor service.
|
ForwardingListIterator<E> |
A list iterator which forwards all its method calls to another list
iterator.
|
ForwardingListMultimap<K,V> |
A list multimap which forwards all its method calls to another list multimap.
|
ForwardingLoadingCache<K,V> |
A cache which forwards all its method calls to another cache.
|
ForwardingLoadingCache.SimpleForwardingLoadingCache<K,V> |
|
ForwardingMap<K,V> |
A map which forwards all its method calls to another map.
|
ForwardingMapEntry<K,V> |
A map entry which forwards all its method calls to another map entry.
|
ForwardingMultimap<K,V> |
A multimap which forwards all its method calls to another multimap.
|
ForwardingMultiset<E> |
A multiset which forwards all its method calls to another multiset.
|
ForwardingNavigableMap<K,V> |
A navigable map which forwards all its method calls to another navigable map.
|
ForwardingNavigableSet<E> |
A navigable set which forwards all its method calls to another navigable set.
|
ForwardingObject |
|
ForwardingQueue<E> |
A queue which forwards all its method calls to another queue.
|
ForwardingSet<E> |
A set which forwards all its method calls to another set.
|
ForwardingSetMultimap<K,V> |
A set multimap which forwards all its method calls to another set multimap.
|
ForwardingSortedMap<K,V> |
A sorted map which forwards all its method calls to another sorted map.
|
ForwardingSortedMultiset<E> |
A sorted multiset which forwards all its method calls to another sorted multiset.
|
ForwardingSortedSet<E> |
A sorted set which forwards all its method calls to another sorted set.
|
ForwardingSortedSetMultimap<K,V> |
A sorted set multimap which forwards all its method calls to another sorted
set multimap.
|
ForwardingTable<R,C,V> |
A table which forwards all its method calls to another table.
|
Function<F,T> |
Determines an output value based on an input value.
|
Functions |
Static utility methods pertaining to Function instances.
|
Funnel<T> |
An object which can send data from an object of type T into a PrimitiveSink .
|
Funnels |
Funnels for common types.
|
FutureCallback<V> |
A callback for accepting the results of a Future
computation asynchronously.
|
FutureFallback<V> |
Deprecated.
|
Futures |
Static utility methods pertaining to the Future interface.
|
GwtCompatible |
The presence of this annotation on a type indicates that the type may be
used with the
Google Web Toolkit (GWT).
|
GwtIncompatible |
The presence of this annotation on a method indicates that the method may
not be used with the
Google Web Toolkit (GWT),
even though its type is annotated as GwtCompatible and accessible in
GWT.
|
HashBasedTable<R,C,V> |
Implementation of Table using hash tables.
|
HashBiMap<K,V> |
A BiMap backed by two hash tables.
|
HashCode |
An immutable hash code of arbitrary bit length.
|
Hasher |
A PrimitiveSink that can compute a hash code after reading the input.
|
HashFunction |
A hash function is a collision-averse pure function that maps an arbitrary block of
data to a number called a hash code.
|
Hashing |
Static methods to obtain HashFunction instances, and other static hashing-related
utilities.
|
HashingInputStream |
An InputStream that maintains a hash of the data read from it.
|
HashingOutputStream |
An OutputStream that maintains a hash of the data written to it.
|
HashMultimap<K,V> |
Implementation of Multimap using hash tables.
|
HashMultiset<E> |
Multiset implementation backed by a HashMap .
|
HostAndPort |
An immutable representation of a host and port.
|
HostSpecifier |
A syntactically valid host specifier, suitable for use in a URI.
|
HtmlEscapers |
Escaper instances suitable for strings to be included in HTML
attribute values and most elements' text contents.
|
HttpHeaders |
Contains constant definitions for the HTTP header field names.
|
ImmutableBiMap<K,V> |
|
ImmutableBiMap.Builder<K,V> |
A builder for creating immutable bimap instances, especially public
static final bimaps ("constant bimaps").
|
ImmutableClassToInstanceMap<B> |
|
ImmutableClassToInstanceMap.Builder<B> |
A builder for creating immutable class-to-instance maps.
|
ImmutableCollection<E> |
A Collection whose contents will never change, and which offers a few additional
guarantees detailed below.
|
ImmutableCollection.Builder<E> |
|
ImmutableList<E> |
A List whose contents will never change, with many other important properties detailed at
ImmutableCollection .
|
ImmutableList.Builder<E> |
A builder for creating immutable list instances, especially public
static final lists ("constant lists").
|
ImmutableListMultimap<K,V> |
|
ImmutableListMultimap.Builder<K,V> |
A builder for creating immutable ListMultimap instances, especially
public static final multimaps ("constant multimaps").
|
ImmutableMap<K,V> |
A Map whose contents will never change, with many other important properties detailed at
ImmutableCollection .
|
ImmutableMap.Builder<K,V> |
A builder for creating immutable map instances, especially public
static final maps ("constant maps").
|
ImmutableMultimap<K,V> |
|
ImmutableMultimap.Builder<K,V> |
A builder for creating immutable multimap instances, especially
public static final multimaps ("constant multimaps").
|
ImmutableMultiset<E> |
|
ImmutableMultiset.Builder<E> |
A builder for creating immutable multiset instances, especially
public static final multisets ("constant multisets").
|
ImmutableRangeMap<K extends java.lang.Comparable<?>,V> |
|
ImmutableRangeMap.Builder<K extends java.lang.Comparable<?>,V> |
A builder for immutable range maps.
|
ImmutableRangeSet<C extends java.lang.Comparable> |
|
ImmutableRangeSet.Builder<C extends java.lang.Comparable<?>> |
A builder for immutable range sets.
|
ImmutableSet<E> |
A Set whose contents will never change, with many other important properties detailed at
ImmutableCollection .
|
ImmutableSet.Builder<E> |
A builder for creating ImmutableSet instances.
|
ImmutableSetMultimap<K,V> |
|
ImmutableSetMultimap.Builder<K,V> |
A builder for creating immutable SetMultimap instances, especially
public static final multimaps ("constant multimaps").
|
ImmutableSortedMap<K,V> |
A NavigableMap whose contents will never change, with many other important properties
detailed at ImmutableCollection .
|
ImmutableSortedMap.Builder<K,V> |
A builder for creating immutable sorted map instances, especially
public static final maps ("constant maps").
|
ImmutableSortedMultiset<E> |
|
ImmutableSortedMultiset.Builder<E> |
A builder for creating immutable multiset instances, especially public static final
multisets ("constant multisets").
|
ImmutableSortedSet<E> |
A NavigableSet whose contents will never change, with many other important properties
detailed at ImmutableCollection .
|
ImmutableSortedSet.Builder<E> |
A builder for creating immutable sorted set instances, especially
public static final sets ("constant sets"), with a given comparator.
|
ImmutableTable<R,C,V> |
|
ImmutableTable.Builder<R,C,V> |
A builder for creating immutable table instances, especially public
static final tables ("constant tables").
|
ImmutableTypeToInstanceMap<B> |
|
ImmutableTypeToInstanceMap.Builder<B> |
A builder for creating immutable type-to-instance maps.
|
InetAddresses |
Static utility methods pertaining to InetAddress instances.
|
InetAddresses.TeredoInfo |
A simple immutable data class to encapsulate the information to be found in a
Teredo address.
|
InputSupplier<T> |
Deprecated.
|
Interner<E> |
Provides equivalent behavior to String.intern() for other immutable
types.
|
Interners |
Contains static methods pertaining to instances of Interner .
|
InternetDomainName |
An immutable well-formed internet domain name, such as com or
foo.co.uk .
|
IntMath |
A class for arithmetic on values of type int .
|
Ints |
Static utility methods pertaining to int primitives, that are not
already found in either Integer or Arrays .
|
Invokable<T,R> |
Wrapper around either a Method or a Constructor .
|
Iterables |
This class contains static utility methods that operate on or return objects
of type Iterable .
|
Iterators |
This class contains static utility methods that operate on or return objects
of type Iterator .
|
JdkFutureAdapters |
Utilities necessary for working with libraries that supply plain Future instances.
|
Joiner |
An object which joins pieces of text (specified as an array, Iterable , varargs or even a
Map ) with a separator.
|
Joiner.MapJoiner |
An object that joins map entries in the same manner as Joiner joins iterables and
arrays.
|
LineProcessor<T> |
A callback to be used with the streaming readLines methods.
|
LineReader |
A class for reading lines of text.
|
LinkedHashMultimap<K,V> |
Implementation of Multimap that does not allow duplicate key-value
entries and that returns collections whose iterators follow the ordering in
which the data was added to the multimap.
|
LinkedHashMultiset<E> |
A Multiset implementation with predictable iteration order.
|
LinkedListMultimap<K,V> |
An implementation of ListMultimap that supports deterministic
iteration order for both keys and values.
|
ListenableFuture<V> |
A Future that accepts completion listeners.
|
ListenableFutureTask<V> |
|
ListenableScheduledFuture<V> |
|
ListeningExecutorService |
|
ListeningScheduledExecutorService |
A ScheduledExecutorService that returns ListenableFuture
instances from its ExecutorService methods.
|
ListMultimap<K,V> |
A Multimap that can hold duplicate key-value pairs and that maintains
the insertion ordering of values for a given key.
|
Lists |
Static utility methods pertaining to List instances.
|
LittleEndianDataInputStream |
An implementation of DataInput that uses little-endian byte ordering
for reading short , int , float , double , and
long values.
|
LittleEndianDataOutputStream |
An implementation of DataOutput that uses little-endian byte ordering
for writing char , short , int , float ,
double , and long values.
|
LoadingCache<K,V> |
A semi-persistent mapping from keys to values.
|
LongMath |
A class for arithmetic on values of type long .
|
Longs |
Static utility methods pertaining to long primitives, that are not
already found in either Long or Arrays .
|
MapConstraint<K,V> |
Deprecated.
|
MapConstraints |
Deprecated.
|
MapDifference<K,V> |
An object representing the differences between two maps.
|
MapDifference.ValueDifference<V> |
A difference between the mappings from two maps with the same key.
|
MapMaker |
A builder of ConcurrentMap instances having any combination of the following features:
keys or values automatically wrapped in weak or soft references
notification of evicted (or otherwise removed) entries
|
Maps |
Static utility methods pertaining to Map instances (including instances of
SortedMap , BiMap , etc.).
|
Maps.EntryTransformer<K,V1,V2> |
A transformation of the value of a key-value pair, using both key and value
as inputs.
|
MediaType |
|
MinMaxPriorityQueue<E> |
A double-ended priority queue, which provides constant-time access to both
its least element and its greatest element, as determined by the queue's
specified comparator.
|
MinMaxPriorityQueue.Builder<B> |
The builder class used in creation of min-max priority queues.
|
Monitor |
A synchronization abstraction supporting waiting on arbitrary boolean conditions.
|
Monitor.Guard |
A boolean condition for which a thread may wait.
|
MoreExecutors |
Factory and utility methods for Executor , ExecutorService , and ThreadFactory .
|
MoreObjects |
Helper functions that operate on any Object , and are not already provided in
Objects .
|
MoreObjects.ToStringHelper |
|
Multimap<K,V> |
A collection that maps keys to values, similar to Map , but in which
each key may be associated with multiple values.
|
MultimapBuilder<K0,V0> |
A builder for a multimap implementation that allows customization of the backing map and value
collection implementations used in a particular multimap.
|
MultimapBuilder.ListMultimapBuilder<K0,V0> |
|
MultimapBuilder.MultimapBuilderWithKeys<K0> |
An intermediate stage in a MultimapBuilder in which the key-value collection map
implementation has been specified, but the value collection implementation has not.
|
MultimapBuilder.SetMultimapBuilder<K0,V0> |
|
MultimapBuilder.SortedSetMultimapBuilder<K0,V0> |
|
Multimaps |
Provides static methods acting on or generating a Multimap .
|
Multiset<E> |
A collection that supports order-independent equality, like Set , but
may have duplicate elements.
|
Multiset.Entry<E> |
An unmodifiable element-count pair for a multiset.
|
Multisets |
Provides static utility methods for creating and working with Multiset instances.
|
MutableClassToInstanceMap<B> |
A mutable class-to-instance map backed by an arbitrary user-provided map.
|
MutableTypeToInstanceMap<B> |
A mutable type-to-instance map.
|
ObjectArrays |
Static utility methods pertaining to object arrays.
|
Objects |
Helper functions that can operate on any Object .
|
Objects.ToStringHelper |
Deprecated.
|
Optional<T> |
An immutable object that may contain a non-null reference to another object.
|
Ordering<T> |
A comparator, with additional methods to support common operations.
|
OutputSupplier<T> |
Deprecated.
|
Parameter |
Represents a method or constructor parameter.
|
PatternFilenameFilter |
File name filter that only accepts files matching a regular expression.
|
PeekingIterator<E> |
An iterator that supports a one-element lookahead while iterating.
|
PercentEscaper |
A UnicodeEscaper that escapes some set of Java characters using a
UTF-8 based percent encoding scheme.
|
Preconditions |
Static convenience methods that help a method or constructor check whether it was invoked
correctly (whether its preconditions have been met).
|
Predicate<T> |
Determines a true or false value for a given input.
|
Predicates |
Static utility methods pertaining to Predicate instances.
|
Primitives |
Contains static utility methods pertaining to primitive types and their
corresponding wrapper types.
|
PrimitiveSink |
An object which can receive a stream of primitive values.
|
Queues |
Static utility methods pertaining to Queue and Deque instances.
|
Range<C extends java.lang.Comparable> |
A range (or "interval") defines the boundaries around a contiguous span of values of some
Comparable type; for example, "integers from 1 to 100 inclusive." Note that it is not
possible to iterate over these contained values.
|
RangeMap<K extends java.lang.Comparable,V> |
A mapping from disjoint nonempty ranges to non-null values.
|
Ranges |
Deprecated.
|
RangeSet<C extends java.lang.Comparable> |
|
RateLimiter |
A rate limiter.
|
Reflection |
Static utilities relating to Java reflection.
|
RemovalCause |
The reason why a cached entry was removed.
|
RemovalListener<K,V> |
An object that can receive a notification when an entry is removed from a cache.
|
RemovalListeners |
A collection of common removal listeners.
|
RemovalNotification<K,V> |
A notification of the removal of a single entry.
|
Resources |
Provides utility methods for working with resources in the classpath.
|
RowSortedTable<R,C,V> |
Interface that extends Table and whose rows are sorted.
|
Runnables |
Static utility methods pertaining to the Runnable interface.
|
Service |
|
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.
|
SetMultimap<K,V> |
A Multimap that cannot hold duplicate key-value pairs.
|
Sets |
Static utility methods pertaining to Set instances.
|
Sets.SetView<E> |
An unmodifiable view of a set which may be backed by other sets; this view
will change as the backing sets do.
|
SettableFuture<V> |
|
Shorts |
Static utility methods pertaining to short primitives, that are not
already found in either Short or Arrays .
|
SignedBytes |
Static utility methods pertaining to byte primitives that
interpret values as signed.
|
SimpleTimeLimiter |
A TimeLimiter that runs method calls in the background using an
ExecutorService .
|
SortedMapDifference<K,V> |
An object representing the differences between two sorted maps.
|
SortedMultiset<E> |
A Multiset which maintains the ordering of its elements, according to
either their natural order or an explicit Comparator .
|
SortedSetMultimap<K,V> |
A SetMultimap whose set of values for a given key are kept sorted;
that is, they comprise a SortedSet .
|
Splitter |
Extracts non-overlapping substrings from an input string, typically by
recognizing appearances of a separator sequence.
|
Splitter.MapSplitter |
An object that splits strings into maps as Splitter splits
iterables and lists.
|
StandardSystemProperty |
Represents a standard system property.
|
Stopwatch |
An object that measures elapsed time in nanoseconds.
|
Strings |
Static utility methods pertaining to String or CharSequence
instances.
|
Striped<L> |
A striped Lock/Semaphore/ReadWriteLock .
|
Subscribe |
Marks a method as an event subscriber.
|
SubscriberExceptionContext |
Context for an exception thrown by a subscriber.
|
SubscriberExceptionHandler |
Handler for exceptions thrown by event subscribers.
|
Supplier<T> |
A class that can supply objects of a single type.
|
Suppliers |
Useful suppliers.
|
Table<R,C,V> |
A collection that associates an ordered pair of keys, called a row key and a
column key, with a single value.
|
Table.Cell<R,C,V> |
Row key / column key / value triplet corresponding to a mapping in a table.
|
Tables |
Provides static methods that involve a Table .
|
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
|
Throwables |
Static utility methods pertaining to instances of Throwable .
|
Ticker |
A time source; returns a time value representing the number of nanoseconds elapsed since some
fixed but arbitrary point in time.
|
TimeLimiter |
Produces proxies that impose a time limit on method
calls to the proxied object.
|
TreeBasedTable<R,C,V> |
Implementation of Table whose row keys and column keys are ordered
by their natural ordering or by supplied comparators.
|
TreeMultimap<K,V> |
Implementation of Multimap whose keys and values are ordered by
their natural ordering or by supplied comparators.
|
TreeMultiset<E> |
A multiset which maintains the ordering of its elements, according to either their natural order
or an explicit Comparator .
|
TreeRangeMap<K extends java.lang.Comparable,V> |
An implementation of RangeMap based on a TreeMap , supporting
all optional operations.
|
TreeRangeSet<C extends java.lang.Comparable<?>> |
An implementation of RangeSet backed by a TreeMap .
|
TreeTraverser<T> |
Views elements of a type T as nodes in a tree, and provides methods to traverse the trees
induced by this traverser.
|
TypeParameter<T> |
|
TypeResolver |
An object of this class encapsulates type mappings from type variables.
|
TypeToInstanceMap<B> |
A map, each entry of which maps a TypeToken to an instance of that type.
|
TypeToken<T> |
A Type with generics.
|
UncaughtExceptionHandlers |
Factories for Thread.UncaughtExceptionHandler instances.
|
UncheckedExecutionException |
Unchecked variant of ExecutionException .
|
UncheckedTimeoutException |
Unchecked version of TimeoutException .
|
UnicodeEscaper |
An Escaper that converts literal text into a format safe for
inclusion in a particular context (such as an XML document).
|
Uninterruptibles |
Utilities for treating interruptible operations as uninterruptible.
|
UnmodifiableIterator<E> |
|
UnmodifiableListIterator<E> |
|
UnsignedBytes |
Static utility methods pertaining to byte primitives that interpret
values as unsigned (that is, any negative value b is treated
as the positive value 256 + b ).
|
UnsignedInteger |
A wrapper class for unsigned int values, supporting arithmetic operations.
|
UnsignedInts |
Static utility methods pertaining to int primitives that interpret values as
unsigned (that is, any negative value x is treated as the positive value
2^32 + x ).
|
UnsignedLong |
A wrapper class for unsigned long values, supporting arithmetic operations.
|
UnsignedLongs |
Static utility methods pertaining to long primitives that interpret values as
unsigned (that is, any negative value x is treated as the positive value
2^64 + x ).
|
UrlEscapers |
Escaper instances suitable for strings to be included in particular
sections of URLs.
|
Utf8 |
Low-level, high-performance utility methods related to the UTF-8
character encoding.
|
Verify |
Static convenience methods that serve the same purpose as Java language
assertions, except that they are always enabled.
|
VerifyException |
Exception thrown upon the failure of a
verification
check, including those performed by the convenience methods of the Verify class.
|
VisibleForTesting |
Annotates a program element that exists, or is more widely visible than
otherwise necessary, only for use in test code.
|
Weigher<K,V> |
Calculates the weights of cache entries.
|
XmlEscapers |
Escaper instances suitable for strings to be included in XML
attribute values and elements' text contents.
|